1
0
Fork 0
mirror of https://github.com/kyverno/kyverno.git synced 2025-03-31 03:45:17 +00:00

update policy status

This commit is contained in:
shivkumar dudhani 2019-08-20 16:40:20 -07:00
parent 3f876e6f46
commit dc47132ade
6 changed files with 117 additions and 146 deletions
pkg

View file

@ -1,8 +1,6 @@
package v1alpha1 package v1alpha1
import ( import (
"time"
metav1 "k8s.io/apimachinery/pkg/apis/meta/v1" metav1 "k8s.io/apimachinery/pkg/apis/meta/v1"
) )
@ -97,9 +95,9 @@ type PolicyStatus struct {
// Count of resources for whom update/create api requests were blocked as the resoruce did not satisfy the policy rules // Count of resources for whom update/create api requests were blocked as the resoruce did not satisfy the policy rules
ResourcesBlockedCount int `json:"resourcesBlockedCount"` ResourcesBlockedCount int `json:"resourcesBlockedCount"`
// average time required to process the policy Mutation rules on a resource // average time required to process the policy Mutation rules on a resource
AvgExecutionTimeMutation time.Duration `json:"averageMutationExecutionTime"` AvgExecutionTimeMutation string `json:"averageMutationExecutionTime"`
// average time required to process the policy Validation rules on a resource // average time required to process the policy Validation rules on a resource
AvgExecutionTimeValidation time.Duration `json:"averageValidationExecutionTime"` AvgExecutionTimeValidation string `json:"averageValidationExecutionTime"`
} }
// +k8s:deepcopy-gen:interfaces=k8s.io/apimachinery/pkg/runtime.Object // +k8s:deepcopy-gen:interfaces=k8s.io/apimachinery/pkg/runtime.Object

View file

