Search Options

Results per page
Sort
Preferred Languages
Advance

Results 51 - 60 of 722 for waitc (0.23 sec)

  1. pkg/controller/volume/attachdetach/attach_detach_controller.go

    	// DesiredStateOfWorldPopulatorLoopSleepPeriod is the amount of time the
    	// DesiredStateOfWorldPopulator loop waits between successive executions
    	DesiredStateOfWorldPopulatorLoopSleepPeriod time.Duration
    
    	// DesiredStateOfWorldPopulatorListPodsRetryDuration is the amount of
    	// time the DesiredStateOfWorldPopulator loop waits between list pods
    	// calls.
    	DesiredStateOfWorldPopulatorListPodsRetryDuration time.Duration
    }
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 32.6K bytes
    - Viewed (0)
  2. staging/src/k8s.io/apiserver/pkg/admission/plugin/policy/internal/generic/controller_test.go

    		require.ErrorIs(t, stopReason, context.Canceled)
    	}()
    
    	// Wait for controller and informer to start up
    	require.True(t, cache.WaitForCacheSync(testContext.Done(), myController.HasSynced))
    
    	// Stop the controller and informer
    	testCancel()
    
    	// Wait for controller and informer to stop
    	wg.Wait()
    
    	// Ensure the event handler was cleaned up
    	require.Empty(t, informer.registrations)
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Mon Feb 12 18:58:24 UTC 2024
    - 16.1K bytes
    - Viewed (0)
  3. src/os/exec/exec_test.go

    	var wg sync.WaitGroup
    	wg.Add(1)
    	defer wg.Wait()
    	go func() {
    		defer wg.Done()
    
    		_, err := io.Copy(stdin, strings.NewReader(stdinCloseTestString))
    		check("Copy", err)
    
    		// Before the fix, this next line would race with cmd.Wait.
    		if err := stdin.Close(); err != nil && !errors.Is(err, os.ErrClosed) {
    			t.Errorf("Close: %v", err)
    		}
    	}()
    
    	check("Wait", cmd.Wait())
    }
    
    // Issue 17647.
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Fri Jun 07 20:13:53 UTC 2024
    - 48.4K bytes
    - Viewed (0)
  4. pkg/kube/multicluster/cluster.go

    	Update
    )
    
    func (a ACTION) String() string {
    	switch a {
    	case Add:
    		return "Add"
    	case Update:
    		return "Update"
    	}
    	return "Unknown"
    }
    
    // Run starts the cluster's informers and waits for caches to sync. Once caches are synced, we mark the cluster synced.
    // This should be called after each of the handlers have registered informers, and should be run in a goroutine.
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Wed Mar 06 02:13:10 UTC 2024
    - 3.8K bytes
    - Viewed (0)
  5. internal/config/batch/batch.go

    	config.KV{
    		Key:   ReplicationWorkersWait,
    		Value: "0ms", // No wait by default between each replication attempts.
    	},
    	config.KV{
    		Key:   KeyRotationWorkersWait,
    		Value: "0ms", // No wait by default between each key rotation attempts.
    	},
    	config.KV{
    		Key:   ExpirationWorkersWait,
    		Value: "0ms", // No wait by default between each expiration attempts.
    	},
    }
    
    Registered: Sun Jun 16 00:44:34 UTC 2024
    - Last Modified: Fri May 24 23:05:23 UTC 2024
    - 4.7K bytes
    - Viewed (0)
  6. guava-tests/test/com/google/common/util/concurrent/TrustedListenableFutureTaskTest.java

          }
          barrier.await(); // release the threads!
          barrier.await(); // wait for them all to complete
          assertEquals(1, task.get().intValue());
          assertEquals(1, counter.get());
        }
        executor.shutdown();
      }
    
      @J2ktIncompatible
      @GwtIncompatible // blocking wait
      public void testToString() throws Exception {
        final CountDownLatch enterLatch = new CountDownLatch(1);
    Registered: Wed Jun 12 16:38:11 UTC 2024
    - Last Modified: Tue Feb 13 14:28:25 UTC 2024
    - 7.3K bytes
    - Viewed (0)
  7. src/unique/handle_test.go

    func drainMaps(t *testing.T) {
    	t.Helper()
    
    	wait := make(chan struct{}, 1)
    
    	// Set up a one-time notification for the next time the cleanup runs.
    	// Note: this will only run if there's no other active cleanup, so
    	// we can be sure that the next time cleanup runs, it'll see the new
    	// notification.
    	cleanupMu.Lock()
    	cleanupNotify = append(cleanupNotify, func() {
    		select {
    		case wait <- struct{}{}:
    		default:
    		}
    	})
    
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Mon Apr 22 18:14:07 UTC 2024
    - 2.5K bytes
    - Viewed (0)
  8. cmd/kubeadm/app/cmd/phases/init/waitcontrolplane.go

    	`)))
    )
    
    // NewWaitControlPlanePhase is a hidden phase that runs after the control-plane and etcd phases
    func NewWaitControlPlanePhase() workflow.Phase {
    	phase := workflow.Phase{
    		Name:  "wait-control-plane",
    		Short: "Wait for the control plane to start",
    		// TODO: unhide this phase once WaitForAllControlPlaneComponents goes GA:
    		// https://github.com/kubernetes/kubeadm/issues/2907
    		Hidden: true,
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat Jun 01 07:10:31 UTC 2024
    - 5K bytes
    - Viewed (0)
  9. pkg/controller/volume/persistentvolume/pv_controller_test.go

    				reactor.DeleteClaimEvent(claim)
    				// wait until claim is cleared from cache, i.e., deleteClaim is called
    				err := wait.Poll(10*time.Millisecond, wait.ForeverTestTimeout, func() (bool, error) {
    					return len(ctrl.claims.ListKeys()) == 0, nil
    				})
    				if err != nil {
    					return err
    				}
    				// wait for volume delete operation to appear once volumeWorker() runs
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed Apr 24 18:25:29 UTC 2024
    - 43.4K bytes
    - Viewed (0)
  10. pkg/test/framework/config.go

    	for ns, y := range c.yamlText {
    		ns, y := ns, y
    		g.Go(func() error {
    			return c.applyYAML(options.Cleanup, ns, y...)
    		})
    	}
    
    	// Wait for all each apply to complete.
    	if err := g.Wait(); err != nil {
    		return err
    	}
    
    	if options.Wait {
    		// TODO: wait for each namespace concurrently once WaitForConfig supports concurrency.
    		for ns, y := range c.yamlText {
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Thu Jun 06 22:12:34 UTC 2024
    - 8.2K bytes
    - Viewed (0)
Back to top