You can not select more than 25 topics Topics must start with a letter or number, can include dashes ('-') and can be up to 35 characters long.
 
 

137 lines
4.6 KiB

// Copyright 2017 PingCAP, Inc.
//
// 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,
// See the License for the specific language governing permissions and
// limitations under the License.
package statistics
import (
"time"
. "github.com/pingcap/check"
"github.com/pingcap/parser/mysql"
"github.com/pingcap/tidb/sessionctx/stmtctx"
"github.com/pingcap/tidb/types"
"github.com/pingcap/tidb/util/collate"
"github.com/pingcap/tidb/util/mock"
"github.com/pingcap/tidb/util/sqlexec"
)
var _ = Suite(&testSampleSuite{})
type testSampleSuite struct {
count int
rs sqlexec.RecordSet
}
func (s *testSampleSuite) SetUpSuite(c *C) {
s.count = 10000
rs := &recordSet{
data: make([]types.Datum, s.count),
count: s.count,
cursor: 0,
firstIsID: true,
}
rs.setFields(mysql.TypeLonglong, mysql.TypeLonglong)
start := 1000 // 1000 values is null
for i := start; i < rs.count; i++ {
rs.data[i].SetInt64(int64(i))
}
for i := start; i < rs.count; i += 3 {
rs.data[i].SetInt64(rs.data[i].GetInt64() + 1)
}
for i := start; i < rs.count; i += 5 {
rs.data[i].SetInt64(rs.data[i].GetInt64() + 2)
}
s.rs = rs
}
func (s *testSampleSuite) TestCollectColumnStats(c *C) {
sc := mock.NewContext().GetSessionVars().StmtCtx
builder := SampleBuilder{
Sc: sc,
RecordSet: s.rs,
ColLen: 1,
PkBuilder: NewSortedBuilder(sc, 256, 1, types.NewFieldType(mysql.TypeLonglong)),
MaxSampleSize: 10000,
MaxBucketSize: 256,
MaxFMSketchSize: 1000,
CMSketchWidth: 2048,
CMSketchDepth: 8,
Collators: make([]collate.Collator, 1),
ColsFieldType: []*types.FieldType{types.NewFieldType(mysql.TypeLonglong)},
}
c.Assert(s.rs.Close(), IsNil)
collectors, pkBuilder, err := builder.CollectColumnStats()
c.Assert(err, IsNil)
c.Assert(collectors[0].NullCount+collectors[0].Count, Equals, int64(s.count))
c.Assert(collectors[0].FMSketch.NDV(), Equals, int64(6232))
c.Assert(collectors[0].CMSketch.TotalCount(), Equals, uint64(collectors[0].Count))
c.Assert(int64(pkBuilder.Count), Equals, int64(s.count))
c.Assert(pkBuilder.Hist().NDV, Equals, int64(s.count))
}
func (s *testSampleSuite) TestMergeSampleCollector(c *C) {
builder := SampleBuilder{
Sc: mock.NewContext().GetSessionVars().StmtCtx,
RecordSet: s.rs,
ColLen: 2,
MaxSampleSize: 1000,
MaxBucketSize: 256,
MaxFMSketchSize: 1000,
CMSketchWidth: 2048,
CMSketchDepth: 8,
Collators: make([]collate.Collator, 2),
ColsFieldType: []*types.FieldType{types.NewFieldType(mysql.TypeLonglong), types.NewFieldType(mysql.TypeLonglong)},
}
c.Assert(s.rs.Close(), IsNil)
sc := &stmtctx.StatementContext{TimeZone: time.Local}
collectors, pkBuilder, err := builder.CollectColumnStats()
c.Assert(err, IsNil)
c.Assert(pkBuilder, IsNil)
c.Assert(len(collectors), Equals, 2)
collectors[0].IsMerger = true
collectors[0].MergeSampleCollector(sc, collectors[1])
c.Assert(collectors[0].FMSketch.NDV(), Equals, int64(9280))
c.Assert(len(collectors[0].Samples), Equals, 1000)
c.Assert(collectors[0].NullCount, Equals, int64(1000))
c.Assert(collectors[0].Count, Equals, int64(19000))
c.Assert(collectors[0].CMSketch.TotalCount(), Equals, uint64(collectors[0].Count))
}
func (s *testSampleSuite) TestCollectorProtoConversion(c *C) {
builder := SampleBuilder{
Sc: mock.NewContext().GetSessionVars().StmtCtx,
RecordSet: s.rs,
ColLen: 2,
MaxSampleSize: 10000,
MaxBucketSize: 256,
MaxFMSketchSize: 1000,
CMSketchWidth: 2048,
CMSketchDepth: 8,
Collators: make([]collate.Collator, 2),
ColsFieldType: []*types.FieldType{types.NewFieldType(mysql.TypeLonglong), types.NewFieldType(mysql.TypeLonglong)},
}
c.Assert(s.rs.Close(), IsNil)
collectors, pkBuilder, err := builder.CollectColumnStats()
c.Assert(err, IsNil)
c.Assert(pkBuilder, IsNil)
for _, collector := range collectors {
p := SampleCollectorToProto(collector)
s := SampleCollectorFromProto(p)
c.Assert(collector.Count, Equals, s.Count)
c.Assert(collector.NullCount, Equals, s.NullCount)
c.Assert(collector.CMSketch.TotalCount(), Equals, s.CMSketch.TotalCount())
c.Assert(collector.FMSketch.NDV(), Equals, s.FMSketch.NDV())
c.Assert(collector.TotalSize, Equals, s.TotalSize)
c.Assert(len(collector.Samples), Equals, len(s.Samples))
}
}