Search Options

Results per page
Sort
Preferred Languages
Advance

Results 91 - 100 of 1,038 for stopCh (0.31 sec)

  1. pilot/pkg/bootstrap/certcontroller.go

    					log.Errorf("error watching %v: %v", tlsOptions.KeyFile, err)
    				case <-stop:
    					return
    				}
    			}
    		}()
    		return nil
    	})
    	return nil
    }
    
    func (s *Server) reloadIstiodCert(watchCh <-chan struct{}, stopCh <-chan struct{}) {
    	for {
    		select {
    		case <-stopCh:
    			return
    		case <-watchCh:
    			if err := s.loadIstiodCert(); err != nil {
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Thu Jun 13 17:48:28 UTC 2024
    - 11.3K bytes
    - Viewed (0)
  2. 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)
  3. 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)
  4. 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)
  5. pkg/controller/clusterroleaggregation/clusterroleaggregation_controller.go

    	for _, curr := range haystack {
    		if equality.Semantic.DeepEqual(curr, needle) {
    			return true
    		}
    	}
    	return false
    }
    
    // Run starts the controller and blocks until stopCh is closed.
    func (c *ClusterRoleAggregationController) Run(ctx context.Context, workers int) {
    	defer utilruntime.HandleCrash()
    	defer c.queue.ShutDown()
    
    	logger := klog.FromContext(ctx)
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 8K bytes
    - Viewed (0)
  6. staging/src/k8s.io/apiserver/pkg/util/flowcontrol/apf_filter.go

    		execFn func(),
    	)
    
    	// Run monitors config objects from the main apiservers and causes
    	// any needed changes to local behavior.  This method ceases
    	// activity and returns after the given channel is closed.
    	Run(stopCh <-chan struct{}) error
    
    	// Install installs debugging endpoints to the web-server.
    	Install(c *mux.PathRecorderMux)
    
    	// WatchTracker provides the WatchTracker interface.
    	WatchTracker
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Mon Oct 30 12:18:35 UTC 2023
    - 8K bytes
    - Viewed (0)
  7. pilot/pkg/serviceregistry/serviceentry/controller_test.go

    	if svc != nil {
    		t.Fatalf("expected nil, got %v", svc)
    	}
    }
    
    func BenchmarkServiceEntryHandler(b *testing.B) {
    	_, sd := initServiceDiscoveryWithoutEvents(b)
    	stopCh := make(chan struct{})
    	go sd.Run(stopCh)
    	defer close(stopCh)
    	for i := 0; i < b.N; i++ {
    		sd.serviceEntryHandler(config.Config{}, *httpDNS, model.EventAdd)
    		sd.serviceEntryHandler(config.Config{}, *httpDNSRR, model.EventAdd)
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Wed May 29 15:31:09 UTC 2024
    - 92.9K bytes
    - Viewed (0)
  8. pkg/controller/endpointslice/endpointslice_controller_test.go

    	for _, tc := range tests {
    		t.Run(tc.name, func(t *testing.T) {
    			ns := metav1.NamespaceDefault
    			client, esController := newController(t, []string{"node-1"}, tc.batchPeriod)
    			stopCh := make(chan struct{})
    			defer close(stopCh)
    
    			_, ctx := ktesting.NewTestContext(t)
    			go esController.Run(ctx, 1)
    
    			esController.serviceStore.Add(&v1.Service{
    				ObjectMeta: metav1.ObjectMeta{Name: "foo", Namespace: ns},
    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. 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)
  10. 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)
Back to top