Search Options

Results per page
Sort
Preferred Languages
Advance

Results 1 - 10 of 144 for Await (0.09 sec)

  1. okhttp/src/test/java/okhttp3/internal/http2/HttpOverHttp2Test.kt

              fail("")
            }
          },
        )
        assertThat(server.takeRequest().sequenceNumber)
          .isEqualTo(expectedSequenceNumber)
        responseDequeuedLatch!!.await()
        call.cancel()
        requestCanceledLatch!!.countDown()
        latch.await()
      }
    
      @ParameterizedTest
      @ArgumentsSource(ProtocolParamProvider::class)
      fun noRecoveryFromRefusedStreamWithRetryDisabled(
        protocol: Protocol,
    Registered: Sun Jun 16 04:42:17 UTC 2024
    - Last Modified: Thu Apr 11 22:09:35 UTC 2024
    - 75.3K bytes
    - Viewed (0)
  2. okhttp/src/test/java/okhttp3/internal/http2/Http2ConnectionTest.kt

        peer.acceptFrame() // RST_STREAM
        peer.acceptFrame() // DEGRADED PING
        peer.acceptFrame() // AWAIT PING
        peer.sendFrame().ping(true, Http2Connection.DEGRADED_PING, 1) // DEGRADED PONG
        peer.sendFrame().ping(true, Http2Connection.AWAIT_PING, 0) // AWAIT PONG
        peer.play()
    
        // Play it back.
        val connection = connect(peer)
    Registered: Sun Jun 16 04:42:17 UTC 2024
    - Last Modified: Sat Apr 20 17:03:43 UTC 2024
    - 75.4K bytes
    - Viewed (0)
  3. okhttp/src/test/java/okhttp3/EventListenerTest.kt

              call: Call,
              response: Response,
            ) {
              response.close()
              completionLatch.countDown()
            }
          }
        call.enqueue(callback)
        completionLatch.await()
        assertThat(listener.recordedEventTypes()).containsExactly(
          "CallStart",
          "ProxySelectStart", "ProxySelectEnd", "DnsStart", "DnsEnd",
    Registered: Sun Jun 16 04:42:17 UTC 2024
    - Last Modified: Sat Jan 20 10:30:28 UTC 2024
    - 56.9K bytes
    - Viewed (0)
  4. pkg/controller/job/job_controller.go

    	if !cache.WaitForNamedCacheSync("job", ctx.Done(), jm.podStoreSynced, jm.jobStoreSynced) {
    		return
    	}
    
    	for i := 0; i < workers; i++ {
    		go wait.UntilWithContext(ctx, jm.worker, time.Second)
    	}
    
    	go wait.UntilWithContext(ctx, jm.orphanWorker, time.Second)
    
    	<-ctx.Done()
    }
    
    // getPodJobs returns a list of Jobs that potentially match a Pod.
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Mon Jun 10 23:56:37 UTC 2024
    - 77.6K bytes
    - Viewed (0)
  5. src/runtime/mgc.go

    	// will be, so we pretend to have an arbitrarily large number
    	// of workers, almost all of which are "waiting". While a
    	// worker is working it decrements nwait. If nproc == nwait,
    	// there are no workers.
    	work.nproc = ^uint32(0)
    	work.nwait = ^uint32(0)
    }
    
    // gcBgMarkWorkerNode is an entry in the gcBgMarkWorkerPool. It points to a single
    // gcBgMarkWorker goroutine.
    type gcBgMarkWorkerNode struct {
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Wed May 29 16:25:21 UTC 2024
    - 62K bytes
    - Viewed (0)
  6. staging/src/k8s.io/apiserver/pkg/server/filters/priority-and-fairness_test.go

    		}
    		postEnqueue.Done()
    		postEnqueue.Wait()
    	}
    
    	postDequeueFunc := func() {
    		preDequeue.Done()
    		preDequeue.Wait()
    		if atomicReadOnlyWaiting != 0 {
    			t.Errorf("Wanted %d requests in queue, got %d", 0, atomicReadOnlyWaiting)
    		}
    		postDequeue.Done()
    		postDequeue.Wait()
    	}
    
    	postExecuteFunc := func() {
    		finishExecute.Done()
    		finishExecute.Wait()
    	}
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Mon Oct 30 12:18:40 UTC 2023
    - 52.6K bytes
    - Viewed (0)
  7. 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)
  8. staging/src/k8s.io/apiserver/pkg/storage/cacher/cacher.go

    		defer c.watchCache.RUnlock()
    		return err
    	}
    	return nil
    }
    
    // Wait blocks until the cacher is Ready or Stopped, it returns an error if Stopped.
    func (c *Cacher) Wait(ctx context.Context) error {
    	return c.ready.wait(ctx)
    }
    
    // errWatcher implements watch.Interface to return a single error
    type errWatcher struct {
    	result chan watch.Event
    }
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed Jun 12 10:12:02 UTC 2024
    - 51.8K bytes
    - Viewed (0)
  9. pkg/kubelet/volumemanager/reconciler/reconciler_test.go

    	}
    }
    
    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)
    }
    
    func createTestClient(attachedVolumes ...v1.AttachedVolume) *fake.Clientset {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Tue Apr 09 07:34:33 UTC 2024
    - 75.4K bytes
    - Viewed (0)
  10. staging/src/k8s.io/apiextensions-apiserver/test/integration/validation_test.go

    					}
    					return true, nil
    				})
    				if err != wait.ErrWaitTimeout {
    					t.Fatalf("expected no NonStructuralSchema condition, but got one: %v", cond)
    				}
    				return
    			}
    
    			// wait for condition to appear with the given violations
    			var cond *apiextensionsv1.CustomResourceDefinitionCondition
    			err = wait.PollImmediate(100*time.Millisecond, wait.ForeverTestTimeout, func() (bool, error) {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Mon Apr 26 20:48:36 UTC 2021
    - 63.6K bytes
    - Viewed (0)
Back to top