Search Options

Results per page
Sort
Preferred Languages
Advance

Results 11 - 20 of 21 for newConditions (0.21 sec)

  1. platforms/core-runtime/messaging/src/integTest/groovy/org/gradle/internal/remote/UnicastMessagingIntegrationTest.groovy

            }
            abstract void stop()
        }
    
        class Server extends Participant {
            private final lock = new ReentrantLock()
            private final condition = lock.newCondition()
            private final services = ServiceRegistryBuilder.builder().provider(new TestMessagingServices()).build()
            private ConnectionAcceptor acceptor
            private ObjectConnection connection
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Mon May 27 09:21:43 UTC 2024
    - 8.9K bytes
    - Viewed (0)
  2. platforms/core-runtime/base-services/src/main/java/org/gradle/internal/work/DefaultConditionalExecutionQueue.java

        private final Deque<ConditionalExecution<T>> queue = new LinkedList<ConditionalExecution<T>>();
        private final ReentrantLock lock = new ReentrantLock();
        private final Condition workAvailable = lock.newCondition();
        private QueueState queueState = QueueState.Working;
        @GuardedBy("lock")
        private int workerCount;
    
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Wed May 29 06:47:40 UTC 2024
    - 7.2K bytes
    - Viewed (0)
  3. platforms/core-runtime/launcher/src/main/java/org/gradle/launcher/daemon/server/DaemonStateCoordinator.java

        private static final Logger LOGGER = Logging.getLogger(DaemonStateCoordinator.class);
    
        private final Lock lock = new ReentrantLock();
        private final Condition condition = lock.newCondition();
        private final long cancelTimeoutMs;
    
        private State state = State.Idle;
        private final Timer idleTimer;
        private String currentCommandExecution;
        private Object result;
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Wed May 29 06:47:38 UTC 2024
    - 17.1K bytes
    - Viewed (0)
  4. okhttp/src/main/kotlin/okhttp3/internal/concurrent/TaskRunner.kt

     */
    class TaskRunner(
      val backend: Backend,
      internal val logger: Logger = TaskRunner.logger,
    ) {
      val lock: ReentrantLock = ReentrantLock()
      val condition: Condition = lock.newCondition()
    
      private var nextQueueName = 10000
      private var coordinatorWaiting = false
      private var coordinatorWakeUpAt = 0L
    
      /**
    Registered: Sun Jun 16 04:42:17 UTC 2024
    - Last Modified: Mon Apr 29 00:33:04 UTC 2024
    - 10.6K bytes
    - Viewed (0)
  5. testing/internal-integ-testing/src/main/groovy/org/gradle/test/fixtures/server/http/ExpectMaxNConcurrentRequests.java

            if (expectedRequests.size() < maxConcurrent) {
                throw new IllegalArgumentException("Too few requests specified.");
            }
            this.lock = lock;
            this.condition = lock.newCondition();
            this.testId = testId;
            this.timeoutMs = timeout.toMillis();
            this.waitingFor = maxConcurrent;
            this.previous = previous;
            for (ResourceExpectation expectation : expectedRequests) {
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Thu Apr 04 07:21:38 UTC 2024
    - 14.4K bytes
    - Viewed (0)
  6. pkg/controller/job/job_controller_test.go

    	fakeClock := clocktesting.NewFakeClock(time.Now())
    	now := fakeClock.Now()
    	minuteAgo := now.Add(-time.Minute)
    	completedCond := newCondition(batch.JobComplete, v1.ConditionTrue, "", "", now)
    	succeededCond := newCondition(batch.JobSuccessCriteriaMet, v1.ConditionTrue, "", "", minuteAgo)
    	failedCond := newCondition(batch.JobFailed, v1.ConditionTrue, "", "", now)
    	indexedCompletion := batch.IndexedCompletion
    	mockErr := errors.New("mock error")
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Tue Jun 11 15:36:36 UTC 2024
    - 229.2K bytes
    - Viewed (0)
  7. platforms/core-execution/persistent-cache/src/main/java/org/gradle/cache/internal/DefaultCacheCoordinator.java

        private ExclusiveCacheAccessingWorker cacheAccessWorker;
        private final Lock stateLock = new ReentrantLock(); // protects the following state
        private final Condition condition = stateLock.newCondition();
    
        private boolean open;
        private Thread owner;
        private FileLock fileLock;
        private FileLock.State stateAtOpen;
        private Runnable fileLockHeldByOwner;
        private int cacheClosedCount;
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Wed May 01 12:21:15 UTC 2024
    - 20.5K bytes
    - Viewed (0)
  8. platforms/core-execution/persistent-cache/src/main/java/org/gradle/cache/internal/DefaultFileLockManager.java

        static class AwaitableFileLockReleasedSignal implements FileLockReleasedSignal, ExponentialBackoff.Signal {
    
            private final Lock lock = new ReentrantLock();
            private final Condition condition = lock.newCondition();
            private int waiting;
    
            @SuppressWarnings("WaitNotInLoop")
            @Override
            public boolean await(long millis) throws InterruptedException {
                lock.lock();
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Fri Apr 26 16:02:32 UTC 2024
    - 22.3K bytes
    - Viewed (0)
  9. okhttp/src/main/kotlin/okhttp3/internal/http2/Http2Stream.kt

      val id: Int,
      val connection: Http2Connection,
      outFinished: Boolean,
      inFinished: Boolean,
      headers: Headers?,
    ) {
      internal val lock: ReentrantLock = ReentrantLock()
      val condition: Condition = lock.newCondition()
    
      // Internal state is guarded by [lock]. No long-running or potentially blocking operations are
      // performed while the lock is held.
    
      /** The bytes consumed and acknowledged by the stream. */
    Registered: Sun Jun 16 04:42:17 UTC 2024
    - Last Modified: Sat Apr 20 17:03:43 UTC 2024
    - 23.2K bytes
    - Viewed (0)
  10. guava-tests/test/com/google/common/util/concurrent/UninterruptiblesTest.java

                  delay,
                  unit);
    
          return testCondition;
        }
    
        static TestCondition create() {
          Lock lock = new ReentrantLock();
          Condition condition = lock.newCondition();
          return new TestCondition(lock, condition);
        }
    
        @Override
        public void await() throws InterruptedException {
          lock.lock();
          try {
            condition.await();
    Registered: Wed Jun 12 16:38:11 UTC 2024
    - Last Modified: Mon Jun 10 16:06:39 UTC 2024
    - 31.7K bytes
    - Viewed (0)
Back to top