Search Options

Results per page
Sort
Preferred Languages
Advance

Results 101 - 110 of 787 for waits (0.04 sec)

  1. staging/src/k8s.io/apimachinery/pkg/util/waitgroup/waitgroup.go

    	defer wg.mu.RUnlock()
    	if wg.wait && delta > 0 {
    		return fmt.Errorf("add with positive delta after Wait is forbidden")
    	}
    	wg.wg.Add(delta)
    	return nil
    }
    
    // Done decrements the WaitGroup counter.
    func (wg *SafeWaitGroup) Done() {
    	wg.wg.Done()
    }
    
    // Wait blocks until the WaitGroup counter is zero.
    func (wg *SafeWaitGroup) Wait() {
    	wg.mu.Lock()
    	wg.wait = true
    	wg.mu.Unlock()
    	wg.wg.Wait()
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sun Feb 11 03:04:14 UTC 2018
    - 1.5K bytes
    - Viewed (0)
  2. pkg/controlplane/apiserver/admission/initializer.go

    // and provide the appropriate initialization data
    func (i *PluginInitializer) Initialize(plugin admission.Interface) {
    	if wants, ok := plugin.(initializer.WantsQuotaConfiguration); ok {
    		wants.SetQuotaConfiguration(i.quotaConfiguration)
    	}
    
    	if wants, ok := plugin.(initializer.WantsExcludedAdmissionResources); ok {
    		wants.SetExcludedAdmissionResources(i.excludedAdmissionResources)
    	}
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Mon Apr 29 21:28:42 UTC 2024
    - 1.8K bytes
    - Viewed (0)
  3. testing/internal-integ-testing/src/main/groovy/org/gradle/test/fixtures/server/http/SendPartialResponseThenBlock.java

                    long waitMs = mostRecentEvent + timeout.toMillis() - clock.getCurrentTime();
                    if (waitMs < 0) {
                        failure = new AssertionError("Timeout waiting request to block.");
                        condition.signalAll();
                        throw failure;
                    }
                    try {
                        condition.await(waitMs, TimeUnit.MILLISECONDS);
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Thu Apr 04 07:21:38 UTC 2024
    - 4.7K bytes
    - Viewed (0)
  4. internal/bucket/bandwidth/reader.go

    			need = 1 // to ensure we read at least one byte for every Read
    			tokens = b
    		}
    	} else { // all tokens go towards payload
    		need = int(math.Min(float64(b), float64(need)))
    		tokens = need
    	}
    
    	err = r.throttle.WaitN(r.ctx, tokens)
    	if err != nil {
    		return
    	}
    
    	n, err = r.r.Read(buf[:need])
    	if err != nil {
    		r.lastErr = err
    		return
    	}
    	r.m.updateMeasurement(r.opts.BucketOptions, uint64(tokens))
    	return
    }
    
    Registered: Sun Jun 16 00:44:34 UTC 2024
    - Last Modified: Wed Sep 06 03:21:59 UTC 2023
    - 3.1K bytes
    - Viewed (0)
  5. staging/src/k8s.io/apiserver/plugin/pkg/audit/buffered/buffered_test.go

    	wg.Add(1)
    	go func() {
    		defer wg.Done()
    		batch = backend.collectEvents(tc, nil)
    	}()
    	// Wait for the queued events to be collected.
    	err := wait.Poll(time.Second, wait.ForeverTestTimeout, func() (bool, error) {
    		return len(backend.buffer) == 0, nil
    	})
    	require.NoError(t, err)
    
    	tc <- time.Now() // Trigger "timeout"
    	wg.Wait()
    	assert.Len(t, batch, 2, "Expected partial batch")
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Tue Aug 14 17:20:35 UTC 2018
    - 5.9K bytes
    - Viewed (0)
  6. staging/src/k8s.io/apiserver/pkg/admission/plugin/webhook/initializer/initializer.go

    func (i *PluginInitializer) Initialize(plugin admission.Interface) {
    	if wants, ok := plugin.(WantsServiceResolver); ok {
    		wants.SetServiceResolver(i.serviceResolver)
    	}
    
    	if wants, ok := plugin.(WantsAuthenticationInfoResolverWrapper); ok {
    		if i.authenticationInfoResolverWrapper != nil {
    			wants.SetAuthenticationInfoResolverWrapper(i.authenticationInfoResolverWrapper)
    		}
    	}
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Mon Apr 08 07:19:52 UTC 2019
    - 2.6K bytes
    - Viewed (0)
  7. src/sync/atomic/value.go

    	vlp := (*efaceWords)(unsafe.Pointer(&val))
    	for {
    		typ := LoadPointer(&vp.typ)
    		if typ == nil {
    			// Attempt to start first store.
    			// Disable preemption so that other goroutines can use
    			// active spin wait to wait for completion.
    			runtime_procPin()
    			if !CompareAndSwapPointer(&vp.typ, nil, unsafe.Pointer(&firstStoreInProgress)) {
    				runtime_procUnpin()
    				continue
    			}
    			// Complete first store.
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Mon Feb 26 20:48:55 UTC 2024
    - 5.9K bytes
    - Viewed (0)
  8. internal/ioutil/wait_pipe.go

    	})
    	return err
    }
    
    // PipeReader is similar to io.PipeReader with wait group
    type PipeReader struct {
    	*io.PipeReader
    	wait func()
    }
    
    // CloseWithError close with supplied error the reader end
    func (r *PipeReader) CloseWithError(err error) error {
    	err = r.PipeReader.CloseWithError(err)
    	r.wait()
    	return err
    }
    
    // WaitPipe implements wait-group backend io.Pipe to provide
    Registered: Sun Jun 16 00:44:34 UTC 2024
    - Last Modified: Thu Apr 27 14:55:36 UTC 2023
    - 1.7K bytes
    - Viewed (0)
  9. src/net/cgo_unix_test.go

    package net
    
    import (
    	"context"
    	"testing"
    )
    
    func TestCgoLookupIP(t *testing.T) {
    	defer dnsWaitGroup.Wait()
    	ctx := context.Background()
    	_, err := cgoLookupIP(ctx, "ip", "localhost")
    	if err != nil {
    		t.Error(err)
    	}
    }
    
    func TestCgoLookupIPWithCancel(t *testing.T) {
    	defer dnsWaitGroup.Wait()
    	ctx, cancel := context.WithCancel(context.Background())
    	defer cancel()
    	_, err := cgoLookupIP(ctx, "ip", "localhost")
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Thu May 04 16:28:59 UTC 2023
    - 1.4K bytes
    - Viewed (0)
  10. staging/src/k8s.io/apimachinery/pkg/util/wait/error.go

    // ErrWaitTimeout, as methods that cancel a context may not return that error.
    //
    // Instead of:
    //
    //	err := wait.Poll(...)
    //	if err == wait.ErrWaitTimeout {
    //	    log.Infof("Wait for operation exceeded")
    //	} else ...
    //
    // Use:
    //
    //	err := wait.Poll(...)
    //	if wait.Interrupted(err) {
    //	    log.Infof("Wait for operation exceeded")
    //	} else ...
    func Interrupted(err error) bool {
    	switch {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Tue Mar 14 19:14:11 UTC 2023
    - 3K bytes
    - Viewed (0)
Back to top