Search Options

Results per page
Sort
Preferred Languages
Advance

Results 81 - 90 of 1,432 for stopCh (0.21 sec)

  1. pkg/kubelet/pluginmanager/reconciler/reconciler.go

    	handlers            map[string]cache.PluginHandler
    	sync.RWMutex
    }
    
    var _ Reconciler = &reconciler{}
    
    func (rc *reconciler) Run(stopCh <-chan struct{}) {
    	wait.Until(func() {
    		rc.reconcile()
    	},
    		rc.loopSleepDuration,
    		stopCh)
    }
    
    func (rc *reconciler) AddHandler(pluginType string, pluginHandler cache.PluginHandler) {
    	rc.Lock()
    	defer rc.Unlock()
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sun Dec 18 04:27:38 UTC 2022
    - 6.2K bytes
    - Viewed (0)
  2. pkg/util/concurrent/debouncer.go

    // limitations under the License.
    
    package concurrent
    
    import (
    	"time"
    
    	"istio.io/istio/pkg/util/sets"
    )
    
    type Debouncer[T comparable] struct{}
    
    func (d *Debouncer[T]) Run(ch chan T, stopCh <-chan struct{}, debounceMinInterval, debounceMaxInterval time.Duration, pushFn func(sets.Set[T])) {
    	var timeChan <-chan time.Time
    	var startDebounce time.Time
    	var lastConfigUpdateTime time.Time
    
    	pushCounter := 0
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Mon Apr 01 13:44:06 UTC 2024
    - 2.4K bytes
    - Viewed (0)
  3. 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)
  4. staging/src/k8s.io/apimachinery/pkg/util/wait/poll.go

    // defined by the context package. Will be removed in a future release.
    func PollUntil(interval time.Duration, condition ConditionFunc, stopCh <-chan struct{}) error {
    	return PollUntilWithContext(ContextForChannel(stopCh), interval, condition.WithContext())
    }
    
    // PollUntilWithContext tries a condition func until it returns true,
    // an error or the specified context is cancelled or expired.
    //
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Fri May 26 06:13:35 UTC 2023
    - 14K bytes
    - Viewed (0)
  5. 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)
  6. staging/src/k8s.io/apiserver/pkg/audit/union_test.go

    	events []*auditinternal.Event
    }
    
    func (f *fakeBackend) ProcessEvents(events ...*auditinternal.Event) bool {
    	f.events = append(f.events, events...)
    	return true
    }
    
    func (f *fakeBackend) Run(stopCh <-chan struct{}) error {
    	return nil
    }
    
    func (f *fakeBackend) Shutdown() {
    	// Nothing to do here.
    }
    
    func (f *fakeBackend) String() string {
    	return ""
    }
    
    func TestUnion(t *testing.T) {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Fri May 20 09:51:25 UTC 2022
    - 2.6K bytes
    - Viewed (0)
  7. 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)
  8. staging/src/k8s.io/apiserver/pkg/util/flowcontrol/dropped_requests_tracker_test.go

    					time.Sleep(25 * time.Millisecond)
    				}
    			}()
    		}
    	}
    	// Time-advancing goroutine.
    	stopCh := make(chan struct{})
    	timeWg := sync.WaitGroup{}
    	timeWg.Add(1)
    	go func() {
    		defer timeWg.Done()
    		for {
    			select {
    			case <-stopCh:
    				return
    			case <-time.After(25 * time.Millisecond):
    				fakeClock.Step(time.Second)
    			}
    		}
    	}()
    
    	b.StartTimer()
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Fri May 26 13:50:25 UTC 2023
    - 4.9K bytes
    - Viewed (0)
  9. pkg/kube/multicluster/secretcontroller.go

    		if features.LocalClusterSecretWatcher && features.ExternalIstiod {
    			c.secrets.Start(stopCh)
    		}
    		if !kube.WaitForCacheSync("multicluster remote secrets", stopCh, c.secrets.HasSynced) {
    			return
    		}
    		log.Infof("multicluster remote secrets controller cache synced in %v", time.Since(t0))
    		c.queue.Run(stopCh)
    		c.handleDelete(c.configClusterID)
    	}()
    	return nil
    }
    
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Wed Mar 06 02:13:10 UTC 2024
    - 12.7K bytes
    - Viewed (0)
  10. 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)
Back to top