Search Options

Results per page
Sort
Preferred Languages
Advance

Results 1 - 10 of 57 for lock1 (0.04 sec)

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

     * method equivalent to {@link
     * java.util.concurrent.locks.ReentrantLock#hasWaiters(java.util.concurrent.locks.Condition)},
     * except that the method parameter must accept whatever condition-like object is passed into {@code
     * callAndAssertWaits} by the test.
     *
     * @param <L> the type of the lock-like object to be used
     * @author Justin T. Sampson
     */
    Registered: Wed Jun 12 16:38:11 UTC 2024
    - Last Modified: Tue Jun 11 16:13:05 UTC 2024
    - 10.8K bytes
    - Viewed (0)
  2. guava-tests/test/com/google/common/util/concurrent/TestThread.java

     * method equivalent to {@link
     * java.util.concurrent.locks.ReentrantLock#hasWaiters(java.util.concurrent.locks.Condition)},
     * except that the method parameter must accept whatever condition-like object is passed into {@code
     * callAndAssertWaits} by the test.
     *
     * @param <L> the type of the lock-like object to be used
     * @author Justin T. Sampson
     */
    Registered: Wed Jun 12 16:38:11 UTC 2024
    - Last Modified: Tue Jun 11 16:13:05 UTC 2024
    - 10.8K bytes
    - Viewed (0)
  3. pkg/scheduler/internal/queue/scheduling_queue.go

    func (p *PriorityQueue) Close() {
    	p.lock.Lock()
    	defer p.lock.Unlock()
    	close(p.stop)
    	p.closed = true
    	p.cond.Broadcast()
    }
    
    // DeleteNominatedPodIfExists deletes <pod> from nominatedPods.
    func (npm *nominator) DeleteNominatedPodIfExists(pod *v1.Pod) {
    	npm.lock.Lock()
    	npm.deleteNominatedPodIfExistsUnlocked(pod)
    	npm.lock.Unlock()
    }
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed Jun 12 13:26:09 UTC 2024
    - 61.4K bytes
    - Viewed (0)
  4. platforms/core-configuration/configuration-cache/src/main/kotlin/org/gradle/internal/cc/impl/ConfigurationCacheClassLoaderScopeRegistryListener.kt

        override fun scopeFor(classLoader: ClassLoader?): Pair<ClassLoaderScopeSpec, ClassLoaderRole>? {
            synchronized(lock) {
                return loaders[classLoader]
            }
        }
    
        override fun childScopeCreated(parentId: ClassLoaderScopeId, childId: ClassLoaderScopeId, origin: ClassLoaderScopeOrigin?) {
            synchronized(lock) {
                if (scopeSpecs.containsKey(childId)) {
                    // scope is being reused
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Sat Jun 08 11:29:30 UTC 2024
    - 4.7K bytes
    - Viewed (0)
  5. platforms/core-configuration/configuration-cache/src/integTest/groovy/org/gradle/internal/cc/impl/ConfigurationCacheSkipCacheIntegrationTest.groovy

            then:
            outputContains("bar")
            configurationCache.assertStateLoaded()
    
            where:
            commandLine              | _
            "--refresh-dependencies" | _
            "--write-locks"          | _
            "--update-locks thing:*" | _
        }
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Sat Jun 08 11:29:25 UTC 2024
    - 2.6K bytes
    - Viewed (0)
  6. cmd/metacache-set.go

    			err := o.checkMetacacheState(ctx, rpc)
    			if err != nil {
    				return entries, fmt.Errorf("remote listing canceled: %w", err)
    			}
    			retries = 1
    		}
    
    		// All operations are performed without locks, so we must be careful and allow for failures.
    		// Read metadata associated with the object from a disk.
    		if retries > 0 {
    			for _, disk := range er.getDisks() {
    				if disk == nil {
    					continue
    				}
    Registered: Sun Jun 16 00:44:34 UTC 2024
    - Last Modified: Fri Jun 07 22:18:44 UTC 2024
    - 30.4K bytes
    - Viewed (0)
  7. platforms/core-execution/persistent-cache/src/integTest/groovy/org/gradle/cache/internal/DefaultFileLockManagerContentionIntegrationTest.groovy

                    @TaskAction
                    void lockIt() {
                        def lock
                        try {
                            lock = fileLockManager.lock(projectLayout.projectDirectory.file("locks/testlock").asFile, DefaultLockOptions.mode(FileLockManager.LockMode.Exclusive), "task file lock")
                        } finally {
                            lock?.close()
                        }
                    }
                }
    
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Tue Jun 11 09:51:15 UTC 2024
    - 15.1K bytes
    - Viewed (0)
  8. src/sync/mutex.go

    	// Starvation mode is important to prevent pathological cases of tail latency.
    	starvationThresholdNs = 1e6
    )
    
    // Lock locks m.
    // If the lock is already in use, the calling goroutine
    // blocks until the mutex is available.
    func (m *Mutex) Lock() {
    	// Fast path: grab unlocked mutex.
    	if atomic.CompareAndSwapInt32(&m.state, 0, mutexLocked) {
    		if race.Enabled {
    			race.Acquire(unsafe.Pointer(m))
    		}
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Fri Jun 07 21:14:51 UTC 2024
    - 8.4K bytes
    - Viewed (0)
  9. android/guava/src/com/google/common/hash/Striped64.java

       * needed.
       *
       * A single spinlock ("busy") is used for initializing and
       * resizing the table, as well as populating slots with new Cells.
       * There is no need for a blocking lock; when the lock is not
       * available, threads try other slots (or the base).  During these
       * retries, there is increased contention and reduced locality,
       * which is still better than alternatives.
       *
    Registered: Wed Jun 12 16:38:11 UTC 2024
    - Last Modified: Fri Jun 07 22:25:23 UTC 2024
    - 11.5K bytes
    - Viewed (0)
  10. pilot/pkg/model/endpointshards.go

    }
    
    func (e *EndpointIndex) DeleteServiceShard(shard ShardKey, serviceName, namespace string, preserveKeys bool) {
    	e.mu.Lock()
    	defer e.mu.Unlock()
    	e.deleteServiceInner(shard, serviceName, namespace, preserveKeys)
    }
    
    func (e *EndpointIndex) DeleteShard(shardKey ShardKey) {
    	e.mu.Lock()
    	defer e.mu.Unlock()
    	for svc, shardsByNamespace := range e.shardsBySvc {
    		for ns := range shardsByNamespace {
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Fri Jun 14 04:34:37 UTC 2024
    - 15.6K bytes
    - Viewed (0)
Back to top