Search Options

Results per page
Sort
Preferred Languages
Advance

Results 121 - 130 of 401 for Informer (0.15 sec)

  1. staging/src/k8s.io/apiextensions-apiserver/pkg/controller/finalizer/crd_finalizer.go

    // NewCRDFinalizer creates a new CRDFinalizer.
    func NewCRDFinalizer(
    	crdInformer informers.CustomResourceDefinitionInformer,
    	crdClient client.CustomResourceDefinitionsGetter,
    	crClientGetter CRClientGetter,
    ) *CRDFinalizer {
    	c := &CRDFinalizer{
    		crdClient:      crdClient,
    		crdLister:      crdInformer.Lister(),
    		crdSynced:      crdInformer.Informer().HasSynced,
    		crClientGetter: crClientGetter,
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 12.6K bytes
    - Viewed (0)
  2. pkg/controller/daemon/daemon_controller.go

    	dsc.podStoreSynced = podInformer.Informer().HasSynced
    
    	nodeInformer.Informer().AddEventHandler(cache.ResourceEventHandlerFuncs{
    		AddFunc: func(obj interface{}) {
    			dsc.addNode(logger, obj)
    		},
    		UpdateFunc: func(oldObj, newObj interface{}) {
    			dsc.updateNode(logger, oldObj, newObj)
    		},
    	},
    	)
    	dsc.nodeStoreSynced = nodeInformer.Informer().HasSynced
    	dsc.nodeLister = nodeInformer.Lister()
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 51.3K bytes
    - Viewed (0)
  3. pilot/pkg/serviceregistry/kube/controller/multicluster.go

    						nc := NewNamespaceController(client, m.caBundleWatcher)
    						// Start informers again. This fixes the case where informers for namespace do not start,
    						// as we create them only after acquiring the leader lock
    						// Note: stop here should be the overall pilot stop, NOT the leader election stop. We are
    						// basically lazy loading the informer, if we stop it when we lose the lock we will never
    						// recreate it again.
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Thu May 23 21:07:03 UTC 2024
    - 12.7K bytes
    - Viewed (0)
  4. staging/src/k8s.io/apiextensions-apiserver/pkg/apiserver/customresource_discovery_controller.go

    		crdLister:       crdInformer.Lister(),
    		crdsSynced:      crdInformer.Informer().HasSynced,
    
    		queue: workqueue.NewTypedRateLimitingQueueWithConfig(
    			workqueue.DefaultTypedControllerRateLimiter[schema.GroupVersion](),
    			workqueue.TypedRateLimitingQueueConfig[schema.GroupVersion]{Name: "DiscoveryController"},
    		),
    	}
    
    	crdInformer.Informer().AddEventHandler(cache.ResourceEventHandlerFuncs{
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sun Apr 21 11:40:03 UTC 2024
    - 12.8K bytes
    - Viewed (0)
  5. pkg/controller/nodeipam/node_ipam_controller.go

    		if err != nil {
    			return nil, err
    		}
    	}
    
    	ic.nodeLister = nodeInformer.Lister()
    	ic.nodeInformerSynced = nodeInformer.Informer().HasSynced
    
    	return ic, nil
    }
    
    // Run starts an asynchronous loop that monitors the status of cluster nodes.
    func (nc *Controller) Run(ctx context.Context) {
    	defer utilruntime.HandleCrash()
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Thu Jun 06 16:18:38 UTC 2024
    - 5.4K bytes
    - Viewed (0)
  6. pkg/controller/validatingadmissionpolicystatus/controller.go

    			workqueue.TypedRateLimitingQueueConfig[string]{Name: ControllerName},
    		),
    		policyClient: policyClient,
    		typeChecker:  typeChecker,
    	}
    	reg, err := policyInformer.Informer().AddEventHandler(cache.ResourceEventHandlerFuncs{
    		AddFunc: func(obj interface{}) {
    			c.enqueuePolicy(obj)
    		},
    		UpdateFunc: func(oldObj, newObj interface{}) {
    			c.enqueuePolicy(newObj)
    		},
    	})
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 5.3K bytes
    - Viewed (0)
  7. pkg/scheduler/framework/plugins/volumebinding/binder_test.go

    		classInformer,
    		capacityCheck,
    		10*time.Second)
    
    	// Wait for informers cache sync
    	informerFactory.Start(ctx.Done())
    	for v, synced := range informerFactory.WaitForCacheSync(ctx.Done()) {
    		if !synced {
    			logger.Error(nil, "Error syncing informer", "informer", v)
    			os.Exit(1)
    		}
    	}
    
    	// Add storageclasses
    	waitMode := storagev1.VolumeBindingWaitForFirstConsumer
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Thu Apr 25 09:46:58 UTC 2024
    - 82.8K bytes
    - Viewed (0)
  8. pkg/controller/endpointslice/endpointslice_controller_test.go

    	return client, &endpointSliceController{
    		esController,
    		informerFactory.Discovery().V1().EndpointSlices().Informer().GetStore(),
    		informerFactory.Core().V1().Nodes().Informer().GetStore(),
    		informerFactory.Core().V1().Pods().Informer().GetStore(),
    		informerFactory.Core().V1().Services().Informer().GetStore(),
    	}
    }
    
    func newPod(n int, namespace string, ready bool, nPorts int, terminating bool) *v1.Pod {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Tue Jun 04 08:33:32 UTC 2024
    - 65.5K bytes
    - Viewed (0)
  9. pkg/scheduler/framework/plugins/nodeunschedulable/node_unschedulable.go

    	}
    }
    
    // isSchedulableAfterNodeChange is invoked for all node events reported by
    // an informer. It checks whether that change made a previously unschedulable
    // pod schedulable.
    func (pl *NodeUnschedulable) isSchedulableAfterNodeChange(logger klog.Logger, pod *v1.Pod, oldObj, newObj interface{}) (framework.QueueingHint, error) {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat Dec 16 12:50:11 UTC 2023
    - 3.9K bytes
    - Viewed (0)
  10. staging/src/k8s.io/apiserver/pkg/admission/plugin/policy/generic/policy_dispatcher.go

    		}
    
    		// If the param informer for this admission policy has not yet
    		// had time to perform an initial listing, don't attempt to use
    		// it.
    		timeoutCtx, cancel := context.WithTimeout(context.Background(), 1*time.Second)
    		defer cancel()
    
    		if !cache.WaitForCacheSync(timeoutCtx.Done(), paramInformer.Informer().HasSynced) {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed Mar 06 00:00:21 UTC 2024
    - 12.1K bytes
    - Viewed (0)
Back to top