Search Options

Results per page
Sort
Preferred Languages
Advance

Results 81 - 90 of 954 for waitc (0.05 sec)

  1. 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)
  2. platforms/documentation/docs/src/snippets/workerApi/waitForCompletion/groovy/build.gradle

                }
            }
    
            // Wait for all asynchronous work submitted to this queue to complete before continuing
            workQueue.await()
            logger.lifecycle("Created ${outputDir.get().asFile.listFiles().length} reversed files in ${projectLayout.projectDirectory.asFile.relativePath(outputDir.get().asFile)}")
    
            // end::wait-for-completion[]
        }
    }
    
    task reverseFiles(type: ReverseFiles) {
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Mon Nov 27 17:53:42 UTC 2023
    - 2.1K bytes
    - Viewed (0)
  3. 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)
  4. pkg/queue/instance_test.go

    			out = append(out, i)
    			defer mu.Unlock()
    			wg.Done()
    			return nil
    		})
    
    		// Start the queue at the halfway point.
    		if i == numValues/2 {
    			go q.Run(stop)
    		}
    	}
    
    	// wait for all task processed
    	wg.Wait()
    
    	if len(out) != numValues {
    		t.Fatalf("expected output array length %d to equal %d", len(out), numValues)
    	}
    
    	for i := 0; i < numValues; i++ {
    		if i != out[i] {
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Fri Jul 21 16:30:36 UTC 2023
    - 3.4K bytes
    - Viewed (0)
  5. src/cmd/vendor/golang.org/x/sys/unix/syscall_aix.go

    }
    
    //sys	wait4(pid Pid_t, status *_C_int, options int, rusage *Rusage) (wpid Pid_t, err error)
    
    func Wait4(pid int, wstatus *WaitStatus, options int, rusage *Rusage) (wpid int, err error) {
    	var status _C_int
    	var r Pid_t
    	err = ERESTART
    	// AIX wait4 may return with ERESTART errno, while the processus is still
    	// active.
    	for err == ERESTART {
    		r, err = wait4(Pid_t(pid), &status, options, rusage)
    	}
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Wed Nov 29 21:28:33 UTC 2023
    - 16.1K bytes
    - Viewed (0)
  6. platforms/software/version-control/src/integTest/groovy/org/gradle/vcs/internal/ParallelSourceDependencyIntegrationTest.groovy

            """
    
            when:
            // Wait for each project to list versions concurrently
            httpServer.expectConcurrent("A", "B", "C", "D")
            // Only one project should clone
            repo.expectListVersions()
            repo.expectCloneSomething()
    
            then:
            succeeds('resolve', '--parallel', '--max-workers=4')
    
            when:
            // Wait for each project to list versions concurrently
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Tue Oct 24 06:54:47 UTC 2023
    - 4.5K bytes
    - Viewed (0)
  7. 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)
  8. 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)
  9. 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)
  10. pkg/kubelet/winstats/perfcounters_test.go

    			}
    
    			// There are some counters that we can't expect to see any non-zero values, like the
    			// networking-related counters.
    			if tc.skipCheck {
    				return
    			}
    
    			// Wait until we get a non-zero perf counter data.
    			if pollErr := wait.Poll(100*time.Millisecond, 5*perfCounterUpdatePeriod, func() (bool, error) {
    				data, err := counter.getData()
    				if err != nil {
    					return false, err
    				}
    
    				if data != 0 {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Thu Apr 25 14:24:16 UTC 2024
    - 3.5K bytes
    - Viewed (0)
Back to top