Search Options

Results per page
Sort
Preferred Languages
Advance

Results 1 - 10 of 19 for Dequeue (0.37 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. tensorflow/compiler/jit/deadness_analysis.cc

            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;
      ready.push_back(src_node);
    Registered: Sun Jun 16 05:45:23 UTC 2024
    - Last Modified: Tue Mar 12 06:33:33 UTC 2024
    - 60.4K bytes
    - Viewed (0)
  3. okhttp/src/test/java/okhttp3/internal/http2/HttpOverHttp2Test.kt

      ) {
        setUp(protocol, mockWebServer)
        server.enqueue(
          MockResponse.Builder()
            .body(Buffer().write(ByteArray(Http2Connection.OKHTTP_CLIENT_WINDOW_SIZE + 1)))
            .build(),
        )
        server.enqueue(
          MockResponse(body = "abc"),
        )
        // Enqueue an additional response that show if we burnt a good prior response.
        server.enqueue(
          MockResponse(body = "XXX"),
        )
    Registered: Sun Jun 16 04:42:17 UTC 2024
    - Last Modified: Thu Apr 11 22:09:35 UTC 2024
    - 75.3K bytes
    - Viewed (0)
  4. okhttp/src/test/java/okhttp3/EventListenerTest.kt

        enableTlsWithTunnel()
        server.enqueue(
          MockResponse.Builder()
            .inTunnel()
            .code(407)
            .addHeader("Proxy-Authenticate: Basic realm=\"localhost\"")
            .addHeader("Connection: close")
            .build(),
        )
        server.enqueue(
          MockResponse.Builder()
            .inTunnel()
            .build(),
        )
        server.enqueue(MockResponse())
        client =
    Registered: Sun Jun 16 04:42:17 UTC 2024
    - Last Modified: Sat Jan 20 10:30:28 UTC 2024
    - 56.9K bytes
    - Viewed (0)
  5. 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)
  6. 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)
  7. 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)
  8. 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)
  9. 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)
  10. 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)
Back to top