2021-04-19 13:47:10 +08:00
|
|
|
// Copyright (C) 2019-2020 Zilliz. All rights reserved.
|
|
|
|
//
|
|
|
|
// Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance
|
|
|
|
// with the License. You may obtain a copy of the License at
|
|
|
|
//
|
|
|
|
// http://www.apache.org/licenses/LICENSE-2.0
|
|
|
|
//
|
|
|
|
// Unless required by applicable law or agreed to in writing, software distributed under the License
|
|
|
|
// is distributed on an "AS IS" BASIS, 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.
|
|
|
|
|
2021-06-22 16:44:09 +08:00
|
|
|
package querycoord
|
2021-01-15 15:28:54 +08:00
|
|
|
|
2021-01-16 15:31:10 +08:00
|
|
|
import (
|
2021-01-22 14:28:06 +08:00
|
|
|
"context"
|
2021-03-08 15:25:55 +08:00
|
|
|
"math/rand"
|
2021-06-19 11:45:09 +08:00
|
|
|
"path/filepath"
|
2021-06-03 14:58:34 +08:00
|
|
|
"strconv"
|
2021-06-19 11:45:09 +08:00
|
|
|
"sync"
|
2021-01-22 14:28:06 +08:00
|
|
|
"sync/atomic"
|
2021-02-20 09:20:51 +08:00
|
|
|
"time"
|
2021-01-22 14:28:06 +08:00
|
|
|
|
2021-06-19 11:45:09 +08:00
|
|
|
"github.com/golang/protobuf/proto"
|
2021-08-24 09:45:51 +08:00
|
|
|
"go.etcd.io/etcd/api/v3/mvccpb"
|
2021-06-04 16:29:35 +08:00
|
|
|
"go.uber.org/zap"
|
|
|
|
|
2021-06-15 12:41:40 +08:00
|
|
|
etcdkv "github.com/milvus-io/milvus/internal/kv/etcd"
|
2021-04-22 14:45:57 +08:00
|
|
|
"github.com/milvus-io/milvus/internal/log"
|
|
|
|
"github.com/milvus-io/milvus/internal/msgstream"
|
2021-06-19 11:45:09 +08:00
|
|
|
"github.com/milvus-io/milvus/internal/proto/commonpb"
|
2021-04-22 14:45:57 +08:00
|
|
|
"github.com/milvus-io/milvus/internal/proto/internalpb"
|
2021-06-19 11:45:09 +08:00
|
|
|
"github.com/milvus-io/milvus/internal/proto/querypb"
|
2021-04-22 14:45:57 +08:00
|
|
|
"github.com/milvus-io/milvus/internal/types"
|
2021-09-15 20:40:07 +08:00
|
|
|
"github.com/milvus-io/milvus/internal/util/metricsinfo"
|
2021-06-19 11:45:09 +08:00
|
|
|
"github.com/milvus-io/milvus/internal/util/retry"
|
2021-05-21 19:28:52 +08:00
|
|
|
"github.com/milvus-io/milvus/internal/util/sessionutil"
|
2021-04-22 14:45:57 +08:00
|
|
|
"github.com/milvus-io/milvus/internal/util/typeutil"
|
2021-01-16 15:31:10 +08:00
|
|
|
)
|
2021-01-15 15:28:54 +08:00
|
|
|
|
2021-10-04 17:14:07 +08:00
|
|
|
// Timestamp is an alias for the Int64 type
|
2021-04-15 15:15:46 +08:00
|
|
|
type Timestamp = typeutil.Timestamp
|
|
|
|
|
2021-02-18 16:26:02 +08:00
|
|
|
type queryChannelInfo struct {
|
|
|
|
requestChannel string
|
|
|
|
responseChannel string
|
|
|
|
}
|
|
|
|
|
2021-10-05 15:34:26 +08:00
|
|
|
// QueryCoord is the coordinator of queryNodes
|
2021-06-22 16:44:09 +08:00
|
|
|
type QueryCoord struct {
|
2021-01-22 14:28:06 +08:00
|
|
|
loopCtx context.Context
|
|
|
|
loopCancel context.CancelFunc
|
2021-06-19 11:45:09 +08:00
|
|
|
loopWg sync.WaitGroup
|
|
|
|
kvClient *etcdkv.EtcdKV
|
2021-01-22 14:28:06 +08:00
|
|
|
|
2021-09-23 21:56:02 +08:00
|
|
|
initOnce sync.Once
|
|
|
|
|
2021-06-22 16:44:09 +08:00
|
|
|
queryCoordID uint64
|
2021-08-02 22:39:25 +08:00
|
|
|
meta Meta
|
2021-09-15 20:40:07 +08:00
|
|
|
cluster Cluster
|
2021-08-26 14:17:54 +08:00
|
|
|
newNodeFn newQueryNodeFn
|
2021-06-22 16:44:09 +08:00
|
|
|
scheduler *TaskScheduler
|
2021-01-22 14:28:06 +08:00
|
|
|
|
2021-09-03 17:15:26 +08:00
|
|
|
metricsCacheManager *metricsinfo.MetricsCacheManager
|
|
|
|
|
2021-06-21 18:22:13 +08:00
|
|
|
dataCoordClient types.DataCoord
|
|
|
|
rootCoordClient types.RootCoord
|
2021-01-22 14:28:06 +08:00
|
|
|
|
2021-06-19 11:45:09 +08:00
|
|
|
session *sessionutil.Session
|
2021-09-23 18:29:55 +08:00
|
|
|
liveCh <-chan bool
|
2021-06-19 11:45:09 +08:00
|
|
|
eventChan <-chan *sessionutil.SessionEvent
|
2021-05-21 19:28:52 +08:00
|
|
|
|
2021-01-26 15:13:20 +08:00
|
|
|
stateCode atomic.Value
|
|
|
|
enableGrpc bool
|
2021-02-08 14:30:54 +08:00
|
|
|
|
|
|
|
msFactory msgstream.Factory
|
2021-01-22 14:28:06 +08:00
|
|
|
}
|
|
|
|
|
2021-05-25 15:06:05 +08:00
|
|
|
// Register register query service at etcd
|
2021-06-22 16:44:09 +08:00
|
|
|
func (qc *QueryCoord) Register() error {
|
2021-07-13 14:16:00 +08:00
|
|
|
log.Debug("query coord session info", zap.String("metaPath", Params.MetaRootPath), zap.Strings("etcdEndPoints", Params.EtcdEndpoints), zap.String("address", Params.Address))
|
2021-06-22 16:44:09 +08:00
|
|
|
qc.session = sessionutil.NewSession(qc.loopCtx, Params.MetaRootPath, Params.EtcdEndpoints)
|
2021-09-23 18:29:55 +08:00
|
|
|
qc.liveCh = qc.session.Init(typeutil.QueryCoordRole, Params.Address, true)
|
2021-06-22 16:44:09 +08:00
|
|
|
Params.NodeID = uint64(qc.session.ServerID)
|
2021-10-01 08:52:50 +08:00
|
|
|
Params.SetLogger(typeutil.UniqueID(-1))
|
2021-05-25 15:06:05 +08:00
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2021-06-22 16:44:09 +08:00
|
|
|
func (qc *QueryCoord) Init() error {
|
2021-06-19 11:45:09 +08:00
|
|
|
connectEtcdFn := func() error {
|
2021-08-13 11:04:09 +08:00
|
|
|
etcdKV, err := etcdkv.NewEtcdKV(Params.EtcdEndpoints, Params.MetaRootPath)
|
2021-06-19 11:45:09 +08:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
2021-06-22 16:44:09 +08:00
|
|
|
qc.kvClient = etcdKV
|
2021-08-03 22:03:25 +08:00
|
|
|
return nil
|
2021-06-19 11:45:09 +08:00
|
|
|
}
|
2021-09-23 21:56:02 +08:00
|
|
|
var initError error = nil
|
|
|
|
qc.initOnce.Do(func() {
|
|
|
|
log.Debug("query coordinator try to connect etcd")
|
|
|
|
initError = retry.Do(qc.loopCtx, connectEtcdFn, retry.Attempts(300))
|
|
|
|
if initError != nil {
|
|
|
|
log.Debug("query coordinator try to connect etcd failed", zap.Error(initError))
|
|
|
|
return
|
|
|
|
}
|
|
|
|
log.Debug("query coordinator try to connect etcd success")
|
|
|
|
qc.meta, initError = newMeta(qc.kvClient)
|
|
|
|
if initError != nil {
|
|
|
|
log.Error("query coordinator init meta failed", zap.Error(initError))
|
|
|
|
return
|
|
|
|
}
|
2021-08-03 22:03:25 +08:00
|
|
|
|
2021-09-23 21:56:02 +08:00
|
|
|
qc.cluster, initError = newQueryNodeCluster(qc.loopCtx, qc.meta, qc.kvClient, qc.newNodeFn, qc.session)
|
|
|
|
if initError != nil {
|
|
|
|
log.Error("query coordinator init cluster failed", zap.Error(initError))
|
|
|
|
return
|
|
|
|
}
|
2021-08-03 22:03:25 +08:00
|
|
|
|
2021-09-23 21:56:02 +08:00
|
|
|
qc.scheduler, initError = NewTaskScheduler(qc.loopCtx, qc.meta, qc.cluster, qc.kvClient, qc.rootCoordClient, qc.dataCoordClient)
|
|
|
|
if initError != nil {
|
|
|
|
log.Error("query coordinator init task scheduler failed", zap.Error(initError))
|
|
|
|
return
|
|
|
|
}
|
2021-08-03 22:03:25 +08:00
|
|
|
|
2021-09-23 21:56:02 +08:00
|
|
|
qc.metricsCacheManager = metricsinfo.NewMetricsCacheManager()
|
|
|
|
})
|
2021-09-03 17:15:26 +08:00
|
|
|
|
2021-09-23 21:56:02 +08:00
|
|
|
return initError
|
2021-01-22 14:28:06 +08:00
|
|
|
}
|
|
|
|
|
2021-06-22 16:44:09 +08:00
|
|
|
func (qc *QueryCoord) Start() error {
|
|
|
|
qc.scheduler.Start()
|
2021-04-15 15:15:46 +08:00
|
|
|
log.Debug("start scheduler ...")
|
2021-06-22 16:44:09 +08:00
|
|
|
qc.UpdateStateCode(internalpb.StateCode_Healthy)
|
2021-06-19 11:45:09 +08:00
|
|
|
|
2021-06-22 16:44:09 +08:00
|
|
|
qc.loopWg.Add(1)
|
|
|
|
go qc.watchNodeLoop()
|
2021-06-19 11:45:09 +08:00
|
|
|
|
2021-06-22 16:44:09 +08:00
|
|
|
qc.loopWg.Add(1)
|
|
|
|
go qc.watchMetaLoop()
|
2021-06-19 11:45:09 +08:00
|
|
|
|
2021-09-23 18:29:55 +08:00
|
|
|
go qc.session.LivenessCheck(qc.loopCtx, qc.liveCh, func() {
|
|
|
|
qc.Stop()
|
|
|
|
})
|
|
|
|
|
2021-01-22 14:28:06 +08:00
|
|
|
return nil
|
2021-01-16 15:31:10 +08:00
|
|
|
}
|
|
|
|
|
2021-06-22 16:44:09 +08:00
|
|
|
func (qc *QueryCoord) Stop() error {
|
|
|
|
qc.scheduler.Close()
|
2021-04-15 15:15:46 +08:00
|
|
|
log.Debug("close scheduler ...")
|
2021-06-22 16:44:09 +08:00
|
|
|
qc.loopCancel()
|
|
|
|
qc.UpdateStateCode(internalpb.StateCode_Abnormal)
|
2021-06-19 11:45:09 +08:00
|
|
|
|
2021-06-22 16:44:09 +08:00
|
|
|
qc.loopWg.Wait()
|
2021-01-22 14:28:06 +08:00
|
|
|
return nil
|
2021-01-16 15:31:10 +08:00
|
|
|
}
|
|
|
|
|
2021-06-22 16:44:09 +08:00
|
|
|
func (qc *QueryCoord) UpdateStateCode(code internalpb.StateCode) {
|
|
|
|
qc.stateCode.Store(code)
|
2021-02-23 11:40:30 +08:00
|
|
|
}
|
|
|
|
|
2021-06-22 16:44:09 +08:00
|
|
|
func NewQueryCoord(ctx context.Context, factory msgstream.Factory) (*QueryCoord, error) {
|
2021-03-08 15:25:55 +08:00
|
|
|
rand.Seed(time.Now().UnixNano())
|
2021-02-18 16:26:02 +08:00
|
|
|
queryChannels := make([]*queryChannelInfo, 0)
|
2021-06-03 14:58:34 +08:00
|
|
|
channelID := len(queryChannels)
|
|
|
|
searchPrefix := Params.SearchChannelPrefix
|
|
|
|
searchResultPrefix := Params.SearchResultChannelPrefix
|
|
|
|
allocatedQueryChannel := searchPrefix + "-" + strconv.FormatInt(int64(channelID), 10)
|
|
|
|
allocatedQueryResultChannel := searchResultPrefix + "-" + strconv.FormatInt(int64(channelID), 10)
|
|
|
|
|
|
|
|
queryChannels = append(queryChannels, &queryChannelInfo{
|
|
|
|
requestChannel: allocatedQueryChannel,
|
|
|
|
responseChannel: allocatedQueryResultChannel,
|
|
|
|
})
|
|
|
|
|
2021-01-22 14:28:06 +08:00
|
|
|
ctx1, cancel := context.WithCancel(ctx)
|
2021-06-22 16:44:09 +08:00
|
|
|
service := &QueryCoord{
|
2021-06-15 12:41:40 +08:00
|
|
|
loopCtx: ctx1,
|
|
|
|
loopCancel: cancel,
|
|
|
|
msFactory: factory,
|
2021-08-26 14:17:54 +08:00
|
|
|
newNodeFn: newQueryNode,
|
2021-01-22 14:28:06 +08:00
|
|
|
}
|
2021-02-24 09:48:17 +08:00
|
|
|
|
2021-03-12 14:22:09 +08:00
|
|
|
service.UpdateStateCode(internalpb.StateCode_Abnormal)
|
2021-06-22 16:44:09 +08:00
|
|
|
log.Debug("query coordinator", zap.Any("queryChannels", queryChannels))
|
2021-01-22 14:28:06 +08:00
|
|
|
return service, nil
|
2021-01-15 15:28:54 +08:00
|
|
|
}
|
2021-01-26 15:13:20 +08:00
|
|
|
|
2021-06-22 16:44:09 +08:00
|
|
|
func (qc *QueryCoord) SetRootCoord(rootCoord types.RootCoord) {
|
|
|
|
qc.rootCoordClient = rootCoord
|
2021-01-26 15:13:20 +08:00
|
|
|
}
|
|
|
|
|
2021-06-22 16:44:09 +08:00
|
|
|
func (qc *QueryCoord) SetDataCoord(dataCoord types.DataCoord) {
|
|
|
|
qc.dataCoordClient = dataCoord
|
2021-01-26 15:13:20 +08:00
|
|
|
}
|
2021-06-19 11:45:09 +08:00
|
|
|
|
2021-06-22 16:44:09 +08:00
|
|
|
func (qc *QueryCoord) watchNodeLoop() {
|
|
|
|
ctx, cancel := context.WithCancel(qc.loopCtx)
|
2021-06-19 11:45:09 +08:00
|
|
|
defer cancel()
|
2021-06-22 16:44:09 +08:00
|
|
|
defer qc.loopWg.Done()
|
|
|
|
log.Debug("query coordinator start watch node loop")
|
2021-06-19 11:45:09 +08:00
|
|
|
|
2021-09-15 20:40:07 +08:00
|
|
|
offlineNodes, err := qc.cluster.offlineNodes()
|
|
|
|
if err == nil {
|
|
|
|
offlineNodeIDs := make([]int64, 0)
|
|
|
|
for id := range offlineNodes {
|
|
|
|
offlineNodeIDs = append(offlineNodeIDs, id)
|
|
|
|
}
|
|
|
|
loadBalanceSegment := &querypb.LoadBalanceRequest{
|
|
|
|
Base: &commonpb.MsgBase{
|
|
|
|
MsgType: commonpb.MsgType_LoadBalanceSegments,
|
|
|
|
SourceID: qc.session.ServerID,
|
|
|
|
},
|
|
|
|
SourceNodeIDs: offlineNodeIDs,
|
2021-06-19 11:45:09 +08:00
|
|
|
}
|
|
|
|
|
2021-09-15 20:40:07 +08:00
|
|
|
loadBalanceTask := &LoadBalanceTask{
|
|
|
|
BaseTask: BaseTask{
|
|
|
|
ctx: qc.loopCtx,
|
|
|
|
Condition: NewTaskCondition(qc.loopCtx),
|
|
|
|
triggerCondition: querypb.TriggerCondition_nodeDown,
|
|
|
|
},
|
|
|
|
LoadBalanceRequest: loadBalanceSegment,
|
|
|
|
rootCoord: qc.rootCoordClient,
|
|
|
|
dataCoord: qc.dataCoordClient,
|
|
|
|
cluster: qc.cluster,
|
|
|
|
meta: qc.meta,
|
2021-06-19 11:45:09 +08:00
|
|
|
}
|
2021-09-15 20:40:07 +08:00
|
|
|
qc.scheduler.Enqueue([]task{loadBalanceTask})
|
|
|
|
log.Debug("start a loadBalance task", zap.Any("task", loadBalanceTask))
|
2021-06-19 11:45:09 +08:00
|
|
|
}
|
|
|
|
|
2021-09-15 20:40:07 +08:00
|
|
|
qc.eventChan = qc.session.WatchServices(typeutil.QueryNodeRole, qc.cluster.getSessionVersion()+1)
|
2021-06-19 11:45:09 +08:00
|
|
|
for {
|
|
|
|
select {
|
|
|
|
case <-ctx.Done():
|
|
|
|
return
|
2021-06-22 16:44:09 +08:00
|
|
|
case event := <-qc.eventChan:
|
2021-06-19 11:45:09 +08:00
|
|
|
switch event.EventType {
|
|
|
|
case sessionutil.SessionAddEvent:
|
|
|
|
serverID := event.Session.ServerID
|
2021-07-13 14:16:00 +08:00
|
|
|
log.Debug("start add a queryNode to cluster", zap.Any("nodeID", serverID))
|
2021-09-15 20:40:07 +08:00
|
|
|
err := qc.cluster.registerNode(ctx, event.Session, serverID, disConnect)
|
2021-07-13 14:16:00 +08:00
|
|
|
if err != nil {
|
|
|
|
log.Error("query node failed to register", zap.Int64("nodeID", serverID), zap.String("error info", err.Error()))
|
|
|
|
}
|
2021-09-03 17:15:26 +08:00
|
|
|
qc.metricsCacheManager.InvalidateSystemInfoMetrics()
|
2021-06-19 11:45:09 +08:00
|
|
|
case sessionutil.SessionDelEvent:
|
|
|
|
serverID := event.Session.ServerID
|
2021-07-13 14:16:00 +08:00
|
|
|
log.Debug("get a del event after queryNode down", zap.Int64("nodeID", serverID))
|
|
|
|
_, err := qc.cluster.getNodeByID(serverID)
|
|
|
|
if err != nil {
|
|
|
|
log.Error("queryNode not exist", zap.Int64("nodeID", serverID))
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
|
|
|
qc.cluster.stopNode(serverID)
|
|
|
|
loadBalanceSegment := &querypb.LoadBalanceRequest{
|
|
|
|
Base: &commonpb.MsgBase{
|
|
|
|
MsgType: commonpb.MsgType_LoadBalanceSegments,
|
|
|
|
SourceID: qc.session.ServerID,
|
|
|
|
},
|
|
|
|
SourceNodeIDs: []int64{serverID},
|
|
|
|
BalanceReason: querypb.TriggerCondition_nodeDown,
|
|
|
|
}
|
|
|
|
|
|
|
|
loadBalanceTask := &LoadBalanceTask{
|
|
|
|
BaseTask: BaseTask{
|
|
|
|
ctx: qc.loopCtx,
|
|
|
|
Condition: NewTaskCondition(qc.loopCtx),
|
|
|
|
triggerCondition: querypb.TriggerCondition_nodeDown,
|
|
|
|
},
|
|
|
|
LoadBalanceRequest: loadBalanceSegment,
|
|
|
|
rootCoord: qc.rootCoordClient,
|
|
|
|
dataCoord: qc.dataCoordClient,
|
|
|
|
cluster: qc.cluster,
|
|
|
|
meta: qc.meta,
|
2021-06-27 12:16:09 +08:00
|
|
|
}
|
2021-07-13 14:16:00 +08:00
|
|
|
qc.scheduler.Enqueue([]task{loadBalanceTask})
|
2021-09-15 20:40:07 +08:00
|
|
|
log.Debug("start a loadBalance task", zap.Any("task", loadBalanceTask))
|
2021-09-03 17:15:26 +08:00
|
|
|
qc.metricsCacheManager.InvalidateSystemInfoMetrics()
|
2021-06-19 11:45:09 +08:00
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2021-06-22 16:44:09 +08:00
|
|
|
func (qc *QueryCoord) watchMetaLoop() {
|
|
|
|
ctx, cancel := context.WithCancel(qc.loopCtx)
|
2021-06-19 11:45:09 +08:00
|
|
|
|
|
|
|
defer cancel()
|
2021-06-22 16:44:09 +08:00
|
|
|
defer qc.loopWg.Done()
|
2021-08-02 22:39:25 +08:00
|
|
|
log.Debug("query coordinator start watch MetaReplica loop")
|
2021-06-19 11:45:09 +08:00
|
|
|
|
2021-08-02 22:39:25 +08:00
|
|
|
watchChan := qc.kvClient.WatchWithPrefix("queryNode-segmentMeta")
|
2021-06-19 11:45:09 +08:00
|
|
|
|
|
|
|
for {
|
|
|
|
select {
|
|
|
|
case <-ctx.Done():
|
|
|
|
return
|
|
|
|
case resp := <-watchChan:
|
2021-08-02 22:39:25 +08:00
|
|
|
log.Debug("segment MetaReplica updated.")
|
2021-06-19 11:45:09 +08:00
|
|
|
for _, event := range resp.Events {
|
|
|
|
segmentID, err := strconv.ParseInt(filepath.Base(string(event.Kv.Key)), 10, 64)
|
|
|
|
if err != nil {
|
2021-08-02 22:39:25 +08:00
|
|
|
log.Error("watch MetaReplica loop error when get segmentID", zap.Any("error", err.Error()))
|
2021-06-19 11:45:09 +08:00
|
|
|
}
|
|
|
|
segmentInfo := &querypb.SegmentInfo{}
|
2021-09-29 20:26:00 +08:00
|
|
|
err = proto.Unmarshal(event.Kv.Value, segmentInfo)
|
2021-06-19 11:45:09 +08:00
|
|
|
if err != nil {
|
2021-08-02 22:39:25 +08:00
|
|
|
log.Error("watch MetaReplica loop error when unmarshal", zap.Any("error", err.Error()))
|
2021-06-19 11:45:09 +08:00
|
|
|
}
|
|
|
|
switch event.Type {
|
|
|
|
case mvccpb.PUT:
|
|
|
|
//TODO::
|
2021-06-22 16:44:09 +08:00
|
|
|
qc.meta.setSegmentInfo(segmentID, segmentInfo)
|
2021-06-19 11:45:09 +08:00
|
|
|
case mvccpb.DELETE:
|
|
|
|
//TODO::
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
}
|