@ -119,7 +119,8 @@ func NewPolicyController(kyvernoClient *kyvernoclient.Clientset, client *client.
pc.rm = NewResourceManager(30) pc.rm = NewResourceManager(30)
// aggregator // aggregator
pc.statusAggregator = NewPolicyStatAggregator(kyvernoClient, pInformer) // pc.statusAggregator = NewPolicyStatAggregator(kyvernoClient, pInformer)
pc.statusAggregator = NewPolicyStatAggregator(kyvernoClient)
return &pc, nil return &pc, nil
} }
@ -392,6 +393,8 @@ func (pc *PolicyController) syncPolicy(key string) error {
policy, err := pc.pLister.Get(key) policy, err := pc.pLister.Get(key)
if errors.IsNotFound(err) { if errors.IsNotFound(err) {
glog.V(2).Infof("Policy %v has been deleted", key) glog.V(2).Infof("Policy %v has been deleted", key)
// remove the recorded stats for the policy
pc.statusAggregator.RemovePolicyStats(key)
return nil return nil
} }
@ -412,15 +415,15 @@ func (pc *PolicyController) syncPolicy(key string) error {
// report errors // report errors
pc.report(policyInfos) pc.report(policyInfos)
// fetch the policy again via the aggreagator to remain consistent // fetch the policy again via the aggreagator to remain consistent
return pc.statusAggregator.UpdateViolationCount(p.Name, pvList) // return pc.statusAggregator.UpdateViolationCount(p.Name, pvList)
// return pc.syncStatusOnly(p, pvList) return pc.syncStatusOnly(p, pvList)
} }
//syncStatusOnly updates the policy status subresource //syncStatusOnly updates the policy status subresource
// status: // status:
// - violations : (count of the resources that violate this policy ) // - violations : (count of the resources that violate this policy )
func (pc *PolicyController) syncStatusOnly(p *kyverno.Policy, pvList []*kyverno.PolicyViolation) error { func (pc *PolicyController) syncStatusOnly(p *kyverno.Policy, pvList []*kyverno.PolicyViolation) error {
newStatus := calculateStatus(pvList) newStatus := pc.calculateStatus(p.Name, pvList)
if reflect.DeepEqual(newStatus, p.Status) { if reflect.DeepEqual(newStatus, p.Status) {
// no update to status // no update to status
return nil return nil
@ -432,6 +435,21 @@ func (pc *PolicyController) syncStatusOnly(p *kyverno.Policy, pvList []*kyverno.
return err return err
} }
func (pc *PolicyController) calculateStatus(policyName string, pvList []*kyverno.PolicyViolation) kyverno.PolicyStatus {
violationCount := len(pvList)
status := kyverno.PolicyStatus{
ViolationCount: violationCount,
}
// get stats
stats := pc.statusAggregator.GetPolicyStats(policyName)
if stats != (PolicyStatInfo{}) {
status.RulesAppliedCount = stats.RulesAppliedCount
status.ResourcesBlockedCount = stats.ResourceBlocked
status.AvgExecutionTimeMutation = stats.MutationExecutionTime.String()
status.AvgExecutionTimeValidation = stats.ValidationExecutionTime.String()
}
return status
}
func (pc *PolicyController) getPolicyViolationsForPolicy(p *kyverno.Policy) ([]*kyverno.PolicyViolation, error) { func (pc *PolicyController) getPolicyViolationsForPolicy(p *kyverno.Policy) ([]*kyverno.PolicyViolation, error) {
// List all PolicyViolation to find those we own but that no longer match our // List all PolicyViolation to find those we own but that no longer match our
// selector. They will be orphaned by ClaimPolicyViolation(). // selector. They will be orphaned by ClaimPolicyViolation().

View file

@ -1,59 +1,38 @@
package policy package policy
import ( import (
"fmt"
"reflect"
"sync" "sync"
"time" "time"
"github.com/golang/glog" "github.com/golang/glog"
kyverno "github.com/nirmata/kyverno/pkg/api/kyverno/v1alpha1"
kyvernoclient "github.com/nirmata/kyverno/pkg/client/clientset/versioned" kyvernoclient "github.com/nirmata/kyverno/pkg/client/clientset/versioned"
kyvernoinformer "github.com/nirmata/kyverno/pkg/client/informers/externalversions/kyverno/v1alpha1"
kyvernolister "github.com/nirmata/kyverno/pkg/client/listers/kyverno/v1alpha1"
utilruntime "k8s.io/apimachinery/pkg/util/runtime" utilruntime "k8s.io/apimachinery/pkg/util/runtime"
"k8s.io/apimachinery/pkg/util/wait" "k8s.io/apimachinery/pkg/util/wait"
"k8s.io/client-go/tools/cache"
) )
// type PolicyStatus struct {
// // average time required to process the policy rules on a resource
// avgExecutionTime time.Duration
// // Count of rules that were applied succesfully
// rulesAppliedCount int
// // Count of resources for whom update/create api requests were blocked as the resoruce did not satisfy the policy rules
// resourcesBlockedCount int
// // Count of the resource for whom the mutation rules were applied succesfully
// resourcesMutatedCount int
// }
//PolicyStatusAggregator stores information abt aggregation //PolicyStatusAggregator stores information abt aggregation
type PolicyStatusAggregator struct { type PolicyStatusAggregator struct {
// time since we start aggregating the stats // time since we start aggregating the stats
startTime time.Time startTime time.Time
// channel to recieve stats // channel to recieve stats
ch chan PolicyStat ch chan PolicyStat
// update policy status //TODO: lock based on key, possibly sync.Map ?
psControl PStatusControlInterface //sync RW for policyData
// pLister can list/get policy from the shared informer's store mux sync.RWMutex
pLister kyvernolister.PolicyLister // stores aggregated stats for policy
// pListerSynced returns true if the Policy store has been synced at least once policyData map[string]PolicyStatInfo
pListerSynced cache.InformerSynced
// UpdateViolationCount and SendStat can update same policy status
// we need to sync the updates using policyName
policyUpdateData sync.Map
} }
//NewPolicyStatAggregator returns a new policy status //NewPolicyStatAggregator returns a new policy status
func NewPolicyStatAggregator(client *kyvernoclient.Clientset, pInformer kyvernoinformer.PolicyInformer) *PolicyStatusAggregator { func NewPolicyStatAggregator(client *kyvernoclient.Clientset,
// pInformer kyvernoinformer.PolicyInformer
) *PolicyStatusAggregator {
psa := PolicyStatusAggregator{ psa := PolicyStatusAggregator{
startTime: time.Now(), startTime: time.Now(),
ch: make(chan PolicyStat), ch: make(chan PolicyStat),
policyData: map[string]PolicyStatInfo{},
} }
psa.pLister = pInformer.Lister()
psa.pListerSynced = pInformer.Informer().HasSynced
psa.psControl = PSControl{Client: client}
//TODO: add WaitGroup
return &psa return &psa
} }
@ -65,10 +44,11 @@ func (psa *PolicyStatusAggregator) Run(workers int, stopCh <-chan struct{}) {
glog.V(4).Info("Shutting down aggregator for policy status stats") glog.V(4).Info("Shutting down aggregator for policy status stats")
}() }()
for i := 0; i < workers; i++ { for i := 0; i < workers; i++ {
go wait.Until(psa.aggregate, time.Second, stopCh) go wait.Until(psa.process, time.Second, stopCh)
} }
} }
func (psa *PolicyStatusAggregator) aggregate() {
func (psa *PolicyStatusAggregator) process() {
// As mutation and validation are handled seperately // As mutation and validation are handled seperately
// ideally we need to combine the exection time from both for a policy // ideally we need to combine the exection time from both for a policy
// but its tricky to detect here the type of rules policy contains // but its tricky to detect here the type of rules policy contains
@ -76,74 +56,96 @@ func (psa *PolicyStatusAggregator) aggregate() {
// mutation & validation rules seperately // mutation & validation rules seperately
for r := range psa.ch { for r := range psa.ch {
glog.V(4).Infof("recieved policy stats %v", r) glog.V(4).Infof("recieved policy stats %v", r)
if err := psa.updateStats(r); err != nil { // if err := psa.updateStats(r); err != nil {
glog.Infof("Failed to update stats for policy %s: %v", r.PolicyName, err) // glog.Infof("Failed to update stats for policy %s: %v", r.PolicyName, err)
} // }
psa.aggregate(r)
} }
} }
func (psa *PolicyStatusAggregator) updateStats(stats PolicyStat) error { func (psa *PolicyStatusAggregator) aggregate(ps PolicyStat) {
func() { func() {
glog.V(4).Infof("lock updates for policy %s", stats.PolicyName) glog.V(4).Infof("write lock update policy %s", ps.PolicyName)
// Lock the update for policy psa.mux.Lock()
psa.policyUpdateData.Store(stats.PolicyName, struct{}{})
}() }()
defer func() { defer func() {
glog.V(4).Infof("Unlock updates for policy %s", stats.PolicyName) glog.V(4).Infof("write Unlock update policy %s", ps.PolicyName)
psa.policyUpdateData.Delete(stats.PolicyName) psa.mux.Unlock()
}() }()
info, ok := psa.policyData[ps.PolicyName]
// //wait for cache sync if !ok {
// if !cache.WaitForCacheSync(nil, psa.pListerSynced) { psa.policyData[ps.PolicyName] = ps.Stats
// glog.Infof("unable to sync cache for policy informer") glog.V(4).Infof("added stats for policy %s", ps.PolicyName)
// return nil return
// }
// get policy
policy, err := psa.pLister.Get(stats.PolicyName)
if err != nil {
glog.V(4).Infof("failed to get policy %s. Unable to update violation count: %v", stats.PolicyName, err)
return err
} }
newpolicy := policy // aggregate
fmt.Println(newpolicy.ResourceVersion) info.RulesAppliedCount = info.RulesAppliedCount + ps.Stats.RulesAppliedCount
newpolicy.Status = kyverno.PolicyStatus{} if ps.Stats.ResourceBlocked == 1 {
glog.V(4).Infof("updating stats for policy %s", policy.Name) info.ResourceBlocked++
// rules applied count
newpolicy.Status.RulesAppliedCount = newpolicy.Status.RulesAppliedCount + stats.RulesAppliedCount
// resource blocked count
if stats.ResourceBlocked {
policy.Status.ResourcesBlockedCount++
} }
var zeroDuration time.Duration var zeroDuration time.Duration
if newpolicy.Status.AvgExecutionTimeMutation != zeroDuration { if info.MutationExecutionTime != zeroDuration {
// avg execution time for mutation rules info.MutationExecutionTime = (info.MutationExecutionTime + ps.Stats.MutationExecutionTime) / 2
newpolicy.Status.AvgExecutionTimeMutation = (newpolicy.Status.AvgExecutionTimeMutation + stats.MutationExecutionTime) / 2 glog.V(4).Infof("updated avg mutation time %v", info.MutationExecutionTime)
} else { } else {
newpolicy.Status.AvgExecutionTimeMutation = stats.MutationExecutionTime info.MutationExecutionTime = ps.Stats.MutationExecutionTime
} }
if policy.Status.AvgExecutionTimeValidation != zeroDuration { if info.ValidationExecutionTime != zeroDuration {
// avg execution time for validation rules info.ValidationExecutionTime = (info.ValidationExecutionTime + ps.Stats.ValidationExecutionTime) / 2
newpolicy.Status.AvgExecutionTimeValidation = (newpolicy.Status.AvgExecutionTimeValidation + stats.ValidationExecutionTime) / 2 glog.V(4).Infof("updated avg validation time %v", info.ValidationExecutionTime)
} else { } else {
newpolicy.Status.AvgExecutionTimeValidation = stats.ValidationExecutionTime info.ValidationExecutionTime = ps.Stats.ValidationExecutionTime
} }
return psa.psControl.UpdatePolicyStatus(newpolicy) // update
psa.policyData[ps.PolicyName] = info
glog.V(4).Infof("updated stats for policy %s", ps.PolicyName)
}
//GetPolicyStats returns the policy stats
func (psa *PolicyStatusAggregator) GetPolicyStats(policyName string) PolicyStatInfo {
func() {
glog.V(4).Infof("read lock update policy %s", policyName)
psa.mux.RLock()
}()
defer func() {
glog.V(4).Infof("read Unlock update policy %s", policyName)
psa.mux.RUnlock()
}()
glog.V(4).Infof("read stats for policy %s", policyName)
return psa.policyData[policyName]
}
//RemovePolicyStats rmves policy stats records
func (psa *PolicyStatusAggregator) RemovePolicyStats(policyName string) {
func() {
glog.V(4).Infof("write lock update policy %s", policyName)
psa.mux.Lock()
}()
defer func() {
glog.V(4).Infof("write Unlock update policy %s", policyName)
psa.mux.Unlock()
}()
glog.V(4).Infof("removing stats for policy %s", policyName)
delete(psa.policyData, policyName)
} }
//PolicyStatusInterface provides methods to modify policyStatus //PolicyStatusInterface provides methods to modify policyStatus
type PolicyStatusInterface interface { type PolicyStatusInterface interface {
SendStat(stat PolicyStat) SendStat(stat PolicyStat)
UpdateViolationCount(policyName string, pvList []*kyverno.PolicyViolation) error // UpdateViolationCount(policyName string, pvList []*kyverno.PolicyViolation) error
} }
//PolicyStat stored stats for policy //PolicyStat stored stats for policy
type PolicyStat struct { type PolicyStat struct {
PolicyName string PolicyName string
Stats PolicyStatInfo
}
type PolicyStatInfo struct {
MutationExecutionTime time.Duration MutationExecutionTime time.Duration
ValidationExecutionTime time.Duration ValidationExecutionTime time.Duration
RulesAppliedCount int RulesAppliedCount int
ResourceBlocked bool ResourceBlocked int
} }
//SendStat sends the stat information for aggregation //SendStat sends the stat information for aggregation
@ -153,62 +155,7 @@ func (psa *PolicyStatusAggregator) SendStat(stat PolicyStat) {
psa.ch <- stat psa.ch <- stat
} }
//UpdateViolationCount updates the active violation count
func (psa *PolicyStatusAggregator) UpdateViolationCount(policyName string, pvList []*kyverno.PolicyViolation) error {
func() {
glog.V(4).Infof("lock updates for policy %s", policyName)
// Lock the update for policy
psa.policyUpdateData.Store(policyName, struct{}{})
}()
defer func() {
glog.V(4).Infof("Unlock updates for policy %s", policyName)
psa.policyUpdateData.Delete(policyName)
}()
// get policy
policy, err := psa.pLister.Get(policyName)
if err != nil {
glog.V(4).Infof("failed to get policy %s. Unable to update violation count: %v", policyName, err)
return err
}
newStatus := calculateStatus(pvList)
if reflect.DeepEqual(newStatus, policy.Status) {
// no update to status
glog.V(4).Infof("no changes in policy violation count for policy %s", policy.Name)
return nil
}
// update status
newPolicy := policy
newPolicy.Status = newStatus
return psa.psControl.UpdatePolicyStatus(newPolicy)
}
func calculateStatus(pvList []*kyverno.PolicyViolation) kyverno.PolicyStatus {
violationCount := len(pvList)
status := kyverno.PolicyStatus{
ViolationCount: violationCount,
}
return status
}
//GetPolicyStatusAggregator returns interface to send policy status stats //GetPolicyStatusAggregator returns interface to send policy status stats
func (pc *PolicyController) GetPolicyStatusAggregator() PolicyStatusInterface { func (pc *PolicyController) GetPolicyStatusAggregator() PolicyStatusInterface {
return pc.statusAggregator return pc.statusAggregator
} }
//PStatusControlInterface Provides interface to operate on policy status
type PStatusControlInterface interface {
UpdatePolicyStatus(newPolicy *kyverno.Policy) error
}
//PSControl allows update for policy status
type PSControl struct {
Client kyvernoclient.Interface
}
//UpdatePolicyStatus update policy status
func (c PSControl) UpdatePolicyStatus(newPolicy *kyverno.Policy) error {
_, err := c.Client.KyvernoV1alpha1().Policies().UpdateStatus(newPolicy)
return err
}

View file

@ -86,3 +86,11 @@ func NewKubeClient(config *rest.Config) (kubernetes.Interface, error) {
} }
return kclient, nil return kclient, nil
} }
//Btoi converts boolean to int
func Btoi(b bool) int {
if b {
return 1
}
return 0
}

