Search Options

Results per page
Sort
Preferred Languages
Advance

Results 21 - 30 of 106 for HandleCrash (0.45 sec)

  1. pkg/kubelet/pluginmanager/plugin_manager.go

    	desiredStateOfWorld cache.DesiredStateOfWorld
    }
    
    var _ PluginManager = &pluginManager{}
    
    func (pm *pluginManager) Run(sourcesReady config.SourcesReady, stopCh <-chan struct{}) {
    	defer runtime.HandleCrash()
    
    	if err := pm.desiredStateOfWorldPopulator.Start(stopCh); err != nil {
    		klog.ErrorS(err, "The desired_state_of_world populator (plugin watcher) starts failed!")
    		return
    	}
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Fri Jul 01 05:56:33 UTC 2022
    - 4.3K bytes
    - Viewed (0)
  2. pkg/kubelet/prober/worker.go

    // Returns whether the worker should continue.
    func (w *worker) doProbe(ctx context.Context) (keepGoing bool) {
    	defer func() { recover() }() // Actually eat panics (HandleCrash takes care of logging)
    	defer runtime.HandleCrash(func(_ interface{}) { keepGoing = true })
    
    	startTime := time.Now()
    	status, ok := w.probeManager.statusManager.GetPodStatus(w.pod.UID)
    	if !ok {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Thu Jul 27 01:28:06 UTC 2023
    - 10.7K bytes
    - Viewed (0)
  3. pkg/controller/validatingadmissionpolicystatus/controller.go

    	// Types of object are calculated from policy.Spec.MatchingConstraints
    	typeChecker *validatingadmissionpolicy.TypeChecker
    }
    
    func (c *Controller) Run(ctx context.Context, workers int) {
    	defer utilruntime.HandleCrash()
    
    	if !cache.WaitForNamedCacheSync(ControllerName, ctx.Done(), c.policySynced) {
    		return
    	}
    
    	defer c.policyQueue.ShutDown()
    	for i := 0; i < workers; i++ {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 5.3K bytes
    - Viewed (0)
  4. staging/src/k8s.io/apimachinery/pkg/watch/streamwatcher.go

    	default:
    		close(sw.done)
    		sw.source.Close()
    	}
    }
    
    // receive reads result from the decoder in a loop and sends down the result channel.
    func (sw *StreamWatcher) receive() {
    	defer utilruntime.HandleCrash()
    	defer close(sw.result)
    	defer sw.Stop()
    	for {
    		action, obj, err := sw.source.Decode()
    		if err != nil {
    			switch err {
    			case io.EOF:
    				// watch closed normally
    			case io.ErrUnexpectedEOF:
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat Mar 06 13:42:59 UTC 2021
    - 3.9K bytes
    - Viewed (0)
  5. staging/src/k8s.io/apiserver/pkg/storage/value/encrypt/envelope/grpc_service.go

    	if err != nil {
    		return nil, fmt.Errorf("failed to create connection to %s, error: %v", endpoint, err)
    	}
    
    	s.kmsClient = kmsapi.NewKeyManagementServiceClient(s.connection)
    
    	go func() {
    		defer utilruntime.HandleCrash()
    
    		<-ctx.Done()
    		_ = s.connection.Close()
    	}()
    
    	return s, nil
    }
    
    func (g *gRPCService) checkAPIVersion(ctx context.Context) error {
    	g.mux.Lock()
    	defer g.mux.Unlock()
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Mon Feb 27 00:47:46 UTC 2023
    - 4.4K bytes
    - Viewed (0)
  6. pkg/controller/resourcequota/resource_quota_monitor.go

    }
    
    // Run sets the stop channel and starts monitor execution until stopCh is
    // closed. Any running monitors will be stopped before Run returns.
    func (qm *QuotaMonitor) Run(ctx context.Context) {
    	defer utilruntime.HandleCrash()
    
    	logger := klog.FromContext(ctx)
    
    	logger.Info("QuotaMonitor running")
    	defer logger.Info("QuotaMonitor stopping")
    
    	// Set up the stop channel.
    	qm.monitorLock.Lock()
    	qm.stopCh = ctx.Done()
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 11.6K bytes
    - Viewed (0)
  7. pkg/controlplane/controller/legacytokentracking/controller.go

    	})
    
    	return c
    }
    
    func (c *Controller) enqueue() {
    	c.queue.Add(queueKey)
    }
    
    // Run starts the controller sync loop.
    func (c *Controller) Run(stopCh <-chan struct{}) {
    	defer utilruntime.HandleCrash()
    	defer c.queue.ShutDown()
    
    	klog.Info("Starting legacy_token_tracking_controller")
    	defer klog.Infof("Shutting down legacy_token_tracking_controller")
    
    	go c.configMapInformer.Run(stopCh)
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 6K bytes
    - Viewed (0)
  8. pkg/controller/nodeipam/node_ipam_controller.go

    	return ic, nil
    }
    
    // Run starts an asynchronous loop that monitors the status of cluster nodes.
    func (nc *Controller) Run(ctx context.Context) {
    	defer utilruntime.HandleCrash()
    
    	// Start event processing pipeline.
    	nc.eventBroadcaster.StartStructuredLogging(3)
    	nc.eventBroadcaster.StartRecordingToSink(&v1core.EventSinkImpl{Interface: nc.kubeClient.CoreV1().Events("")})
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Thu Jun 06 16:18:38 UTC 2024
    - 5.4K bytes
    - Viewed (0)
  9. pkg/controller/certificates/certificate_controller.go

    	return cc
    }
    
    // Run the main goroutine responsible for watching and syncing jobs.
    func (cc *CertificateController) Run(ctx context.Context, workers int) {
    	defer utilruntime.HandleCrash()
    	defer cc.queue.ShutDown()
    
    	logger := klog.FromContext(ctx)
    	logger.Info("Starting certificate controller", "name", cc.name)
    	defer logger.Info("Shutting down certificate controller", "name", cc.name)
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 6.4K bytes
    - Viewed (0)
  10. pkg/util/goroutinemap/goroutinemap.go

    	grm.operations[operationName] = operation{
    		operationPending: true,
    		expBackoff:       existingOp.expBackoff,
    	}
    	go func() (err error) {
    		// Handle unhandled panics (very unlikely)
    		defer k8sRuntime.HandleCrash()
    		// Handle completion of and error, if any, from operationFunc()
    		defer grm.operationComplete(operationName, &err)
    		// Handle panic, if any, from operationFunc()
    		defer k8sRuntime.RecoverFromPanic(&err)
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 16 11:54:27 UTC 2020
    - 6.8K bytes
    - Viewed (0)
Back to top