Search Options

Results per page
Sort
Preferred Languages
Advance

Results 1 - 10 of 15 for Dequeue (0.11 sec)

  1. pkg/scheduler/internal/queue/scheduling_queue.go

    //
    // If any of pInfo.PendingPlugins return Queue,
    // the scheduling queue is supposed to enqueue this Pod to activeQ, skipping backoffQ.
    // If any of pInfo.unschedulablePlugins return Queue,
    // the scheduling queue is supposed to enqueue this Pod to activeQ/backoffQ depending on the remaining backoff time of the Pod.
    // If all QueueingHintFns returns Skip, the scheduling queue enqueues the Pod back to unschedulable Pod pool
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed Jun 12 13:26:09 UTC 2024
    - 61.4K bytes
    - Viewed (0)
  2. pkg/controller/job/job_controller_test.go

    			manager.podControl = &fakePodControl
    			manager.podStoreSynced = alwaysReady
    			manager.jobStoreSynced = alwaysReady
    			queue := &fakeRateLimitingQueue{}
    			manager.queue = queue
    			sharedInformerFactory.Batch().V1().Jobs().Informer().GetIndexer().Add(job)
    
    			queue.requeues = tc.requeues
    			newPod.Status.Phase = tc.phase
    			oldPod.Status.Phase = v1.PodRunning
    			if tc.oldPodPhase != "" {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Tue Jun 11 15:36:36 UTC 2024
    - 229.2K bytes
    - Viewed (0)
  3. pilot/pkg/config/kube/crdclient/client.go

    		schemasByCRDName[name] = s
    	}
    	out := &Client{
    		domainSuffix:     opts.DomainSuffix,
    		schemas:          schemas,
    		schemasByCRDName: schemasByCRDName,
    		revision:         opts.Revision,
    		queue:            queue.NewQueue(1 * time.Second),
    		started:          atomic.NewBool(false),
    		kinds:            map[config.GroupVersionKind]kclient.Untyped{},
    		handlers:         map[config.GroupVersionKind][]model.EventHandler{},
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Fri Jun 14 00:12:28 UTC 2024
    - 13.7K bytes
    - Viewed (0)
  4. tensorflow/compiler/mlir/tensorflow/transforms/shape_inference.cc

      void EnqueueCallers(func::FuncOp fn);
    
      // Returns the function at the front of the queue.
      func::FuncOp front() { return queue_.front(); }
    
      // Returns whether work queue is empty.
      bool EmptyQueue() const { return queue_.empty(); }
    
      // Returns function from the front of the work queue.
      func::FuncOp pop_front() {
        func::FuncOp ret = queue_.front();
        queue_.pop();
    Registered: Sun Jun 16 05:45:23 UTC 2024
    - Last Modified: Sat Jun 08 07:28:49 UTC 2024
    - 134.1K bytes
    - Viewed (0)
  5. pkg/controller/job/job_controller.go

    func (jm *Controller) processNextWorkItem(ctx context.Context) bool {
    	key, quit := jm.queue.Get()
    	if quit {
    		return false
    	}
    	defer jm.queue.Done(key)
    
    	err := jm.syncHandler(ctx, key)
    	if err == nil {
    		jm.queue.Forget(key)
    		return true
    	}
    
    	utilruntime.HandleError(fmt.Errorf("syncing job: %w", err))
    	jm.queue.AddRateLimited(key)
    
    	return true
    }
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Mon Jun 10 23:56:37 UTC 2024
    - 77.6K bytes
    - Viewed (0)
  6. pkg/scheduler/internal/queue/scheduling_queue_test.go

    		queue.flushBackoffQCompleted(logger)
    	}
    	moveClockForward = func(t *testing.T, logger klog.Logger, queue *PriorityQueue, _ *framework.QueuedPodInfo) {
    		queue.clock.(*testingclock.FakeClock).Step(2 * time.Second)
    	}
    	flushUnschedulerQ = func(t *testing.T, logger klog.Logger, queue *PriorityQueue, _ *framework.QueuedPodInfo) {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed Jun 12 13:26:09 UTC 2024
    - 146.9K bytes
    - Viewed (0)
  7. tensorflow/compiler/mlir/tensorflow/transforms/passes.h

    // that are only used for host computation.
    std::unique_ptr<OperationPass<func::FuncOp>>
    CreateTPUHostComputationExpansionPass();
    
    // Creates a pass that updates inputs to TPU embedding layer enqueue ops so that
    // correct ops are invoked during training and evaluation.
    std::unique_ptr<OperationPass<func::FuncOp>>
    CreateTPUUpdateEmbeddingEnqueueOpInputsPass();
    
    // Creates a pass that propagates TPU devices to users.
    Registered: Sun Jun 16 05:45:23 UTC 2024
    - Last Modified: Wed Jun 12 21:18:05 UTC 2024
    - 31.8K bytes
    - Viewed (0)
  8. pkg/kubelet/kubelet_test.go

    	pods[2].Status.StartTime = &startTime
    	pods[2].Spec.ActiveDeadlineSeconds = &exceededActiveDeadlineSeconds
    
    	kubelet.podManager.SetPods(pods)
    	kubelet.workQueue.Enqueue(pods[2].UID, 0)
    	kubelet.workQueue.Enqueue(pods[3].UID, 30*time.Second)
    	kubelet.workQueue.Enqueue(pods[4].UID, 2*time.Minute)
    
    	clock.Step(1 * time.Minute)
    
    	expected := []*v1.Pod{pods[2], pods[3], pods[0]}
    	podsToSync := kubelet.getPodsToSync()
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Fri Jun 14 16:09:17 UTC 2024
    - 106.9K bytes
    - Viewed (0)
  9. tensorflow/compiler/mlir/tensorflow/transforms/tf_passes.td

    }
    
    def TPUUpdateEmbeddingEnqueueOpInputsPass : Pass<"tf-tpu-update-embedding-enqueue-op-inputs", "mlir::func::FuncOp"> {
      let summary = "Updates inputs to TPU embedding enqueue ops depending on whether graph is in training mode or in evaluation mode.";
    
      let description = [{
        Updates inputs to TPU embedding enqueue ops depending on whether graph
        is in training mode or in evaluation mode.
      }];
    
    Registered: Sun Jun 16 05:45:23 UTC 2024
    - Last Modified: Wed Jun 12 21:18:05 UTC 2024
    - 99.6K bytes
    - Viewed (0)
  10. 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)
Back to top