Search Options

Results per page
Sort
Preferred Languages
Advance

Results 181 - 190 of 1,377 for waitc (0.12 sec)

  1. pkg/kubelet/kuberuntime/kuberuntime_termination_order_test.go

    		time.Sleep(1 * time.Second)
    		to.containerTerminated("main")
    		wg.Done()
    	}()
    	wg.Wait()
    	if sidecarWaitDelay != 1 {
    		t.Errorf("expected sidecar to wait for main container to exit, got delay of %d", sidecarWaitDelay)
    	}
    	if mainWaitDelay != 0 {
    		t.Errorf("expected main container to not wait to exit, got delay of %d", mainWaitDelay)
    	}
    }
    
    func TestTerminationOrderingSidecarsInReverseOrder(t *testing.T) {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed Oct 18 00:07:21 UTC 2023
    - 6.7K bytes
    - Viewed (0)
  2. src/net/fd_unix.go

    	}
    
    	// Start the "interrupter" goroutine, if this context might be canceled.
    	//
    	// The interrupter goroutine waits for the context to be done and
    	// interrupts the dial (by altering the fd's write deadline, which
    	// wakes up waitWrite).
    	ctxDone := ctx.Done()
    	if ctxDone != nil {
    		// Wait for the interrupter goroutine to exit before returning
    		// from connect.
    		done := make(chan struct{})
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Wed May 24 20:19:46 UTC 2023
    - 5.4K bytes
    - Viewed (0)
  3. staging/src/k8s.io/apimachinery/pkg/util/wait/loop.go

    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    See the License for the specific language governing permissions and
    limitations under the License.
    */
    
    package wait
    
    import (
    	"context"
    	"time"
    
    	"k8s.io/apimachinery/pkg/util/runtime"
    )
    
    // loopConditionUntilContext executes the provided condition at intervals defined by
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Thu Oct 19 02:47:00 UTC 2023
    - 2.8K bytes
    - Viewed (0)
  4. platforms/core-runtime/base-services/src/integTest/groovy/org/gradle/internal/work/ProjectLockStatisticsIntegrationTest.groovy

            createDirs("child")
            settingsFile << """
                include ':child'
            """
            buildFile << """
                apply plugin: "java"
    
                task wait {
                    doLast {
                        sleep 2000
                    }
                }
    
                project(':child') {
                    configurations {
                        foo
                    }
    
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Tue Oct 24 06:54:47 UTC 2023
    - 1.8K bytes
    - Viewed (0)
  5. cmd/kube-scheduler/app/testing/testserver.go

    limitations under the License.
    */
    
    package testing
    
    import (
    	"context"
    	"fmt"
    	"net"
    	"os"
    	"time"
    
    	"github.com/spf13/pflag"
    
    	"k8s.io/apimachinery/pkg/util/wait"
    	"k8s.io/client-go/kubernetes"
    	restclient "k8s.io/client-go/rest"
    	"k8s.io/component-base/configz"
    	logsapi "k8s.io/component-base/logs/api/v1"
    	"k8s.io/kubernetes/cmd/kube-scheduler/app"
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Thu Aug 24 10:35:59 UTC 2023
    - 5.2K bytes
    - Viewed (0)
  6. staging/src/k8s.io/apiserver/pkg/storage/value/encrypt/envelope/kmsv2/cache_test.go

    			cache.set([]byte(key), transformer)
    		}(k)
    	}
    	wg.Wait()
    
    	if cache.cache.Len() != 10 {
    		t.Fatalf("Expected 10 items in the cache, got %v", cache.cache.Len())
    	}
    
    	for i := 0; i < 10; i++ {
    		k := fmt.Sprintf("key-%d", i)
    		if cache.get([]byte(k)) != transformer {
    			t.Fatalf("Expected to get the transformer for key %v", k)
    		}
    	}
    
    	// Wait for the cache to expire
    	fakeClock.Step(6 * time.Second)
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Thu Aug 31 20:26:58 UTC 2023
    - 4.9K bytes
    - Viewed (0)
  7. 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)
  8. cluster/gce/gci/health-monitor.sh

          systemctl kill --kill-who=main "${container_runtime_name}"
          # Wait for a while, as we don't want to kill it again before it is really up.
          sleep 120
        else
          sleep "${SLEEP_SECONDS}"
        fi
      done
    }
    
    function kubelet_monitoring {
      echo "Wait for 2 minutes for kubelet to be functional"
      # TODO(andyzheng0831): replace it with a more reliable method if possible.
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Thu Jan 20 09:19:08 UTC 2022
    - 3.3K bytes
    - Viewed (0)
  9. security/pkg/cmd/constants.go

    	DefaultRootCertGracePeriodPercentile = 20
    
    	// ReadSigningCertRetryInterval specifies the time to wait between retries on reading the signing key and cert.
    	ReadSigningCertRetryInterval = time.Second * 5
    
    	// ReadSigningCertRetryMax specifies the total max time to wait between retries on reading the signing key and cert.
    	ReadSigningCertRetryMax = time.Second * 30
    
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Tue Jul 07 03:27:36 UTC 2020
    - 1.7K bytes
    - Viewed (0)
  10. 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)
Back to top