Search Options

Results per page
Sort
Preferred Languages
Advance

Results 21 - 30 of 49 for HandleCrash (0.16 sec)

  1. 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)
  2. 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)
  3. 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)
  4. 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)
  5. 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)
  6. 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)
  7. pkg/controller/certificates/rootcacertpublisher/publisher.go

    	nsListerSynced cache.InformerSynced
    
    	queue workqueue.TypedRateLimitingInterface[string]
    }
    
    // Run starts process
    func (c *Publisher) Run(ctx context.Context, workers int) {
    	defer utilruntime.HandleCrash()
    	defer c.queue.ShutDown()
    
    	logger := klog.FromContext(ctx)
    	logger.Info("Starting root CA cert publisher controller")
    	defer logger.Info("Shutting down root CA cert publisher controller")
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 6.8K bytes
    - Viewed (0)
  8. pilot/pkg/networking/core/envoyfilter/cluster_patch.go

    func ApplyClusterMerge(pctx networking.EnvoyFilter_PatchContext, efw *model.EnvoyFilterWrapper,
    	c *cluster.Cluster, hosts []host.Name,
    ) (out *cluster.Cluster) {
    	defer runtime.HandleCrash(runtime.LogPanic, func(any) {
    		log.Errorf("clusters patch %s/%s caused panic, so the patches did not take effect", efw.Namespace, efw.Name)
    		IncrementEnvoyFilterErrorMetric(Cluster)
    	})
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Thu Mar 28 17:09:02 UTC 2024
    - 6.8K bytes
    - Viewed (0)
  9. pkg/controller/bootstrap/tokencleaner.go

    			},
    		},
    		options.SecretResync,
    	)
    
    	return e, nil
    }
    
    // Run runs controller loops and returns when they are done
    func (tc *TokenCleaner) Run(ctx context.Context) {
    	defer utilruntime.HandleCrash()
    	defer tc.queue.ShutDown()
    
    	logger := klog.FromContext(ctx)
    	logger.Info("Starting token cleaner controller")
    	defer logger.Info("Shutting down token cleaner controller")
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 6.3K bytes
    - Viewed (0)
  10. pkg/controller/clusterroleaggregation/clusterroleaggregation_controller.go

    		}
    	}
    	return false
    }
    
    // Run starts the controller and blocks until stopCh is closed.
    func (c *ClusterRoleAggregationController) Run(ctx context.Context, workers int) {
    	defer utilruntime.HandleCrash()
    	defer c.queue.ShutDown()
    
    	logger := klog.FromContext(ctx)
    	logger.Info("Starting ClusterRoleAggregator controller")
    	defer logger.Info("Shutting down ClusterRoleAggregator controller")
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 8K bytes
    - Viewed (0)
Back to top