mirror of https://github.com/milvus-io/milvus.git
Fix collectionName not found error
Signed-off-by: godchen <qingxiang.chen@zilliz.com>pull/4973/head^2
parent
07167f41e4
commit
c231f6da79
|
@ -457,7 +457,13 @@ func (t *ShowPartitionReqTask) IgnoreTimeStamp() bool {
|
||||||
}
|
}
|
||||||
|
|
||||||
func (t *ShowPartitionReqTask) Execute() error {
|
func (t *ShowPartitionReqTask) Execute() error {
|
||||||
coll, err := t.core.MetaTable.GetCollectionByName(t.Req.CollectionName)
|
var coll *etcdpb.CollectionInfo
|
||||||
|
var err error
|
||||||
|
if t.Req.CollectionName == "" {
|
||||||
|
coll, err = t.core.MetaTable.GetCollectionByID(t.Req.CollectionID)
|
||||||
|
} else {
|
||||||
|
coll, err = t.core.MetaTable.GetCollectionByName(t.Req.CollectionName)
|
||||||
|
}
|
||||||
if err != nil {
|
if err != nil {
|
||||||
return err
|
return err
|
||||||
}
|
}
|
||||||
|
|
|
@ -32,7 +32,6 @@ type QueryNodeStatsMsg = msgstream.QueryNodeStatsMsg
|
||||||
type RepackFunc = msgstream.RepackFunc
|
type RepackFunc = msgstream.RepackFunc
|
||||||
type Consumer = pulsar.Consumer
|
type Consumer = pulsar.Consumer
|
||||||
type Producer = pulsar.Producer
|
type Producer = pulsar.Producer
|
||||||
type MessageID = pulsar.MessageID
|
|
||||||
type UnmarshalDispatcher = msgstream.UnmarshalDispatcher
|
type UnmarshalDispatcher = msgstream.UnmarshalDispatcher
|
||||||
|
|
||||||
type PulsarMsgStream struct {
|
type PulsarMsgStream struct {
|
||||||
|
@ -47,8 +46,6 @@ type PulsarMsgStream struct {
|
||||||
wait *sync.WaitGroup
|
wait *sync.WaitGroup
|
||||||
streamCancel func()
|
streamCancel func()
|
||||||
pulsarBufSize int64
|
pulsarBufSize int64
|
||||||
consumerLock *sync.Mutex
|
|
||||||
consumerReflects []reflect.SelectCase
|
|
||||||
}
|
}
|
||||||
|
|
||||||
func newPulsarMsgStream(ctx context.Context,
|
func newPulsarMsgStream(ctx context.Context,
|
||||||
|
@ -61,30 +58,22 @@ func newPulsarMsgStream(ctx context.Context,
|
||||||
producers := make([]Producer, 0)
|
producers := make([]Producer, 0)
|
||||||
consumers := make([]Consumer, 0)
|
consumers := make([]Consumer, 0)
|
||||||
consumerChannels := make([]string, 0)
|
consumerChannels := make([]string, 0)
|
||||||
consumerReflects := make([]reflect.SelectCase, 0)
|
|
||||||
receiveBuf := make(chan *MsgPack, receiveBufSize)
|
|
||||||
|
|
||||||
client, err := pulsar.NewClient(pulsar.ClientOptions{URL: address})
|
|
||||||
if err != nil {
|
|
||||||
defer streamCancel()
|
|
||||||
log.Printf("Set pulsar client failed, error = %v", err)
|
|
||||||
return nil, err
|
|
||||||
}
|
|
||||||
|
|
||||||
stream := &PulsarMsgStream{
|
stream := &PulsarMsgStream{
|
||||||
ctx: streamCtx,
|
ctx: streamCtx,
|
||||||
client: client,
|
streamCancel: streamCancel,
|
||||||
producers: producers,
|
producers: producers,
|
||||||
consumers: consumers,
|
consumers: consumers,
|
||||||
consumerChannels: consumerChannels,
|
consumerChannels: consumerChannels,
|
||||||
unmarshal: unmarshal,
|
unmarshal: unmarshal,
|
||||||
pulsarBufSize: pulsarBufSize,
|
pulsarBufSize: pulsarBufSize,
|
||||||
receiveBuf: receiveBuf,
|
|
||||||
streamCancel: streamCancel,
|
|
||||||
consumerReflects: consumerReflects,
|
|
||||||
consumerLock: &sync.Mutex{},
|
|
||||||
}
|
}
|
||||||
|
client, err := pulsar.NewClient(pulsar.ClientOptions{URL: address})
|
||||||
|
if err != nil {
|
||||||
|
log.Printf("Set pulsar client failed, error = %v", err)
|
||||||
|
return nil, err
|
||||||
|
}
|
||||||
|
stream.client = client
|
||||||
|
stream.receiveBuf = make(chan *MsgPack, receiveBufSize)
|
||||||
return stream, nil
|
return stream, nil
|
||||||
}
|
}
|
||||||
|
|
||||||
|
@ -129,14 +118,7 @@ func (ms *PulsarMsgStream) AsConsumer(channels []string,
|
||||||
return errors.New("pulsar is not ready, consumer is nil")
|
return errors.New("pulsar is not ready, consumer is nil")
|
||||||
}
|
}
|
||||||
|
|
||||||
ms.consumerLock.Lock()
|
|
||||||
ms.consumers = append(ms.consumers, pc)
|
ms.consumers = append(ms.consumers, pc)
|
||||||
ms.consumerChannels = append(ms.consumerChannels, channels[i])
|
|
||||||
ms.consumerReflects = append(ms.consumerReflects, reflect.SelectCase{
|
|
||||||
Dir: reflect.SelectRecv,
|
|
||||||
Chan: reflect.ValueOf(pc.Chan()),
|
|
||||||
})
|
|
||||||
ms.consumerLock.Unlock()
|
|
||||||
return nil
|
return nil
|
||||||
}
|
}
|
||||||
err := util.Retry(10, time.Millisecond*200, fn)
|
err := util.Retry(10, time.Millisecond*200, fn)
|
||||||
|
@ -317,6 +299,12 @@ func (ms *PulsarMsgStream) Consume() *MsgPack {
|
||||||
func (ms *PulsarMsgStream) bufMsgPackToChannel() {
|
func (ms *PulsarMsgStream) bufMsgPackToChannel() {
|
||||||
defer ms.wait.Done()
|
defer ms.wait.Done()
|
||||||
|
|
||||||
|
cases := make([]reflect.SelectCase, len(ms.consumers))
|
||||||
|
for i := 0; i < len(ms.consumers); i++ {
|
||||||
|
ch := ms.consumers[i].Chan()
|
||||||
|
cases[i] = reflect.SelectCase{Dir: reflect.SelectRecv, Chan: reflect.ValueOf(ch)}
|
||||||
|
}
|
||||||
|
|
||||||
for {
|
for {
|
||||||
select {
|
select {
|
||||||
case <-ms.ctx.Done():
|
case <-ms.ctx.Done():
|
||||||
|
@ -326,9 +314,7 @@ func (ms *PulsarMsgStream) bufMsgPackToChannel() {
|
||||||
tsMsgList := make([]TsMsg, 0)
|
tsMsgList := make([]TsMsg, 0)
|
||||||
|
|
||||||
for {
|
for {
|
||||||
ms.consumerLock.Lock()
|
chosen, value, ok := reflect.Select(cases)
|
||||||
chosen, value, ok := reflect.Select(ms.consumerReflects)
|
|
||||||
ms.consumerLock.Unlock()
|
|
||||||
if !ok {
|
if !ok {
|
||||||
log.Printf("channel closed")
|
log.Printf("channel closed")
|
||||||
return
|
return
|
||||||
|
@ -353,11 +339,6 @@ func (ms *PulsarMsgStream) bufMsgPackToChannel() {
|
||||||
log.Printf("Failed to unmarshal tsMsg, error = %v", err)
|
log.Printf("Failed to unmarshal tsMsg, error = %v", err)
|
||||||
continue
|
continue
|
||||||
}
|
}
|
||||||
|
|
||||||
tsMsg.SetPosition(&msgstream.MsgPosition{
|
|
||||||
ChannelName: filepath.Base(pulsarMsg.Topic()),
|
|
||||||
MsgID: typeutil.PulsarMsgIDToString(pulsarMsg.ID()),
|
|
||||||
})
|
|
||||||
tsMsgList = append(tsMsgList, tsMsg)
|
tsMsgList = append(tsMsgList, tsMsg)
|
||||||
|
|
||||||
noMoreMessage := true
|
noMoreMessage := true
|
||||||
|
@ -405,7 +386,6 @@ func (ms *PulsarMsgStream) Seek(mp *internalpb2.MsgPosition) error {
|
||||||
type PulsarTtMsgStream struct {
|
type PulsarTtMsgStream struct {
|
||||||
PulsarMsgStream
|
PulsarMsgStream
|
||||||
unsolvedBuf map[Consumer][]TsMsg
|
unsolvedBuf map[Consumer][]TsMsg
|
||||||
unsolvedMutex *sync.Mutex
|
|
||||||
lastTimeStamp Timestamp
|
lastTimeStamp Timestamp
|
||||||
}
|
}
|
||||||
|
|
||||||
|
@ -414,53 +394,27 @@ func NewPulsarTtMsgStream(ctx context.Context,
|
||||||
receiveBufSize int64,
|
receiveBufSize int64,
|
||||||
pulsarBufSize int64,
|
pulsarBufSize int64,
|
||||||
unmarshal msgstream.UnmarshalDispatcher) (*PulsarTtMsgStream, error) {
|
unmarshal msgstream.UnmarshalDispatcher) (*PulsarTtMsgStream, error) {
|
||||||
pulsarMsgStream, err := newPulsarMsgStream(ctx, address, receiveBufSize, pulsarBufSize, unmarshal)
|
|
||||||
|
streamCtx, streamCancel := context.WithCancel(ctx)
|
||||||
|
pulsarMsgStream := PulsarMsgStream{
|
||||||
|
ctx: streamCtx,
|
||||||
|
streamCancel: streamCancel,
|
||||||
|
pulsarBufSize: pulsarBufSize,
|
||||||
|
unmarshal: unmarshal,
|
||||||
|
}
|
||||||
|
|
||||||
|
client, err := pulsar.NewClient(pulsar.ClientOptions{URL: address})
|
||||||
if err != nil {
|
if err != nil {
|
||||||
|
log.Printf("Set pulsar client failed, error = %v", err)
|
||||||
return nil, err
|
return nil, err
|
||||||
}
|
}
|
||||||
unsolvedBuf := make(map[Consumer][]TsMsg)
|
pulsarMsgStream.client = client
|
||||||
|
pulsarMsgStream.receiveBuf = make(chan *MsgPack, receiveBufSize)
|
||||||
return &PulsarTtMsgStream{
|
return &PulsarTtMsgStream{
|
||||||
PulsarMsgStream: *pulsarMsgStream,
|
PulsarMsgStream: pulsarMsgStream,
|
||||||
unsolvedBuf: unsolvedBuf,
|
|
||||||
unsolvedMutex: &sync.Mutex{},
|
|
||||||
}, nil
|
}, nil
|
||||||
}
|
}
|
||||||
|
|
||||||
func (ms *PulsarTtMsgStream) AsConsumer(channels []string,
|
|
||||||
subName string) {
|
|
||||||
for i := 0; i < len(channels); i++ {
|
|
||||||
fn := func() error {
|
|
||||||
receiveChannel := make(chan pulsar.ConsumerMessage, ms.pulsarBufSize)
|
|
||||||
pc, err := ms.client.Subscribe(pulsar.ConsumerOptions{
|
|
||||||
Topic: channels[i],
|
|
||||||
SubscriptionName: subName,
|
|
||||||
Type: pulsar.KeyShared,
|
|
||||||
SubscriptionInitialPosition: pulsar.SubscriptionPositionEarliest,
|
|
||||||
MessageChannel: receiveChannel,
|
|
||||||
})
|
|
||||||
if err != nil {
|
|
||||||
return err
|
|
||||||
}
|
|
||||||
if pc == nil {
|
|
||||||
return errors.New("pulsar is not ready, consumer is nil")
|
|
||||||
}
|
|
||||||
|
|
||||||
ms.consumerLock.Lock()
|
|
||||||
ms.consumers = append(ms.consumers, pc)
|
|
||||||
ms.unsolvedBuf[pc] = make([]TsMsg, 0)
|
|
||||||
ms.consumerChannels = append(ms.consumerChannels, channels[i])
|
|
||||||
ms.consumerLock.Unlock()
|
|
||||||
return nil
|
|
||||||
}
|
|
||||||
err := util.Retry(10, time.Millisecond*200, fn)
|
|
||||||
if err != nil {
|
|
||||||
errMsg := "Failed to create consumer " + channels[i] + ", error = " + err.Error()
|
|
||||||
panic(errMsg)
|
|
||||||
}
|
|
||||||
}
|
|
||||||
}
|
|
||||||
|
|
||||||
func (ms *PulsarTtMsgStream) Start() {
|
func (ms *PulsarTtMsgStream) Start() {
|
||||||
ms.wait = &sync.WaitGroup{}
|
ms.wait = &sync.WaitGroup{}
|
||||||
if ms.consumers != nil {
|
if ms.consumers != nil {
|
||||||
|
@ -474,32 +428,33 @@ func (ms *PulsarTtMsgStream) bufMsgPackToChannel() {
|
||||||
ms.unsolvedBuf = make(map[Consumer][]TsMsg)
|
ms.unsolvedBuf = make(map[Consumer][]TsMsg)
|
||||||
isChannelReady := make(map[Consumer]bool)
|
isChannelReady := make(map[Consumer]bool)
|
||||||
eofMsgTimeStamp := make(map[Consumer]Timestamp)
|
eofMsgTimeStamp := make(map[Consumer]Timestamp)
|
||||||
|
for _, consumer := range ms.consumers {
|
||||||
|
ms.unsolvedBuf[consumer] = make([]TsMsg, 0)
|
||||||
|
}
|
||||||
for {
|
for {
|
||||||
select {
|
select {
|
||||||
case <-ms.ctx.Done():
|
case <-ms.ctx.Done():
|
||||||
return
|
return
|
||||||
default:
|
default:
|
||||||
wg := sync.WaitGroup{}
|
wg := sync.WaitGroup{}
|
||||||
|
mu := sync.Mutex{}
|
||||||
findMapMutex := sync.RWMutex{}
|
findMapMutex := sync.RWMutex{}
|
||||||
ms.consumerLock.Lock()
|
|
||||||
for _, consumer := range ms.consumers {
|
for _, consumer := range ms.consumers {
|
||||||
if isChannelReady[consumer] {
|
if isChannelReady[consumer] {
|
||||||
continue
|
continue
|
||||||
}
|
}
|
||||||
wg.Add(1)
|
wg.Add(1)
|
||||||
go ms.findTimeTick(consumer, eofMsgTimeStamp, &wg, &findMapMutex)
|
go ms.findTimeTick(consumer, eofMsgTimeStamp, &wg, &mu, &findMapMutex)
|
||||||
}
|
}
|
||||||
wg.Wait()
|
wg.Wait()
|
||||||
timeStamp, ok := checkTimeTickMsg(eofMsgTimeStamp, isChannelReady, &findMapMutex)
|
timeStamp, ok := checkTimeTickMsg(eofMsgTimeStamp, isChannelReady, &findMapMutex)
|
||||||
ms.consumerLock.Unlock()
|
|
||||||
if !ok || timeStamp <= ms.lastTimeStamp {
|
if !ok || timeStamp <= ms.lastTimeStamp {
|
||||||
//log.Printf("All timeTick's timestamps are inconsistent")
|
//log.Printf("All timeTick's timestamps are inconsistent")
|
||||||
continue
|
continue
|
||||||
}
|
}
|
||||||
|
|
||||||
timeTickBuf := make([]TsMsg, 0)
|
timeTickBuf := make([]TsMsg, 0)
|
||||||
msgPositions := make([]*internalpb2.MsgPosition, 0)
|
msgPositions := make([]*internalpb2.MsgPosition, 0)
|
||||||
ms.unsolvedMutex.Lock()
|
|
||||||
for consumer, msgs := range ms.unsolvedBuf {
|
for consumer, msgs := range ms.unsolvedBuf {
|
||||||
tempBuffer := make([]TsMsg, 0)
|
tempBuffer := make([]TsMsg, 0)
|
||||||
var timeTickMsg TsMsg
|
var timeTickMsg TsMsg
|
||||||
|
@ -530,7 +485,6 @@ func (ms *PulsarTtMsgStream) bufMsgPackToChannel() {
|
||||||
})
|
})
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
ms.unsolvedMutex.Unlock()
|
|
||||||
|
|
||||||
msgPack := MsgPack{
|
msgPack := MsgPack{
|
||||||
BeginTs: ms.lastTimeStamp,
|
BeginTs: ms.lastTimeStamp,
|
||||||
|
@ -548,6 +502,7 @@ func (ms *PulsarTtMsgStream) bufMsgPackToChannel() {
|
||||||
func (ms *PulsarTtMsgStream) findTimeTick(consumer Consumer,
|
func (ms *PulsarTtMsgStream) findTimeTick(consumer Consumer,
|
||||||
eofMsgMap map[Consumer]Timestamp,
|
eofMsgMap map[Consumer]Timestamp,
|
||||||
wg *sync.WaitGroup,
|
wg *sync.WaitGroup,
|
||||||
|
mu *sync.Mutex,
|
||||||
findMapMutex *sync.RWMutex) {
|
findMapMutex *sync.RWMutex) {
|
||||||
defer wg.Done()
|
defer wg.Done()
|
||||||
for {
|
for {
|
||||||
|
@ -564,13 +519,14 @@ func (ms *PulsarTtMsgStream) findTimeTick(consumer Consumer,
|
||||||
headerMsg := commonpb.MsgHeader{}
|
headerMsg := commonpb.MsgHeader{}
|
||||||
err := proto.Unmarshal(pulsarMsg.Payload(), &headerMsg)
|
err := proto.Unmarshal(pulsarMsg.Payload(), &headerMsg)
|
||||||
if err != nil {
|
if err != nil {
|
||||||
log.Printf("Failed to unmarshal message header, error = %v", err)
|
log.Printf("Failed to unmarshal, error = %v", err)
|
||||||
continue
|
|
||||||
}
|
}
|
||||||
tsMsg, err := ms.unmarshal.Unmarshal(pulsarMsg.Payload(), headerMsg.Base.MsgType)
|
tsMsg, err := ms.unmarshal.Unmarshal(pulsarMsg.Payload(), headerMsg.Base.MsgType)
|
||||||
|
if tsMsg == nil && err != nil {
|
||||||
|
panic("null unMarshalFunc for " + headerMsg.Base.MsgType.String() + " msg type")
|
||||||
|
}
|
||||||
if err != nil {
|
if err != nil {
|
||||||
log.Printf("Failed to unmarshal tsMsg, error = %v", err)
|
log.Printf("Failed to unmarshal, error = %v", err)
|
||||||
continue
|
|
||||||
}
|
}
|
||||||
// set pulsar info to tsMsg
|
// set pulsar info to tsMsg
|
||||||
tsMsg.SetPosition(&msgstream.MsgPosition{
|
tsMsg.SetPosition(&msgstream.MsgPosition{
|
||||||
|
@ -578,9 +534,9 @@ func (ms *PulsarTtMsgStream) findTimeTick(consumer Consumer,
|
||||||
MsgID: typeutil.PulsarMsgIDToString(pulsarMsg.ID()),
|
MsgID: typeutil.PulsarMsgIDToString(pulsarMsg.ID()),
|
||||||
})
|
})
|
||||||
|
|
||||||
ms.unsolvedMutex.Lock()
|
mu.Lock()
|
||||||
ms.unsolvedBuf[consumer] = append(ms.unsolvedBuf[consumer], tsMsg)
|
ms.unsolvedBuf[consumer] = append(ms.unsolvedBuf[consumer], tsMsg)
|
||||||
ms.unsolvedMutex.Unlock()
|
mu.Unlock()
|
||||||
|
|
||||||
if headerMsg.Base.MsgType == commonpb.MsgType_kTimeTick {
|
if headerMsg.Base.MsgType == commonpb.MsgType_kTimeTick {
|
||||||
findMapMutex.Lock()
|
findMapMutex.Lock()
|
||||||
|
@ -593,60 +549,50 @@ func (ms *PulsarTtMsgStream) findTimeTick(consumer Consumer,
|
||||||
}
|
}
|
||||||
|
|
||||||
func (ms *PulsarTtMsgStream) Seek(mp *internalpb2.MsgPosition) error {
|
func (ms *PulsarTtMsgStream) Seek(mp *internalpb2.MsgPosition) error {
|
||||||
var consumer Consumer
|
|
||||||
var messageID MessageID
|
|
||||||
for index, channel := range ms.consumerChannels {
|
for index, channel := range ms.consumerChannels {
|
||||||
if filepath.Base(channel) == filepath.Base(mp.ChannelName) {
|
if filepath.Base(channel) == filepath.Base(mp.ChannelName) {
|
||||||
seekMsgID, err := typeutil.StringToPulsarMsgID(mp.MsgID)
|
messageID, err := typeutil.StringToPulsarMsgID(mp.MsgID)
|
||||||
|
if err != nil {
|
||||||
|
return err
|
||||||
|
}
|
||||||
|
consumer := ms.consumers[index]
|
||||||
|
err = (consumer).Seek(messageID)
|
||||||
if err != nil {
|
if err != nil {
|
||||||
return err
|
return err
|
||||||
}
|
}
|
||||||
consumer = ms.consumers[index]
|
|
||||||
messageID = seekMsgID
|
|
||||||
break
|
|
||||||
}
|
|
||||||
}
|
|
||||||
|
|
||||||
if consumer != nil {
|
for {
|
||||||
err := (consumer).Seek(messageID)
|
select {
|
||||||
if err != nil {
|
case <-ms.ctx.Done():
|
||||||
return err
|
return nil
|
||||||
}
|
case pulsarMsg, ok := <-consumer.Chan():
|
||||||
|
if !ok {
|
||||||
ms.unsolvedMutex.Lock()
|
return errors.New("consumer closed")
|
||||||
ms.unsolvedBuf[consumer] = make([]TsMsg, 0)
|
}
|
||||||
for {
|
consumer.Ack(pulsarMsg)
|
||||||
select {
|
|
||||||
case <-ms.ctx.Done():
|
headerMsg := commonpb.MsgHeader{}
|
||||||
return nil
|
err := proto.Unmarshal(pulsarMsg.Payload(), &headerMsg)
|
||||||
case pulsarMsg, ok := <-consumer.Chan():
|
if err != nil {
|
||||||
if !ok {
|
log.Printf("Failed to unmarshal msgHeader, error = %v", err)
|
||||||
return errors.New("consumer closed")
|
}
|
||||||
}
|
tsMsg, err := ms.unmarshal.Unmarshal(pulsarMsg.Payload(), headerMsg.Base.MsgType)
|
||||||
consumer.Ack(pulsarMsg)
|
if tsMsg == nil && err != nil {
|
||||||
|
panic("null unMarshalFunc for " + headerMsg.Base.MsgType.String() + " msg type")
|
||||||
headerMsg := commonpb.MsgHeader{}
|
|
||||||
err := proto.Unmarshal(pulsarMsg.Payload(), &headerMsg)
|
}
|
||||||
if err != nil {
|
if err != nil {
|
||||||
log.Printf("Failed to unmarshal message header, error = %v", err)
|
log.Printf("Failed to unmarshal pulsarMsg, error = %v", err)
|
||||||
}
|
}
|
||||||
tsMsg, err := ms.unmarshal.Unmarshal(pulsarMsg.Payload(), headerMsg.Base.MsgType)
|
if tsMsg.Type() == commonpb.MsgType_kTimeTick {
|
||||||
if err != nil {
|
if tsMsg.BeginTs() >= mp.Timestamp {
|
||||||
log.Printf("Failed to unmarshal tsMsg, error = %v", err)
|
return nil
|
||||||
}
|
}
|
||||||
if tsMsg.Type() == commonpb.MsgType_kTimeTick {
|
continue
|
||||||
if tsMsg.BeginTs() >= mp.Timestamp {
|
}
|
||||||
ms.unsolvedMutex.Unlock()
|
if tsMsg.BeginTs() > mp.Timestamp {
|
||||||
return nil
|
ms.unsolvedBuf[consumer] = append(ms.unsolvedBuf[consumer], tsMsg)
|
||||||
}
|
}
|
||||||
continue
|
|
||||||
}
|
|
||||||
if tsMsg.BeginTs() > mp.Timestamp {
|
|
||||||
tsMsg.SetPosition(&msgstream.MsgPosition{
|
|
||||||
ChannelName: filepath.Base(pulsarMsg.Topic()),
|
|
||||||
MsgID: typeutil.PulsarMsgIDToString(pulsarMsg.ID()),
|
|
||||||
})
|
|
||||||
ms.unsolvedBuf[consumer] = append(ms.unsolvedBuf[consumer], tsMsg)
|
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
|
@ -568,7 +568,7 @@ func TestStream_PulsarTtMsgStream_Seek(t *testing.T) {
|
||||||
msgPack3.Msgs = append(msgPack3.Msgs, getTsMsg(commonpb.MsgType_kInsert, 9, 9))
|
msgPack3.Msgs = append(msgPack3.Msgs, getTsMsg(commonpb.MsgType_kInsert, 9, 9))
|
||||||
|
|
||||||
msgPack4 := MsgPack{}
|
msgPack4 := MsgPack{}
|
||||||
msgPack4.Msgs = append(msgPack4.Msgs, getTimeTickMsg(11, 11, 11))
|
msgPack4.Msgs = append(msgPack2.Msgs, getTimeTickMsg(11, 11, 11))
|
||||||
|
|
||||||
msgPack5 := MsgPack{}
|
msgPack5 := MsgPack{}
|
||||||
msgPack5.Msgs = append(msgPack5.Msgs, getTimeTickMsg(15, 15, 15))
|
msgPack5.Msgs = append(msgPack5.Msgs, getTimeTickMsg(15, 15, 15))
|
||||||
|
|
|
@ -2,7 +2,7 @@ grpcio==1.26.0
|
||||||
grpcio-tools==1.26.0
|
grpcio-tools==1.26.0
|
||||||
numpy==1.18.1
|
numpy==1.18.1
|
||||||
pytest-cov==2.8.1
|
pytest-cov==2.8.1
|
||||||
pymilvus-distributed==0.0.20
|
pymilvus-distributed==0.0.19
|
||||||
sklearn==0.0
|
sklearn==0.0
|
||||||
pytest==4.5.0
|
pytest==4.5.0
|
||||||
pytest-timeout==1.3.3
|
pytest-timeout==1.3.3
|
||||||
|
|
Loading…
Reference in New Issue