tidb plan_cacheable_checker 源码
tidb plan_cacheable_checker 代码
文件路径:/planner/core/plan_cacheable_checker.go
// 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,
// 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.
package core
import (
"github.com/pingcap/tidb/expression"
"github.com/pingcap/tidb/infoschema"
"github.com/pingcap/tidb/parser/ast"
"github.com/pingcap/tidb/parser/model"
"github.com/pingcap/tidb/sessionctx"
driver "github.com/pingcap/tidb/types/parser_driver"
"github.com/pingcap/tidb/util/logutil"
"go.uber.org/zap"
)
// Cacheable checks whether the input ast is cacheable with empty session context, which is mainly for testing.
func Cacheable(node ast.Node, is infoschema.InfoSchema) bool {
return CacheableWithCtx(nil, node, is)
}
// CacheableWithCtx checks whether the input ast is cacheable.
// Handle "ignore_plan_cache()" hint
// If there are multiple hints, only one will take effect
func CacheableWithCtx(sctx sessionctx.Context, node ast.Node, is infoschema.InfoSchema) bool {
_, isSelect := node.(*ast.SelectStmt)
_, isUpdate := node.(*ast.UpdateStmt)
_, isInsert := node.(*ast.InsertStmt)
_, isDelete := node.(*ast.DeleteStmt)
_, isSetOpr := node.(*ast.SetOprStmt)
if !(isSelect || isUpdate || isInsert || isDelete || isSetOpr) {
return false
}
checker := cacheableChecker{
sctx: sctx,
cacheable: true,
schema: is,
}
node.Accept(&checker)
return checker.cacheable
}
// cacheableChecker checks whether a query's plan can be cached, querys that:
// 1. have ExistsSubqueryExpr, or
// 2. have VariableExpr
//
// will not be cached currently.
// NOTE: we can add more rules in the future.
type cacheableChecker struct {
sctx sessionctx.Context
cacheable bool
schema infoschema.InfoSchema
}
// Enter implements Visitor interface.
func (checker *cacheableChecker) Enter(in ast.Node) (out ast.Node, skipChildren bool) {
switch node := in.(type) {
case *ast.SelectStmt:
for _, hints := range node.TableHints {
if hints.HintName.L == HintIgnorePlanCache {
checker.cacheable = false
return in, true
}
}
case *ast.DeleteStmt:
for _, hints := range node.TableHints {
if hints.HintName.L == HintIgnorePlanCache {
checker.cacheable = false
return in, true
}
}
case *ast.UpdateStmt:
for _, hints := range node.TableHints {
if hints.HintName.L == HintIgnorePlanCache {
checker.cacheable = false
return in, true
}
}
case *ast.VariableExpr, *ast.ExistsSubqueryExpr, *ast.SubqueryExpr:
checker.cacheable = false
return in, true
case *ast.FuncCallExpr:
if _, found := expression.UnCacheableFunctions[node.FnName.L]; found {
checker.cacheable = false
return in, true
}
case *ast.OrderByClause:
for _, item := range node.Items {
if _, isParamMarker := item.Expr.(*driver.ParamMarkerExpr); isParamMarker {
checker.cacheable = false
return in, true
}
}
case *ast.GroupByClause:
for _, item := range node.Items {
if _, isParamMarker := item.Expr.(*driver.ParamMarkerExpr); isParamMarker {
checker.cacheable = false
return in, true
}
}
case *ast.Limit:
if node.Count != nil {
if _, isParamMarker := node.Count.(*driver.ParamMarkerExpr); isParamMarker {
checker.cacheable = false
return in, true
}
}
if node.Offset != nil {
if _, isParamMarker := node.Offset.(*driver.ParamMarkerExpr); isParamMarker {
checker.cacheable = false
return in, true
}
}
case *ast.FrameBound:
if _, ok := node.Expr.(*driver.ParamMarkerExpr); ok {
checker.cacheable = false
return in, true
}
case *ast.TableName:
if checker.schema != nil {
if isPartitionTable(checker.schema, node) {
// Temporary disable prepared plan cache until https://github.com/pingcap/tidb/issues/33031
// is fixed and additional tests with dynamic partition prune mode has been added.
/*
if checker.sctx != nil && checker.sctx.GetSessionVars().UseDynamicPartitionPrune() {
return in, false // dynamic-mode for partition tables can use plan-cache
}
*/
checker.cacheable = false
return in, true
}
if hasGeneratedCol(checker.schema, node) {
checker.cacheable = false
return in, true
}
if isTempTable(checker.schema, node) {
checker.cacheable = false
return in, true
}
}
}
return in, false
}
// Leave implements Visitor interface.
func (checker *cacheableChecker) Leave(in ast.Node) (out ast.Node, ok bool) {
return in, checker.cacheable
}
// GeneralPlanCacheable checks whether the input ast is cacheable for general plan cache with empty session context, which is mainly for testing.
func GeneralPlanCacheable(node ast.Node, is infoschema.InfoSchema) bool {
return GeneralPlanCacheableWithCtx(nil, node, is)
}
// GeneralPlanCacheableWithCtx checks whether the input ast is cacheable for general plan cache.
// Only support: select {field} from {single-table} where {cond} and {cond} ...
// {cond}: {col} {op} {val}
// {op}: >, <, =
func GeneralPlanCacheableWithCtx(sctx sessionctx.Context, node ast.Node, is infoschema.InfoSchema) bool {
selectStmt, isSelect := node.(*ast.SelectStmt)
if !isSelect { // only support select statement now
return false
}
if selectStmt.Kind != ast.SelectStmtKindSelect {
return false
}
if len(selectStmt.TableHints) > 0 || // hints
selectStmt.Distinct || selectStmt.GroupBy != nil || selectStmt.Having != nil || // agg
selectStmt.WindowSpecs != nil || // window function
selectStmt.OrderBy != nil || // order
selectStmt.Limit != nil || // limit
selectStmt.LockInfo != nil || selectStmt.SelectIntoOpt != nil { // lock info
return false
}
from := selectStmt.From
if from == nil || selectStmt.From.TableRefs == nil {
return false
}
tableRefs := from.TableRefs
if tableRefs.Right != nil {
// We don't support the join for the general plan cache now.
return false
}
switch x := tableRefs.Left.(type) {
case *ast.TableSource:
_, isTableName := x.Source.(*ast.TableName)
if !isTableName {
return false
}
}
checker := generalPlanCacheableChecker{
sctx: sctx,
cacheable: true,
schema: is,
}
node.Accept(&checker)
return checker.cacheable
}
// generalPlanCacheableChecker checks whether a query's plan can be cached for general plan cache.
// NOTE: we can add more rules in the future.
type generalPlanCacheableChecker struct {
sctx sessionctx.Context
cacheable bool
schema infoschema.InfoSchema
}
// Enter implements Visitor interface.
func (checker *generalPlanCacheableChecker) Enter(in ast.Node) (out ast.Node, skipChildren bool) {
switch node := in.(type) {
case *ast.UnaryOperationExpr:
if _, found := expression.GeneralPlanCacheableOp[node.Op.String()]; !found {
checker.cacheable = false
return in, true
}
case *ast.FuncCallExpr:
checker.cacheable = false
return in, true
case *ast.TableName:
if checker.schema != nil {
if isPartitionTable(checker.schema, node) {
checker.cacheable = false
return in, true
}
if hasGeneratedCol(checker.schema, node) {
checker.cacheable = false
return in, true
}
if isTempTable(checker.schema, node) {
checker.cacheable = false
return in, true
}
}
}
return in, false
}
// Leave implements Visitor interface.
func (checker *generalPlanCacheableChecker) Leave(in ast.Node) (out ast.Node, ok bool) {
return in, checker.cacheable
}
func hasGeneratedCol(schema infoschema.InfoSchema, tn *ast.TableName) bool {
tb, err := schema.TableByName(tn.Schema, tn.Name)
if err != nil {
logutil.BgLogger().Error("Error occur in checking cacheable", zap.Error(err))
return false
}
for _, col := range tb.Cols() {
if col.IsGenerated() {
return true
}
}
return false
}
func isTempTable(schema infoschema.InfoSchema, tn *ast.TableName) bool {
tb, err := schema.TableByName(tn.Schema, tn.Name)
if err != nil {
logutil.BgLogger().Error("Error occur in checking cacheable", zap.Error(err))
return false
}
if tb.Meta().TempTableType != model.TempTableNone {
return true
}
return false
}
func isPartitionTable(schema infoschema.InfoSchema, tn *ast.TableName) bool {
tb, err := schema.TableByName(tn.Schema, tn.Name)
if err != nil {
logutil.BgLogger().Error("Error occur in checking cacheable", zap.Error(err))
return false
}
if tb.Meta().GetPartitionInfo() != nil {
return true
}
return false
}
相关信息
相关文章
tidb collect_column_stats_usage 源码
0
赞
热门推荐
-
2、 - 优质文章
-
3、 gate.io
-
8、 golang
-
9、 openharmony
-
10、 Vue中input框自动聚焦