Search Options

Results per page
Sort
Preferred Languages
Advance

Results 1 - 10 of 39 for lock1 (0.07 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. 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)
  7. 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)
  8. staging/src/k8s.io/apiserver/pkg/storage/cacher/watch_cache.go

    		wcEvent.PrevObjFields = previousElem.Fields
    	}
    
    	if err := func() error {
    		w.Lock()
    		defer w.Unlock()
    
    		w.updateCache(wcEvent)
    		w.resourceVersion = resourceVersion
    		defer w.cond.Broadcast()
    
    		return updateFunc(elem)
    	}(); err != nil {
    		return err
    	}
    
    	// Avoid calling event handler under lock.
    	// This is safe as long as there is at most one call to Add/Update/Delete and
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Tue Jun 11 10:20:57 UTC 2024
    - 26.2K bytes
    - Viewed (0)
  9. staging/src/k8s.io/apiserver/pkg/storage/cacher/cacher.go

    }
    
    func (c *Cacher) startCaching(stopChannel <-chan struct{}) {
    	// The 'usable' lock is always 'RLock'able when it is safe to use the cache.
    	// It is safe to use the cache after a successful list until a disconnection.
    	// We start with usable (write) locked. The below OnReplace function will
    	// unlock it after a successful list. The below defer will then re-lock
    	// it when this function exits (always due to disconnection), only if
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed Jun 12 10:12:02 UTC 2024
    - 51.8K bytes
    - Viewed (0)
  10. subprojects/core/src/main/java/org/gradle/api/services/internal/RegisteredBuildServiceProvider.java

        private Try<T> instantiate() {
            // TODO - extract some shared infrastructure to take care of instantiation (eg which services are visible, strict vs lenient, decorated or not?)
            // TODO - should hold the project lock to do the isolation. Should work the same way as artifact transforms (a work node does the isolation, etc)
            P isolatedParameters = isolatableFactory.isolate(getParameters()).isolate();
            // TODO - reuse this in other places
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Sat Jun 08 09:24:00 UTC 2024
    - 8.1K bytes
    - Viewed (0)
Back to top