Search Options

Results per page
Sort
Preferred Languages
Advance

Results 51 - 60 of 471 for stopCh (0.15 sec)

  1. cmd/kube-controller-manager/app/controllermanager.go

    			logger.Error(err, "Error starting controllers")
    			klog.FlushAndExit(klog.ExitFlushTimeout, 1)
    		}
    
    		controllerContext.InformerFactory.Start(stopCh)
    		controllerContext.ObjectOrMetadataInformerFactory.Start(stopCh)
    		close(controllerContext.InformersStarted)
    
    		<-ctx.Done()
    	}
    
    	// No leader election, run directly
    	if !c.ComponentConfig.Generic.LeaderElection.LeaderElect {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed May 01 13:03:53 UTC 2024
    - 37.5K bytes
    - Viewed (0)
  2. staging/src/k8s.io/apiserver/pkg/storage/cacher/watch_cache_test.go

    		case <-ctx.Done():
    			return
    		}
    	}()
    	return nil
    }
    
    func (w *testWatchCache) Stop() {
    	close(w.stopCh)
    }
    
    func TestWatchCacheBasic(t *testing.T) {
    	store := newTestWatchCache(2, &cache.Indexers{})
    	defer store.Stop()
    
    	// Test Add/Update/Delete.
    	pod1 := makeTestPod("pod", 1)
    	if err := store.Add(pod1); err != nil {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Tue Jun 04 09:20:10 UTC 2024
    - 35.4K bytes
    - Viewed (0)
  3. staging/src/k8s.io/apiserver/pkg/server/config.go

    		if !s.isPostStartHookRegistered(genericApiServerHookName) {
    			err := s.AddPostStartHook(genericApiServerHookName, func(context PostStartHookContext) error {
    				c.SharedInformerFactory.Start(context.StopCh)
    				return nil
    			})
    			if err != nil {
    				return nil, err
    			}
    		}
    		// TODO: Once we get rid of /healthz consider changing this to post-start-hook.
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Tue May 28 08:48:22 UTC 2024
    - 47.7K bytes
    - Viewed (0)
  4. staging/src/k8s.io/apiserver/pkg/server/genericapiserver_graceful_termination_test.go

    type fakeAudit struct {
    	shutdownCh chan struct{}
    	lock       sync.Mutex
    	audits     map[string]struct{}
    	completed  bool
    }
    
    func (a *fakeAudit) Run(stopCh <-chan struct{}) error {
    	a.shutdownCh = make(chan struct{})
    	go func() {
    		defer close(a.shutdownCh)
    		<-stopCh
    	}()
    	return nil
    }
    
    func (a *fakeAudit) Shutdown() {
    	<-a.shutdownCh
    
    	a.lock.Lock()
    	defer a.lock.Unlock()
    	a.completed = true
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Mon Apr 29 18:59:21 UTC 2024
    - 38.3K bytes
    - Viewed (0)
  5. pkg/kubelet/cm/dra/manager_test.go

    		return fakeDRAServerInfo{
    			server:     nil,
    			socketName: "",
    			teardownFn: nil,
    		}, err
    	}
    
    	socketName := filepath.Join(socketDir, "server.sock")
    	stopCh := make(chan struct{})
    
    	teardown := func() {
    		close(stopCh)
    		os.RemoveAll(socketName)
    	}
    
    	l, err := net.Listen("unix", socketName)
    	if err != nil {
    		teardown()
    		return fakeDRAServerInfo{
    			server:     nil,
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Fri May 03 13:30:29 UTC 2024
    - 42K bytes
    - Viewed (0)
  6. staging/src/k8s.io/apiserver/pkg/util/flowcontrol/apf_controller.go

    	}
    
    	klog.Info("Running API Priority and Fairness config worker")
    	go wait.Until(cfgCtlr.runWorker, time.Second, stopCh)
    
    	klog.Info("Running API Priority and Fairness periodic rebalancing process")
    	go wait.Until(cfgCtlr.updateBorrowing, borrowingAdjustmentPeriod, stopCh)
    
    	<-stopCh
    	klog.Info("Shutting down API Priority and Fairness config worker")
    	return nil
    }
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 48.8K bytes
    - Viewed (0)
  7. pkg/controller/resourcequota/resource_quota_controller.go

    }
    
    // waitForStopOrTimeout returns a stop channel that closes when the provided stop channel closes or when the specified timeout is reached
    func waitForStopOrTimeout(stopCh <-chan struct{}, timeout time.Duration) <-chan struct{} {
    	stopChWithTimeout := make(chan struct{})
    	go func() {
    		defer close(stopChWithTimeout)
    		select {
    		case <-stopCh:
    		case <-time.After(timeout):
    		}
    	}()
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 21.3K bytes
    - Viewed (0)
  8. pkg/volume/plugins.go

    	}
    
    	return nil, nil
    }
    
    func (pm *VolumePluginMgr) Run(stopCh <-chan struct{}) {
    	kletHost, ok := pm.Host.(KubeletVolumeHost)
    	if ok {
    		// start informer for CSIDriver
    		informerFactory := kletHost.GetInformerFactory()
    		informerFactory.Start(stopCh)
    		informerFactory.WaitForCacheSync(stopCh)
    	}
    }
    
    // NewPersistentVolumeRecyclerPodTemplate creates a template for a recycler
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Thu Jun 06 16:13:15 UTC 2024
    - 38.2K bytes
    - Viewed (0)
  9. staging/src/k8s.io/apiserver/pkg/authentication/request/headerrequest/requestheader_controller.go

    }
    
    func (c *RequestHeaderAuthRequestController) AllowedClientNames() []string {
    	return c.loadRequestHeaderFor(c.allowedClientNamesKey)
    }
    
    // Run starts RequestHeaderAuthRequestController controller and blocks until stopCh is closed.
    func (c *RequestHeaderAuthRequestController) Run(ctx context.Context, workers int) {
    	defer utilruntime.HandleCrash()
    	defer c.queue.ShutDown()
    
    	klog.Infof("Starting %s", c.name)
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 10.9K bytes
    - Viewed (0)
  10. pilot/pkg/autoregistration/controller.go

    	return c
    }
    
    func (c *Controller) Run(stop <-chan struct{}) {
    	if c == nil {
    		return
    	}
    	if c.store != nil && c.cleanupQueue != nil {
    		go c.periodicWorkloadEntryCleanup(stop)
    		go c.cleanupQueue.Run(stop)
    	}
    	if features.WorkloadEntryAutoRegistration {
    		go c.lateRegistrationQueue.Run(stop)
    	}
    
    	go c.queue.Run(stop)
    	go c.healthController.Run(stop)
    	<-stop
    }
    
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Tue Apr 16 00:00:36 UTC 2024
    - 26.4K bytes
    - Viewed (0)
Back to top