Search Options

Results per page
Sort
Preferred Languages
Advance

Results 1 - 10 of 142 for workqueue (0.11 sec)

  1. platforms/core-execution/workers/src/main/java/org/gradle/workers/WorkQueue.java

    import org.gradle.api.Action;
    
    /**
     * Represents a queue of work items with a uniform set of worker requirements.
     *
     * Note that this object is not thread-safe.
     *
     * @since 5.6
     */
    public interface WorkQueue {
        /**
         * Submits a piece of work to be executed asynchronously.
         *
         * Execution of the work may begin immediately.
         *
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Fri Sep 22 09:36:27 UTC 2023
    - 2K bytes
    - Viewed (0)
  2. pkg/kubelet/util/queue/work_queue.go

    }
    
    type basicWorkQueue struct {
    	clock clock.Clock
    	lock  sync.Mutex
    	queue map[types.UID]time.Time
    }
    
    var _ WorkQueue = &basicWorkQueue{}
    
    // NewBasicWorkQueue returns a new basic WorkQueue with the provided clock
    func NewBasicWorkQueue(clock clock.Clock) WorkQueue {
    	queue := make(map[types.UID]time.Time)
    	return &basicWorkQueue{queue: queue, clock: clock}
    }
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Fri Sep 10 10:20:09 UTC 2021
    - 1.7K bytes
    - Viewed (0)
  3. platforms/core-execution/workers/src/main/java/org/gradle/workers/WorkerExecutor.java

    public interface WorkerExecutor {
    
        /**
         * Creates a {@link WorkQueue} to submit work for asynchronous execution with no isolation.
         *
         * @since 5.6
         */
        WorkQueue noIsolation();
    
        /**
         * Creates a {@link WorkQueue} to submit work for asynchronous execution with an isolated classloader.
         *
         * @since 5.6
         */
        WorkQueue classLoaderIsolation();
    
        /**
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Tue Mar 12 02:21:10 UTC 2024
    - 4K bytes
    - Viewed (0)
  4. platforms/documentation/docs/src/snippets/workerApi/waitForCompletion/groovy/build.gradle

        }
    
        @TaskAction
        void reverseFiles() {
            // tag::wait-for-completion[]
            // Create a WorkQueue to submit work items
            WorkQueue workQueue = workerExecutor.noIsolation()
    
            // Create and submit a unit of work for each file
            source.each { file ->
                workQueue.submit(ReverseFile.class) { ReverseParameters parameters ->
                    parameters.fileToReverse = file
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Mon Nov 27 17:53:42 UTC 2023
    - 2.1K bytes
    - Viewed (0)
  5. platforms/documentation/docs/src/snippets/workerApi/workerDaemon/groovy/build.gradle

            this.workerExecutor = workerExecutor
        }
    
        @TaskAction
        void reverseFiles() {
            // tag::worker-daemon[]
            // Create a WorkQueue with process isolation
            WorkQueue workQueue = workerExecutor.processIsolation() { ProcessWorkerSpec spec ->
                // Configure the options for the forked process
                forkOptions { JavaForkOptions options ->
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Mon Nov 27 17:53:42 UTC 2023
    - 2.2K bytes
    - Viewed (0)
  6. pkg/scheduler/framework/parallelize/parallelism.go

    		s = r
    	} else if s < 1 {
    		s = 1
    	}
    	return s
    }
    
    // Until is a wrapper around workqueue.ParallelizeUntil to use in scheduling algorithms.
    // A given operation will be a label that is recorded in the goroutine metric.
    func (p Parallelizer) Until(ctx context.Context, pieces int, doWorkPiece workqueue.DoWorkPieceFunc, operation string) {
    	goroutinesMetric := metrics.Goroutines.WithLabelValues(operation)
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Thu Mar 09 17:12:30 UTC 2023
    - 2K bytes
    - Viewed (0)
  7. platforms/documentation/docs/src/snippets/workerApi/md5NoIsolation/kotlin/buildSrc/src/main/java/CreateMD5.java

        @TaskAction
        public void createHashes() {
            WorkQueue workQueue = getWorkerExecutor().noIsolation(); // <2>
    
            for (File sourceFile : getSource().getFiles()) {
                Provider<RegularFile> md5File = getDestinationDirectory().file(sourceFile.getName() + ".md5");
                workQueue.submit(GenerateMD5.class, parameters -> { // <3>
                    parameters.getSourceFile().set(sourceFile);
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Mon Nov 27 17:53:42 UTC 2023
    - 990 bytes
    - Viewed (0)
  8. pilot/pkg/status/resourcelock.go

    		}
    	}
    	return Resource{}, nil
    }
    
    func (wq *WorkQueue) Length() int {
    	wq.lock.Lock()
    	defer wq.lock.Unlock()
    	return len(wq.tasks)
    }
    
    func (wq *WorkQueue) Delete(target Resource) {
    	wq.lock.Lock()
    	defer wq.lock.Unlock()
    	delete(wq.cache, convert(target))
    }
    
    type WorkerPool struct {
    	q WorkQueue
    	// indicates the queue is closing
    	closing bool
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Sun Feb 04 03:39:42 UTC 2024
    - 6.4K bytes
    - Viewed (0)
  9. platforms/documentation/docs/src/snippets/plugins/buildServiceFromWorkAction/groovy/buildSrc/src/main/java/Download.java

        @ServiceReference("web")
        abstract Property<WebServer> getServer();
    
        @TaskAction
        public void download() {
            WorkQueue workQueue = getWorkerExecutor().noIsolation();
            workQueue.submit(DownloadWorkAction.class, parameter -> {
                parameter.getServer().set(getServer());
            });
        }
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Mon Nov 27 17:53:42 UTC 2023
    - 1.5K bytes
    - Viewed (0)
  10. platforms/core-execution/persistent-cache/src/main/java/org/gradle/cache/internal/ExclusiveCacheAccessingWorker.java

    import java.util.concurrent.TimeUnit;
    import java.util.function.Supplier;
    
    public class ExclusiveCacheAccessingWorker implements Runnable, Stoppable, AsyncCacheAccess {
        private final BlockingQueue<Runnable> workQueue;
        private final String displayName;
        private final ExclusiveCacheAccessCoordinator cacheAccess;
        private final long batchWindowMillis;
        private final long maximumLockingTimeMillis;
        private boolean closed;
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Tue Apr 16 15:49:50 UTC 2024
    - 8.8K bytes
    - Viewed (0)
Back to top