Search Options

Results per page
Sort
Preferred Languages
Advance

Results 81 - 90 of 205 for isShutdown (0.29 sec)

  1. platforms/enterprise/enterprise/src/test/groovy/org/gradle/internal/enterprise/impl/DefaultGradleEnterprisePluginBackgroundJobExecutorsTest.groovy

            when:
            def task = new FutureTask<>(() -> 1)
            jobExecutors.userJobExecutor.execute(task)
    
            then:
            task.get() == 1
        }
    
        def "background job is rejected if submitted after shutdown"() {
            given:
            jobExecutors.stop()
    
            when:
            jobExecutors.userJobExecutor.execute {}
    
            then:
            thrown RejectedExecutionException
        }
    
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Sat Jun 08 11:29:25 UTC 2024
    - 2K bytes
    - Viewed (0)
  2. platforms/core-execution/workers/src/integTest/groovy/org/gradle/workers/internal/WorkerDaemonIntegrationTest.groovy

                constructorAction = """
                    Runtime.getRuntime().addShutdownHook(new Thread(new Runnable() {
                        @Override
                        public void run() {
                            println "Shutdown working dir: " + System.getProperty("user.dir")
                        }
                    }));
                """
                action += """
                    println "Execution working dir: " + System.getProperty("user.dir")
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Fri Sep 22 09:36:27 UTC 2023
    - 8.6K bytes
    - Viewed (0)
  3. pkg/queue/instance.go

    	}
    	q.cond.Signal()
    }
    
    func (q *queueImpl) Closed() <-chan struct{} {
    	return q.closed
    }
    
    // get blocks until it can return a task to be processed. If shutdown = true,
    // the processing go routine should stop.
    func (q *queueImpl) get() (task *queueTask, shutdown bool) {
    	q.cond.L.Lock()
    	defer q.cond.L.Unlock()
    	// wait for closing to be set, or a task to be pushed
    	for !q.closing && len(q.tasks) == 0 {
    		q.cond.Wait()
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Fri Jul 21 16:30:36 UTC 2023
    - 4.1K bytes
    - Viewed (0)
  4. guava-testlib/src/com/google/common/util/concurrent/testing/AbstractListenableFutureTest.java

        assertTrue(future.isDone());
    
        assertTrue(successLatch.await(200, MILLISECONDS));
        assertTrue(listenerLatch.await(200, MILLISECONDS));
    
        latch.countDown();
    
        exec.shutdown();
        exec.awaitTermination(100, MILLISECONDS);
      }
    
      /**
       * Tests that all listeners complete, even if they were added before or after the future was
    Registered: Wed Jun 12 16:38:11 UTC 2024
    - Last Modified: Wed Sep 06 18:30:30 UTC 2023
    - 6K bytes
    - Viewed (0)
  5. platforms/core-execution/snapshots/src/test/groovy/org/gradle/internal/vfs/impl/DefaultFileSystemAccessConcurrencyTest.groovy

                def updatedLocation = dir.file(num).file("in-dir.txt")
                assertIsFileSnapshot(read(updatedLocation), updatedLocation)
            }
    
            cleanup:
            executorService.shutdown()
        }
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Fri Sep 22 09:34:50 UTC 2023
    - 1.8K bytes
    - Viewed (0)
  6. cmd/kube-controller-manager/app/testing/testserver.go

    	var errCh chan error
    	tearDown := func() {
    		cancel()
    
    		// If the kube-controller-manager was started, let's wait for
    		// it to shutdown cleanly.
    		if errCh != nil {
    			err, ok := <-errCh
    			if ok && err != nil {
    				logger.Error(err, "Failed to shutdown test server cleanly")
    			}
    		}
    		if len(result.TmpDir) != 0 {
    			os.RemoveAll(result.TmpDir)
    		}
    	}
    	defer func() {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Fri Oct 27 11:28:02 UTC 2023
    - 5.4K bytes
    - Viewed (0)
  7. okhttp/src/test/java/okhttp3/SocksProxy.kt

          Proxy.Type.SOCKS,
          InetSocketAddress.createUnresolved("localhost", serverSocket!!.localPort),
        )
      }
    
      fun connectionCount(): Int = connectionCount.get()
    
      fun shutdown() {
        serverSocket!!.close()
        executor.shutdown()
        if (!executor.awaitTermination(5, TimeUnit.SECONDS)) {
          throw IOException("Gave up waiting for executor to shut down")
        }
      }
    
      private fun service(from: Socket) {
    Registered: Sun Jun 16 04:42:17 UTC 2024
    - Last Modified: Thu Apr 11 22:09:35 UTC 2024
    - 7.7K bytes
    - Viewed (0)
  8. staging/src/k8s.io/apiserver/pkg/server/healthz.go

    	return s.livezRegistry.addDelayedHealthChecks(delay, checks...)
    }
    
    // addReadyzShutdownCheck is a convenience function for adding a readyz shutdown check, so
    // that we can register that the api-server is no longer ready while we attempt to gracefully
    // shutdown.
    func (s *GenericAPIServer) addReadyzShutdownCheck(stopCh <-chan struct{}) error {
    	return s.AddReadyzChecks(healthz.NewShutdownHealthz(stopCh))
    }
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Mon May 27 19:11:24 UTC 2024
    - 6K bytes
    - Viewed (0)
  9. pkg/controller/volume/ephemeral/controller.go

    func (ec *ephemeralController) runWorker(ctx context.Context) {
    	for ec.processNextWorkItem(ctx) {
    	}
    }
    
    func (ec *ephemeralController) processNextWorkItem(ctx context.Context) bool {
    	key, shutdown := ec.queue.Get()
    	if shutdown {
    		return false
    	}
    	defer ec.queue.Done(key)
    
    	err := ec.syncHandler(ctx, key)
    	if err == nil {
    		ec.queue.Forget(key)
    		return true
    	}
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 9.2K bytes
    - Viewed (0)
  10. platforms/core-execution/persistent-cache/src/test/groovy/org/gradle/cache/ManualEvictionInMemoryCacheTest.groovy

                        latch.await()
                        println "Created key ${key}"
                        key
                    } as Supplier<String>)
                }
            }
            executor.shutdown()
            executor.awaitTermination(2, TimeUnit.SECONDS)
            then:
            executor.isTerminated()
            concurrency.times {
                String key = "key${it}"
                assert cache.getIfPresent(key) == key
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Fri Sep 22 09:08:47 UTC 2023
    - 1.9K bytes
    - Viewed (0)
Back to top