View file

@ -20,14 +20,14 @@ func (ws *WebhookServer) HandleMutation(request *v1beta1.AdmissionRequest) (bool
gatherStat := func(policyName string, er engine.EngineResponse) { gatherStat := func(policyName string, er engine.EngineResponse) {
ps := policyctr.PolicyStat{} ps := policyctr.PolicyStat{}
ps.PolicyName = policyName ps.PolicyName = policyName
ps.MutationExecutionTime = er.ExecutionTime ps.Stats.MutationExecutionTime = er.ExecutionTime
ps.RulesAppliedCount = er.RulesAppliedCount ps.Stats.RulesAppliedCount = er.RulesAppliedCount
policyStats = append(policyStats, ps) policyStats = append(policyStats, ps)
} }
// send stats for aggregation // send stats for aggregation
sendStat := func(blocked bool) { sendStat := func(blocked bool) {
for _, stat := range policyStats { for _, stat := range policyStats {
stat.ResourceBlocked = blocked stat.Stats.ResourceBlocked = utils.Btoi(blocked)
//SEND //SEND
ws.policyStatus.SendStat(stat) ws.policyStatus.SendStat(stat)
} }

View file

@ -23,14 +23,14 @@ func (ws *WebhookServer) HandleValidation(request *v1beta1.AdmissionRequest, res
gatherStat := func(policyName string, er engine.EngineResponse) { gatherStat := func(policyName string, er engine.EngineResponse) {
ps := policyctr.PolicyStat{} ps := policyctr.PolicyStat{}
ps.PolicyName = policyName ps.PolicyName = policyName
ps.ValidationExecutionTime = er.ExecutionTime ps.Stats.ValidationExecutionTime = er.ExecutionTime
ps.RulesAppliedCount = er.RulesAppliedCount ps.Stats.RulesAppliedCount = er.RulesAppliedCount
policyStats = append(policyStats, ps) policyStats = append(policyStats, ps)
} }
// send stats for aggregation // send stats for aggregation
sendStat := func(blocked bool) { sendStat := func(blocked bool) {
for _, stat := range policyStats { for _, stat := range policyStats {
stat.ResourceBlocked = blocked stat.Stats.ResourceBlocked = utils.Btoi(blocked)
//SEND //SEND
ws.policyStatus.SendStat(stat) ws.policyStatus.SendStat(stat)
} }