Search Options

Results per page
Sort
Preferred Languages
Advance

Results 31 - 40 of 63 for isShutdown (0.15 sec)

  1. staging/src/k8s.io/apiextensions-apiserver/pkg/cmd/server/testing/testserver.go

    		// including shutting down its storage layer.
    		cancel(errors.New("tearing down"))
    
    		// If the apiextensions 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)
    			}
    		}
    
    		if len(result.TmpDir) != 0 {
    			os.RemoveAll(result.TmpDir)
    		}
    	}
    	defer func() {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Mon Apr 29 18:59:21 UTC 2024
    - 9K bytes
    - Viewed (1)
  2. pilot/pkg/xds/discovery_test.go

    		return false
    	}
    }
    
    func TestSendPushesManyPushes(t *testing.T) {
    	stopCh := make(chan struct{})
    	defer close(stopCh)
    
    	semaphore := make(chan struct{}, 2)
    	queue := NewPushQueue()
    	defer queue.ShutDown()
    
    	proxies := createProxies(5)
    
    	pushes := make(map[string]int)
    	pushesMu := &sync.Mutex{}
    
    	for _, proxy := range proxies {
    		proxy := proxy
    		// Start receive thread
    		go func() {
    			for {
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Tue Apr 30 00:26:45 UTC 2024
    - 9.2K bytes
    - Viewed (0)
  3. pilot/pkg/serviceregistry/kube/controller/fake.go

    	}
    	c := NewController(opts.Client, options)
    	meshServiceController.AddRegistry(c)
    
    	if opts.ServiceHandler != nil {
    		c.AppendServiceHandler(opts.ServiceHandler)
    	}
    
    	t.Cleanup(func() {
    		c.client.Shutdown()
    	})
    	if !opts.SkipRun {
    		t.Cleanup(func() {
    			assert.NoError(t, queue.WaitForClose(c.queue, time.Second*5))
    		})
    	}
    	c.stop = stop
    	if cleanupStop {
    		t.Cleanup(func() {
    			close(stop)
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Thu May 23 21:07:03 UTC 2024
    - 4K bytes
    - Viewed (0)
  4. pkg/zdsapi/zds.proto

    // to signal ztunnel to not delete the workload if it has it.
    message KeepWorkload {
      string uid = 1;
    }
    
    // Delete a workload from the ztunnel. Ztunnel should shutdown the workload's proxy.
    message DelWorkload {
      string uid = 2;
    }
    
    // Let ztunnel know that a full snapshot was sent. Ztunnel should reconcile its internal state
    // and remove internal entries that were not sent.
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Thu May 23 22:07:03 UTC 2024
    - 2.7K bytes
    - Viewed (0)
  5. staging/src/k8s.io/apiextensions-apiserver/pkg/controller/establish/establishing_controller.go

    	ec.queue.AddAfter(key, timeout)
    }
    
    // Run starts the EstablishingController.
    func (ec *EstablishingController) Run(stopCh <-chan struct{}) {
    	defer utilruntime.HandleCrash()
    	defer ec.queue.ShutDown()
    
    	klog.Info("Starting EstablishingController")
    	defer klog.Info("Shutting down EstablishingController")
    
    	if !cache.WaitForCacheSync(stopCh, ec.crdSynced) {
    		return
    	}
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 4.4K bytes
    - Viewed (0)
  6. prow/integ-suite-kind.sh

      trace "test" make "${PARAMS[*]}"
    fi
    
    # Check if the user is running the clusters in manual mode.
    if [[ -n "${MANUAL:-}" ]]; then
      echo "Running cluster(s) in manual mode. Press any key to shutdown and exit..."
      read -rsn1
      exit 0
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Thu Apr 18 05:42:41 UTC 2024
    - 5.1K bytes
    - Viewed (0)
  7. pkg/controller/nodeipam/node_ipam_controller.go

    	// Start event processing pipeline.
    	nc.eventBroadcaster.StartStructuredLogging(3)
    	nc.eventBroadcaster.StartRecordingToSink(&v1core.EventSinkImpl{Interface: nc.kubeClient.CoreV1().Events("")})
    	defer nc.eventBroadcaster.Shutdown()
    	klog.FromContext(ctx).Info("Starting ipam controller")
    	defer klog.FromContext(ctx).Info("Shutting down ipam controller")
    
    	if !cache.WaitForNamedCacheSync("node", ctx.Done(), nc.nodeInformerSynced) {
    		return
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Thu Jun 06 16:18:38 UTC 2024
    - 5.4K bytes
    - Viewed (0)
  8. pkg/controlplane/controller/legacytokentracking/controller.go

    }
    
    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)
  9. samples/bookinfo/src/details/details.rb

    server = WEBrick::HTTPServer.new(
        :BindAddress => '*',
        :Port => port,
        :AcceptCallback => -> (s) { s.setsockopt(Socket::IPPROTO_TCP, Socket::TCP_NODELAY, 1) },
    )
    
    trap 'INT' do server.shutdown end
    
    server.mount_proc '/health' do |req, res|
        res.status = 200
        res.body = {'status' => 'Details is healthy'}.to_json
        res['Content-Type'] = 'application/json'
    end
    
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Mon Jun 10 14:35:54 UTC 2024
    - 5.8K bytes
    - Viewed (0)
  10. 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)
Back to top