Search Options

Results per page
Sort
Preferred Languages
Advance

Results 11 - 20 of 195 for stopped_ (0.14 sec)

  1. platforms/core-runtime/launcher/src/main/java/org/gradle/launcher/daemon/server/DaemonStopState.java

    package org.gradle.launcher.daemon.server;
    
    /**
     * Indicates the state of the daemon when it stops doing work.
     */
    public enum DaemonStopState {
        /**
         * Daemon was stopped cleanly and all work stopped.
         */
        Clean,
        /**
         * Daemon could not be stopped cleanly and some work may still be running.
         */
        Forced
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Sun May 05 22:45:11 UTC 2024
    - 953 bytes
    - Viewed (0)
  2. staging/src/k8s.io/apiserver/pkg/storage/cacher/watch_progress.go

    	defer timer.Stop()
    	for {
    		stopped := func() bool {
    			pr.mux.Lock()
    			defer pr.mux.Unlock()
    			for pr.waiting == 0 && !pr.stopped {
    				pr.cond.Wait()
    			}
    			return pr.stopped
    		}()
    		if stopped {
    			return
    		}
    
    		select {
    		case <-timer.C():
    			shouldRequest := func() bool {
    				pr.mux.Lock()
    				defer pr.mux.Unlock()
    				return pr.waiting > 0 && !pr.stopped
    			}()
    			if !shouldRequest {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Fri May 24 09:56:38 UTC 2024
    - 3K bytes
    - Viewed (0)
  3. platforms/core-execution/persistent-cache/src/main/java/org/gradle/cache/internal/locklistener/FileLockCommunicator.java

                    socket.send(packet);
                } catch (IOException e) {
                    if (!stopped) {
                        LOGGER.debug("Failed to confirm lock release to Gradle process at port {} for lock with id {}.", packet.getPort(), lockId);
                    }
                }
            }
        }
    
        public void stop() {
            stopped = true;
            socket.close();
        }
    
        public int getPort() {
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Tue Apr 16 15:49:49 UTC 2024
    - 5.9K bytes
    - Viewed (0)
  4. pkg/kubelet/util/manager/watch_based_manager.go

    	// to be retried.
    	if !i.stopped && i.store.hasSynced() && now.After(i.lastAccessTime.Add(maxIdleTime)) {
    		return i.stopThreadUnsafe()
    	}
    	return false
    }
    
    func (i *objectCacheItem) restartReflectorIfNeeded() {
    	i.lock.Lock()
    	defer i.lock.Unlock()
    	if i.immutable || !i.stopped {
    		return
    	}
    	i.stopCh = make(chan struct{})
    	i.stopped = false
    	go i.startReflector()
    }
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Tue Jun 04 06:25:43 UTC 2024
    - 11.6K bytes
    - Viewed (0)
  5. platforms/core-runtime/concurrent/src/main/java/org/gradle/internal/concurrent/ExecutorFactory.java

         * Creates an executor which can run multiple actions concurrently. It is the caller's responsibility to stop the executor.
         *
         * The executor will collect failures thrown by actions and rethrow when the executor is stopped.
         *
         * @param displayName The display name for the this executor. Used for thread names, logging and error message.
         * @return The executor.
         */
        ManagedExecutor create(String displayName);
    
        /**
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Thu Apr 11 19:07:35 UTC 2024
    - 3.4K bytes
    - Viewed (0)
  6. pilot/pkg/autoregistration/controller_test.go

    	return f.proxy
    }
    
    func (f *fakeConn) ConnectedAt() time.Time {
    	return f.connTime
    }
    
    func (f *fakeConn) Stop() {
    	f.Lock()
    	defer f.Unlock()
    	f.stopped = true
    }
    
    func (f *fakeConn) Stopped() bool {
    	f.RLock()
    	defer f.RUnlock()
    	return f.stopped
    }
    
    var (
    	tmplA = &v1alpha3.WorkloadGroup{
    		Template: &v1alpha3.WorkloadEntry{
    			Ports:          map[string]uint32{"http": 80},
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Tue Apr 16 00:00:36 UTC 2024
    - 31.4K bytes
    - Viewed (0)
  7. src/runtime/preempt.go

    	// state was observed, so the caller must not assume that it
    	// remains dead.
    	dead bool
    
    	// stopped indicates that this suspendG transitioned the G to
    	// _Gwaiting via g.preemptStop and thus is responsible for
    	// readying it when done.
    	stopped bool
    }
    
    // suspendG suspends goroutine gp at a safe-point and returns the
    // state of the suspended goroutine. The caller gets read access to
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Fri May 17 15:41:45 UTC 2024
    - 15.1K bytes
    - Viewed (0)
  8. testing/internal-integ-testing/src/main/groovy/org/gradle/integtests/fixtures/daemon/AbstractDaemonFixture.groovy

            this
        }
    
        DaemonFixture stops() {
            waitForState(Stopped)
            this
        }
    
        @Override
        void assertIdle() {
            assertHasState(Idle)
        }
    
        @Override
        void assertBusy() {
            assertHasState(Busy)
        }
    
        @Override
        void assertStopped() {
            assertHasState(Stopped)
        }
    
        @Override
        void assertCanceled() {
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Wed May 29 15:22:16 UTC 2024
    - 3.8K bytes
    - Viewed (0)
  9. security/pkg/nodeagent/sds/server.go

    	workloadSds *sdsservice
    
    	grpcWorkloadListener net.Listener
    
    	grpcWorkloadServer *grpc.Server
    	stopped            *atomic.Bool
    }
    
    // NewServer creates and starts the Grpc server for SDS.
    func NewServer(options *security.Options, workloadSecretCache security.SecretManager, pkpConf *mesh.PrivateKeyProvider) *Server {
    	s := &Server{stopped: atomic.NewBool(false)}
    	s.workloadSds = newSDSService(workloadSecretCache, options, pkpConf)
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Fri Jun 07 17:44:41 UTC 2024
    - 3.3K bytes
    - Viewed (0)
  10. platforms/core-runtime/concurrent/src/main/java/org/gradle/internal/concurrent/ExecutorPolicy.java

         */
        <T> T onExecute(Callable<T> command) throws Exception;
    
        /**
         * Special behavior after an executor is stopped.
         *
         * This is called after the underlying Executor has been stopped.
         */
        void onStop();
    
        /**
         * Runs the Runnable, catches all Throwables and logs them.
         *
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Thu Apr 11 19:07:35 UTC 2024
    - 3.3K bytes
    - Viewed (0)
Back to top