Search Options

Results per page
Sort
Preferred Languages
Advance

Results 11 - 20 of 693 for _top (0.09 sec)

  1. platforms/core-runtime/launcher/src/test/groovy/org/gradle/launcher/daemon/server/DefaultDaemonConnectionTest.groovy

            daemonConnection.stop()
    
            then:
            0 * handler._
        }
    
        def "does not notify disconnect handler on stop"() {
            Runnable handler = Mock()
    
            when:
            daemonConnection.onDisconnect(handler)
            daemonConnection.stop()
    
            then:
            0 * handler._
        }
    
        def "can stop after disconnect handler fails"() {
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Wed May 15 19:51:37 UTC 2024
    - 11.7K bytes
    - Viewed (0)
  2. src/main/resources/fess_indices/fess.json

            },
            "japanese_stop": {
              "type":       "stop",
              "stopwords_path": "${fess.dictionary.path}ja/stopwords.txt"
            },
            "korean_stop": {
              "type":       "stop",
              "stopwords_path": "${fess.dictionary.path}ko/stopwords.txt"
            },
            "latvian_stop": {
              "type":       "stop",
              "stopwords_path": "${fess.dictionary.path}lv/stopwords.txt"
    Registered: Wed Jun 12 13:08:18 UTC 2024
    - Last Modified: Thu Aug 11 01:26:55 UTC 2022
    - 39.9K bytes
    - Viewed (0)
  3. pilot/pkg/bootstrap/configcontroller.go

    					// Note: stop here should be the overall pilot stop, NOT the leader election stop. We are
    					// basically lazy loading the informer, if we stop it when we lose the lock we will never
    					// recreate it again.
    					s.kubeClient.RunAndWait(stop)
    					log.Infof("Starting ingress controller")
    					ingressSyncer.Run(leaderStop)
    				}).
    				Run(stop)
    			return nil
    		})
    	}
    
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Wed Feb 28 16:41:38 UTC 2024
    - 14.1K bytes
    - Viewed (0)
  4. src/time/tick_test.go

    		})
    	}
    }
    
    type timer interface {
    	Stop() bool
    	Reset(Duration) bool
    }
    
    // tickerTimer is a Timer with Reset and Stop methods that return bools,
    // to have the same signatures as Timer.
    type tickerTimer struct {
    	*Ticker
    	stopped bool
    }
    
    func (t *tickerTimer) Stop() bool {
    	pending := !t.stopped
    	t.stopped = true
    	t.Ticker.Stop()
    	return pending
    }
    
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Tue Jun 11 17:10:37 UTC 2024
    - 14.7K bytes
    - Viewed (0)
  5. platforms/core-runtime/messaging/src/test/groovy/org/gradle/internal/remote/internal/hub/MessageHubTest.groovy

            then:
            IllegalStateException e = thrown()
            e.message == 'Cannot add connection, as <hub> has been stopped.'
        }
    
        def "stop and request stop do nothing when already stopped"() {
            when:
            hub.stop()
            hub.stop()
            hub.requestStop()
    
            then:
            0 * _._
        }
    
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Fri Sep 22 08:59:22 UTC 2023
    - 21.8K bytes
    - Viewed (0)
  6. platforms/core-runtime/logging/src/test/groovy/org/gradle/internal/logging/services/DefaultLoggingManagerTest.groovy

            0 * stdOutLoggingSystem._
            0 * stdErrLoggingSystem._
    
            when:
            loggingManager.stop()
    
            then:
            1 * stdOutLoggingSystem.restore(stdOutSnapshot)
            1 * stdErrLoggingSystem.restore(stdErrSnapshot)
        }
    
        public void "can start and stop with system capture enabled"() {
            loggingManager.captureSystemSources()
    
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Fri Sep 22 09:05:18 UTC 2023
    - 15.8K bytes
    - Viewed (0)
  7. pilot/pkg/serviceregistry/kube/controller/multicluster.go

    						// as we create them only after acquiring the leader lock
    						// Note: stop here should be the overall pilot stop, NOT the leader election stop. We are
    						// basically lazy loading the informer, if we stop it when we lose the lock we will never
    						// recreate it again.
    						client.RunAndWait(clusterStopCh)
    						nc.Run(leaderStop)
    					})
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Thu May 23 21:07:03 UTC 2024
    - 12.7K bytes
    - Viewed (0)
  8. platforms/software/testing-base/src/main/java/org/gradle/api/internal/tasks/testing/junit/result/TestOutputStore.java

                if (stdErr.start < 0) {
                    stdErr.start = index.stdErr.start;
                }
                if (index.stdOut.stop > stdOut.stop) {
                    stdOut.stop = index.stdOut.stop;
                }
                if (index.stdErr.stop > stdErr.stop) {
                    stdErr.stop = index.stdErr.stop;
                }
    
                children.put(key, index);
            }
    
            Index build() {
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Tue Apr 16 15:49:51 UTC 2024
    - 14.3K bytes
    - Viewed (0)
  9. platforms/core-runtime/launcher/src/test/groovy/org/gradle/launcher/daemon/server/DaemonStateCoordinatorTest.groovy

        def "can stop multiple times"() {
            expect:
            notStopped
    
            when: "stopped first time"
            coordinator.stop()
    
            then: "stops"
            stopped
    
            when: "requested again"
            coordinator.stop()
    
            then:
            stopped
            0 * _._
        }
    
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Sun May 05 22:24:02 UTC 2024
    - 16.3K bytes
    - Viewed (0)
  10. src/time/sleep_test.go

    		<-ticker.C
    	}
    	ticker.Stop()
    	stop.Store(true)
    }
    
    func TestTickerConcurrentStress(t *testing.T) {
    	var stop atomic.Bool
    	go func() {
    		for !stop.Load() {
    			runtime.GC()
    			// Yield so that the OS can wake up the timer thread,
    			// so that it can generate channel sends for the main goroutine,
    			// which will eventually set stop = 1 for us.
    			Sleep(Nanosecond)
    		}
    	}()
    	ticker := NewTicker(1)
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Fri Mar 22 16:33:57 UTC 2024
    - 22.5K bytes
    - Viewed (0)
Back to top