Search Options

Results per page
Sort
Preferred Languages
Advance

Results 1 - 10 of 10 for dequeue1 (0.23 sec)

  1. platforms/software/dependency-management/src/main/java/org/gradle/api/internal/artifacts/ivyservice/resolveengine/graph/builder/NodeState.java

        }
    
        // the enqueue and dequeue methods are used for performance reasons
        // in order to avoid tracking the set of enqueued nodes
        boolean enqueue() {
            if (queued) {
                return false;
            }
            queued = true;
            return true;
        }
    
        NodeState dequeue() {
            queued = false;
            return this;
        }
    
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Fri Jun 07 14:19:34 UTC 2024
    - 58.9K bytes
    - Viewed (0)
  2. pkg/scheduler/internal/queue/scheduling_queue.go

    	queueSkip queueingStrategy = iota
    	// queueAfterBackoff indicates that the scheduling queue should requeue the Pod after backoff is completed.
    	queueAfterBackoff
    	// queueImmediately indicates that the scheduling queue should skip backoff and requeue the Pod immediately to activeQ.
    	queueImmediately
    )
    
    // isEventOfInterest returns true if the event is of interest by some plugins.
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed Jun 12 13:26:09 UTC 2024
    - 61.4K bytes
    - Viewed (0)
  3. pkg/controller/replicaset/replica_set_test.go

    	manager.queue = workqueue.NewTypedRateLimitingQueue(workqueue.NewTypedMaxOfRateLimiter[string]())
    	manager.enqueueRS(rs)
    	manager.processNextWorkItem(ctx)
    	// It should have been requeued.
    	if got, want := manager.queue.Len(), 1; got != want {
    		t.Errorf("queue.Len() = %v, want %v", got, want)
    	}
    }
    
    func TestControllerUpdateStatusWithFailure(t *testing.T) {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 69.2K bytes
    - Viewed (0)
  4. pkg/kubelet/pod_workers.go

    		delete(p.startedStaticPodsByFullname, status.fullname)
    	}
    }
    
    // completeWork requeues on error or the next sync interval and then immediately executes any pending
    // work.
    func (p *podWorkers) completeWork(podUID types.UID, phaseTransition bool, syncErr error) {
    	// Requeue the last update if the last sync returned error.
    	switch {
    	case phaseTransition:
    		p.workQueue.Enqueue(podUID, 0)
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Tue Apr 02 13:22:37 UTC 2024
    - 74.8K bytes
    - Viewed (0)
  5. pkg/controller/nodelifecycle/node_lifecycle_controller.go

    		if shutdown {
    			return
    		}
    		nodeName := obj
    		if err := nc.doNoScheduleTaintingPass(ctx, nodeName); err != nil {
    			logger.Error(err, "Failed to taint NoSchedule on node, requeue it", "node", klog.KRef("", nodeName))
    			// TODO(k82cn): Add nodeName back to the queue
    		}
    		// TODO: re-evaluate whether there are any labels that need to be
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 51.6K bytes
    - Viewed (0)
  6. tensorflow/compiler/jit/deadness_analysis.cc

        if (IsMerge(node)) {
          for (const Edge* e : node->in_edges()) {
            if (IsNextIteration(e->src())) {
              ++num_ready_inputs[node->id()];
            }
          }
        }
      }
    
      // dequeue is used to ensure that the nodes are first-in-first-out.  This
      // order guarantees that the exits in the ready queue are visited before
      // nodes that will become ready in the future.
      std::deque<Node*> ready;
    Registered: Sun Jun 16 05:45:23 UTC 2024
    - Last Modified: Tue Mar 12 06:33:33 UTC 2024
    - 60.4K bytes
    - Viewed (0)
  7. pkg/controller/daemon/daemon_controller.go

    		if _, updateErr = dsClient.UpdateStatus(ctx, toUpdate, metav1.UpdateOptions{}); updateErr == nil {
    			return nil
    		}
    
    		// Stop retrying if we exceed statusUpdateRetries - the DaemonSet will be requeued with a rate limit.
    		if i >= StatusUpdateRetries {
    			break
    		}
    		// Update the set with the latest resource version for the next poll
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 51.3K bytes
    - Viewed (0)
  8. okhttp/src/test/java/okhttp3/internal/http2/HttpOverHttp2Test.kt

        @Synchronized
        override fun dispatch(request: RecordedRequest): MockResponse {
          // This guarantees a deterministic sequence when handling the canceled request:
          // 1. Server reads request and dequeues first response
          // 2. Client cancels request
          // 3. Server tries to send response on the canceled stream
          // Otherwise, there is no guarantee for the sequence. For example, the server may use the
    Registered: Sun Jun 16 04:42:17 UTC 2024
    - Last Modified: Thu Apr 11 22:09:35 UTC 2024
    - 75.3K bytes
    - Viewed (0)
  9. staging/src/k8s.io/apiserver/pkg/storage/cacher/cacher.go

    		watcher.stopLocked()
    	}
    	c.watchersToStop = c.watchersToStop[:0]
    
    	for _, watcher := range c.expiredBookmarkWatchers {
    		if watcher.stopped {
    			continue
    		}
    		// requeue the watcher for the next bookmark if needed.
    		c.bookmarkWatchers.addWatcherThreadUnsafe(watcher)
    	}
    	c.expiredBookmarkWatchers = c.expiredBookmarkWatchers[:0]
    }
    
    func (c *Cacher) terminateAllWatchers() {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed Jun 12 10:12:02 UTC 2024
    - 51.8K bytes
    - Viewed (0)
  10. pkg/controller/job/job_controller.go

    	if err != nil {
    		utilruntime.HandleError(fmt.Errorf("couldn't get key for object %+v: %v", obj, err))
    		return
    	}
    	jm.orphanQueue.Add(key)
    }
    
    // worker runs a worker thread that just dequeues items, processes them, and marks them done.
    // It enforces that the syncHandler is never invoked concurrently with the same key.
    func (jm *Controller) worker(ctx context.Context) {
    	for jm.processNextWorkItem(ctx) {
    	}
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Mon Jun 10 23:56:37 UTC 2024
    - 77.6K bytes
    - Viewed (0)
Back to top