Search Options

Results per page
Sort
Preferred Languages
Advance

Results 21 - 30 of 505 for stopCh (0.36 sec)

  1. staging/src/k8s.io/apiserver/pkg/server/hooks.go

    	LoopbackClientConfig *restclient.Config
    	// StopCh is the channel that will be closed when the server stops.
    	//
    	// Deprecated: use the PostStartHookContext itself instead, it contains a context that
    	// gets cancelled when the server stops. StopCh keeps getting provided for existing code.
    	StopCh <-chan struct{}
    	// Context gets cancelled when the server stops.
    	context.Context
    }
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Mon Apr 29 18:59:21 UTC 2024
    - 8K bytes
    - Viewed (0)
  2. pkg/proxy/config/config.go

    }
    
    // Run waits for cache synced and invokes handlers after syncing.
    func (c *EndpointSliceConfig) Run(stopCh <-chan struct{}) {
    	c.logger.Info("Starting endpoint slice config controller")
    
    	if !cache.WaitForNamedCacheSync("endpoint slice config", stopCh, c.listerSynced) {
    		return
    	}
    
    	for _, h := range c.eventHandlers {
    		c.logger.V(3).Info("Calling handler.OnEndpointSlicesSynced()")
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Mon Apr 22 05:08:41 UTC 2024
    - 15.1K bytes
    - Viewed (0)
  3. staging/src/k8s.io/apimachinery/pkg/watch/watch.go

    func (pw *ProxyWatcher) StopChan() <-chan struct{} {
    	return pw.stopCh
    }
    
    // MockWatcher implements watch.Interface with mockable functions.
    type MockWatcher struct {
    	StopFunc       func()
    	ResultChanFunc func() <-chan Event
    }
    
    var _ Interface = &MockWatcher{}
    
    // Stop calls StopFunc
    func (mw MockWatcher) Stop() {
    	mw.StopFunc()
    }
    
    // ResultChan calls ResultChanFunc
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed Jun 12 20:06:22 UTC 2024
    - 8.1K bytes
    - Viewed (1)
  4. staging/src/k8s.io/apiserver/pkg/server/dynamiccertificates/tlsconfig.go

    	_ = c.RunOnce()
    
    	// doesn't matter what workers say, only start one.
    	go wait.Until(c.runWorker, time.Second, stopCh)
    
    	// start timer that rechecks every minute, just in case.  this also serves to prime the controller quickly.
    	go wait.Until(func() {
    		c.Enqueue()
    	}, 1*time.Minute, stopCh)
    
    	<-stopCh
    }
    
    func (c *DynamicServingCertificateController) runWorker() {
    	for c.processNextWorkItem() {
    	}
    }
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 10.3K bytes
    - Viewed (0)
  5. staging/src/k8s.io/apiserver/pkg/storage/storagebackend/factory/etcd3.go

    	}
    	return l
    }
    
    func newETCD3HealthCheck(c storagebackend.Config, stopCh <-chan struct{}) (func() error, error) {
    	timeout := storagebackend.DefaultHealthcheckTimeout
    	if c.HealthcheckTimeout != time.Duration(0) {
    		timeout = c.HealthcheckTimeout
    	}
    	return newETCD3Check(c, timeout, stopCh)
    }
    
    func newETCD3ReadyCheck(c storagebackend.Config, stopCh <-chan struct{}) (func() error, error) {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed Apr 24 07:56:39 UTC 2024
    - 15.1K bytes
    - Viewed (0)
  6. staging/src/k8s.io/apiextensions-apiserver/pkg/apiserver/customresource_discovery_controller.go

    	})
    }
    
    func (c *DiscoveryController) Run(stopCh <-chan struct{}, synchedCh chan<- struct{}) {
    	defer utilruntime.HandleCrash()
    	defer c.queue.ShutDown()
    	defer klog.Info("Shutting down DiscoveryController")
    
    	klog.Info("Starting DiscoveryController")
    
    	if !cache.WaitForCacheSync(stopCh, c.crdsSynced) {
    		utilruntime.HandleError(fmt.Errorf("timed out waiting for caches to sync"))
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sun Apr 21 11:40:03 UTC 2024
    - 12.8K bytes
    - Viewed (0)
  7. staging/src/k8s.io/apiextensions-apiserver/pkg/controller/apiapproval/apiapproval_controller.go

    func (c *KubernetesAPIApprovalPolicyConformantConditionController) Run(workers int, stopCh <-chan struct{}) {
    	defer utilruntime.HandleCrash()
    	defer c.queue.ShutDown()
    
    	klog.Infof("Starting KubernetesAPIApprovalPolicyConformantConditionController")
    	defer klog.Infof("Shutting down KubernetesAPIApprovalPolicyConformantConditionController")
    
    	if !cache.WaitForCacheSync(stopCh, c.crdSynced) {
    		return
    	}
    
    	for i := 0; i < workers; i++ {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 9.2K bytes
    - Viewed (0)
  8. pkg/controller/tainteviction/taint_eviction.go

    	// into channels.
    	go func(stopCh <-chan struct{}) {
    		for {
    			nodeUpdate, shutdown := tc.nodeUpdateQueue.Get()
    			if shutdown {
    				break
    			}
    			hash := hash(nodeUpdate.nodeName, UpdateWorkerSize)
    			select {
    			case <-stopCh:
    				tc.nodeUpdateQueue.Done(nodeUpdate)
    				return
    			case tc.nodeUpdateChannels[hash] <- nodeUpdate:
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 19.9K bytes
    - Viewed (0)
  9. pkg/controller/deployment/deployment_controller_test.go

    	c, informers, err := f.newController(ctx)
    	if err != nil {
    		f.t.Fatalf("error creating Deployment controller: %v", err)
    	}
    	if startInformers {
    		stopCh := make(chan struct{})
    		defer close(stopCh)
    		informers.Start(stopCh)
    	}
    
    	err = c.syncDeployment(ctx, deploymentName)
    	if !expectError && err != nil {
    		f.t.Errorf("error syncing deployment: %v", err)
    	} else if expectError && err == nil {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 32.5K bytes
    - Viewed (0)
  10. staging/src/k8s.io/apiextensions-apiserver/pkg/controller/nonstructuralschema/nonstructuralschema_controller.go

    }
    
    // Run starts the controller.
    func (c *ConditionController) Run(workers int, stopCh <-chan struct{}) {
    	defer utilruntime.HandleCrash()
    	defer c.queue.ShutDown()
    
    	klog.Infof("Starting NonStructuralSchemaConditionController")
    	defer klog.Infof("Shutting down NonStructuralSchemaConditionController")
    
    	if !cache.WaitForCacheSync(stopCh, c.crdSynced) {
    		return
    	}
    
    	for i := 0; i < workers; i++ {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 8.3K bytes
    - Viewed (0)
Back to top