Search Options

Results per page
Sort
Preferred Languages
Advance

Results 21 - 30 of 46 for HandleCrash (0.52 sec)

  1. 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)
  2. 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)
  3. 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)
  4. 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)
  5. 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)
  6. 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)
  7. 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)
  8. staging/src/k8s.io/apiserver/pkg/server/dynamiccertificates/dynamic_serving_content.go

    	return c.loadCertKeyPair()
    }
    
    // Run starts the controller and blocks until context is killed.
    func (c *DynamicCertKeyPairContent) Run(ctx context.Context, workers int) {
    	defer utilruntime.HandleCrash()
    	defer c.queue.ShutDown()
    
    	klog.InfoS("Starting controller", "name", c.name)
    	defer klog.InfoS("Shutting down controller", "name", c.name)
    
    	// doesn't matter what workers say, only start one.
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 6.9K bytes
    - Viewed (0)
  9. staging/src/k8s.io/apiserver/pkg/storage/feature/feature_support_checker.go

    	defer f.lock.Unlock()
    	for _, ep := range c.Endpoints() {
    		if _, found := f.checkingEndpoint[ep]; found {
    			continue
    		}
    		f.checkingEndpoint[ep] = struct{}{}
    		go func(ep string) {
    			defer runtime.HandleCrash()
    			err := delayFunc.Until(ctx, true, true, func(ctx context.Context) (done bool, err error) {
    				internalErr := f.clientSupportsRequestWatchProgress(ctx, c, ep)
    				return internalErr == nil, nil
    			})
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Fri May 10 11:56:42 UTC 2024
    - 6.2K bytes
    - Viewed (0)
  10. pkg/controller/volume/pvprotection/pv_protection_controller.go

    			e.pvAddedUpdated(logger, new)
    		},
    	})
    
    	return e
    }
    
    // Run runs the controller goroutines.
    func (c *Controller) Run(ctx context.Context, workers int) {
    	defer utilruntime.HandleCrash()
    	defer c.queue.ShutDown()
    
    	logger := klog.FromContext(ctx)
    	logger.Info("Starting PV protection controller")
    	defer logger.Info("Shutting down PV protection controller")
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 6.4K bytes
    - Viewed (0)
Back to top