Search Options

Results per page
Sort
Preferred Languages
Advance

Results 1 - 10 of 49 for LeaderElection (0.21 sec)

  1. pilot/pkg/leaderelection/leaderelection.go

    // limitations under the License.
    
    package leaderelection
    
    import (
    	"context"
    	"fmt"
    	"os"
    	"strings"
    	"sync"
    	"time"
    
    	"go.uber.org/atomic"
    	metav1 "k8s.io/apimachinery/pkg/apis/meta/v1"
    	"k8s.io/client-go/kubernetes"
    
    	"istio.io/istio/pilot/pkg/features"
    	"istio.io/istio/pilot/pkg/leaderelection/k8sleaderelection"
    	"istio.io/istio/pilot/pkg/leaderelection/k8sleaderelection/k8sresourcelock"
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Fri Apr 12 16:44:32 UTC 2024
    - 9.7K bytes
    - Viewed (0)
  2. pilot/pkg/leaderelection/k8sleaderelection/leaderelection.go

    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    See the License for the specific language governing permissions and
    limitations under the License.
    */
    
    // Package leaderelection implements leader election of a set of endpoints.
    // It uses an annotation in the endpoints object to store the record of the
    // election state. This implementation does not guarantee that only one
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Mon Jul 24 04:04:42 UTC 2023
    - 16.3K bytes
    - Viewed (0)
  3. cmd/kube-scheduler/app/options/options.go

    		cfg.LeaderElection.LeaderElect = o.LeaderElection.LeaderElect
    	}
    	if leaderelection.Changed("leader-elect-lease-duration") {
    		cfg.LeaderElection.LeaseDuration = o.LeaderElection.LeaseDuration
    	}
    	if leaderelection.Changed("leader-elect-renew-deadline") {
    		cfg.LeaderElection.RenewDeadline = o.LeaderElection.RenewDeadline
    	}
    	if leaderelection.Changed("leader-elect-retry-period") {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed Jan 17 17:06:29 UTC 2024
    - 13.3K bytes
    - Viewed (0)
  4. cmd/kube-scheduler/app/config/config.go

    	//nolint:staticcheck // SA1019 this deprecated field still needs to be used for now. It will be removed once the migration is done.
    	EventBroadcaster events.EventBroadcasterAdapter
    
    	// LeaderElection is optional.
    	LeaderElection *leaderelection.LeaderElectionConfig
    
    	// PodMaxInUnschedulablePodsDuration is the maximum time a pod can stay in
    	// unschedulablePods. If a pod stays in unschedulablePods for longer than this
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Thu Mar 24 09:38:49 UTC 2022
    - 2.7K bytes
    - Viewed (0)
  5. pkg/scheduler/apis/config/v1/defaults.go

    	}
    
    	if len(obj.LeaderElection.ResourceLock) == 0 {
    		// Use lease-based leader election to reduce cost.
    		// We migrated for EndpointsLease lock in 1.17 and starting in 1.20 we
    		// migrated to Lease lock.
    		obj.LeaderElection.ResourceLock = "leases"
    	}
    	if len(obj.LeaderElection.ResourceNamespace) == 0 {
    		obj.LeaderElection.ResourceNamespace = configv1.SchedulerDefaultLockObjectNamespace
    	}
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed Sep 13 07:42:19 UTC 2023
    - 7.2K bytes
    - Viewed (0)
  6. pilot/pkg/leaderelection/leaderelection_test.go

    ) (*LeaderElection, chan struct{}) {
    	t.Helper()
    	return createElectionMulticluster(t, name, revision, false, false, watcher, expectLeader, client, fns...)
    }
    
    func createPerRevisionElection(t *testing.T,
    	name string, revision string,
    	watcher revisions.DefaultWatcher,
    	expectLeader bool,
    	client kubernetes.Interface,
    ) (*LeaderElection, chan struct{}) {
    	t.Helper()
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Sun Apr 28 04:22:19 UTC 2024
    - 11.4K bytes
    - Viewed (0)
  7. cmd/kube-scheduler/app/server.go

    		logger.V(3).Info("Handlers synced")
    	}
    	if !cc.ComponentConfig.DelayCacheUntilActive || cc.LeaderElection == nil {
    		startInformersAndWaitForSync(ctx)
    	}
    	// If leader election is enabled, runCommand via LeaderElector until done and exit.
    	if cc.LeaderElection != nil {
    		cc.LeaderElection.Callbacks = leaderelection.LeaderCallbacks{
    			OnStartedLeading: func(ctx context.Context) {
    				close(waitingForLeader)
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Mon May 27 19:11:24 UTC 2024
    - 14.3K bytes
    - Viewed (0)
  8. pkg/scheduler/apis/config/validation/validation_test.go

    	invalidParallelismValue.Parallelism = 0
    
    	resourceNameNotSet := validConfig.DeepCopy()
    	resourceNameNotSet.LeaderElection.ResourceName = ""
    
    	resourceNamespaceNotSet := validConfig.DeepCopy()
    	resourceNamespaceNotSet.LeaderElection.ResourceNamespace = ""
    
    	resourceLockNotLeases := validConfig.DeepCopy()
    	resourceLockNotLeases.LeaderElection.ResourceLock = "configmap"
    
    	enableContentProfilingSetWithoutEnableProfiling := validConfig.DeepCopy()
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Thu Apr 25 06:27:01 UTC 2024
    - 12.2K bytes
    - Viewed (0)
  9. cluster/addons/volumesnapshots/volume-snapshot-controller/rbac-volume-snapshot-controller.yaml

    apiVersion: rbac.authorization.k8s.io/v1
    metadata:
      name: volume-snapshot-controller-leaderelection
      namespace: kube-system
      labels:
        addonmanager.kubernetes.io/mode: Reconcile
    subjects:
      - kind: ServiceAccount
        name: volume-snapshot-controller
        namespace: kube-system
    roleRef:
      kind: Role
      name: volume-snapshot-controller-leaderelection
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Fri Sep 16 14:09:47 UTC 2022
    - 2.9K bytes
    - Viewed (0)
  10. pkg/controller/apis/config/fuzzer/fuzzer.go

    			obj.Generic.ClientConnection.ContentType = fmt.Sprintf("%s/%s.%s.%s", c.RandString(), c.RandString(), c.RandString(), c.RandString())
    			if obj.Generic.LeaderElection.ResourceLock == "" {
    				obj.Generic.LeaderElection.ResourceLock = "endpoints"
    			}
    			obj.Generic.Controllers = []string{fmt.Sprintf("%s", c.RandString())}
    			if obj.KubeCloudShared.ClusterName == "" {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Thu Oct 25 09:31:47 UTC 2018
    - 1.9K bytes
    - Viewed (0)
Back to top