Search Options

Results per page
Sort
Preferred Languages
Advance

Results 31 - 40 of 857 for crBlock (0.12 sec)

  1. android/guava-tests/test/com/google/common/util/concurrent/CycleDetectingLockFactoryTest.java

        assertFalse(lockA.tryLock());
    
        thread.releaseLockAndFinish();
        assertTrue(lockA.tryLock());
      }
    
      public void testReentrantWriteLock_tryLock() throws Exception {
        LockingThread thread = new LockingThread(writeLockA);
        thread.start();
    
        thread.waitUntilHoldingLock();
        assertFalse(writeLockA.tryLock());
        assertFalse(readLockA.tryLock());
    
        thread.releaseLockAndFinish();
    Registered: Wed Jun 12 16:38:11 UTC 2024
    - Last Modified: Wed Sep 06 17:04:31 UTC 2023
    - 16.1K bytes
    - Viewed (0)
  2. guava-tests/test/com/google/common/util/concurrent/CycleDetectingLockFactoryTest.java

        assertFalse(lockA.tryLock());
    
        thread.releaseLockAndFinish();
        assertTrue(lockA.tryLock());
      }
    
      public void testReentrantWriteLock_tryLock() throws Exception {
        LockingThread thread = new LockingThread(writeLockA);
        thread.start();
    
        thread.waitUntilHoldingLock();
        assertFalse(writeLockA.tryLock());
        assertFalse(readLockA.tryLock());
    
        thread.releaseLockAndFinish();
    Registered: Wed Jun 12 16:38:11 UTC 2024
    - Last Modified: Wed Sep 06 17:04:31 UTC 2023
    - 16.1K bytes
    - Viewed (0)
  3. android/guava/src/com/google/common/util/concurrent/ForwardingLock.java

        delegate().lockInterruptibly();
      }
    
      @Override
      public boolean tryLock() {
        return delegate().tryLock();
      }
    
      @Override
      public boolean tryLock(long time, TimeUnit unit) throws InterruptedException {
        return delegate().tryLock(time, unit);
      }
    
      @Override
      public void unlock() {
        delegate().unlock();
      }
    
      @Override
    Registered: Wed Jun 12 16:38:11 UTC 2024
    - Last Modified: Tue Apr 04 09:45:04 UTC 2023
    - 1.5K bytes
    - Viewed (0)
  4. pkg/scheduler/internal/queue/scheduling_queue.go

    }
    
    // Option configures a PriorityQueue
    type Option func(*priorityQueueOptions)
    
    // WithClock sets clock for PriorityQueue, the default clock is clock.RealClock.
    func WithClock(clock clock.Clock) Option {
    	return func(o *priorityQueueOptions) {
    		o.clock = clock
    	}
    }
    
    // WithPodInitialBackoffDuration sets pod initial backoff duration for PriorityQueue.
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed Jun 12 13:26:09 UTC 2024
    - 61.4K bytes
    - Viewed (0)
  5. src/internal/poll/fd_mutex_test.go

    	if mu.Incref() {
    		t.Fatal("broken")
    	}
    	if mu.RWLock(true) {
    		t.Fatal("broken")
    	}
    	if mu.RWLock(false) {
    		t.Fatal("broken")
    	}
    	if mu.IncrefAndClose() {
    		t.Fatal("broken")
    	}
    }
    
    func TestMutexCloseUnblock(t *testing.T) {
    	c := make(chan bool, 4)
    	var mu XFDMutex
    	mu.RWLock(true)
    	for i := 0; i < 4; i++ {
    		go func() {
    			if mu.RWLock(true) {
    				t.Error("broken")
    				return
    			}
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Sat Oct 08 03:57:40 UTC 2022
    - 4K bytes
    - Viewed (0)
  6. subprojects/core/src/test/groovy/org/gradle/execution/plan/DefaultPlanExecutorTest.groovy

            then:
            result.failures.empty
    
            1 * workerLeaseService.currentWorkerLease >> workerLease
    
            then:
            1 * cancellationHandler.isCancellationRequested() >> false
            1 * workerLease.tryLock() >> true
            1 * workSource.executionState() >> WorkSource.State.MaybeWorkReadyToStart
            1 * workSource.selectNext() >> WorkSource.Selection.of(node)
            1 * worker.execute(node)
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Fri Apr 05 16:29:26 UTC 2024
    - 4.3K bytes
    - Viewed (0)
  7. staging/src/k8s.io/apiserver/pkg/server/egressselector/metrics/metrics.go

    	legacyregistry.MustRegister(failures)
    	return &DialMetrics{starts: starts, latencies: latencies, failures: failures, clock: clock.RealClock{}}
    }
    
    // Clock returns the clock.
    func (m *DialMetrics) Clock() clock.Clock {
    	return m.clock
    }
    
    // SetClock sets the clock.
    func (m *DialMetrics) SetClock(c clock.Clock) {
    	m.clock = c
    }
    
    // Reset resets the metrics.
    func (m *DialMetrics) Reset() {
    	m.starts.Reset()
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Tue Nov 01 23:36:51 UTC 2022
    - 4.3K bytes
    - Viewed (0)
  8. staging/src/k8s.io/apimachinery/pkg/util/wait/backoff.go

    	resetInterval  time.Duration
    
    	clock clock.Clock
    
    	lock      sync.Mutex
    	lastStart time.Time
    	timer     clock.Timer
    }
    
    // Step returns the expected next duration to wait.
    func (b *backoffManager) Step() time.Duration {
    	b.lock.Lock()
    	defer b.lock.Unlock()
    
    	switch {
    	case b.resetInterval == 0:
    		b.backoff = b.initialBackoff
    	case b.clock.Now().Sub(b.lastStart) > b.resetInterval:
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Tue Mar 14 19:14:11 UTC 2023
    - 16.5K bytes
    - Viewed (0)
  9. staging/src/k8s.io/apiserver/plugin/pkg/authenticator/token/oidc/metrics.go

    	return newInstrumentedAuthenticatorWithClock(jwtIssuer, delegate, clock.RealClock{})
    }
    
    func newInstrumentedAuthenticatorWithClock(jwtIssuer string, delegate AuthenticatorTokenWithHealthCheck, clock clock.PassiveClock) *instrumentedAuthenticator {
    	RegisterMetrics()
    	return &instrumentedAuthenticator{
    		jwtIssuerHash: getHash(jwtIssuer),
    		delegate:      delegate,
    		clock:         clock,
    	}
    }
    
    type instrumentedAuthenticator struct {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat Mar 09 19:29:33 UTC 2024
    - 3.3K bytes
    - Viewed (0)
  10. platforms/core-runtime/logging/src/main/java/org/gradle/internal/logging/progress/DefaultProgressLoggerFactory.java

        public DefaultProgressLoggerFactory(ProgressListener progressListener, Clock clock, BuildOperationIdFactory buildOperationIdFactory) {
            this.progressListener = progressListener;
            this.clock = clock;
            this.buildOperationIdFactory = buildOperationIdFactory;
        }
    
        @Override
        public ProgressLogger newOperation(Class<?> loggerCategory) {
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Tue May 28 13:09:37 UTC 2024
    - 10.5K bytes
    - Viewed (0)
Back to top