Search Options

Results per page
Sort
Preferred Languages
Advance

Results 1 - 10 of 12 for workerCount (0.24 sec)

  1. platforms/core-runtime/base-services/src/main/java/org/gradle/internal/work/DefaultConditionalExecutionQueue.java

        private final ReentrantLock lock = new ReentrantLock();
        private final Condition workAvailable = lock.newCondition();
        private QueueState queueState = QueueState.Working;
        @GuardedBy("lock")
        private int workerCount;
    
        public DefaultConditionalExecutionQueue(String displayName, WorkerLimits workerLimits, ExecutorFactory executorFactory, WorkerLeaseService workerLeaseService) {
            this.workerLimits = workerLimits;
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Wed May 29 06:47:40 UTC 2024
    - 7.2K bytes
    - Viewed (0)
  2. testing/soak/src/integTest/groovy/org/gradle/workers/internal/WorkerPruningSoakTest.groovy

            def workerCount = 200
    
            singleProjectBuild("root") {
                fixture.withAlternateWorkActionClassInBuildSrc()
                buildFile << """
                def buildCounter = project.property('counter')
                def runAllInWorkers = tasks.register("runAllInWorkers")
                for (int i = 0; i < $workerCount; i++) {
                    def projectCounter = i
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Thu Apr 04 07:21:38 UTC 2024
    - 2.7K bytes
    - Viewed (0)
  3. subprojects/core/src/main/java/org/gradle/initialization/ParallelismBuildOptions.java

                try {
                    int workerCount = Integer.parseInt(value);
                    if (workerCount < 1) {
                        origin.handleInvalidValue(value, HINT);
                    }
                    settings.setMaxWorkerCount(workerCount);
                } catch (NumberFormatException e) {
                    origin.handleInvalidValue(value, HINT);
                }
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Mon Apr 08 19:00:19 UTC 2024
    - 3.2K bytes
    - Viewed (0)
  4. internal/event/targetlist.go

    			TotalEvents:      stats.totalEvents,
    		}
    	}
    
    	return t
    }
    
    func (list *TargetList) startSendWorkers(workerCount int) {
    	if workerCount == 0 {
    		workerCount = runtime.GOMAXPROCS(0)
    	}
    	wk, err := workers.New(workerCount)
    	if err != nil {
    		panic(err)
    	}
    	for i := 0; i < workerCount; i++ {
    		wk.Take()
    		go func() {
    			defer wk.Give()
    
    			for {
    				select {
    				case av := <-list.queue:
    Registered: Sun Jun 16 00:44:34 UTC 2024
    - Last Modified: Fri May 24 23:05:23 UTC 2024
    - 9.2K bytes
    - Viewed (0)
  5. subprojects/core/src/main/java/org/gradle/internal/operations/DefaultBuildOperationQueue.java

                    return;
                }
                workQueue.add(operation);
                pendingOperations++;
                workAvailable.signalAll();
                if (workerCount == 0 || workerCount < workerLeases.getMaxWorkerCount() - 1) {
                    // `getMaxWorkerCount() - 1` because main thread executes work as well. See https://github.com/gradle/gradle/issues/3273
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Tue Jan 31 15:18:20 UTC 2023
    - 10.4K bytes
    - Viewed (0)
  6. platforms/core-runtime/base-services/src/test/groovy/org/gradle/internal/work/DefaultConditionalExecutionQueueTest.groovy

                    }
                    instant.allSubmitted
                }
            }
            thread.blockUntil.allSubmitted
            assert queue.workerCount <= MAX_WORKERS
            executions.each { it.await() }
    
            and:
            ConcurrentTestUtil.poll {
                queue.workerCount <= MAX_WORKERS
            }
        }
    
        def "can get a result from an execution"() {
            def execution = testExecution({
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Fri Apr 05 16:29:26 UTC 2024
    - 6.9K bytes
    - Viewed (0)
  7. pilot/pkg/status/resourcelock.go

    func (wp *WorkerPool) maybeAddWorker() {
    	wp.lock.Lock()
    	if wp.workerCount >= wp.maxWorkers || wp.q.Length() == 0 {
    		wp.lock.Unlock()
    		return
    	}
    	wp.workerCount++
    	wp.lock.Unlock()
    	go func() {
    		for {
    			wp.lock.Lock()
    			if wp.closing || wp.q.Length() == 0 {
    				wp.workerCount--
    				wp.lock.Unlock()
    				return
    			}
    
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Sun Feb 04 03:39:42 UTC 2024
    - 6.4K bytes
    - Viewed (0)
  8. pkg/kubelet/prober/prober_manager_test.go

    func cleanup(t *testing.T, m *manager) {
    	m.CleanupPods(nil)
    
    	condition := func() (bool, error) {
    		workerCount := m.workerCount()
    		if workerCount > 0 {
    			t.Logf("Waiting for %d workers to exit...", workerCount)
    		}
    		return workerCount == 0, nil
    	}
    	if exited, _ := condition(); exited {
    		return // Already exited, no need to poll.
    	}
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed Apr 24 18:25:29 UTC 2024
    - 18.8K bytes
    - Viewed (0)
  9. subprojects/core/src/test/groovy/org/gradle/internal/operations/DefaultBuildOperationQueueTest.groovy

            then:
            !waitForCompletionThread.alive
            // The main thread sometimes processes items when there are more items than threads available, so
            // we may only submit workerCount - 1 work processors, but we should never submit more than workerCount
            ((expectedWorkerCount-1)..expectedWorkerCount) * executor.execute(_) >> { args -> delegateExecutor.execute(args[0]) }
    
            where:
            runs | threads
            1    | 1
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Fri Apr 05 16:29:26 UTC 2024
    - 9.4K bytes
    - Viewed (0)
  10. pkg/kubelet/prober/prober_manager.go

    	m.workerLock.Lock()
    	defer m.workerLock.Unlock()
    	delete(m.workers, probeKey{podUID, containerName, probeType})
    }
    
    // workerCount returns the total number of probe workers. For testing.
    func (m *manager) workerCount() int {
    	m.workerLock.RLock()
    	defer m.workerLock.RUnlock()
    	return len(m.workers)
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Fri Jul 07 22:26:12 UTC 2023
    - 11K bytes
    - Viewed (0)
Back to top