Search Options

Results per page
Sort
Preferred Languages
Advance

Results 71 - 80 of 706 for waitc (0.16 sec)

  1. staging/src/k8s.io/apiserver/pkg/admission/plugin/policy/internal/generic/controller.go

    		go func() {
    			defer waitGroup.Done()
    			wait.Until(c.runWorker, time.Second, ctx.Done())
    		}()
    	}
    
    	klog.Infof("Started %v workers for %v", c.options.Workers, c.options.Name)
    
    	// Wait for context cancel.
    	<-ctx.Done()
    
    	// Forcefully shutdown workqueue. Drop any enqueued items.
    	c.queue.ShutDown()
    
    	// Workqueue shutdown signals for workers to stop. Wait for all workers to
    	// clean up
    	waitGroup.Wait()
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 7.5K bytes
    - Viewed (0)
  2. pkg/kubelet/pluginmanager/plugin_manager_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 TestPluginRegistration(t *testing.T) {
    	defer cleanup(t)
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Tue Jun 04 06:25:43 UTC 2024
    - 4.4K bytes
    - Viewed (0)
  3. cmd/erasure.go

    				w := xioutil.NewDeadlineWorker(globalDriveConfig.GetMaxTimeout())
    				return w.Run(func() error {
    					wait := deleteCleanupSleeper.Timer(ctx)
    					removeAll(pathJoin(drivePath, minioMetaTmpDeletedBucket, ddir))
    					wait()
    					return nil
    				})
    			})
    		}(disk)
    	}
    	wg.Wait()
    }
    
    // nsScanner will start scanning buckets and send updated totals as they are traversed.
    Registered: Sun Jun 16 00:44:34 UTC 2024
    - Last Modified: Fri May 24 23:05:23 UTC 2024
    - 16K bytes
    - Viewed (0)
  4. src/runtime/runtime-gdb_unix_test.go

    		t.Fatalf("error starting test binary: %v", err)
    	}
    
    	pid := cmd.Process.Pid
    
    	err = cmd.Wait()
    	t.Logf("child output:\n%s", output.String())
    	if err == nil {
    		t.Fatalf("Wait succeeded, want SIGABRT")
    	}
    	ee, ok := err.(*exec.ExitError)
    	if !ok {
    		t.Fatalf("Wait err got %T %v, want exec.ExitError", ee, ee)
    	}
    	ws, ok := ee.Sys().(syscall.WaitStatus)
    	if !ok {
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Wed Jan 17 19:05:30 UTC 2024
    - 9.4K bytes
    - Viewed (0)
  5. cmd/kubeadm/app/phases/upgrade/health.go

    	if client.Discovery().RESTClient() == nil {
    		fmt.Printf("[upgrade/health] Would create the Job with the prefix %q in namespace %q and wait until it completes\n", prefix, ns)
    		return nil
    	}
    
    	// Check if there is at least one Node where a Job's Pod can schedule. If not, skip this preflight check.
    	err = wait.PollUntilContextTimeout(ctx, time.Second*1, timeout, true, func(_ context.Context) (bool, error) {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Fri Apr 26 09:18:02 UTC 2024
    - 8.8K bytes
    - Viewed (0)
  6. pkg/proxy/config/api_test.go

    	epsHandler := NewEndpointSliceHandlerMock()
    	epsConfig.RegisterEventHandler(epsHandler)
    
    	stopCh := make(chan struct{})
    	defer close(stopCh)
    	sharedInformers.Start(stopCh)
    
    	err := wait.PollImmediate(time.Millisecond*10, wait.ForeverTestTimeout, func() (bool, error) {
    		svcHandler.lock.Lock()
    		defer svcHandler.lock.Unlock()
    		if reflect.DeepEqual(svcHandler.state, expectedSvcState) {
    			return true, nil
    		}
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Mon Apr 22 05:08:41 UTC 2024
    - 8.2K bytes
    - Viewed (0)
  7. staging/src/k8s.io/apiserver/pkg/storage/cacher/watch_progress.go

    limitations under the License.
    */
    
    package cacher
    
    import (
    	"context"
    	"sync"
    	"time"
    
    	"google.golang.org/grpc/metadata"
    
    	utilruntime "k8s.io/apimachinery/pkg/util/runtime"
    	"k8s.io/apimachinery/pkg/util/wait"
    
    	"k8s.io/klog/v2"
    	"k8s.io/utils/clock"
    )
    
    const (
    	// progressRequestPeriod determines period of requesting progress
    	// from etcd when there is a request waiting for watch cache to be fresh.
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Fri May 24 09:56:38 UTC 2024
    - 3K bytes
    - Viewed (0)
  8. guava-testlib/src/com/google/common/testing/GcFinalization.java

        // TODO(user): Consider scaling by number of mutator threads,
        // e.g. using Thread#activeCount()
        return Math.max(10L, Runtime.getRuntime().totalMemory() / (32L * 1024L * 1024L));
      }
    
      /**
       * Waits until the given future {@linkplain Future#isDone is done}, invoking the garbage collector
       * as necessary to try to ensure that this will happen.
       *
       * @throws RuntimeException if timed out or interrupted while waiting
    Registered: Wed Jun 12 16:38:11 UTC 2024
    - Last Modified: Thu Feb 22 17:40:56 UTC 2024
    - 11.6K bytes
    - Viewed (0)
  9. 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)
  10. staging/src/k8s.io/apimachinery/pkg/util/wait/wait_test.go

    		i++
    		return false, nil
    	})
    	if err != ErrWaitTimeout || i != 0 {
    		t.Errorf("unexpected error: %v", err)
    	}
    
    	opts := Backoff{Factor: 1.0, Steps: 3}
    
    	// waits up to steps
    	i = 0
    	err = ExponentialBackoff(opts, func() (bool, error) {
    		i++
    		return false, nil
    	})
    	if err != ErrWaitTimeout || i != opts.Steps {
    		t.Errorf("unexpected error: %v", err)
    	}
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Tue Mar 26 16:28:45 UTC 2024
    - 41.1K bytes
    - Viewed (0)
Back to top