Search Options

Results per page
Sort
Preferred Languages
Advance

Results 171 - 180 of 390 for Informer (0.18 sec)

  1. pilot/pkg/serviceregistry/kube/controller/network.go

    	"istio.io/istio/pkg/slices"
    )
    
    type networkManager struct {
    	sync.RWMutex
    	// CIDR ranger based on path-compressed prefix trie
    	ranger    cidranger.Ranger
    	clusterID cluster.ID
    
    	gatewayResourceClient kclient.Informer[*v1beta1.Gateway]
    	meshNetworksWatcher   mesh.NetworksWatcher
    
    	// Network name for to be used when the meshNetworks fromRegistry nor network label on pod is specified
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Fri May 31 22:23:22 UTC 2024
    - 15.4K bytes
    - Viewed (0)
  2. pkg/scheduler/framework/plugins/nodevolumelimits/non_csi.go

    var _ framework.EnqueueExtensions = &nonCSILimits{}
    
    // newNonCSILimitsWithInformerFactory returns a plugin with filter name and informer factory.
    func newNonCSILimitsWithInformerFactory(
    	ctx context.Context,
    	filterName string,
    	informerFactory informers.SharedInformerFactory,
    	fts feature.Features,
    ) framework.Plugin {
    	pvLister := informerFactory.Core().V1().PersistentVolumes().Lister()
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat Dec 30 23:00:56 UTC 2023
    - 19.6K bytes
    - Viewed (0)
  3. pkg/scheduler/apis/config/types.go

    	Extenders []Extender
    
    	// DelayCacheUntilActive specifies when to start caching. If this is true and leader election is enabled,
    	// the scheduler will wait to fill informer caches until it is the leader. Doing so will have slower
    	// failover with the benefit of lower memory overhead while waiting to become leader.
    	// Defaults to false.
    	DelayCacheUntilActive bool
    }
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Fri Jan 19 18:47:23 UTC 2024
    - 14.8K bytes
    - Viewed (0)
  4. pkg/controller/daemon/daemon_controller_test.go

    	podControl.podStore = informerFactory.Core().V1().Pods().Informer().GetStore()
    
    	newDsc := &daemonSetsController{
    		dsc,
    		informerFactory.Apps().V1().DaemonSets().Informer().GetStore(),
    		informerFactory.Apps().V1().ControllerRevisions().Informer().GetStore(),
    		informerFactory.Core().V1().Pods().Informer().GetStore(),
    		informerFactory.Core().V1().Nodes().Informer().GetStore(),
    		fakeRecorder,
    	}
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 111.4K bytes
    - Viewed (0)
  5. pkg/scheduler/framework/plugins/volumebinding/binder.go

    		classLister:   storageClassInformer.Lister(),
    		nodeLister:    nodeInformer.Lister(),
    		csiNodeLister: csiNodeInformer.Lister(),
    		pvcCache:      NewPVCAssumeCache(logger, pvcInformer.Informer()),
    		pvCache:       NewPVAssumeCache(logger, pvInformer.Informer()),
    		bindTimeout:   bindTimeout,
    		translator:    csitrans.New(),
    	}
    
    	b.csiDriverLister = capacityCheck.CSIDriverInformer.Lister()
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Thu May 09 14:55:34 UTC 2024
    - 42.6K bytes
    - Viewed (0)
  6. pkg/kubelet/kubelet.go

    		kubeInformers := informers.NewSharedInformerFactoryWithOptions(kubeDeps.KubeClient, 0, informers.WithTweakListOptions(func(options *metav1.ListOptions) {
    			options.FieldSelector = fields.Set{metav1.ObjectNameField: string(nodeName)}.String()
    		}))
    		nodeLister = kubeInformers.Core().V1().Nodes().Lister()
    		nodeHasSynced = func() bool {
    			return kubeInformers.Core().V1().Nodes().Informer().HasSynced()
    		}
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Fri Jun 14 16:09:17 UTC 2024
    - 126.1K bytes
    - Viewed (0)
  7. pkg/kubelet/volumemanager/volume_manager.go

    }
    
    func (vm *volumeManager) Run(sourcesReady config.SourcesReady, stopCh <-chan struct{}) {
    	defer runtime.HandleCrash()
    
    	if vm.kubeClient != nil {
    		// start informer for CSIDriver
    		go vm.volumePluginMgr.Run(stopCh)
    	}
    
    	go vm.desiredStateOfWorldPopulator.Run(sourcesReady, stopCh)
    	klog.V(2).InfoS("The desired_state_of_world populator starts")
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Tue Jun 04 06:25:43 UTC 2024
    - 21.5K bytes
    - Viewed (0)
  8. pkg/scheduler/framework/plugins/dynamicresources/dynamicresources_test.go

    			testCtx := setup(t, nil, tc.claims, nil, nil, nil)
    			if claim, ok := tc.newObj.(*resourcev1alpha2.ResourceClaim); ok {
    				// Update the informer because the lister gets called and must have the claim.
    				store := testCtx.informerFactory.Resource().V1alpha2().ResourceClaims().Informer().GetStore()
    				if tc.oldObj == nil {
    					require.NoError(t, store.Add(claim))
    				} else {
    					require.NoError(t, store.Update(claim))
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Mon May 27 07:57:10 UTC 2024
    - 61.9K bytes
    - Viewed (0)
  9. pkg/scheduler/framework/plugins/volumebinding/volume_binding_test.go

    			}
    			for _, pv := range item.pvs {
    				client.CoreV1().PersistentVolumes().Create(ctx, pv, metav1.CreateOptions{})
    			}
    
    			t.Log("Start informer factory after initialization")
    			informerFactory.Start(ctx.Done())
    
    			t.Log("Wait for all started informers' cache were synced")
    			informerFactory.WaitForCacheSync(ctx.Done())
    
    			t.Log("Verify")
    
    			p := pl.(*VolumeBinding)
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Fri Dec 15 03:30:06 UTC 2023
    - 32K bytes
    - Viewed (0)
  10. pkg/scheduler/schedule_one.go

    		logger.Error(err, "Error scheduling pod; retrying", "pod", klog.KObj(pod))
    	}
    
    	// Check if the Pod exists in informer cache.
    	podLister := fwk.SharedInformerFactory().Core().V1().Pods().Lister()
    	cachedPod, e := podLister.Pods(pod.Namespace).Get(pod.Name)
    	if e != nil {
    		logger.Info("Pod doesn't exist in informer cache", "pod", klog.KObj(pod), "err", e)
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Thu Jun 06 13:28:08 UTC 2024
    - 43.4K bytes
    - Viewed (0)
Back to top