2021-11-10 23:56:17 +08:00
|
|
|
// Licensed to the LF AI & Data foundation under one
|
|
|
|
// or more contributor license agreements. See the NOTICE file
|
|
|
|
// distributed with this work for additional information
|
|
|
|
// regarding copyright ownership. The ASF licenses this file
|
|
|
|
// to you under the Apache License, Version 2.0 (the
|
|
|
|
// "License"); you may not use this file except in compliance
|
2021-08-31 10:33:58 +08:00
|
|
|
// with the License. You may obtain a copy of the License at
|
|
|
|
//
|
2021-11-10 23:56:17 +08:00
|
|
|
// http://www.apache.org/licenses/LICENSE-2.0
|
2021-08-31 10:33:58 +08:00
|
|
|
//
|
2021-11-10 23:56:17 +08:00
|
|
|
// 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-08-31 10:33:58 +08:00
|
|
|
|
|
|
|
package proxy
|
|
|
|
|
|
|
|
import (
|
|
|
|
"context"
|
2021-09-09 10:06:29 +08:00
|
|
|
"sync"
|
2021-08-31 10:33:58 +08:00
|
|
|
"time"
|
|
|
|
|
2023-09-26 09:57:25 +08:00
|
|
|
"google.golang.org/grpc"
|
|
|
|
|
2023-06-09 01:28:37 +08:00
|
|
|
"github.com/milvus-io/milvus-proto/go-api/v2/commonpb"
|
|
|
|
"github.com/milvus-io/milvus-proto/go-api/v2/schemapb"
|
2022-10-09 10:06:58 +08:00
|
|
|
"github.com/milvus-io/milvus/internal/allocator"
|
2021-08-31 10:33:58 +08:00
|
|
|
"github.com/milvus-io/milvus/internal/proto/rootcoordpb"
|
2024-06-25 21:18:15 +08:00
|
|
|
"github.com/milvus-io/milvus/pkg/mq/common"
|
2023-04-06 19:14:32 +08:00
|
|
|
"github.com/milvus-io/milvus/pkg/mq/msgstream"
|
|
|
|
"github.com/milvus-io/milvus/pkg/util/funcutil"
|
2023-09-20 10:57:23 +08:00
|
|
|
"github.com/milvus-io/milvus/pkg/util/merr"
|
2023-04-06 19:14:32 +08:00
|
|
|
"github.com/milvus-io/milvus/pkg/util/paramtable"
|
2024-05-14 14:33:33 +08:00
|
|
|
"github.com/milvus-io/milvus/pkg/util/testutils"
|
2023-04-06 19:14:32 +08:00
|
|
|
"github.com/milvus-io/milvus/pkg/util/uniquegenerator"
|
2021-08-31 10:33:58 +08:00
|
|
|
)
|
|
|
|
|
|
|
|
type mockTimestampAllocatorInterface struct {
|
2021-09-09 10:06:29 +08:00
|
|
|
lastTs Timestamp
|
|
|
|
mtx sync.Mutex
|
2021-08-31 10:33:58 +08:00
|
|
|
}
|
|
|
|
|
2023-09-26 09:57:25 +08:00
|
|
|
func (tso *mockTimestampAllocatorInterface) AllocTimestamp(ctx context.Context, req *rootcoordpb.AllocTimestampRequest, opts ...grpc.CallOption) (*rootcoordpb.AllocTimestampResponse, error) {
|
2021-09-09 10:06:29 +08:00
|
|
|
tso.mtx.Lock()
|
|
|
|
defer tso.mtx.Unlock()
|
|
|
|
|
|
|
|
ts := uint64(time.Now().UnixNano())
|
|
|
|
if ts < tso.lastTs+Timestamp(req.Count) {
|
|
|
|
ts = tso.lastTs + Timestamp(req.Count)
|
|
|
|
}
|
|
|
|
|
|
|
|
tso.lastTs = ts
|
2021-08-31 10:33:58 +08:00
|
|
|
return &rootcoordpb.AllocTimestampResponse{
|
2023-10-11 21:01:35 +08:00
|
|
|
Status: merr.Success(),
|
2021-09-09 10:06:29 +08:00
|
|
|
Timestamp: ts,
|
2021-08-31 10:33:58 +08:00
|
|
|
Count: req.Count,
|
|
|
|
}, nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func newMockTimestampAllocatorInterface() timestampAllocatorInterface {
|
2021-09-09 10:06:29 +08:00
|
|
|
return &mockTimestampAllocatorInterface{
|
|
|
|
lastTs: Timestamp(time.Now().UnixNano()),
|
|
|
|
}
|
2021-08-31 10:33:58 +08:00
|
|
|
}
|
2021-09-06 20:49:04 +08:00
|
|
|
|
|
|
|
type mockTsoAllocator struct {
|
2023-03-15 11:17:55 +08:00
|
|
|
mu sync.Mutex
|
|
|
|
logicPart uint32
|
2021-09-06 20:49:04 +08:00
|
|
|
}
|
|
|
|
|
2023-03-09 18:51:52 +08:00
|
|
|
func (tso *mockTsoAllocator) AllocOne(ctx context.Context) (Timestamp, error) {
|
2023-03-15 11:17:55 +08:00
|
|
|
tso.mu.Lock()
|
|
|
|
defer tso.mu.Unlock()
|
|
|
|
tso.logicPart++
|
|
|
|
physical := uint64(time.Now().UnixMilli())
|
|
|
|
return (physical << 18) + uint64(tso.logicPart), nil
|
2021-09-06 20:49:04 +08:00
|
|
|
}
|
|
|
|
|
|
|
|
func newMockTsoAllocator() tsoAllocator {
|
|
|
|
return &mockTsoAllocator{}
|
|
|
|
}
|
|
|
|
|
2023-09-21 09:45:27 +08:00
|
|
|
type mockIDAllocatorInterface struct{}
|
2021-09-06 20:49:04 +08:00
|
|
|
|
|
|
|
func (m *mockIDAllocatorInterface) AllocOne() (UniqueID, error) {
|
2021-09-09 10:06:29 +08:00
|
|
|
return UniqueID(uniquegenerator.GetUniqueIntGeneratorIns().GetInt()), nil
|
2021-09-06 20:49:04 +08:00
|
|
|
}
|
|
|
|
|
2022-10-09 10:06:58 +08:00
|
|
|
func (m *mockIDAllocatorInterface) Alloc(count uint32) (UniqueID, UniqueID, error) {
|
|
|
|
return UniqueID(uniquegenerator.GetUniqueIntGeneratorIns().GetInt()), UniqueID(uniquegenerator.GetUniqueIntGeneratorIns().GetInt() + int(count)), nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func newMockIDAllocatorInterface() allocator.Interface {
|
2021-09-06 20:49:04 +08:00
|
|
|
return &mockIDAllocatorInterface{}
|
|
|
|
}
|
|
|
|
|
|
|
|
type mockTask struct {
|
2024-07-23 14:23:52 +08:00
|
|
|
baseTask
|
2021-09-06 20:49:04 +08:00
|
|
|
*TaskCondition
|
|
|
|
id UniqueID
|
|
|
|
name string
|
|
|
|
tType commonpb.MsgType
|
|
|
|
ts Timestamp
|
|
|
|
}
|
|
|
|
|
2024-02-21 09:52:59 +08:00
|
|
|
func (m *mockTask) CanSkipAllocTimestamp() bool {
|
|
|
|
return false
|
|
|
|
}
|
|
|
|
|
2021-09-06 20:49:04 +08:00
|
|
|
func (m *mockTask) TraceCtx() context.Context {
|
|
|
|
return m.TaskCondition.ctx
|
|
|
|
}
|
|
|
|
|
|
|
|
func (m *mockTask) ID() UniqueID {
|
|
|
|
return m.id
|
|
|
|
}
|
|
|
|
|
|
|
|
func (m *mockTask) SetID(uid UniqueID) {
|
|
|
|
m.id = uid
|
|
|
|
}
|
|
|
|
|
|
|
|
func (m *mockTask) Name() string {
|
|
|
|
return m.name
|
|
|
|
}
|
|
|
|
|
|
|
|
func (m *mockTask) Type() commonpb.MsgType {
|
|
|
|
return m.tType
|
|
|
|
}
|
|
|
|
|
|
|
|
func (m *mockTask) BeginTs() Timestamp {
|
|
|
|
return m.ts
|
|
|
|
}
|
|
|
|
|
|
|
|
func (m *mockTask) EndTs() Timestamp {
|
|
|
|
return m.ts
|
|
|
|
}
|
|
|
|
|
|
|
|
func (m *mockTask) SetTs(ts Timestamp) {
|
|
|
|
m.ts = ts
|
|
|
|
}
|
|
|
|
|
|
|
|
func (m *mockTask) OnEnqueue() error {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func (m *mockTask) PreExecute(ctx context.Context) error {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func (m *mockTask) Execute(ctx context.Context) error {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func (m *mockTask) PostExecute(ctx context.Context) error {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func newMockTask(ctx context.Context) *mockTask {
|
|
|
|
return &mockTask{
|
|
|
|
TaskCondition: NewTaskCondition(ctx),
|
2021-09-09 10:06:29 +08:00
|
|
|
id: UniqueID(uniquegenerator.GetUniqueIntGeneratorIns().GetInt()),
|
|
|
|
name: funcutil.GenRandomStr(),
|
2021-09-06 20:49:04 +08:00
|
|
|
tType: commonpb.MsgType_Undefined,
|
|
|
|
ts: Timestamp(time.Now().Nanosecond()),
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
func newDefaultMockTask() *mockTask {
|
|
|
|
return newMockTask(context.Background())
|
|
|
|
}
|
|
|
|
|
|
|
|
type mockDdlTask struct {
|
|
|
|
*mockTask
|
|
|
|
}
|
|
|
|
|
|
|
|
func newMockDdlTask(ctx context.Context) *mockDdlTask {
|
|
|
|
return &mockDdlTask{
|
|
|
|
mockTask: newMockTask(ctx),
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
func newDefaultMockDdlTask() *mockDdlTask {
|
|
|
|
return newMockDdlTask(context.Background())
|
|
|
|
}
|
|
|
|
|
|
|
|
type mockDmlTask struct {
|
|
|
|
*mockTask
|
|
|
|
vchans []vChan
|
|
|
|
pchans []pChan
|
|
|
|
}
|
|
|
|
|
2023-06-16 16:36:40 +08:00
|
|
|
func (m *mockDmlTask) setChannels() error {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func (m *mockDmlTask) getChannels() []vChan {
|
|
|
|
return m.vchans
|
2021-09-06 20:49:04 +08:00
|
|
|
}
|
|
|
|
|
|
|
|
func newMockDmlTask(ctx context.Context) *mockDmlTask {
|
|
|
|
shardNum := 2
|
|
|
|
|
|
|
|
vchans := make([]vChan, 0, shardNum)
|
|
|
|
pchans := make([]pChan, 0, shardNum)
|
|
|
|
|
|
|
|
for i := 0; i < shardNum; i++ {
|
2021-09-09 10:06:29 +08:00
|
|
|
vchans = append(vchans, funcutil.GenRandomStr())
|
|
|
|
pchans = append(pchans, funcutil.GenRandomStr())
|
2021-09-06 20:49:04 +08:00
|
|
|
}
|
|
|
|
|
|
|
|
return &mockDmlTask{
|
|
|
|
mockTask: newMockTask(ctx),
|
2023-09-19 10:05:22 +08:00
|
|
|
vchans: vchans,
|
|
|
|
pchans: pchans,
|
2021-09-06 20:49:04 +08:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
func newDefaultMockDmlTask() *mockDmlTask {
|
|
|
|
return newMockDmlTask(context.Background())
|
|
|
|
}
|
|
|
|
|
|
|
|
type mockDqlTask struct {
|
|
|
|
*mockTask
|
|
|
|
}
|
|
|
|
|
|
|
|
func newMockDqlTask(ctx context.Context) *mockDqlTask {
|
|
|
|
return &mockDqlTask{
|
|
|
|
mockTask: newMockTask(ctx),
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
func newDefaultMockDqlTask() *mockDqlTask {
|
|
|
|
return newMockDqlTask(context.Background())
|
|
|
|
}
|
2021-09-09 19:02:08 +08:00
|
|
|
|
|
|
|
type simpleMockMsgStream struct {
|
|
|
|
msgChan chan *msgstream.MsgPack
|
|
|
|
|
|
|
|
msgCount int
|
|
|
|
msgCountMtx sync.RWMutex
|
|
|
|
}
|
|
|
|
|
|
|
|
func (ms *simpleMockMsgStream) Close() {
|
|
|
|
}
|
|
|
|
|
|
|
|
func (ms *simpleMockMsgStream) Chan() <-chan *msgstream.MsgPack {
|
2022-03-11 20:09:59 +08:00
|
|
|
if ms.getMsgCount() <= 0 {
|
|
|
|
ms.msgChan <- nil
|
|
|
|
return ms.msgChan
|
|
|
|
}
|
|
|
|
|
|
|
|
defer ms.decreaseMsgCount(1)
|
|
|
|
|
2021-09-09 19:02:08 +08:00
|
|
|
return ms.msgChan
|
|
|
|
}
|
|
|
|
|
|
|
|
func (ms *simpleMockMsgStream) AsProducer(channels []string) {
|
|
|
|
}
|
|
|
|
|
2024-06-25 21:18:15 +08:00
|
|
|
func (ms *simpleMockMsgStream) AsConsumer(ctx context.Context, channels []string, subName string, position common.SubscriptionInitialPosition) error {
|
2023-09-08 09:51:17 +08:00
|
|
|
return nil
|
2021-10-15 11:46:33 +08:00
|
|
|
}
|
|
|
|
|
2021-09-09 19:02:08 +08:00
|
|
|
func (ms *simpleMockMsgStream) SetRepackFunc(repackFunc msgstream.RepackFunc) {
|
|
|
|
}
|
|
|
|
|
|
|
|
func (ms *simpleMockMsgStream) getMsgCount() int {
|
|
|
|
ms.msgCountMtx.RLock()
|
|
|
|
defer ms.msgCountMtx.RUnlock()
|
|
|
|
|
|
|
|
return ms.msgCount
|
|
|
|
}
|
|
|
|
|
|
|
|
func (ms *simpleMockMsgStream) increaseMsgCount(delta int) {
|
|
|
|
ms.msgCountMtx.Lock()
|
|
|
|
defer ms.msgCountMtx.Unlock()
|
|
|
|
|
|
|
|
ms.msgCount += delta
|
|
|
|
}
|
|
|
|
|
|
|
|
func (ms *simpleMockMsgStream) decreaseMsgCount(delta int) {
|
|
|
|
ms.increaseMsgCount(-delta)
|
|
|
|
}
|
|
|
|
|
|
|
|
func (ms *simpleMockMsgStream) Produce(pack *msgstream.MsgPack) error {
|
|
|
|
defer ms.increaseMsgCount(1)
|
|
|
|
|
|
|
|
ms.msgChan <- pack
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2022-12-05 20:55:17 +08:00
|
|
|
func (ms *simpleMockMsgStream) Broadcast(pack *msgstream.MsgPack) (map[string][]msgstream.MessageID, error) {
|
2021-09-27 14:10:09 +08:00
|
|
|
return map[string][]msgstream.MessageID{}, nil
|
|
|
|
}
|
|
|
|
|
2021-09-09 19:02:08 +08:00
|
|
|
func (ms *simpleMockMsgStream) GetProduceChannels() []string {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2024-05-27 10:31:41 +08:00
|
|
|
func (ms *simpleMockMsgStream) Seek(ctx context.Context, msgPositions []*msgstream.MsgPosition, includeCurrentMsg bool) error {
|
2021-09-09 19:02:08 +08:00
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2022-03-15 14:45:22 +08:00
|
|
|
func (ms *simpleMockMsgStream) GetLatestMsgID(channel string) (msgstream.MessageID, error) {
|
|
|
|
return nil, nil
|
|
|
|
}
|
|
|
|
|
2023-04-03 16:44:23 +08:00
|
|
|
func (ms *simpleMockMsgStream) CheckTopicValid(topic string) error {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2023-10-20 14:26:09 +08:00
|
|
|
func (ms *simpleMockMsgStream) EnableProduce(enabled bool) {
|
|
|
|
}
|
|
|
|
|
2021-09-09 19:02:08 +08:00
|
|
|
func newSimpleMockMsgStream() *simpleMockMsgStream {
|
|
|
|
return &simpleMockMsgStream{
|
|
|
|
msgChan: make(chan *msgstream.MsgPack, 1024),
|
|
|
|
msgCount: 0,
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2023-09-21 09:45:27 +08:00
|
|
|
type simpleMockMsgStreamFactory struct{}
|
2021-09-09 19:02:08 +08:00
|
|
|
|
2022-03-24 10:15:25 +08:00
|
|
|
func (factory *simpleMockMsgStreamFactory) Init(param *paramtable.ComponentParam) error {
|
2021-09-09 19:02:08 +08:00
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func (factory *simpleMockMsgStreamFactory) NewMsgStream(ctx context.Context) (msgstream.MsgStream, error) {
|
|
|
|
return newSimpleMockMsgStream(), nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func (factory *simpleMockMsgStreamFactory) NewTtMsgStream(ctx context.Context) (msgstream.MsgStream, error) {
|
|
|
|
return newSimpleMockMsgStream(), nil
|
|
|
|
}
|
|
|
|
|
2022-06-16 17:28:11 +08:00
|
|
|
func (factory *simpleMockMsgStreamFactory) NewMsgStreamDisposer(ctx context.Context) func([]string, string) error {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2021-09-09 19:02:08 +08:00
|
|
|
func newSimpleMockMsgStreamFactory() *simpleMockMsgStreamFactory {
|
|
|
|
return &simpleMockMsgStreamFactory{}
|
|
|
|
}
|
2021-09-11 11:36:22 +08:00
|
|
|
|
2022-04-29 13:35:49 +08:00
|
|
|
func generateFieldData(dataType schemapb.DataType, fieldName string, numRows int) *schemapb.FieldData {
|
2024-05-14 14:33:33 +08:00
|
|
|
if dataType < 100 {
|
|
|
|
return testutils.GenerateScalarFieldData(dataType, fieldName, numRows)
|
2022-03-25 14:27:25 +08:00
|
|
|
}
|
2024-05-14 14:33:33 +08:00
|
|
|
return testutils.GenerateVectorFieldData(dataType, fieldName, numRows, testVecDim)
|
2022-03-25 14:27:25 +08:00
|
|
|
}
|
|
|
|
|
|
|
|
func newScalarFieldData(fieldSchema *schemapb.FieldSchema, fieldName string, numRows int) *schemapb.FieldData {
|
2024-05-14 14:33:33 +08:00
|
|
|
return testutils.GenerateScalarFieldData(fieldSchema.GetDataType(), fieldName, numRows)
|
2021-09-11 11:36:22 +08:00
|
|
|
}
|
|
|
|
|
|
|
|
func newFloatVectorFieldData(fieldName string, numRows, dim int) *schemapb.FieldData {
|
2024-05-14 14:33:33 +08:00
|
|
|
return testutils.NewFloatVectorFieldData(fieldName, numRows, dim)
|
2021-09-11 11:36:22 +08:00
|
|
|
}
|
|
|
|
|
|
|
|
func newBinaryVectorFieldData(fieldName string, numRows, dim int) *schemapb.FieldData {
|
2024-05-14 14:33:33 +08:00
|
|
|
return testutils.NewBinaryVectorFieldData(fieldName, numRows, dim)
|
2021-09-11 11:36:22 +08:00
|
|
|
}
|
|
|
|
|
2024-01-11 15:48:51 +08:00
|
|
|
func newFloat16VectorFieldData(fieldName string, numRows, dim int) *schemapb.FieldData {
|
2024-05-14 14:33:33 +08:00
|
|
|
return testutils.NewFloat16VectorFieldData(fieldName, numRows, dim)
|
2024-01-11 15:48:51 +08:00
|
|
|
}
|
|
|
|
|
|
|
|
func newBFloat16VectorFieldData(fieldName string, numRows, dim int) *schemapb.FieldData {
|
2024-05-14 14:33:33 +08:00
|
|
|
return testutils.NewBFloat16VectorFieldData(fieldName, numRows, dim)
|
2021-09-11 11:36:22 +08:00
|
|
|
}
|