Search Options

Results per page
Sort
Preferred Languages
Advance

Results 1 - 10 of 70 for waitc (0.08 sec)

  1. staging/src/k8s.io/apiserver/pkg/storage/cacher/cacher_whitebox_test.go

    			default:
    				cacher.Lock()
    				cacher.bookmarkWatchers.popExpiredWatchersThreadUnsafe()
    				cacher.Unlock()
    			}
    		}
    	}()
    
    	// wait for adding/removing watchers to end
    	wg.Wait()
    
    	if watchErr != nil {
    		t.Fatal(watchErr)
    	}
    
    	// wait out the expiration period and pop expired watchers
    	time.Sleep(2 * time.Second)
    	cacher.Lock()
    	defer cacher.Unlock()
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed Jun 12 10:12:02 UTC 2024
    - 82.9K bytes
    - Viewed (0)
  2. guava-tests/test/com/google/common/util/concurrent/AbstractClosingFutureTest.java

      }
    
      /**
       * Marks the given step final, waits for it to be finished, and returns the value.
       *
       * @throws ExecutionException if the step failed
       * @throws CancellationException if the step was cancelled
       */
      abstract <T> T getFinalValue(ClosingFuture<T> closingFuture) throws ExecutionException;
    
      /** Marks the given step final, cancels it, and waits for the cancellation to happen. */
    Registered: Wed Jun 12 16:38:11 UTC 2024
    - Last Modified: Tue May 07 12:37:15 UTC 2024
    - 75.3K bytes
    - Viewed (0)
  3. src/net/dnsclient_unix_test.go

    					A: TestAddr,
    				},
    			},
    		}
    	}
    	return r, nil
    }}
    
    // Issue 13705: don't try to resolve onion addresses, etc
    func TestLookupTorOnion(t *testing.T) {
    	defer dnsWaitGroup.Wait()
    	r := Resolver{PreferGo: true, Dial: fakeDNSServerSuccessful.DialContext}
    	addrs, err := r.LookupIPAddr(context.Background(), "foo.onion.")
    	if err != nil {
    		t.Fatalf("lookup = %v; want nil", err)
    	}
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Sun Apr 14 18:23:45 UTC 2024
    - 72.4K bytes
    - Viewed (0)
  4. src/net/http/transport.go

    	// ResponseHeaderTimeout, if non-zero, specifies the amount of
    	// time to wait for a server's response headers after fully
    	// writing the request (including its body, if any). This
    	// time does not include the time to read the response body.
    	ResponseHeaderTimeout time.Duration
    
    	// ExpectContinueTimeout, if non-zero, specifies the amount of
    	// time to wait for a server's first response headers after fully
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Thu Jun 06 21:59:21 UTC 2024
    - 91K bytes
    - Viewed (0)
  5. src/runtime/mgc.go

    	//
    	// 1. In sweep termination, mark, or mark termination of cycle
    	// N, wait until mark termination N completes and transitions
    	// to sweep N.
    	//
    	// 2. In sweep N, help with sweep N.
    	//
    	// At this point we can begin a full cycle N+1.
    	//
    	// 3. Trigger cycle N+1 by starting sweep termination N+1.
    	//
    	// 4. Wait for mark termination N+1 to complete.
    	//
    	// 5. Help with sweep N+1 until it's done.
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Wed May 29 16:25:21 UTC 2024
    - 62K bytes
    - Viewed (0)
  6. pkg/volume/csi/csi_attacher_test.go

    	ticker := time.NewTicker(10 * time.Millisecond)
    	var attach *storage.VolumeAttachment
    	var err error
    	defer ticker.Stop()
    	// wait for attachment to be saved
    	for i := 0; i < 100; i++ {
    		attach, err = client.StorageV1().VolumeAttachments().Get(context.TODO(), attachID, metav1.GetOptions{})
    		if err != nil {
    			attach = nil
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Thu Apr 18 12:23:16 UTC 2024
    - 58.1K bytes
    - Viewed (0)
  7. cmd/batch-handlers.go

    				// persist in-memory state to disk after every 10secs.
    				batchLogIf(ctx, ri.updateAfter(ctx, api, 10*time.Second, job))
    
    				if wait := globalBatchConfig.ReplicationWait(); wait > 0 {
    					time.Sleep(wait)
    				}
    			}()
    		}
    		wk.Wait()
    
    		ri.RetryAttempts = attempts
    		ri.Complete = ri.ObjectsFailed == 0
    		ri.Failed = ri.ObjectsFailed > 0
    
    		globalBatchJobsMetrics.save(job.ID, ri)
    Registered: Sun Jun 16 00:44:34 UTC 2024
    - Last Modified: Tue Jun 11 03:13:30 UTC 2024
    - 56K bytes
    - Viewed (0)
  8. staging/src/k8s.io/apiserver/pkg/storage/testing/watcher_tests.go

    	})
    	if err != nil {
    		t.Fatal(err)
    	}
    
    	select {
    	case _, ok := <-w.ResultChan():
    		if ok {
    			t.Error("ResultChan() should be closed")
    		}
    	case <-time.After(wait.ForeverTestTimeout):
    		t.Errorf("timeout after %v", wait.ForeverTestTimeout)
    	}
    }
    
    func RunTestWatcherTimeout(ctx context.Context, t *testing.T, store storage.Interface) {
    	// initialRV is used to initate the watcher at the beginning of the world.
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed Apr 24 18:25:29 UTC 2024
    - 63.8K bytes
    - Viewed (0)
  9. pkg/scheduler/internal/queue/scheduling_queue.go

    	return pq
    }
    
    // Run starts the goroutine to pump from podBackoffQ to activeQ
    func (p *PriorityQueue) Run(logger klog.Logger) {
    	go wait.Until(func() {
    		p.flushBackoffQCompleted(logger)
    	}, 1.0*time.Second, p.stop)
    	go wait.Until(func() {
    		p.flushUnschedulablePodsLeftover(logger)
    	}, 30*time.Second, p.stop)
    }
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed Jun 12 13:26:09 UTC 2024
    - 61.4K bytes
    - Viewed (0)
  10. pkg/controller/volume/attachdetach/reconciler/reconciler_test.go

    			fakePlugin.GetNewDetacherCallCount())
    	}
    }
    
    func retryWithExponentialBackOff(initialDuration time.Duration, fn wait.ConditionFunc) error {
    	backoff := wait.Backoff{
    		Duration: initialDuration,
    		Factor:   3,
    		Jitter:   0,
    		Steps:    6,
    	}
    	return wait.ExponentialBackoff(backoff, fn)
    }
    
    // verifies the force detach metric with reason
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Thu Apr 18 07:00:14 UTC 2024
    - 72.8K bytes
    - Viewed (0)
Back to top