Documentation ¶
Index ¶
- Constants
- Variables
- func CheckMilvusStopped(ctx context.Context, cli client.Client, mc v1beta1.Milvus) (bool, error)
- func DeploymentReady(status appsv1.DeploymentStatus) bool
- func GetCondition(getter func() v1beta1.MilvusCondition, eps []string) v1beta1.MilvusCondition
- func GetConditionStatus(b bool) corev1.ConditionStatus
- func GetConfCheckSum(spec v1beta1.MilvusSpec) string
- func GetContainerIndex(containers []corev1.Container, name string) int
- func GetContainerMessage(status corev1.ContainerStatus) string
- func GetDeploymentConditionByType(conditions []appsv1.DeploymentCondition, Type appsv1.DeploymentConditionType) appsv1.DeploymentCondition
- func GetDeploymentFalseCondition(deploy appsv1.Deployment) (*appsv1.DeploymentCondition, error)
- func GetEndpointsHealth(endpoints []string) map[string]EtcdEndPointHealth
- func GetEtcdCondition(ctx context.Context, endpoints []string) v1beta1.MilvusCondition
- func GetKafkaCondition(ctx context.Context, logger logr.Logger, p v1beta1.MilvusKafka) v1beta1.MilvusCondition
- func GetLivenessProbe() *corev1.Probe
- func GetMilvusConditionByType(conditions []v1beta1.MilvusCondition, Type v1beta1.MilvusConditionType) *v1beta1.MilvusCondition
- func GetMilvusConfCheckSum(spec v1beta1.MilvusSpec) string
- func GetMilvusEndpoint(ctx context.Context, logger logr.Logger, client client.Client, ...) string
- func GetMilvusUpdatedCondition(m *v1beta1.Milvus) v1beta1.MilvusCondition
- func GetMinioBucket(conf map[string]interface{}) string
- func GetMinioCondition(ctx context.Context, logger logr.Logger, cli client.Client, ...) v1beta1.MilvusCondition
- func GetMinioIAMEndpoint(conf map[string]interface{}) string
- func GetMinioSecure(conf map[string]interface{}) bool
- func GetMinioUseIAM(conf map[string]interface{}) bool
- func GetNotReadyDependencyConditions(conditions []v1beta1.MilvusCondition) map[v1beta1.MilvusConditionType]*v1beta1.MilvusCondition
- func GetPodConditionByType(conditions []corev1.PodCondition, Type corev1.PodConditionType) corev1.PodCondition
- func GetPodFalseCondition(pod corev1.Pod) (*corev1.PodCondition, error)
- func GetPulsarCondition(ctx context.Context, logger logr.Logger, p v1beta1.MilvusPulsar) v1beta1.MilvusCondition
- func GetReadinessProbe() *corev1.Probe
- func GetServiceInstanceName(instance string) string
- func GetStartupProbe() *corev1.Probe
- func GetStorageSecretRefEnv(secretRef string) []corev1.EnvVar
- func GetVolumeIndex(volumes []corev1.Volume, name string) int
- func GetVolumeMountIndex(volumeMounts []corev1.VolumeMount, mountPath string) int
- func InitializeMetrics()
- func IsDependencyReady(conditions []v1beta1.MilvusCondition) bool
- func IsEqual(obj1, obj2 interface{}) bool
- func IsMilvusConditionTrueByType(conditions []v1beta1.MilvusCondition, Type v1beta1.MilvusConditionType) bool
- func IsMilvusDeploymentsComplete(m *v1beta1.Milvus) bool
- func IsSetDefaultDone(mc *v1beta1.Milvus) bool
- func LoopWithInterval(ctx context.Context, loopFunc func() error, interval time.Duration, ...)
- func MergeContainerPort(src, dst []corev1.ContainerPort) []corev1.ContainerPort
- func MergeEnvVar(src, dst []corev1.EnvVar) []corev1.EnvVar
- func MergeLabels(allLabels ...map[string]string) map[string]string
- func MergeServicePort(src, dst []corev1.ServicePort) []corev1.ServicePort
- func MergeVolumeMount(src, dst []corev1.VolumeMount) []corev1.VolumeMount
- func MilvusStatusToCode(status v1beta1.MilvusHealthStatus, isMaintaining bool) float64
- func NamespacedName(namespace, name string) types.NamespacedName
- func NewAppLabels(instance string) map[string]string
- func NewComponentAppLabels(instance, component string) map[string]string
- func NewServicePodLabels(instance string) map[string]string
- func PodReady(pod corev1.Pod) bool
- func RemoveConditions(status *v1beta1.MilvusStatus, typesToRemove []v1beta1.MilvusConditionType)
- func SetupControllers(ctx context.Context, mgr manager.Manager, stopReconcilers []string, ...) error
- func UpdateCondition(status *v1beta1.MilvusStatus, c v1beta1.MilvusCondition)
- func WarppedReconcileComponentFunc(f func(context.Context, v1beta1.Milvus, MilvusComponent) error, ...) func() error
- func WrappedFunc(f interface{}, args ...interface{}) func() error
- type Args
- type Chart
- type CommonInfo
- type ComponentConditionGetter
- type ComponentConditionGetterImpl
- type ComponentErrorDetail
- type ComponentSpec
- type EndpointCheckCache
- type EndpointCheckCacheImpl
- func (e EndpointCheckCacheImpl) EndProbeFor(endpoints []string)
- func (e EndpointCheckCacheImpl) Get(endpoints []string) (condition *v1beta1.MilvusCondition, isUpToDate bool)
- func (e EndpointCheckCacheImpl) Set(endpoints []string, condition *v1beta1.MilvusCondition)
- func (e EndpointCheckCacheImpl) TryStartProbeFor(endpoints []string) bool
- type EtcdClient
- type EtcdConditionInfo
- type EtcdEndPointHealth
- type Func
- type Group
- type GroupRunner
- type HelmReconciler
- type ImageInfo
- type K8sClient
- type LocalHelmReconciler
- type Logger
- type MilvusComponent
- func (c MilvusComponent) GetComponentPort(spec v1beta1.MilvusSpec) int32
- func (c MilvusComponent) GetComponentSpec(spec v1beta1.MilvusSpec) v1beta1.ComponentSpec
- func (c MilvusComponent) GetContainerName() string
- func (c MilvusComponent) GetContainerPorts(spec v1beta1.MilvusSpec) []corev1.ContainerPort
- func (c MilvusComponent) GetDependencies(spec v1beta1.MilvusSpec) []MilvusComponent
- func (c MilvusComponent) GetDeploymentName(instance string) string
- func (c MilvusComponent) GetDeploymentStrategy(configs map[string]interface{}) appsv1.DeploymentStrategy
- func (c MilvusComponent) GetInitContainers(spec v1beta1.MilvusSpec) []corev1.Container
- func (c MilvusComponent) GetMilvusReplicas(status *v1beta1.MilvusReplicas) int
- func (c MilvusComponent) GetName() string
- func (c MilvusComponent) GetPortName() string
- func (c MilvusComponent) GetReplicas(spec v1beta1.MilvusSpec) *int32
- func (c MilvusComponent) GetRestfulPort(spec v1beta1.MilvusSpec) int32
- func (c MilvusComponent) GetRunCommands() []string
- func (c MilvusComponent) GetServicePorts(spec v1beta1.MilvusSpec) []corev1.ServicePort
- func (c MilvusComponent) GetServiceType(spec v1beta1.MilvusSpec) corev1.ServiceType
- func (c MilvusComponent) GetSideCars(spec v1beta1.MilvusSpec) []corev1.Container
- func (c MilvusComponent) IsCoord() bool
- func (c MilvusComponent) IsImageUpdated(m *v1beta1.Milvus) bool
- func (c MilvusComponent) IsNode() bool
- func (c MilvusComponent) IsService() bool
- func (c MilvusComponent) IsStandalone() bool
- func (c MilvusComponent) SetReplicas(spec v1beta1.MilvusSpec, replicas *int32) error
- func (c MilvusComponent) SetStatusReplicas(status *v1beta1.MilvusReplicas, replicas int)
- type MilvusEndpointInfo
- type MilvusHealthStatusInfo
- type MilvusPredicate
- type MilvusReconcileFunc
- type MilvusReconciler
- func (r *MilvusReconciler) Finalize(ctx context.Context, mc v1beta1.Milvus) error
- func (r *MilvusReconciler) Reconcile(ctx context.Context, req ctrl.Request) (ctrl.Result, error)
- func (r *MilvusReconciler) ReconcileAll(ctx context.Context, mc v1beta1.Milvus) error
- func (r *MilvusReconciler) ReconcileComponentDeployment(ctx context.Context, mc v1beta1.Milvus, component MilvusComponent) error
- func (r *MilvusReconciler) ReconcileComponentService(ctx context.Context, mc v1beta1.Milvus, component MilvusComponent) error
- func (r *MilvusReconciler) ReconcileConfigMaps(ctx context.Context, mc v1beta1.Milvus) error
- func (r *MilvusReconciler) ReconcileDeployments(ctx context.Context, mc v1beta1.Milvus) error
- func (r *MilvusReconciler) ReconcileEtcd(ctx context.Context, mc v1beta1.Milvus) error
- func (r *MilvusReconciler) ReconcileIngress(ctx context.Context, mc v1beta1.Milvus) error
- func (r *MilvusReconciler) ReconcileKafka(ctx context.Context, mc v1beta1.Milvus) error
- func (r *MilvusReconciler) ReconcileLegacyValues(ctx context.Context, old, milvus *v1beta1.Milvus) error
- func (r *MilvusReconciler) ReconcileMilvus(ctx context.Context, mc v1beta1.Milvus) error
- func (r *MilvusReconciler) ReconcileMinio(ctx context.Context, mc v1beta1.Milvus) error
- func (r *MilvusReconciler) ReconcileMsgStream(ctx context.Context, mc v1beta1.Milvus) error
- func (r *MilvusReconciler) ReconcilePVCs(ctx context.Context, mil v1beta1.Milvus) error
- func (r *MilvusReconciler) ReconcilePodMonitor(ctx context.Context, mc v1beta1.Milvus) error
- func (r *MilvusReconciler) ReconcilePulsar(ctx context.Context, mc v1beta1.Milvus) error
- func (r *MilvusReconciler) ReconcileServices(ctx context.Context, mc v1beta1.Milvus) error
- func (r *MilvusReconciler) RemoveOldStandlone(ctx context.Context, mc v1beta1.Milvus) error
- func (r *MilvusReconciler) SetDefaultStatus(ctx context.Context, mc *v1beta1.Milvus) error
- func (r *MilvusReconciler) SetupWithManager(mgr ctrl.Manager) error
- type MilvusStatusSyncer
- func (r *MilvusStatusSyncer) GetEtcdCondition(ctx context.Context, mc v1beta1.Milvus) (v1beta1.MilvusCondition, error)
- func (r *MilvusStatusSyncer) GetMilvusEndpoint(ctx context.Context, mc v1beta1.Milvus) string
- func (r *MilvusStatusSyncer) GetMinioCondition(ctx context.Context, mc v1beta1.Milvus) (v1beta1.MilvusCondition, error)
- func (r *MilvusStatusSyncer) GetMsgStreamCondition(ctx context.Context, mc v1beta1.Milvus) (v1beta1.MilvusCondition, error)
- func (r *MilvusStatusSyncer) RunIfNot()
- func (r *MilvusStatusSyncer) UpdateIngressStatus(ctx context.Context, mc *v1beta1.Milvus) error
- func (r *MilvusStatusSyncer) UpdateStatusForNewGeneration(ctx context.Context, mc *v1beta1.Milvus) error
- func (r *MilvusStatusSyncer) UpdateStatusRoutine(ctx context.Context, mc *v1beta1.Milvus) error
- type MilvusStatusSyncerInterface
- type MilvusUpgradeReconciler
- func (r *MilvusUpgradeReconciler) BackupMeta(ctx context.Context, upgrade *v1beta1.MilvusUpgrade, milvus *v1beta1.Milvus) (v1beta1.MilvusUpgradeState, error)
- func (r *MilvusUpgradeReconciler) DetermineCurrentState(ctx context.Context, upgrade *v1beta1.MilvusUpgrade) (nextState v1beta1.MilvusUpgradeState)
- func (r *MilvusUpgradeReconciler) HandleBakupMetaFailed(ctx context.Context, upgrade *v1beta1.MilvusUpgrade, milvus *v1beta1.Milvus) (v1beta1.MilvusUpgradeState, error)
- func (r *MilvusUpgradeReconciler) HandleUpgradeFailed(ctx context.Context, upgrade *v1beta1.MilvusUpgrade, milvus *v1beta1.Milvus) (v1beta1.MilvusUpgradeState, error)
- func (r *MilvusUpgradeReconciler) OldVersionStopping(ctx context.Context, upgrade *v1beta1.MilvusUpgrade, milvus *v1beta1.Milvus) (v1beta1.MilvusUpgradeState, error)
- func (r *MilvusUpgradeReconciler) Reconcile(ctx context.Context, req ctrl.Request) (ctrl.Result, error)
- func (r *MilvusUpgradeReconciler) RollbackNewVersionStopping(ctx context.Context, upgrade *v1beta1.MilvusUpgrade, milvus *v1beta1.Milvus) (v1beta1.MilvusUpgradeState, error)
- func (r *MilvusUpgradeReconciler) RollbackOldVersionStarting(ctx context.Context, upgrade *v1beta1.MilvusUpgrade, milvus *v1beta1.Milvus) (v1beta1.MilvusUpgradeState, error)
- func (r *MilvusUpgradeReconciler) RollbackRestoringOldMeta(ctx context.Context, upgrade *v1beta1.MilvusUpgrade, milvus *v1beta1.Milvus) (v1beta1.MilvusUpgradeState, error)
- func (r *MilvusUpgradeReconciler) RunStateMachine(ctx context.Context, upgrade *v1beta1.MilvusUpgrade) error
- func (r *MilvusUpgradeReconciler) SetupWithManager(mgr ctrl.Manager) error
- func (r *MilvusUpgradeReconciler) StartingMilvusNewVersion(ctx context.Context, upgrade *v1beta1.MilvusUpgrade, milvus *v1beta1.Milvus) (v1beta1.MilvusUpgradeState, error)
- func (r *MilvusUpgradeReconciler) UpdatingMeta(ctx context.Context, upgrade *v1beta1.MilvusUpgrade, milvus *v1beta1.Milvus) (v1beta1.MilvusUpgradeState, error)
- type MilvusUpgradeReconcilerCommonFunc
- type NewEtcdClientFunc
- type ParallelGroupRunner
- func (ParallelGroupRunner) Run(funcs []Func, ctx context.Context, args ...interface{}) error
- func (ParallelGroupRunner) RunDiffArgs(f MilvusReconcileFunc, ctx context.Context, argsArray []*v1beta1.Milvus) error
- func (ParallelGroupRunner) RunWithResult(funcs []Func, ctx context.Context, args ...interface{}) []Result
- type PulsarClient
- type PulsarReader
- type Result
- type StorageConditionInfo
- type Values
Constants ¶
const ( MetricPortName = "metrics" MetricPath = "/metrics" RestfulPortName = "restful" MixCoordName = "mixcoord" RootCoordName = "rootcoord" DataCoordName = "datacoord" QueryCoordName = "querycoord" IndexCoordName = "indexcoord" DataNodeName = "datanode" QueryNodeName = "querynode" IndexNodeName = "indexnode" ProxyName = "proxy" StandaloneName = "standalone" MilvusName = "milvus" MixCoordFieldName = "MixCoord" RootCoordFieldName = "RootCoord" DataCoordFieldName = "DataCoord" QueryCoordFieldName = "QueryCoord" IndexCoordFieldName = "IndexCoord" DataNodeFieldName = "DataNode" QueryNodeFieldName = "QueryNode" IndexNodeFieldName = "IndexNode" ProxyFieldName = "Proxy" StandaloneFieldName = "Standalone" MetricPort = 9091 MultiplePorts = -1 RootCoordPort = 53100 DataCoordPort = 13333 QueryCoordPort = 19531 IndexCoordPort = 31000 IndexNodePort = 21121 QueryNodePort = 21123 DataNodePort = 21124 ProxyPort = 19530 // TODO: use configurable port? MilvusPort = ProxyPort StandalonePort = MilvusPort )
const name or ports
const ( Etcd = "etcd" Minio = "minio" Pulsar = "pulsar" Kafka = "kafka" )
const ( MilvusDataVolumeName = "milvus-data" // for standalone persistence only MilvusConfigVolumeName = "milvus-config" MilvusOriginalConfigPath = "/milvus/configs/milvus.yaml" MilvusUserConfigMountPath = "/milvus/configs/user.yaml" MilvusUserConfigMountSubPath = "user.yaml" AccessKey = "accesskey" SecretKey = "secretkey" AnnotationCheckSum = "checksum/config" ToolsVolumeName = "tools" ToolsMountPath = "/milvus/tools" RunScriptPath = ToolsMountPath + "/run.sh" MergeToolPath = ToolsMountPath + "/merge" )
const ( MilvusStatusCodePending = float64(0) MilvusStatusCodeHealthy = float64(1) MilvusStatusCodeUnHealthy = float64(2) MilvusStatusCodeDeleting = float64(3) MilvusStautsCodeStopped = float64(4) MilvusStautsCodeMaintaining = float64(5) )
MilvusStatusCode for milvusStatusCollector
const ( MilvusFinalizerName = "milvus.milvus.io/finalizer" PauseReconcileAnnotation = "milvus.io/pause-reconcile" MaintainingAnnotation = "milvus.io/maintaining" )
const ( ConditionCheckingUpgrationState = "CheckingUpgrationState" ConditionUpgraded = "Upgraded" ConditionRollbacked = "Rollbacked" )
const ( LabelUpgrade = v1beta1.MilvusIO + "/upgrade" LabelTaskKind = v1beta1.MilvusIO + "/task-kind" BackupMeta = "backup-meta" UpdateMeta = "update-meta" RollbackMeta = "rollback-meta" )
const ( MessageEtcdReady = "Etcd endpoints is healthy" MessageEtcdNotReady = "All etcd endpoints are unhealthy" MessageStorageReady = "Storage endpoints is healthy" MessageStorageNotReady = "All Storage endpoints are unhealthy" MessageMsgStreamReady = "MsgStream is ready" MessageMsgStreamNotReady = "MsgStream is not ready" MessageSecretNotExist = "Secret not exist" MessageKeyNotExist = "accesskey or secretkey not exist in secret" MessageDecodeErr = "accesskey or secretkey decode error" MessageMilvusHealthy = "All Milvus components are healthy" MessageMilvusStopped = "All Milvus components are stopped" MessageMilvusStopping = "All Milvus components are stopping" )
const ( AppLabel = "app.kubernetes.io/" AppLabelInstance = AppLabel + "instance" AppLabelVersion = AppLabel + "version" AppLabelComponent = AppLabel + "component" AppLabelName = AppLabel + "name" AppLabelManagedBy = AppLabel + "managed-by" HelmReleaseLabel = "release" )
const (
CacheSizeEnvVarName = "CACHE_SIZE"
)
const ManagerName = "milvus-operator"
Variables ¶
var ( MixCoord = MilvusComponent{MixCoordName, MixCoordFieldName, MultiplePorts} RootCoord = MilvusComponent{RootCoordName, RootCoordFieldName, RootCoordPort} DataCoord = MilvusComponent{DataCoordName, DataCoordFieldName, DataCoordPort} QueryCoord = MilvusComponent{QueryCoordName, QueryCoordFieldName, QueryCoordPort} IndexCoord = MilvusComponent{IndexCoordName, IndexCoordFieldName, IndexCoordPort} DataNode = MilvusComponent{DataNodeName, DataNodeFieldName, DataNodePort} QueryNode = MilvusComponent{QueryNodeName, QueryNodeFieldName, QueryNodePort} IndexNode = MilvusComponent{IndexNodeName, IndexNodeFieldName, IndexNodePort} Proxy = MilvusComponent{ProxyName, ProxyFieldName, ProxyPort} // Milvus standalone MilvusStandalone = MilvusComponent{StandaloneName, StandaloneFieldName, StandalonePort} MixtureComponents = []MilvusComponent{ MixCoord, DataNode, QueryNode, IndexNode, Proxy, MilvusStandalone, } MilvusComponents = []MilvusComponent{ RootCoord, DataCoord, QueryCoord, IndexCoord, DataNode, QueryNode, IndexNode, Proxy, MilvusStandalone, } StandaloneComponents = []MilvusComponent{ MilvusStandalone, } MilvusCoords = []MilvusComponent{ RootCoord, DataCoord, QueryCoord, IndexCoord, } )
define MilvusComponents
var ( MilvusConfigMapMode int32 = 420 ErrRequeue = pkgerr.New("requeue") )
var ( DefaultOperatorImageInfo = ImageInfo{ Image: "milvusdb/milvus-operator:main-latest", ImagePullPolicy: corev1.PullAlways, } ToolImage = "" )
var ( CacheSizeEnvVar = corev1.EnvVar{ Name: CacheSizeEnvVarName, ValueFrom: &corev1.EnvVarSource{ ResourceFieldRef: &corev1.ResourceFieldSelector{ Divisor: resource.MustParse("1Gi"), Resource: "limits.memory", }, }, } )
var ( // DefaultValuesPath is the path to the default values file // variable in test, const in runtime DefaultValuesPath = "config/assets/charts/values.yaml" )
var DeploymentConditionNotSet = appsv1.DeploymentCondition{}
var MergeAnnotations = MergeLabels
var PodConditionNotSet = corev1.PodCondition{}
PodConditionNotSet is used when pod condition is not found when calling GetPodConditionByType
var ( S3ReadyCondition = v1beta1.MilvusCondition{ Type: v1beta1.StorageReady, Status: GetConditionStatus(true), Reason: v1beta1.ReasonS3Ready, } )
var ( SetControllerReference = func(owner, controlled metav1.Object, scheme *kruntime.Scheme) error { if err := ctrl.SetControllerReference(owner, controlled, scheme); err != nil { if reflect.TypeOf(err) == alreadyOwnedErrorType { if err.(*controllerutil.AlreadyOwnedError).Owner.Kind == milvusclusterOwnerKind { return nil } } return errors.Wrap(err, "set controller reference") } return nil } )
Functions ¶
func CheckMilvusStopped ¶ added in v0.7.16
func DeploymentReady ¶
func DeploymentReady(status appsv1.DeploymentStatus) bool
DeploymentReady deployment is ready when all components are available
func GetCondition ¶ added in v0.4.0
func GetCondition(getter func() v1beta1.MilvusCondition, eps []string) v1beta1.MilvusCondition
func GetConditionStatus ¶
func GetConditionStatus(b bool) corev1.ConditionStatus
func GetConfCheckSum ¶ added in v0.2.0
func GetConfCheckSum(spec v1beta1.MilvusSpec) string
GetConfCheckSum returns the checksum of the component configuration
func GetContainerIndex ¶
GetContainerIndex returns index of container @name in @containers, -1 if not found
func GetContainerMessage ¶ added in v0.6.8
func GetContainerMessage(status corev1.ContainerStatus) string
func GetDeploymentConditionByType ¶ added in v0.6.8
func GetDeploymentConditionByType(conditions []appsv1.DeploymentCondition, Type appsv1.DeploymentConditionType) appsv1.DeploymentCondition
func GetDeploymentFalseCondition ¶ added in v0.6.8
func GetDeploymentFalseCondition(deploy appsv1.Deployment) (*appsv1.DeploymentCondition, error)
func GetEndpointsHealth ¶
func GetEndpointsHealth(endpoints []string) map[string]EtcdEndPointHealth
func GetEtcdCondition ¶ added in v0.2.3
func GetEtcdCondition(ctx context.Context, endpoints []string) v1beta1.MilvusCondition
func GetKafkaCondition ¶ added in v0.5.0
func GetKafkaCondition(ctx context.Context, logger logr.Logger, p v1beta1.MilvusKafka) v1beta1.MilvusCondition
func GetLivenessProbe ¶ added in v0.2.0
func GetMilvusConditionByType ¶ added in v0.7.6
func GetMilvusConditionByType(conditions []v1beta1.MilvusCondition, Type v1beta1.MilvusConditionType) *v1beta1.MilvusCondition
func GetMilvusConfCheckSum ¶ added in v0.2.0
func GetMilvusConfCheckSum(spec v1beta1.MilvusSpec) string
GetMilvusConfCheckSum returns the checksum of the component configuration
func GetMilvusEndpoint ¶ added in v0.2.3
func GetMilvusUpdatedCondition ¶ added in v0.7.6
func GetMilvusUpdatedCondition(m *v1beta1.Milvus) v1beta1.MilvusCondition
func GetMinioBucket ¶ added in v0.5.0
func GetMinioCondition ¶ added in v0.2.3
func GetMinioCondition(ctx context.Context, logger logr.Logger, cli client.Client, info StorageConditionInfo) v1beta1.MilvusCondition
func GetMinioIAMEndpoint ¶ added in v0.5.0
func GetMinioSecure ¶
func GetMinioUseIAM ¶ added in v0.5.0
func GetNotReadyDependencyConditions ¶ added in v0.7.10
func GetNotReadyDependencyConditions(conditions []v1beta1.MilvusCondition) map[v1beta1.MilvusConditionType]*v1beta1.MilvusCondition
func GetPodConditionByType ¶ added in v0.6.8
func GetPodConditionByType(conditions []corev1.PodCondition, Type corev1.PodConditionType) corev1.PodCondition
GetPodConditionByType returns the condition with the provided type, return ConditionNotSet if not found
func GetPodFalseCondition ¶ added in v0.6.8
func GetPodFalseCondition(pod corev1.Pod) (*corev1.PodCondition, error)
func GetPulsarCondition ¶ added in v0.2.3
func GetPulsarCondition(ctx context.Context, logger logr.Logger, p v1beta1.MilvusPulsar) v1beta1.MilvusCondition
func GetReadinessProbe ¶ added in v0.2.0
func GetServiceInstanceName ¶ added in v0.4.0
GetServiceInstanceName returns the name of the component service
func GetStartupProbe ¶ added in v0.6.0
func GetStorageSecretRefEnv ¶
func GetVolumeIndex ¶
GetVolumeIndex returns index of volume @name in @volumes, -1 if not found
func GetVolumeMountIndex ¶
func GetVolumeMountIndex(volumeMounts []corev1.VolumeMount, mountPath string) int
GetVolumeMountIndex returns index of volumeMount with @mountPath in @volumeMounts, -1 if not found
func IsDependencyReady ¶
func IsDependencyReady(conditions []v1beta1.MilvusCondition) bool
func IsMilvusConditionTrueByType ¶ added in v0.7.6
func IsMilvusConditionTrueByType(conditions []v1beta1.MilvusCondition, Type v1beta1.MilvusConditionType) bool
func IsMilvusDeploymentsComplete ¶ added in v0.7.5
func IsSetDefaultDone ¶ added in v0.2.0
func LoopWithInterval ¶ added in v0.2.3
func MergeContainerPort ¶
func MergeContainerPort(src, dst []corev1.ContainerPort) []corev1.ContainerPort
func MergeEnvVar ¶
Merge dst env into src
func MergeLabels ¶
MergeLabels merges all labels together and returns a new label.
func MergeServicePort ¶
func MergeServicePort(src, dst []corev1.ServicePort) []corev1.ServicePort
func MergeVolumeMount ¶
func MergeVolumeMount(src, dst []corev1.VolumeMount) []corev1.VolumeMount
func MilvusStatusToCode ¶ added in v0.7.4
func MilvusStatusToCode(status v1beta1.MilvusHealthStatus, isMaintaining bool) float64
func NamespacedName ¶
func NamespacedName(namespace, name string) types.NamespacedName
func NewAppLabels ¶
func NewComponentAppLabels ¶
func NewServicePodLabels ¶ added in v0.7.16
func PodReady ¶ added in v0.6.8
PodReady returns whether a pod is running and each container has passed it's ready state.
func RemoveConditions ¶ added in v0.7.16
func RemoveConditions(status *v1beta1.MilvusStatus, typesToRemove []v1beta1.MilvusConditionType)
func SetupControllers ¶
func UpdateCondition ¶
func UpdateCondition(status *v1beta1.MilvusStatus, c v1beta1.MilvusCondition)
func WrappedFunc ¶ added in v0.2.3
func WrappedFunc(f interface{}, args ...interface{}) func() error
Types ¶
type CommonInfo ¶ added in v0.3.0
type CommonInfo struct { OperatorImageInfo ImageInfo // contains filtered or unexported fields }
CommonInfo should be init when before time reconcile
func (*CommonInfo) InitIfNot ¶ added in v0.3.0
func (c *CommonInfo) InitIfNot(cli client.Client)
type ComponentConditionGetter ¶ added in v0.7.16
type ComponentConditionGetter interface {
GetMilvusInstanceCondition(ctx context.Context, cli client.Client, mc v1beta1.Milvus) (v1beta1.MilvusCondition, error)
}
func GetComponentConditionGetter ¶ added in v0.7.16
func GetComponentConditionGetter() ComponentConditionGetter
type ComponentConditionGetterImpl ¶ added in v0.7.16
type ComponentConditionGetterImpl struct{}
func (ComponentConditionGetterImpl) GetMilvusInstanceCondition ¶ added in v0.7.16
func (c ComponentConditionGetterImpl) GetMilvusInstanceCondition(ctx context.Context, cli client.Client, mc v1beta1.Milvus) (v1beta1.MilvusCondition, error)
type ComponentErrorDetail ¶ added in v0.6.8
type ComponentErrorDetail struct { ComponentName string NotObserved bool Deployment *appsv1.DeploymentCondition PodName string Pod *corev1.PodCondition Container *corev1.ContainerStatus }
ComponentErrorDetail is one sample of error detail among all error pods
func (ComponentErrorDetail) String ¶ added in v0.6.8
func (m ComponentErrorDetail) String() string
type ComponentSpec ¶ added in v0.3.2
type ComponentSpec = v1beta1.ComponentSpec
func MergeComponentSpec ¶ added in v0.3.2
func MergeComponentSpec(src, dst ComponentSpec) ComponentSpec
MergeComponentSpec merges the src ComponentSpec to dst
type EndpointCheckCache ¶ added in v0.4.0
type EndpointCheckCache interface { TryStartProbeFor(endpoint []string) bool EndProbeFor(endpoint []string) Get(endpoint []string) (condition *v1beta1.MilvusCondition, found bool) Set(endpoints []string, condition *v1beta1.MilvusCondition) }
EndpointCheckCache coordinates endpoint check to avoid duplicated check for same endpoint
func NewEndpointCheckCacheImpl ¶ added in v0.4.0
func NewEndpointCheckCacheImpl() EndpointCheckCache
type EndpointCheckCacheImpl ¶ added in v0.4.0
type EndpointCheckCacheImpl struct {
// contains filtered or unexported fields
}
EndpointCheckCacheImpl implements EndpointCheckCache
func (EndpointCheckCacheImpl) EndProbeFor ¶ added in v0.7.16
func (e EndpointCheckCacheImpl) EndProbeFor(endpoints []string)
func (EndpointCheckCacheImpl) Get ¶ added in v0.4.0
func (e EndpointCheckCacheImpl) Get(endpoints []string) (condition *v1beta1.MilvusCondition, isUpToDate bool)
func (EndpointCheckCacheImpl) Set ¶ added in v0.4.0
func (e EndpointCheckCacheImpl) Set(endpoints []string, condition *v1beta1.MilvusCondition)
func (EndpointCheckCacheImpl) TryStartProbeFor ¶ added in v0.7.16
func (e EndpointCheckCacheImpl) TryStartProbeFor(endpoints []string) bool
TryStartProbeFor use an atomic int32 to lock the endpoint
type EtcdClient ¶ added in v0.2.3
type EtcdClient interface { Get(ctx context.Context, key string, opts ...clientv3.OpOption) (*clientv3.GetResponse, error) AlarmList(ctx context.Context) (*clientv3.AlarmResponse, error) Close() error }
EtcdClient for mock
type EtcdConditionInfo ¶ added in v0.2.3
type EtcdConditionInfo struct {
Endpoints []string
}
type EtcdEndPointHealth ¶
type Group ¶
type Group struct {
// contains filtered or unexported fields
}
type GroupRunner ¶ added in v0.2.3
type GroupRunner interface { // Run runs a group of funcs by same args, if any func fail, it should return err Run(funcs []Func, ctx context.Context, args ...interface{}) error // RunWithResult runs a group of funcs by same args, returns results with data & err for each func called RunWithResult(funcs []Func, ctx context.Context, args ...interface{}) []Result // RunDiffArgs runs a func by groups of args from @argsArray multiple times, if any failed, it should return err RunDiffArgs(f MilvusReconcileFunc, ctx context.Context, argsArray []*v1beta1.Milvus) error }
GroupRunner does a group of funcs in parallel
type HelmReconciler ¶ added in v0.2.3
type HelmReconciler interface { NewHelmCfg(namespace string) *action.Configuration Reconcile(ctx context.Context, request helm.ChartRequest) error GetValues(namespace, release string) (map[string]interface{}, error) }
HelmReconciler reconciles Helm releases
type ImageInfo ¶ added in v0.3.0
type ImageInfo struct { Image string ImagePullPolicy corev1.PullPolicy }
ImageInfo for image pulling
type LocalHelmReconciler ¶ added in v0.2.3
type LocalHelmReconciler struct {
// contains filtered or unexported fields
}
LocalHelmReconciler implements HelmReconciler at local
func MustNewLocalHelmReconciler ¶ added in v0.3.0
func MustNewLocalHelmReconciler(helmSettings *cli.EnvSettings, logger logr.Logger) *LocalHelmReconciler
func (*LocalHelmReconciler) GetValues ¶ added in v0.5.1
func (l *LocalHelmReconciler) GetValues(namespace, release string) (map[string]interface{}, error)
func (LocalHelmReconciler) NewHelmCfg ¶ added in v0.2.3
func (l LocalHelmReconciler) NewHelmCfg(namespace string) *action.Configuration
func (LocalHelmReconciler) Reconcile ¶ added in v0.2.3
func (l LocalHelmReconciler) Reconcile(ctx context.Context, request helm.ChartRequest) error
ReconcileHelm reconciles Helm releases
type MilvusComponent ¶
MilvusComponent contains basic info of a milvus cluster component
func GetComponentsBySpec ¶ added in v0.5.0
func GetComponentsBySpec(spec v1beta1.MilvusSpec) []MilvusComponent
GetComponentsBySpec returns the components by the spec
func (MilvusComponent) GetComponentPort ¶
func (c MilvusComponent) GetComponentPort(spec v1beta1.MilvusSpec) int32
GetComponentPort returns the port of the component
func (MilvusComponent) GetComponentSpec ¶
func (c MilvusComponent) GetComponentSpec(spec v1beta1.MilvusSpec) v1beta1.ComponentSpec
GetComponentSpec returns the component spec
func (MilvusComponent) GetContainerName ¶
func (c MilvusComponent) GetContainerName() string
GetContainerName returns the name of the component container
func (MilvusComponent) GetContainerPorts ¶
func (c MilvusComponent) GetContainerPorts(spec v1beta1.MilvusSpec) []corev1.ContainerPort
GetContainerPorts returns the ports of the component container
func (MilvusComponent) GetDependencies ¶ added in v0.7.6
func (c MilvusComponent) GetDependencies(spec v1beta1.MilvusSpec) []MilvusComponent
func (MilvusComponent) GetDeploymentName ¶ added in v0.5.0
func (c MilvusComponent) GetDeploymentName(instance string) string
GetDeploymentName returns the name of the component deployment
func (MilvusComponent) GetDeploymentStrategy ¶
func (c MilvusComponent) GetDeploymentStrategy(configs map[string]interface{}) appsv1.DeploymentStrategy
func (MilvusComponent) GetInitContainers ¶ added in v0.7.13
func (c MilvusComponent) GetInitContainers(spec v1beta1.MilvusSpec) []corev1.Container
GetSideCars returns the component init conatiners
func (MilvusComponent) GetMilvusReplicas ¶ added in v0.7.0
func (c MilvusComponent) GetMilvusReplicas(status *v1beta1.MilvusReplicas) int
SetStatusReplica sets the replica status of the component, input status should not be nil
func (MilvusComponent) GetName ¶ added in v0.5.0
func (c MilvusComponent) GetName() string
String returns the name of the component
func (MilvusComponent) GetPortName ¶ added in v0.5.0
func (c MilvusComponent) GetPortName() string
GetPortName returns the port name of the component container
func (MilvusComponent) GetReplicas ¶
func (c MilvusComponent) GetReplicas(spec v1beta1.MilvusSpec) *int32
GetReplicas returns the replicas for the component
func (MilvusComponent) GetRestfulPort ¶ added in v0.7.16
func (c MilvusComponent) GetRestfulPort(spec v1beta1.MilvusSpec) int32
GetComponentPort returns the port of the component
func (MilvusComponent) GetRunCommands ¶ added in v0.5.0
func (c MilvusComponent) GetRunCommands() []string
String returns the name of the component
func (MilvusComponent) GetServicePorts ¶
func (c MilvusComponent) GetServicePorts(spec v1beta1.MilvusSpec) []corev1.ServicePort
GetServicePorts returns the ports of the component service
func (MilvusComponent) GetServiceType ¶
func (c MilvusComponent) GetServiceType(spec v1beta1.MilvusSpec) corev1.ServiceType
GetServiceType returns the type of the component service
func (MilvusComponent) GetSideCars ¶ added in v0.7.13
func (c MilvusComponent) GetSideCars(spec v1beta1.MilvusSpec) []corev1.Container
GetSideCars returns the component sidecar conatiners
func (MilvusComponent) IsCoord ¶
func (c MilvusComponent) IsCoord() bool
IsCoord return if it's a coord by its name
func (MilvusComponent) IsImageUpdated ¶ added in v0.7.6
func (c MilvusComponent) IsImageUpdated(m *v1beta1.Milvus) bool
IsImageUpdated returns whether the image of the component is updated
func (MilvusComponent) IsNode ¶
func (c MilvusComponent) IsNode() bool
IsCoord return if it's a node by its name
func (MilvusComponent) IsService ¶ added in v0.7.16
func (c MilvusComponent) IsService() bool
func (MilvusComponent) IsStandalone ¶ added in v0.5.0
func (c MilvusComponent) IsStandalone() bool
IsCoord return if it's a coord by its name
func (MilvusComponent) SetReplicas ¶ added in v0.7.0
func (c MilvusComponent) SetReplicas(spec v1beta1.MilvusSpec, replicas *int32) error
GetReplicas returns the replicas for the component
func (MilvusComponent) SetStatusReplicas ¶ added in v0.4.0
func (c MilvusComponent) SetStatusReplicas(status *v1beta1.MilvusReplicas, replicas int)
SetStatusReplica sets the replica status of the component, input status should not be nil
type MilvusEndpointInfo ¶ added in v0.2.3
type MilvusEndpointInfo struct { Namespace string Name string ServiceType corev1.ServiceType Port int32 }
MilvusEndpointInfo info for calculate the endpoint
type MilvusHealthStatusInfo ¶ added in v0.7.5
type MilvusHealthStatusInfo struct { LastState v1beta1.MilvusHealthStatus IsStopping bool IsHealthy bool }
func (MilvusHealthStatusInfo) GetMilvusHealthStatus ¶ added in v0.7.5
func (m MilvusHealthStatusInfo) GetMilvusHealthStatus() v1beta1.MilvusHealthStatus
type MilvusPredicate ¶ added in v0.5.0
func (*MilvusPredicate) Create ¶ added in v0.5.0
func (*MilvusPredicate) Create(e event.CreateEvent) bool
func (*MilvusPredicate) Update ¶ added in v0.5.0
func (*MilvusPredicate) Update(e event.UpdateEvent) bool
type MilvusReconcileFunc ¶ added in v0.2.3
type MilvusReconciler ¶ added in v0.2.0
type MilvusReconciler struct { client.Client Scheme *runtime.Scheme // contains filtered or unexported fields }
MilvusReconciler reconciles a Milvus object
func (*MilvusReconciler) Reconcile ¶ added in v0.2.0
Reconcile is part of the main kubernetes reconciliation loop which aims to move the current state of the cluster closer to the desired state.
For more details, check Reconcile and its Result here: - https://pkg.go.dev/sigs.k8s.io/controller-runtime@v0.8.3/pkg/reconcile
func (*MilvusReconciler) ReconcileAll ¶ added in v0.2.0
func (*MilvusReconciler) ReconcileComponentDeployment ¶ added in v0.5.0
func (r *MilvusReconciler) ReconcileComponentDeployment( ctx context.Context, mc v1beta1.Milvus, component MilvusComponent, ) error
func (*MilvusReconciler) ReconcileComponentService ¶ added in v0.5.0
func (r *MilvusReconciler) ReconcileComponentService( ctx context.Context, mc v1beta1.Milvus, component MilvusComponent, ) error
func (*MilvusReconciler) ReconcileConfigMaps ¶ added in v0.2.0
func (*MilvusReconciler) ReconcileDeployments ¶ added in v0.2.0
func (*MilvusReconciler) ReconcileEtcd ¶ added in v0.2.0
func (*MilvusReconciler) ReconcileIngress ¶ added in v0.4.0
func (*MilvusReconciler) ReconcileKafka ¶ added in v0.5.0
func (*MilvusReconciler) ReconcileLegacyValues ¶ added in v0.5.1
func (*MilvusReconciler) ReconcileMilvus ¶ added in v0.2.0
func (*MilvusReconciler) ReconcileMinio ¶ added in v0.2.0
func (*MilvusReconciler) ReconcileMsgStream ¶ added in v0.5.0
func (*MilvusReconciler) ReconcilePVCs ¶ added in v0.4.0
func (*MilvusReconciler) ReconcilePodMonitor ¶ added in v0.2.0
func (*MilvusReconciler) ReconcilePulsar ¶ added in v0.5.0
func (*MilvusReconciler) ReconcileServices ¶ added in v0.2.0
func (*MilvusReconciler) RemoveOldStandlone ¶ added in v0.5.0
func (*MilvusReconciler) SetDefaultStatus ¶ added in v0.2.0
SetDefaultStatus update status if default not set; return true if updated, return false if not, return err if update failed
func (*MilvusReconciler) SetupWithManager ¶ added in v0.2.0
func (r *MilvusReconciler) SetupWithManager(mgr ctrl.Manager) error
SetupWithManager sets up the controller with the Manager.
type MilvusStatusSyncer ¶ added in v0.2.0
type MilvusStatusSyncer struct { client.Client sync.Once // contains filtered or unexported fields }
func NewMilvusStatusSyncer ¶ added in v0.2.0
func (*MilvusStatusSyncer) GetEtcdCondition ¶ added in v0.2.0
func (r *MilvusStatusSyncer) GetEtcdCondition(ctx context.Context, mc v1beta1.Milvus) (v1beta1.MilvusCondition, error)
func (*MilvusStatusSyncer) GetMilvusEndpoint ¶ added in v0.2.0
func (*MilvusStatusSyncer) GetMinioCondition ¶ added in v0.2.0
func (r *MilvusStatusSyncer) GetMinioCondition( ctx context.Context, mc v1beta1.Milvus) (v1beta1.MilvusCondition, error)
TODO: rename as GetStorageCondition
func (*MilvusStatusSyncer) GetMsgStreamCondition ¶ added in v0.5.0
func (r *MilvusStatusSyncer) GetMsgStreamCondition( ctx context.Context, mc v1beta1.Milvus) (v1beta1.MilvusCondition, error)
func (*MilvusStatusSyncer) RunIfNot ¶ added in v0.2.0
func (r *MilvusStatusSyncer) RunIfNot()
func (*MilvusStatusSyncer) UpdateIngressStatus ¶ added in v0.4.0
func (*MilvusStatusSyncer) UpdateStatusForNewGeneration ¶ added in v0.5.2
func (*MilvusStatusSyncer) UpdateStatusRoutine ¶ added in v0.5.2
type MilvusStatusSyncerInterface ¶ added in v0.5.2
type MilvusStatusSyncerInterface interface { RunIfNot() UpdateStatusForNewGeneration(ctx context.Context, mc *v1beta1.Milvus) error }
MilvusStatusSyncerInterface abstracts MilvusStatusSyncer
type MilvusUpgradeReconciler ¶ added in v0.7.0
type MilvusUpgradeReconciler struct { client.Client Scheme *runtime.Scheme // contains filtered or unexported fields }
MilvusUpgradeReconciler reconciles a MilvusUpgrade object
func NewMilvusUpgradeReconciler ¶ added in v0.7.0
func NewMilvusUpgradeReconciler(client client.Client, scheme *runtime.Scheme) *MilvusUpgradeReconciler
NewMilvusUpgradeReconciler returns a new MilvusUpgradeReconciler
func (*MilvusUpgradeReconciler) BackupMeta ¶ added in v0.7.0
func (r *MilvusUpgradeReconciler) BackupMeta(ctx context.Context, upgrade *v1beta1.MilvusUpgrade, milvus *v1beta1.Milvus) (v1beta1.MilvusUpgradeState, error)
func (*MilvusUpgradeReconciler) DetermineCurrentState ¶ added in v0.7.0
func (r *MilvusUpgradeReconciler) DetermineCurrentState(ctx context.Context, upgrade *v1beta1.MilvusUpgrade) (nextState v1beta1.MilvusUpgradeState)
func (*MilvusUpgradeReconciler) HandleBakupMetaFailed ¶ added in v0.7.0
func (r *MilvusUpgradeReconciler) HandleBakupMetaFailed(ctx context.Context, upgrade *v1beta1.MilvusUpgrade, milvus *v1beta1.Milvus) (v1beta1.MilvusUpgradeState, error)
func (*MilvusUpgradeReconciler) HandleUpgradeFailed ¶ added in v0.7.0
func (r *MilvusUpgradeReconciler) HandleUpgradeFailed(ctx context.Context, upgrade *v1beta1.MilvusUpgrade, milvus *v1beta1.Milvus) (v1beta1.MilvusUpgradeState, error)
func (*MilvusUpgradeReconciler) OldVersionStopping ¶ added in v0.7.0
func (r *MilvusUpgradeReconciler) OldVersionStopping(ctx context.Context, upgrade *v1beta1.MilvusUpgrade, milvus *v1beta1.Milvus) (v1beta1.MilvusUpgradeState, error)
func (*MilvusUpgradeReconciler) Reconcile ¶ added in v0.7.0
func (r *MilvusUpgradeReconciler) Reconcile(ctx context.Context, req ctrl.Request) (ctrl.Result, error)
Reconcile is part of the main kubernetes reconciliation loop which aims to move the current state of the cluster closer to the desired state. TODO(user): Modify the Reconcile function to compare the state specified by the MilvusUpgrade object against the actual cluster state, and then perform operations to make the cluster state reflect the state specified by the user.
For more details, check Reconcile and its Result here: - https://pkg.go.dev/sigs.k8s.io/controller-runtime@v0.10.0/pkg/reconcile
func (*MilvusUpgradeReconciler) RollbackNewVersionStopping ¶ added in v0.7.0
func (r *MilvusUpgradeReconciler) RollbackNewVersionStopping(ctx context.Context, upgrade *v1beta1.MilvusUpgrade, milvus *v1beta1.Milvus) (v1beta1.MilvusUpgradeState, error)
func (*MilvusUpgradeReconciler) RollbackOldVersionStarting ¶ added in v0.7.0
func (r *MilvusUpgradeReconciler) RollbackOldVersionStarting(ctx context.Context, upgrade *v1beta1.MilvusUpgrade, milvus *v1beta1.Milvus) (v1beta1.MilvusUpgradeState, error)
func (*MilvusUpgradeReconciler) RollbackRestoringOldMeta ¶ added in v0.7.0
func (r *MilvusUpgradeReconciler) RollbackRestoringOldMeta(ctx context.Context, upgrade *v1beta1.MilvusUpgrade, milvus *v1beta1.Milvus) (v1beta1.MilvusUpgradeState, error)
func (*MilvusUpgradeReconciler) RunStateMachine ¶ added in v0.7.0
func (r *MilvusUpgradeReconciler) RunStateMachine(ctx context.Context, upgrade *v1beta1.MilvusUpgrade) error
func (*MilvusUpgradeReconciler) SetupWithManager ¶ added in v0.7.0
func (r *MilvusUpgradeReconciler) SetupWithManager(mgr ctrl.Manager) error
SetupWithManager sets up the controller with the Manager.
func (*MilvusUpgradeReconciler) StartingMilvusNewVersion ¶ added in v0.7.0
func (r *MilvusUpgradeReconciler) StartingMilvusNewVersion(ctx context.Context, upgrade *v1beta1.MilvusUpgrade, milvus *v1beta1.Milvus) (v1beta1.MilvusUpgradeState, error)
func (*MilvusUpgradeReconciler) UpdatingMeta ¶ added in v0.7.0
func (r *MilvusUpgradeReconciler) UpdatingMeta(ctx context.Context, upgrade *v1beta1.MilvusUpgrade, milvus *v1beta1.Milvus) (v1beta1.MilvusUpgradeState, error)
type MilvusUpgradeReconcilerCommonFunc ¶ added in v0.7.0
type MilvusUpgradeReconcilerCommonFunc func(ctx context.Context, upgrade *v1beta1.MilvusUpgrade, milvus *v1beta1.Milvus) (nextState v1beta1.MilvusUpgradeState, err error)
type NewEtcdClientFunc ¶ added in v0.2.3
type NewEtcdClientFunc func(cfg clientv3.Config) (EtcdClient, error)
type ParallelGroupRunner ¶ added in v0.2.3
type ParallelGroupRunner struct { }
ParallelGroupRunner is a group runner that run funcs in parallel
func (ParallelGroupRunner) Run ¶ added in v0.2.3
func (ParallelGroupRunner) Run(funcs []Func, ctx context.Context, args ...interface{}) error
Run a group of funcs by same args in parallel, if any func fail, it should return err
func (ParallelGroupRunner) RunDiffArgs ¶ added in v0.2.3
func (ParallelGroupRunner) RunDiffArgs(f MilvusReconcileFunc, ctx context.Context, argsArray []*v1beta1.Milvus) error
RunDiffArgs runs a func by groups of args from @argsArray multiple times, if any failed, it should return err
func (ParallelGroupRunner) RunWithResult ¶ added in v0.2.3
func (ParallelGroupRunner) RunWithResult(funcs []Func, ctx context.Context, args ...interface{}) []Result
RunWithResult runs a group of funcs by same args, returns results with data & err for each func called
type PulsarClient ¶ added in v0.2.3
PulsarClient for mock
type PulsarReader ¶ added in v0.2.3
PulsarReader for mock
type Result ¶ added in v0.2.3
type Result struct { Data interface{} Err error }
Result contains data & err for a func's return
type StorageConditionInfo ¶ added in v0.2.3
type StorageConditionInfo struct { Namespace string Bucket string Storage v1beta1.MilvusStorage UseSSL bool UseIAM bool IAMEndpoint string }
StorageConditionInfo is info for acquiring storage condition
Source Files ¶
- component_condition.go
- components.go
- conditions.go
- configmaps.go
- dependencies.go
- dependency_graph.go
- deployment_updater.go
- deployments.go
- endpoint_check_cache.go
- error_detail.go
- external_interfaces.go
- group_runner.go
- groups.go
- ingress.go
- log.go
- metrics.go
- milvus.go
- milvus_controller.go
- milvusupgrade_controller.go
- milvusupgrade_fsm.go
- podmonitor.go
- pvc.go
- services.go
- setup.go
- status_cluster.go
- utils.go