ray

package
v1.0.0-rc.2 Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: Nov 2, 2023 License: Apache-2.0, BSD-2-Clause, MIT Imports: 39 Imported by: 0

Documentation

Index

Constants

View Source
const (
	RayJobDefaultRequeueDuration    = 3 * time.Second
	RayJobDefaultClusterSelectorKey = "ray.io/cluster"
	PythonUnbufferedEnvVarName      = "PYTHONUNBUFFERED"
)
View Source
const (
	ServiceDefaultRequeueDuration      = 2 * time.Second
	ServiceRestartRequeueDuration      = 10 * time.Second
	RayClusterDeletionDelayDuration    = 60 * time.Second
	DeploymentUnhealthySecondThreshold = 300.0 // Dashboard agent related health check.
	ENABLE_ZERO_DOWNTIME               = "ENABLE_ZERO_DOWNTIME"
)

Variables

View Source
var (
	DefaultRequeueDuration = 2 * time.Second
	ForcedClusterUpgrade   bool
	EnableBatchScheduler   bool
)
View Source
var (
	ServiceUnhealthySecondThreshold = 900.0 // Serve deployment related health check.
)

This variable is mutable for unit testing purpose.

Functions

This section is empty.

Types

type RayClusterReconciler

type RayClusterReconciler struct {
	client.Client
	Log               logr.Logger
	Scheme            *runtime.Scheme
	Recorder          record.EventRecorder
	BatchSchedulerMgr *batchscheduler.SchedulerManager
	IsOpenShift       bool
}

RayClusterReconciler reconciles a RayCluster object

func NewReconciler

func NewReconciler(mgr manager.Manager) *RayClusterReconciler

NewReconciler returns a new reconcile.Reconciler

func (*RayClusterReconciler) Reconcile

func (r *RayClusterReconciler) Reconcile(ctx context.Context, request ctrl.Request) (ctrl.Result, error)

Reconcile used to bridge the desired state with the current state

func (*RayClusterReconciler) SetupWithManager

func (r *RayClusterReconciler) SetupWithManager(mgr ctrl.Manager, reconcileConcurrency int) error

SetupWithManager builds the reconciler.

type RayJobReconciler

type RayJobReconciler struct {
	client.Client
	Scheme   *runtime.Scheme
	Log      logr.Logger
	Recorder record.EventRecorder
}

RayJobReconciler reconciles a RayJob object

func NewRayJobReconciler

func NewRayJobReconciler(mgr manager.Manager) *RayJobReconciler

NewRayJobReconciler returns a new reconcile.Reconciler

func (*RayJobReconciler) Reconcile

func (r *RayJobReconciler) Reconcile(ctx context.Context, request ctrl.Request) (ctrl.Result, error)

[WARNING]: There MUST be a newline after kubebuilder markers. Reconcile reads that state of a RayJob object and makes changes based on it and what is in the RayJob.Spec Automatically generate RBAC rules to allow the Controller to read and write workloads Reconcile used to bridge the desired state with the current state

func (*RayJobReconciler) SetupWithManager

func (r *RayJobReconciler) SetupWithManager(mgr ctrl.Manager) error

SetupWithManager sets up the controller with the Manager.

type RayServiceReconciler

type RayServiceReconciler struct {
	client.Client
	Scheme   *runtime.Scheme
	Log      logr.Logger
	Recorder record.EventRecorder
	// Currently, the Ray dashboard doesn't cache the Serve deployment config.
	// To avoid reapplying the same config repeatedly, cache the config in this map.
	ServeConfigs                 cmap.ConcurrentMap
	RayClusterDeletionTimestamps cmap.ConcurrentMap
}

RayServiceReconciler reconciles a RayService object

func NewRayServiceReconciler

func NewRayServiceReconciler(mgr manager.Manager) *RayServiceReconciler

NewRayServiceReconciler returns a new reconcile.Reconciler

func (*RayServiceReconciler) Reconcile

func (r *RayServiceReconciler) Reconcile(ctx context.Context, request ctrl.Request) (ctrl.Result, error)

[WARNING]: There MUST be a newline after kubebuilder markers. Reconcile is part of the main kubernetes reconciliation loop which aims to move the current state of the cluster closer to the desired state.

This the top level reconciliation flow for RayService.

For more details, check Reconcile and its Result here: - https://pkg.go.dev/sigs.k8s.io/controller-runtime@v0.11.2/pkg/reconcile

func (*RayServiceReconciler) SetupWithManager

func (r *RayServiceReconciler) SetupWithManager(mgr ctrl.Manager) error

SetupWithManager sets up the controller with the Manager.

Directories

Path Synopsis

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL