Search Options

Results per page
Sort
Preferred Languages
Advance

Results 71 - 80 of 230 for blocked (0.18 sec)

  1. pkg/scheduler/scheduler.go

    						PluginName:     e.Name(),
    						QueueingHintFn: defaultQueueingHintFn,
    					},
    				)
    		}
    	}
    	return queueingHintMap
    }
    
    // Run begins watching and scheduling. It starts scheduling and blocked until the context is done.
    func (sched *Scheduler) Run(ctx context.Context) {
    	logger := klog.FromContext(ctx)
    	sched.SchedulingQueue.Run(logger)
    
    	// We need to start scheduleOne loop in a dedicated goroutine,
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Tue Jun 04 06:20:55 UTC 2024
    - 20.8K bytes
    - Viewed (0)
  2. pkg/xds/server.go

    	// to tell the receiving goroutines that all data have been sent."
    
    	// Block until either a request is received or a push is triggered.
    	// We need 2 go routines because 'read' blocks in Recv().
    	go Receive(ctx)
    
    	// Wait for the proxy to be fully initialized before we start serving traffic. Because
    	// initialization doesn't have dependencies that will block, there is no need to add any timeout
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Mon May 13 20:55:20 UTC 2024
    - 16.3K bytes
    - Viewed (0)
  3. guava-tests/test/com/google/common/util/concurrent/AbstractFutureTest.java

            // nothing
          }
        }
    
        void awaitWaiting() {
          while (!isBlocked()) {
            if (getState() == State.TERMINATED) {
              throw new RuntimeException("Thread exited");
            }
            Thread.yield();
          }
        }
    
        private boolean isBlocked() {
          return getState() == Thread.State.WAITING && LockSupport.getBlocker(this) == future;
        }
      }
    Registered: Wed Jun 12 16:38:11 UTC 2024
    - Last Modified: Tue Jun 11 16:13:05 UTC 2024
    - 46.7K bytes
    - Viewed (0)
  4. pkg/kubelet/images/image_manager_test.go

    			assert.Nil(t, err)
    			wg.Done()
    		}()
    	}
    	time.Sleep(1 * time.Second)
    	fakeRuntime.AssertCallCounts("PullImage", 5)
    
    	// Next two EnsureImageExists should be blocked because maxParallelImagePulls is hit
    	for i := 0; i < 2; i++ {
    		wg.Add(1)
    		go func() {
    			_, _, err := puller.EnsureImageExists(ctx, pod, container, nil, nil, "")
    			assert.Nil(t, err)
    			wg.Done()
    		}()
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed Apr 24 18:25:29 UTC 2024
    - 19K bytes
    - Viewed (0)
  5. src/syscall/exec_linux.go

    	// Set up and fork. This returns immediately in the parent or
    	// if there's an error.
    	upid, pidfd, err, mapPipe, locked := forkAndExecInChild1(argv0, argv, envv, chroot, dir, attr, sys, pipe)
    	if locked {
    		runtime_AfterFork()
    	}
    	if err != 0 {
    		return 0, err
    	}
    
    	// parent; return PID
    	pid = int(upid)
    	if sys.PidFD != nil {
    		*sys.PidFD = int(pidfd)
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Wed May 15 07:45:37 UTC 2024
    - 23K bytes
    - Viewed (0)
  6. pkg/controller/garbagecollector/garbagecollector_test.go

    	time.Sleep(1 * time.Second)
    
    	err = expectSyncNotBlocked(fakeDiscoveryClient, &gc.workerLock)
    	if err != nil {
    		t.Fatalf("Expected garbagecollector.Sync to be running but it is blocked: %v", err)
    	}
    	assertMonitors(t, gc, "pods", "deployments")
    
    	// Simulate the discovery client returning an error
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 111.6K bytes
    - Viewed (0)
  7. src/time/tick_test.go

    		}
    		t.Fatalf("never got done")
    	}
    
    	// Reset timer in heap (already reset above, but just in case).
    	tim.Reset(10000 * Second)
    	drainAsync()
    
    	// Test stop while timer in heap (because goroutine is blocked on <-C).
    	done := make(chan bool)
    	notDone(done)
    	go func() {
    		<-C
    		close(done)
    	}()
    	Sleep(sched)
    	notDone(done)
    
    	// Test reset far away while timer in heap.
    	tim.Reset(20000 * Second)
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Tue Jun 11 17:10:37 UTC 2024
    - 14.7K bytes
    - Viewed (0)
  8. src/internal/testenv/testenv.go

    	}
    }
    
    // HasLink reports whether the current system can use os.Link.
    func HasLink() bool {
    	// From Android release M (Marshmallow), hard linking files is blocked
    	// and an attempt to call link() on a file will return EACCES.
    	// - https://code.google.com/p/android-developer-preview/issues/detail?id=3150
    	return runtime.GOOS != "plan9" && runtime.GOOS != "android"
    }
    
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Fri May 03 16:41:38 UTC 2024
    - 15.7K bytes
    - Viewed (0)
  9. pkg/api/testing/unstructured_test.go

    // objects produced by both encodings must be identical and be themselves roundtrippable to JSON and
    // CBOR.
    func TestRoundtripToUnstructured(t *testing.T) {
    	// These are GVKs that whose CBOR roundtrippability is blocked by a known issue that must be
    	// resolved as a prerequisite for alpha.
    	knownFailureReasons := map[string][]schema.GroupVersionKind{
    		// Since JSON cannot directly represent arbitrary byte sequences, a byte slice
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed May 29 21:48:10 UTC 2024
    - 16.9K bytes
    - Viewed (0)
  10. cmd/bucket-metadata-sys.go

    	g := errgroup.WithNErrs(len(buckets))
    	bucketMetas := make([]BucketMetadata, len(buckets))
    	for index := range buckets {
    		index := index
    		g.Go(func() error {
    			// Sleep and stagger to avoid blocked CPU and thundering
    			// herd upon start up sequence.
    			time.Sleep(25*time.Millisecond + time.Duration(rand.Int63n(int64(100*time.Millisecond))))
    
    Registered: Sun Jun 16 00:44:34 UTC 2024
    - Last Modified: Fri May 24 23:05:23 UTC 2024
    - 19.8K bytes
    - Viewed (0)
Back to top