Search Options

Results per page
Sort
Preferred Languages
Advance

Results 11 - 20 of 27 for Dequeue (0.22 sec)

  1. src/cmd/go/internal/modload/buildlist.go

    	for len(queue) > 0 {
    		roots = tidy.rootModules
    		mg, err := tidy.Graph(ctx)
    		if err != nil {
    			return nil, err
    		}
    
    		prevQueue := queue
    		queue = nil
    		for _, pkg := range prevQueue {
    			m := pkg.mod
    			if m.Path == "" {
    				continue
    			}
    			for _, dep := range pkg.imports {
    				if !queued[dep] {
    					queue = append(queue, dep)
    					queued[dep] = true
    				}
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Wed May 15 16:04:44 UTC 2024
    - 53.8K bytes
    - Viewed (0)
  2. staging/src/k8s.io/apiserver/pkg/util/flowcontrol/fairqueuing/queueset/queueset_test.go

    			}
    			queue := &queue{
    				requestsWaiting:   newRequestFIFO(),
    				requestsExecuting: sets.New[*request](),
    			}
    			r := &request{
    				qs:           qs,
    				queue:        queue,
    				workEstimate: qs.completeWorkEstimate(&test.workEstimate),
    			}
    			rOther := &request{qs: qs, queue: queue}
    
    			qs.totRequestsExecuting = 111
    			qs.totSeatsInUse = 222
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Tue Sep 26 12:55:23 UTC 2023
    - 58.4K bytes
    - Viewed (0)
  3. pkg/kubelet/pod_workers.go

    	}
    }
    
    // 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)
    	case syncErr == nil:
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Tue Apr 02 13:22:37 UTC 2024
    - 74.8K bytes
    - Viewed (0)
  4. pkg/controller/replicaset/replica_set_test.go

    	manager.podControl = &fakePodControl
    
    	// Enqueue once. Then process it. Disable rate-limiting for this.
    	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)
    	}
    }
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 69.2K bytes
    - Viewed (0)
  5. pkg/controller/daemon/daemon_controller.go

    	}
    }
    
    // processNextWorkItem deals with one key off the queue.  It returns false when it's time to quit.
    func (dsc *DaemonSetsController) processNextWorkItem(ctx context.Context) bool {
    	dsKey, quit := dsc.queue.Get()
    	if quit {
    		return false
    	}
    	defer dsc.queue.Done(dsKey)
    
    	err := dsc.syncHandler(ctx, dsKey)
    	if err == nil {
    		dsc.queue.Forget(dsKey)
    		return true
    	}
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 51.3K bytes
    - Viewed (0)
  6. 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
    		// reconcile in 1.19. Remove this function if it's no longer necessary.
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 51.6K bytes
    - Viewed (0)
  7. 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)
  8. src/runtime/mgcmark.go

    	sched.gFree.stack = gList{}
    	unlock(&sched.gFree.lock)
    	if list.empty() {
    		return
    	}
    
    	// Free stacks.
    	q := gQueue{list.head, list.head}
    	for gp := list.head.ptr(); gp != nil; gp = gp.schedlink.ptr() {
    		stackfree(gp.stack)
    		gp.stack.lo = 0
    		gp.stack.hi = 0
    		// Manipulate the queue directly since the Gs are
    		// already all linked the right way.
    		q.tail.set(gp)
    	}
    
    	// Put Gs back on the free list.
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Thu Apr 18 21:25:11 UTC 2024
    - 52.5K bytes
    - Viewed (0)
  9. tensorflow/compiler/mlir/g3doc/_includes/tf_passes.md

    to 12 feature dimension, which has better performance on TPU.
    ### `-tf-tpu-update-embedding-enqueue-op-inputs`
    
    _Updates inputs to TPU embedding enqueue ops depending on whether graph is in training mode or in evaluation mode._
    
    Updates inputs to TPU embedding enqueue ops depending on whether graph
    is in training mode or in evaluation mode.
    ### `-tf-tpu-validate-inputs`
    
    Registered: Sun Jun 16 05:45:23 UTC 2024
    - Last Modified: Wed Aug 02 02:26:39 UTC 2023
    - 96.4K 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