Search Options

Results per page
Sort
Preferred Languages
Advance

Results 101 - 110 of 299 for isShutdown (0.2 sec)

  1. staging/src/k8s.io/apiserver/pkg/server/genericapiserver_test.go

    	s.NonLongRunningRequestWaitGroup.Wait()
    	<-stoppedCh
    
    	// check server all handlers finished.
    	if !graceShutdown {
    		t.Errorf("server shutdown not gracefully.")
    	}
    	// check client to make sure receive response.
    	select {
    	case <-graceCh:
    		t.Logf("server shutdown gracefully.")
    	case <-time.After(30 * time.Second):
    		t.Errorf("Timed out waiting for response.")
    	}
    }
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Mon Apr 29 18:59:21 UTC 2024
    - 23.2K bytes
    - Viewed (0)
  2. android/guava-tests/test/com/google/common/util/concurrent/AbstractFutureTest.java

            future.get();
          } catch (Throwable t) {
            // Ignore, we just wanted to block.
          }
          String error = errorMessage.get();
          assertNull(error, error);
        }
        executor.shutdown();
      }
    
      /**
       * He did the bash, he did the future bash The future bash, it was a concurrency smash He did the
       * bash, it caught on in a flash He did the bash, he did the future bash
       */
    
    Registered: Wed Jun 12 16:38:11 UTC 2024
    - Last Modified: Tue Jun 11 16:13:05 UTC 2024
    - 46.7K bytes
    - Viewed (0)
  3. pkg/kubelet/metrics/metrics.go

    		},
    	)
    
    	// GracefulShutdownStartTime is a gauge that records the time at which the kubelet started graceful shutdown.
    	GracefulShutdownStartTime = metrics.NewGauge(
    		&metrics.GaugeOpts{
    			Subsystem:      KubeletSubsystem,
    			Name:           "graceful_shutdown_start_time_seconds",
    			Help:           "Last graceful shutdown start time since unix epoch in seconds",
    			StabilityLevel: metrics.ALPHA,
    		},
    	)
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Thu Feb 22 15:13:25 UTC 2024
    - 45.6K bytes
    - Viewed (0)
  4. pkg/controller/garbagecollector/garbagecollector.go

    	defer utilruntime.HandleCrash()
    	defer gc.attemptToDelete.ShutDown()
    	defer gc.attemptToOrphan.ShutDown()
    	defer gc.dependencyGraphBuilder.graphChanges.ShutDown()
    
    	// Start events processing pipeline.
    	gc.eventBroadcaster.StartStructuredLogging(3)
    	gc.eventBroadcaster.StartRecordingToSink(&v1core.EventSinkImpl{Interface: gc.kubeClient.CoreV1().Events("")})
    	defer gc.eventBroadcaster.Shutdown()
    
    	logger := klog.FromContext(ctx)
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 32.9K bytes
    - Viewed (0)
  5. platforms/core-execution/file-watching/src/main/java/org/gradle/internal/watch/registry/impl/DefaultFileWatcherRegistry.java

            );
            fileEventFunctions.invalidateLogLevelCache();
        }
    
        @Override
        public void close() throws IOException {
            stopping = true;
            try {
                watcher.shutdown();
                if (!watcher.awaitTermination(5, TimeUnit.SECONDS)) {
                    throw new RuntimeException("Watcher did not terminate within 5 seconds");
                }
            } catch (InterruptedException e) {
    Registered: Wed Jun 12 18:38:38 UTC 2024
    - Last Modified: Thu Jan 25 15:08:33 UTC 2024
    - 11.2K bytes
    - Viewed (0)
  6. pkg/kubelet/cm/dra/plugin/noderesources.go

    	}
    	logger.Info("ResourceSlice informer has synced")
    
    	for c.processNextWorkItem(ctx) {
    	}
    }
    
    func (c *nodeResourcesController) processNextWorkItem(ctx context.Context) bool {
    	key, shutdown := c.queue.Get()
    	if shutdown {
    		return false
    	}
    	defer c.queue.Done(key)
    
    	driverName := key
    
    	// Panics are caught and treated like errors.
    	var err error
    	func() {
    		defer func() {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Mon May 27 20:12:53 UTC 2024
    - 16.6K bytes
    - Viewed (0)
  7. cmd/kube-apiserver/app/testing/testserver.go

    		// after itself, including shutting down its storage layer.
    		tCtx.Cancel("tearing down")
    
    		// If the apiserver was started, let's wait for it to
    		// shutdown clearly.
    		if errCh != nil {
    			err, ok := <-errCh
    			if ok && err != nil {
    				klog.Errorf("Failed to shutdown test server clearly: %v", err)
    			}
    		}
    		os.RemoveAll(result.TmpDir)
    	}
    	defer func() {
    		if result.TearDownFn == nil {
    			tearDown()
    		}
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Mon Apr 29 18:59:21 UTC 2024
    - 17.6K bytes
    - Viewed (0)
  8. pkg/controlplane/controller/clusterauthenticationtrust/cluster_authentication_trust_controller.go

    }
    
    // Run the controller until stopped.
    func (c *Controller) Run(ctx context.Context, workers int) {
    	defer utilruntime.HandleCrash()
    	// make sure the work queue is shutdown which will trigger workers to end
    	defer c.queue.ShutDown()
    
    	klog.Infof("Starting cluster_authentication_trust_controller controller")
    	defer klog.Infof("Shutting down cluster_authentication_trust_controller controller")
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 18.2K bytes
    - Viewed (0)
  9. guava-tests/test/com/google/common/util/concurrent/AbstractFutureTest.java

            future.get();
          } catch (Throwable t) {
            // Ignore, we just wanted to block.
          }
          String error = errorMessage.get();
          assertNull(error, error);
        }
        executor.shutdown();
      }
    
      /**
       * He did the bash, he did the future bash The future bash, it was a concurrency smash He did the
       * bash, it caught on in a flash He did the bash, he did the future bash
       */
    
    Registered: Wed Jun 12 16:38:11 UTC 2024
    - Last Modified: Tue Jun 11 16:13:05 UTC 2024
    - 46.7K bytes
    - Viewed (0)
  10. pkg/controller/disruption/disruption.go

    	} else {
    		logger.Info("No api server defined - no events will be sent to API server.")
    	}
    	defer dc.broadcaster.Shutdown()
    
    	defer dc.queue.ShutDown()
    	defer dc.recheckQueue.ShutDown()
    	defer dc.stalePodDisruptionQueue.ShutDown()
    
    	logger.Info("Starting disruption controller")
    	defer logger.Info("Shutting down disruption controller")
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 36.1K bytes
    - Viewed (0)
Back to top