Search Options

Results per page
Sort
Preferred Languages
Advance

Results 11 - 20 of 110 for waitc (0.09 sec)

  1. 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)
  2. 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)
  3. 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)
  4. 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)
  5. cluster/gce/windows/k8s-node-setup.psm1

        # after some delay, or it may appear to be removed then you'll add it back
        # but then it will be removed once again. So, we first wait a long
        # unfortunate amount of time to ensure that things have quiesced, then we
        # wait until we're sure the route is really gone before re-adding it again.
        Log-Output "Waiting 45 seconds for host network state to quiesce"
        Start-Sleep 45
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Fri Jun 07 21:13:22 UTC 2024
    - 88.3K bytes
    - Viewed (0)
  6. android/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)
  7. pkg/controller/nodelifecycle/node_lifecycle_controller.go

    		// be re-queued until "Done", so no more than one worker handle the same item and
    		// no event missed.
    		go wait.UntilWithContext(ctx, nc.doNodeProcessingPassWorker, time.Second)
    	}
    
    	for i := 0; i < podUpdateWorkerSize; i++ {
    		go wait.UntilWithContext(ctx, nc.doPodProcessingWorker, time.Second)
    	}
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 51.6K bytes
    - Viewed (0)
  8. pkg/kubelet/kuberuntime/kuberuntime_container.go

    		gracePeriod = gracePeriod - m.executePreStopHook(ctx, pod, containerID, containerSpec, gracePeriod)
    	}
    
    	// if we care about termination ordering, then wait for this container's turn to exit if there is
    	// time remaining
    	if ordering != nil && gracePeriod > 0 {
    		// grace period is only in seconds, so the time we've waited gets truncated downward
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Tue Jun 04 06:25:43 UTC 2024
    - 54.7K bytes
    - Viewed (0)
  9. src/os/os_test.go

    		}
    	}()
    
    	// Note the deferred Wait must be called after the deferred close(done),
    	// to ensure the N goroutines have been released even if the main goroutine
    	// calls Fatalf. It must be called before the Chdir back to the original
    	// directory, and before the deferred deletion implied by TempDir,
    	// so as not to interfere while the N goroutines are still running.
    	defer wg.Wait()
    	defer close(done)
    
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Thu May 23 01:00:11 UTC 2024
    - 83.1K bytes
    - Viewed (0)
  10. pkg/kubelet/cm/devicemanager/manager_test.go

    	"k8s.io/apimachinery/pkg/api/resource"
    	metav1 "k8s.io/apimachinery/pkg/apis/meta/v1"
    	"k8s.io/apimachinery/pkg/types"
    	"k8s.io/apimachinery/pkg/util/sets"
    	"k8s.io/apimachinery/pkg/util/uuid"
    	"k8s.io/apimachinery/pkg/util/wait"
    	"k8s.io/client-go/tools/record"
    	pluginapi "k8s.io/kubelet/pkg/apis/deviceplugin/v1beta1"
    	watcherapi "k8s.io/kubelet/pkg/apis/pluginregistration/v1"
    	"k8s.io/kubernetes/pkg/kubelet/checkpointmanager"
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Tue Jun 04 06:25:43 UTC 2024
    - 65K bytes
    - Viewed (0)
Back to top