Documentation ¶
Index ¶
- Constants
- Variables
- func Append(buf *strings.Builder, node SQLNode)
- func CanNormalize(stmt Statement) bool
- func ColDelimitedString(node SQLNode) string
- func ContainEscapableChars(s string, at AtCount) bool
- func Convert(e Expr) (evalengine.Expr, error)
- func EncodeValue(buf *strings.Builder, value *querypb.BindVariable)
- func ExtractMysqlComment(sql string) (string, string)
- func FetchBindVar(name string, bindVariables map[string]*querypb.BindVariable) (val *querypb.BindVariable, isList bool, err error)
- func FormatID(buf *TrackedBuffer, original, lowered string, at AtCount)
- func FormatImpossibleQuery(buf *TrackedBuffer, node SQLNode)
- func Fuzz(data []byte) int
- func GetBindvars(stmt Statement) map[string]struct{}
- func IgnoreMaxPayloadSizeDirective(stmt Statement) bool
- func IsColName(node Expr) bool
- func IsDML(sql string) bool
- func IsDMLStatement(stmt Statement) bool
- func IsNull(node Expr) bool
- func IsSetStatement(stmt Statement) bool
- func IsSimpleTuple(node Expr) bool
- func IsValue(node Expr) bool
- func IsVschemaDDL(ddl *DDL) bool
- func KeywordString(id int) string
- func LikeToRegexp(likeExpr string) *regexp.Regexp
- func NewPlanValue(node Expr) (sqltypes.PlanValue, error)
- func Normalize(stmt Statement, bindVars map[string]*querypb.BindVariable, prefix string)
- func ParseTokenizer(tokenizer *Tokenizer) int
- func RedactSQLQuery(sql string) (string, error)
- func SkipQueryPlanCacheDirective(stmt Statement) bool
- func SplitStatement(blob string) (string, string, error)
- func SplitStatementToPieces(blob string) (pieces []string, err error)
- func String(node SQLNode) string
- func StripLeadingComments(sql string) string
- func TruncateForLog(query string) string
- func TruncateForUI(query string) string
- func Walk(visit Visit, nodes ...SQLNode) error
- func WriteEscapedString(buf *TrackedBuffer, original string)
- type AccessMode
- type AliasedExpr
- type AliasedTableExpr
- type AndExpr
- type ApplyFunc
- type AtCount
- type Auth
- type AuthRevoke
- type AutoIncSpec
- type Begin
- type BinaryExpr
- type BindVarNeeds
- type BoolVal
- type CaseExpr
- type Characteristic
- type ColIdent
- func (node ColIdent) Accept(vis SQLAstVisitor) error
- func (node ColIdent) AtCount() AtCount
- func (node ColIdent) CompliantName() string
- func (node ColIdent) Equal(in ColIdent) bool
- func (node ColIdent) EqualString(str string) bool
- func (node ColIdent) Format(buf *TrackedBuffer)
- func (node ColIdent) GetAtCount() AtCount
- func (node ColIdent) GetRawVal() string
- func (node ColIdent) IsEmpty() bool
- func (node ColIdent) Lowered() string
- func (node ColIdent) MarshalJSON() ([]byte, error)
- func (node ColIdent) String() string
- func (node *ColIdent) UnmarshalJSON(b []byte) error
- type ColName
- type ColTuple
- type CollateExpr
- type ColumnDefinition
- type ColumnKeyOption
- type ColumnType
- type Columns
- type CommentDirectives
- type Comments
- type Commit
- type ComparisonExpr
- type ConstraintDefinition
- type ConstraintInfo
- type ConvertExpr
- type ConvertType
- type ConvertUsingExpr
- type CurTimeFuncExpr
- type Cursor
- type DBDDL
- type DDL
- type Default
- type Delete
- type DescribeTable
- type Encodable
- type Exec
- type ExecSubquery
- type ExecVarDef
- type ExistsExpr
- type Explain
- type Expr
- type Exprs
- type ForeignKeyDefinition
- type FuncExpr
- type GroupBy
- type GroupConcatExpr
- type IndexColumn
- type IndexDefinition
- type IndexHints
- type IndexInfo
- type IndexOption
- type Insert
- type InsertRows
- type InsertValues
- type IntervalExpr
- type IsExpr
- type IsolationLevel
- type JoinCondition
- type JoinTableExpr
- type LengthScaleOption
- type Limit
- type ListArg
- type ListArgConcatamer
- type MarginComments
- type MatchExpr
- type NativeQuery
- type Nextval
- type NodeFormatter
- type NotExpr
- type NullVal
- type OnDup
- type OptLike
- type OrExpr
- type Order
- type OrderBy
- type OtherAdmin
- type OtherRead
- type ParenSelect
- type ParenTableExpr
- type ParsedQuery
- type PartitionDefinition
- type PartitionSpec
- type Partitions
- type PositionedErr
- type Precendence
- type Purge
- type RangeCond
- type ReferenceAction
- type RefreshMaterializedView
- type Registry
- type Release
- type RewriteASTResult
- type Rollback
- type SQLAstVisitor
- type SQLNode
- type SQLVal
- type SRollback
- type Savepoint
- type Select
- func (node *Select) Accept(vis SQLAstVisitor) error
- func (node *Select) AddHaving(expr Expr)
- func (node *Select) AddOrder(order *Order)
- func (node *Select) AddWhere(expr Expr)
- func (node *Select) Format(buf *TrackedBuffer)
- func (node *Select) SetLimit(limit *Limit)
- func (node *Select) SetLock(lock string)
- type SelectExpr
- type SelectExprs
- type SelectStatement
- type Set
- type SetExpr
- type SetExprs
- type SetTransaction
- type Show
- type ShowFilter
- type ShowTablesOpt
- type SimpleTableExpr
- type Sleep
- type StarExpr
- type Statement
- type StatementType
- type Stream
- type Subquery
- type SubstrExpr
- type TableExpr
- type TableExprs
- type TableIdent
- func (node TableIdent) Accept(vis SQLAstVisitor) error
- func (node TableIdent) CompliantName() string
- func (node TableIdent) Format(buf *TrackedBuffer)
- func (node TableIdent) GetRawVal() string
- func (node TableIdent) IsEmpty() bool
- func (node TableIdent) MarshalJSON() ([]byte, error)
- func (node TableIdent) String() string
- func (node *TableIdent) UnmarshalJSON(b []byte) error
- type TableName
- type TableNames
- type TableSpec
- type TableValuedFuncTableExpr
- type TimestampFuncExpr
- type Tokenizer
- type TrackedBuffer
- func (buf *TrackedBuffer) AstPrintf(currentNode SQLNode, format string, values ...interface{})
- func (buf *TrackedBuffer) HasBindVars() bool
- func (buf *TrackedBuffer) IsDelimitCols() bool
- func (buf *TrackedBuffer) Myprintf(format string, values ...interface{})
- func (buf *TrackedBuffer) ParsedQuery() *ParsedQuery
- func (buf *TrackedBuffer) WithDelimitCols(isDelimitCols bool) *TrackedBuffer
- func (buf *TrackedBuffer) WriteArg(arg string)
- func (buf *TrackedBuffer) WriteNode(node SQLNode) *TrackedBuffer
- type TupleEqualityList
- type UnaryCastConcatamerExpr
- type UnaryExpr
- type Union
- type UnionSelect
- type Update
- type UpdateExpr
- type UpdateExprs
- type Use
- type ValTuple
- type ValType
- type Values
- type ValuesFuncExpr
- type VindexParam
- type VindexSpec
- type Visit
- type When
- type Where
- type XorExpr
Constants ¶
const ( StrVal = ValType(iota) IntVal FloatVal HexNum HexVal ValArg BitVal )
These are the possible Valtype values. HexNum represents a 0x... value. It cannot be treated as a simple value because it can be interpreted differently depending on the context.
const ( // DirectiveMultiShardAutocommit is the query comment directive to allow // single round trip autocommit with a multi-shard statement. DirectiveMultiShardAutocommit = "MULTI_SHARD_AUTOCOMMIT" // DirectiveSkipQueryPlanCache skips query plan cache when set. DirectiveSkipQueryPlanCache = "SKIP_QUERY_PLAN_CACHE" // DirectiveQueryTimeout sets a query timeout in vtgate. Only supported for SELECTS. DirectiveQueryTimeout = "QUERY_TIMEOUT_MS" // DirectiveScatterErrorsAsWarnings enables partial success scatter select queries DirectiveScatterErrorsAsWarnings = "SCATTER_ERRORS_AS_WARNINGS" // DirectiveIgnoreMaxPayloadSize skips payload size validation when set. DirectiveIgnoreMaxPayloadSize = "IGNORE_MAX_PAYLOAD_SIZE" )
const ( // Select.Distinct DistinctStr = "distinct " StraightJoinHint = "straight_join " SQLCalcFoundRowsStr = "sql_calc_found_rows " // Select.Lock ForUpdateStr = " for update" // Select.Cache SQLCacheStr = "sql_cache " SQLNoCacheStr = "sql_no_cache " // Union.Type UnionStr = "union" UnionAllStr = "union all" UnionDistinctStr = "union distinct" // DDL strings. InsertStr = "insert" ReplaceStr = "replace" UpdateStr = "update" // Set.Scope or Show.Scope SessionStr = "session" GlobalStr = "global" VitessMetadataStr = "vitess_metadata" VariableStr = "variable" ImplicitStr = "" // DDL strings. CreateStr = "create" AlterStr = "alter" DropStr = "drop" RenameStr = "rename" TruncateStr = "truncate" FlushStr = "flush" CreateVindexStr = "create vindex" DropVindexStr = "drop vindex" AddVschemaTableStr = "add vschema table" DropVschemaTableStr = "drop vschema table" AddColVindexStr = "on table add vindex" DropColVindexStr = "on table drop vindex" AddSequenceStr = "add sequence" AddAutoIncStr = "add auto_increment" // Vindex DDL param to specify the owner of a vindex VindexOwnerStr = "owner" // Partition strings ReorganizeStr = "reorganize partition" // JoinTableExpr.Join JoinStr = "join" StraightJoinStr = "straight_join" LeftJoinStr = "left join" LeftOuterJoinStr = "left outer join" RightJoinStr = "right join" RightOuterJoinStr = "right outer join" NaturalJoinStr = "natural join" NaturalLeftJoinStr = "natural left join" NaturalRightJoinStr = "natural right join" // Index hints. UseStr = "use " IgnoreStr = "ignore " ForceStr = "force " // Table Modifiers TempStr = "temp" TemporaryStr = "temporary" // View Modifiers MaterializedStr = "materialized" // Where.Type WhereStr = "where" HavingStr = "having" // ComparisonExpr.Operator EqualStr = "=" LessThanStr = "<" GreaterThanStr = ">" LessEqualStr = "<=" GreaterEqualStr = ">=" NotEqualStr = "!=" NullSafeEqualStr = "<=>" InStr = "in" NotInStr = "not in" LikeStr = "like" NotLikeStr = "not like" RegexpStr = "regexp" NotRegexpStr = "not regexp" JSONExtractOp = "->" JSONUnquoteExtractOp = "->>" // RangeCond.Operator BetweenStr = "between" NotBetweenStr = "not between" // IsExpr.Operator IsNullStr = "is null" IsNotNullStr = "is not null" IsTrueStr = "is true" IsNotTrueStr = "is not true" IsFalseStr = "is false" IsNotFalseStr = "is not false" // BinaryExpr.Operator BitAndStr = "&" BitOrStr = "|" BitXorStr = "^" PlusStr = "+" MinusStr = "-" MultStr = "*" DivStr = "/" IntDivStr = "div" ModStr = "%" ShiftLeftStr = "<<" ShiftRightStr = ">>" // UnaryExpr.Operator UPlusStr = "+" UMinusStr = "-" TildaStr = "~" BangStr = "!" BinaryStr = "binary " UBinaryStr = "_binary " Utf8mb4Str = "_utf8mb4 " Utf8Str = "_utf8 " Latin1Str = "_latin1 " // this string is "character set" and this comment is required CharacterSetStr = " character set" CharsetStr = "charset" // MatchExpr.Option BooleanModeStr = " in boolean mode" NaturalLanguageModeStr = " in natural language mode" NaturalLanguageModeWithQueryExpansionStr = " in natural language mode with query expansion" QueryExpansionStr = " with query expansion" // Order.Direction AscScr = "asc" DescScr = "desc" // SetExpr.Expr, for SET TRANSACTION ... or START TRANSACTION // TransactionStr is the Name for a SET TRANSACTION statement TransactionStr = "transaction" // Transaction isolation levels ReadUncommitted = "read uncommitted" ReadCommitted = "read committed" RepeatableRead = "repeatable read" Serializable = "serializable" TxReadOnly = "read only" TxReadWrite = "read write" // Explain formats TreeStr = "tree" JSONStr = "json" VitessStr = "vitess" TraditionalStr = "traditional" AnalyzeStr = "analyze" // Auth constants InteractiveStr = "interactive" ServiceAccountStr = "serviceaccount" // Cardinality increase functions JsonEachStr = "json_each" JsonArrayElementsTextStr = "json_array_elements_text" )
const ( //LastInsertIDName is a reserved bind var name for last_insert_id() LastInsertIDName = "__lastInsertId" //DBVarName is a reserved bind var name for database() DBVarName = "__vtdbname" //FoundRowsName is a reserved bind var name for found_rows() FoundRowsName = "__vtfrows" //RowCountName is a reserved bind var name for row_count() RowCountName = "__vtrcount" //UserDefinedVariableName is what we prepend bind var names for user defined variables UserDefinedVariableName = "__vtudv" )
const ACTION = 57470
const ACTIVE = 57629
const ADD = 57453
const ADMIN = 57630
const AGAINST = 57597
const ALL = 57362
const ALTER = 57449
const ANALYZE = 57452
const AND = 57418
const APPROXNUM = 57549
const ARRAY = 57604
const AS = 57364
const ASC = 57366
const AT_AT_ID = 57401
const AT_ID = 57400
const AUTH = 57689
const AUTO_INCREMENT = 57548
const BEGIN = 57498
const BETWEEN = 57420
const BIGINT = 57512
const BINARY = 57440
const BIT = 57506
const BIT_LITERAL = 57411
const BLOB = 57533
const BOOL = 57525
const BOOLEAN = 57598
const BUCKETS = 57631
const BY = 57358
const CASCADE = 57471
const CASE = 57421
const CAST = 57589
const CHAR = 57523
const CHARACTER = 57526
const CHARSET = 57566
const CHECK = 57468
const CLONE = 57632
const COLLATE = 57439
const COLLATION = 57553
const COLUMN = 57464
const COLUMNS = 57560
const COMMENT = 57409
const COMMENT_KEYWORD = 57410
const COMMIT = 57501
const COMMITTED = 57575
const COMPONENT = 57633
const CONSTRAINT = 57472
const CONVERT = 57588
const CREATE = 57448
const CROSS = 57393
const CUME_DIST = 57605
const CURRENT_DATE = 57580
const CURRENT_TIME = 57581
const CURRENT_TIMESTAMP = 57578
const DATABASE = 57579
const DATABASES = 57554
const DATE = 57480
const DATETIME = 57521
const DECIMAL = 57517
const DEFAULT = 57371
const DEFINITION = 57634
const DELETE = 57352
const DENSE_RANK = 57607
const DESC = 57367
const DESCRIBE = 57478
const DESCRIPTION = 57606
const DISTINCT = 57363
const DISTINCTROW = 57377
const DIV = 57436
const DO = 57376
const DOUBLE = 57515
const DROP = 57450
const DUPLICATE = 57369
const ELSE = 57424
const EMPTY = 57608
const END = 57425
const ENFORCED = 57635
const ENGINES = 57562
const ENUM = 57538
const ESCAPE = 57481
const EXCEPT = 57609
const EXCLUDE = 57636
const EXEC = 57706
const EXISTS = 57365
const EXPANSION = 57602
const EXPLAIN = 57479
const EXTENDED = 57564
const FALSE = 57414
const FIELDS = 57561
const FIRST_VALUE = 57610
const FLOAT = 57405
const FLOAT_TYPE = 57516
const FLUSH = 57454
const FOLLOWING = 57637
const FOR = 57361
const FORCE = 57396
const FOREIGN = 57473
const FORMAT = 57685
const FROM = 57353
const FULL = 57558
const FULLTEXT = 57466
const GE = 57427
const GEOMCOLLECTION = 57638
const GEOMETRY = 57539
const GEOMETRYCOLLECTION = 57543
const GET_MASTER_PUBLIC_KEY = 57639
const GLOBAL = 57567
const GROUP = 57355
const GROUPING = 57611
const GROUPS = 57612
const GROUP_CONCAT = 57592
const HAVING = 57356
const HEX = 57402
const HEXNUM = 57406
const HISTOGRAM = 57640
const HISTORY = 57641
const ID = 57399
const IF = 57461
const IGNORE = 57460
const IN = 57433
const INACTIVE = 57642
const INDEX = 57457
const INDEXES = 57469
const INNER = 57391
const INSERT = 57350
const INT = 57510
const INTEGER = 57511
const INTEGRAL = 57404
const INTERACTIVE = 57690
const INTERVAL = 57445
const INTNUM = 57513
const INTO = 57368
const INVISIBLE = 57643
const IS = 57430
const ISOLATION = 57569
const JOIN = 57387
const JSON = 57537
const JSON_ARRAY_ELEMENTS_TEXT = 57700
const JSON_EACH = 57701
const JSON_EXTRACT_OP = 57446
const JSON_TABLE = 57613
const JSON_UNQUOTE_EXTRACT_OP = 57447
const KEY = 57370
const KEYS = 57375
const KEY_BLOCK_SIZE = 57467
const LAG = 57614
const LANGUAGE = 57599
const LAST_INSERT_ID = 57379
const LAST_VALUE = 57615
const LATERAL = 57616
const LE = 57426
const LEAD = 57617
const LEFT = 57389
const LESS = 57488
const LEVEL = 57570
const LEX_ERROR = 57346
const LIKE = 57431
const LIMIT = 57359
const LINESTRING = 57541
const LIST = 57705
const LIST_ARG = 57408
const LOCALTIME = 57582
const LOCALTIMESTAMP = 57583
const LOCK = 57373
const LOCKED = 57644
const LOGIN = 57691
const LONGBLOB = 57536
const LONGTEXT = 57532
const MASTER_COMPRESSION_ALGORITHMS = 57645
const MASTER_PUBLIC_KEY_PATH = 57646
const MASTER_TLS_CIPHERSUITES = 57647
const MASTER_ZSTD_COMPRESSION_LEVEL = 57648
const MATCH = 57596
const MATERIALIZED = 57696
const MAXVALUE = 57485
const MEDIUMBLOB = 57535
const MEDIUMINT = 57509
const MEDIUMTEXT = 57531
const MEMBER = 57618
const MOD = 57437
const MODE = 57383
const MULTILINESTRING = 57545
const MULTIPOINT = 57544
const MULTIPOLYGON = 57546
const NAMES = 57565
const NATIVEQUERY = 57708
const NATURAL = 57394
const NCHAR = 57528
const NE = 57428
const NESTED = 57649
const NETWORK_NAMESPACE = 57650
const NEXT = 57380
const NO = 57474
const NOT = 57419
const NOWAIT = 57651
const NTH_VALUE = 57619
const NTILE = 57620
const NULL = 57412
const NULLS = 57652
const NULLX = 57547
const NULL_SAFE_EQUAL = 57429
const NUMERIC = 57518
const OF = 57621
const OFF = 57415
const OFFSET = 57360
const OJ = 57653
const OLD = 57654
const ON = 57397
const ONLY = 57573
const OPTIMIZE = 57483
const OPTIONAL = 57655
const OR = 57416
const ORDER = 57357
const ORDINALITY = 57656
const ORGANIZATION = 57657
const OTHERS = 57658
const OUTER = 57392
const OVER = 57622
const PARTITION = 57486
const PATH = 57659
const PERCENT_RANK = 57623
const PERSIST = 57660
const PERSIST_ONLY = 57661
const PLUGINS = 57563
const POINT = 57540
const POLYGON = 57542
const PRECEDING = 57662
const PRIMARY = 57463
const PRIVILEGE_CHECKS_USER = 57663
const PROCEDURE = 57490
const PROCESS = 57664
const PROCESSLIST = 57559
const PULL = 57704
const PURGE = 57707
const QUERY = 57601
const RANDOM = 57665
const RANK = 57624
const READ = 57571
const REAL = 57514
const RECURSIVE = 57625
const REFERENCE = 57666
const REFERENCES = 57475
const REFRESH = 57699
const REGEXP = 57432
const REGISTRY = 57703
const RELEASE = 57504
const RENAME = 57451
const REORGANIZE = 57487
const REPAIR = 57482
const REPEATABLE = 57574
const REPLACE = 57587
const REQUIRE_ROW_FORMAT = 57667
const RESOURCE = 57668
const RESPECT = 57669
const RESTART = 57670
const RESTRICT = 57476
const RETAIN = 57671
const REUSE = 57672
const REVOKE = 57692
const RIGHT = 57390
const ROLE = 57673
const ROLLBACK = 57502
const ROW_NUMBER = 57626
const SA = 57693
const SAVEPOINT = 57503
const SCHEMA = 57455
const SECONDARY = 57674
const SECONDARY_ENGINE = 57675
const SECONDARY_LOAD = 57676
const SECONDARY_UNLOAD = 57677
const SELECT = 57348
const SEPARATOR = 57593
const SEQUENCE = 57497
const SERIALIZABLE = 57577
const SERVICEACCOUNT = 57694
const SESSION = 57568
const SET = 57372
const SHARE = 57382
const SHIFT_LEFT = 57434
const SHIFT_RIGHT = 57435
const SHOW = 57477
const SIGNED = 57550
const SKIP = 57678
const SLEEP = 57695
const SMALLINT = 57508
const SPATIAL = 57465
const SQL_CACHE = 57385
const SQL_CALC_FOUND_ROWS = 57386
const SQL_NO_CACHE = 57384
const SRID = 57679
const STACKQL = 57709
const START = 57499
const STATUS = 57494
const STRAIGHT_JOIN = 57388
const STREAM = 57349
const STRING = 57403
const SUBSTR = 57590
const SUBSTRING = 57591
const SYSTEM = 57627
const TABLE = 57456
const TABLES = 57555
const TEMP = 57697
const TEMPORARY = 57698
const TEXT = 57529
const THAN = 57489
const THEN = 57423
const THREAD_PRIORITY = 57680
const TIES = 57681
const TIME = 57519
const TIMESTAMP = 57520
const TIMESTAMPADD = 57594
const TIMESTAMPDIFF = 57595
const TINYBLOB = 57534
const TINYINT = 57507
const TINYTEXT = 57530
const TO = 57459
const TRADITIONAL = 57688
const TRANSACTION = 57500
const TREE = 57686
const TRIGGER = 57491
const TRUE = 57413
const TRUNCATE = 57484
const UNARY = 57438
const UNBOUNDED = 57682
const UNCOMMITTED = 57576
const UNDERSCORE_BINARY = 57441
const UNDERSCORE_LATIN1 = 57444
const UNDERSCORE_UTF8 = 57443
const UNDERSCORE_UTF8MB4 = 57442
const UNION = 57347
const UNIQUE = 57462
const UNLOCK = 57374
const UNNEST = 57702
const UNSIGNED = 57551
const UNUSED = 57603
const UPDATE = 57351
const USE = 57395
const USING = 57398
const UTC_DATE = 57584
const UTC_TIME = 57585
const UTC_TIMESTAMP = 57586
const VALUE = 57381
const VALUES = 57378
const VALUE_ARG = 57407
const VARBINARY = 57527
const VARCHAR = 57524
const VARIABLES = 57495
const VCPU = 57683
const VIEW = 57458
const VINDEX = 57492
const VINDEXES = 57493
const VISIBLE = 57684
const VITESS = 57687
const VITESS_METADATA = 57556
const VSCHEMA = 57557
const WARNINGS = 57496
const WHEN = 57422
const WHERE = 57354
const WINDOW = 57628
const WITH = 57600
const WORK = 57505
const WRITE = 57572
const XOR = 57417
const YEAR = 57522
const ZEROFILL = 57552
Variables ¶
var ( // TruncateUILen truncate queries in debug UIs to the given length. 0 means unlimited. TruncateUILen = flag.Int("sql-max-length-ui", 512, "truncate queries in debug UIs to the given length (default 512)") // TruncateErrLen truncate queries in error logs to the given length. 0 means unlimited. TruncateErrLen = flag.Int("sql-max-length-errors", 0, "truncate queries in error logs to the given length (default unlimited)") )
var Aggregates = map[string]bool{ "avg": true, "bit_and": true, "bit_or": true, "bit_xor": true, "count": true, "group_concat": true, "max": true, "min": true, "std": true, "stddev_pop": true, "stddev_samp": true, "stddev": true, "sum": true, "var_pop": true, "var_samp": true, "variance": true, }
Aggregates is a map of all aggregate functions.
var ErrEmpty = errors.New("empty statement")
ErrEmpty is a sentinel error returned when parsing empty statements.
var ExprNotSupported = fmt.Errorf("Expr Not Supported")
var KeywordStrings = map[int]string{}
KeywordStrings contains the reverse mapping of token to keyword strings
Functions ¶
func CanNormalize ¶
CanNormalize takes Statement and returns if the statement can be normalized.
func ColDelimitedString ¶
String returns a string representation of an SQLNode.
func ContainEscapableChars ¶
func Convert ¶
func Convert(e Expr) (evalengine.Expr, error)
Convert converts between AST expressions and executable expressions
func EncodeValue ¶
func EncodeValue(buf *strings.Builder, value *querypb.BindVariable)
EncodeValue encodes one bind variable value into the query.
func ExtractMysqlComment ¶
ExtractMysqlComment extracts the version and SQL from a comment-only query such as /*!50708 sql here */
func FetchBindVar ¶
func FetchBindVar(name string, bindVariables map[string]*querypb.BindVariable) (val *querypb.BindVariable, isList bool, err error)
FetchBindVar resolves the bind variable by fetching it from bindVariables.
func FormatID ¶
func FormatID(buf *TrackedBuffer, original, lowered string, at AtCount)
func FormatImpossibleQuery ¶
func FormatImpossibleQuery(buf *TrackedBuffer, node SQLNode)
FormatImpossibleQuery creates an impossible query in a TrackedBuffer. An impossible query is a modified version of a query where all selects have where clauses that are impossible for mysql to resolve. This is used in the vtgate and vttablet:
- In the vtgate it's used for joins: if the first query returns no result, then vtgate uses the impossible query just to fetch field info from vttablet - In the vttablet, it's just an optimization: the field info is fetched once form MySQL, cached and reused for subsequent queries
func GetBindvars ¶
GetBindvars returns a map of the bind vars referenced in the statement. TODO(sougou); This function gets called again from vtgate/planbuilder. Ideally, this should be done only once.
func IgnoreMaxPayloadSizeDirective ¶
IgnoreMaxPayloadSizeDirective returns true if the max payload size override directive is set to true.
func IsDMLStatement ¶
IsDMLStatement returns true if the query is an INSERT, UPDATE or DELETE statement.
func IsSetStatement ¶
IsSetStatement takes Statement and returns if the statement is set statement.
func IsSimpleTuple ¶
IsSimpleTuple returns true if the Expr is a ValTuple that contains simple values or if it's a list arg.
func IsValue ¶
IsValue returns true if the Expr is a string, integral or value arg. NULL is not considered to be a value.
func IsVschemaDDL ¶
IsVschemaDDL returns true if the query is an Vschema alter ddl.
func KeywordString ¶
KeywordString returns the string corresponding to the given keyword
func LikeToRegexp ¶
LikeToRegexp converts a like sql expression to regular expression
func NewPlanValue ¶
NewPlanValue builds a sqltypes.PlanValue from an Expr.
func Normalize ¶
func Normalize(stmt Statement, bindVars map[string]*querypb.BindVariable, prefix string)
Normalize changes the statement to use bind values, and updates the bind vars to those values. The supplied prefix is used to generate the bind var names. The function ensures that there are no collisions with existing bind vars. Within Select constructs, bind vars are deduped. This allows us to identify vindex equality. Otherwise, every value is treated as distinct.
func ParseTokenizer ¶
ParseTokenizer is a raw interface to parse from the given tokenizer. This does not used pooled parsers, and should not be used in general.
func RedactSQLQuery ¶
RedactSQLQuery returns a sql string with the params stripped out for display
func SkipQueryPlanCacheDirective ¶
SkipQueryPlanCacheDirective returns true if skip query plan cache directive is set to true in query.
func SplitStatement ¶
SplitStatement returns the first sql statement up to either a ; or EOF and the remainder from the given buffer
func SplitStatementToPieces ¶
SplitStatementToPieces split raw sql statement that may have multi sql pieces to sql pieces returns the sql pieces blob contains; or error if sql cannot be parsed
func StripLeadingComments ¶
StripLeadingComments trims the SQL string and removes any leading comments
func TruncateForLog ¶
TruncateForLog is used when displaying queries as part of error logs to avoid overwhelming logging systems with potentially long queries and bind value data.
func TruncateForUI ¶
TruncateForUI is used when displaying queries on various Vitess status pages to keep the pages small enough to load and render properly
func Walk ¶
Walk calls visit on every node. If visit returns true, the underlying nodes are also visited. If it returns an error, walking is interrupted, and the error is returned.
func WriteEscapedString ¶
func WriteEscapedString(buf *TrackedBuffer, original string)
Types ¶
type AccessMode ¶
type AccessMode struct {
Mode string
}
AccessMode is ReadOnly/ReadWrite
func (*AccessMode) Accept ¶
func (node *AccessMode) Accept(vis SQLAstVisitor) error
func (*AccessMode) Format ¶
func (node *AccessMode) Format(buf *TrackedBuffer)
Format formats the node.
type AliasedExpr ¶
AliasedExpr defines an aliased SELECT expression.
func (*AliasedExpr) Accept ¶
func (node *AliasedExpr) Accept(vis SQLAstVisitor) error
func (*AliasedExpr) Format ¶
func (node *AliasedExpr) Format(buf *TrackedBuffer)
Format formats the node.
type AliasedTableExpr ¶
type AliasedTableExpr struct { Expr SimpleTableExpr Partitions Partitions As TableIdent Hints *IndexHints }
AliasedTableExpr represents a table expression coupled with an optional alias or index hint. If As is empty, no alias was used.
func (*AliasedTableExpr) Accept ¶
func (node *AliasedTableExpr) Accept(vis SQLAstVisitor) error
func (*AliasedTableExpr) Format ¶
func (node *AliasedTableExpr) Format(buf *TrackedBuffer)
Format formats the node.
func (*AliasedTableExpr) RemoveHints ¶
func (node *AliasedTableExpr) RemoveHints() *AliasedTableExpr
RemoveHints returns a new AliasedTableExpr with the hints removed.
type AndExpr ¶
type AndExpr struct {
Left, Right Expr
}
AndExpr represents an AND expression.
func (*AndExpr) Accept ¶
func (node *AndExpr) Accept(vis SQLAstVisitor) error
type ApplyFunc ¶
An ApplyFunc is invoked by Rewrite for each node n, even if n is nil, before and/or after the node's children, using a Cursor describing the current node and providing operations on it.
The return value of ApplyFunc controls the syntax tree traversal. See Rewrite for details.
type Auth ¶
type Auth struct { SessionAuth BoolVal Provider string Type string KeyFilePath string KeyEnvVar string }
Statements
func (*Auth) Accept ¶
func (node *Auth) Accept(vis SQLAstVisitor) error
type AuthRevoke ¶
Statements
func (*AuthRevoke) Accept ¶
func (node *AuthRevoke) Accept(vis SQLAstVisitor) error
func (*AuthRevoke) Format ¶
func (node *AuthRevoke) Format(buf *TrackedBuffer)
Format formats the node.
type AutoIncSpec ¶
AutoIncSpec defines and autoincrement value for a ADD AUTO_INCREMENT statement
func (*AutoIncSpec) Accept ¶
func (node *AutoIncSpec) Accept(vis SQLAstVisitor) error
func (*AutoIncSpec) Format ¶
func (node *AutoIncSpec) Format(buf *TrackedBuffer)
Format formats the node.
type Begin ¶
type Begin struct{}
Begin represents a Begin statement.
func (*Begin) Accept ¶
func (node *Begin) Accept(vis SQLAstVisitor) error
type BinaryExpr ¶
BinaryExpr represents a binary value expression.
func (*BinaryExpr) Accept ¶
func (node *BinaryExpr) Accept(vis SQLAstVisitor) error
func (*BinaryExpr) Format ¶
func (node *BinaryExpr) Format(buf *TrackedBuffer)
Format formats the node.
type BindVarNeeds ¶
type BindVarNeeds struct { NeedLastInsertID bool NeedDatabase bool NeedFoundRows bool NeedRowCount bool NeedUserDefinedVariables []string }
BindVarNeeds represents the bind vars that need to be provided as the result of expression rewriting.
type BoolVal ¶
type BoolVal bool
BoolVal is true or false.
func (BoolVal) Accept ¶
func (node BoolVal) Accept(vis SQLAstVisitor) error
type CaseExpr ¶
CaseExpr represents a CASE expression.
func (*CaseExpr) Accept ¶
func (node *CaseExpr) Accept(vis SQLAstVisitor) error
type Characteristic ¶
type Characteristic interface { SQLNode // contains filtered or unexported methods }
Characteristic is a transaction related change
type ColIdent ¶
type ColIdent struct {
// contains filtered or unexported fields
}
ColIdent is a case insensitive SQL identifier. It will be escaped with backquotes if necessary.
func NewColIdentWithAt ¶
NewColIdentWithAt makes a new ColIdent.
func (ColIdent) Accept ¶
func (node ColIdent) Accept(vis SQLAstVisitor) error
func (ColIdent) CompliantName ¶
CompliantName returns a compliant id name that can be used for a bind var.
func (ColIdent) EqualString ¶
EqualString performs a case-insensitive compare with str.
func (ColIdent) GetAtCount ¶
func (ColIdent) Lowered ¶
Lowered returns a lower-cased column name. This function should generally be used only for optimizing comparisons.
func (ColIdent) MarshalJSON ¶
MarshalJSON marshals into JSON.
func (ColIdent) String ¶
String returns the unescaped column name. It must not be used for SQL generation. Use sqlparser.String instead. The Stringer conformance is for usage in templates.
func (*ColIdent) UnmarshalJSON ¶
UnmarshalJSON unmarshals from JSON.
type ColName ¶
type ColName struct { // Metadata is not populated by the parser. // It's a placeholder for analyzers to store // additional data, typically info about which // table or column this node references. Metadata interface{} Name ColIdent Qualifier TableName }
ColName represents a column name.
func (*ColName) Accept ¶
func (node *ColName) Accept(vis SQLAstVisitor) error
type ColTuple ¶
type ColTuple interface { Expr // contains filtered or unexported methods }
ColTuple represents a list of column values. It can be ValTuple, Subquery, ListArg.
type CollateExpr ¶
CollateExpr represents dynamic collate operator.
func (*CollateExpr) Accept ¶
func (node *CollateExpr) Accept(vis SQLAstVisitor) error
func (*CollateExpr) Format ¶
func (node *CollateExpr) Format(buf *TrackedBuffer)
Format formats the node.
type ColumnDefinition ¶
type ColumnDefinition struct { Name ColIdent // TODO: Should this not be a reference? Type ColumnType }
ColumnDefinition describes a column in a CREATE TABLE statement
func (*ColumnDefinition) Accept ¶
func (node *ColumnDefinition) Accept(vis SQLAstVisitor) error
func (*ColumnDefinition) Format ¶
func (col *ColumnDefinition) Format(buf *TrackedBuffer)
Format formats the node.
type ColumnKeyOption ¶
type ColumnKeyOption int
ColumnKeyOption indicates whether or not the given column is defined as an index element and contains the type of the option
const ( ColKeyPrimary ColumnKeyOption ColKeySpatialKey ColKeyUnique ColKeyUniqueKey ColKey )
type ColumnType ¶
type ColumnType struct { // The base type string Type string // Generic field options. NotNull BoolVal Autoincrement BoolVal Default Expr OnUpdate Expr Comment *SQLVal // Numeric field options Length *SQLVal Unsigned BoolVal Zerofill BoolVal Scale *SQLVal // Text field options Charset string Collate string // Enum values EnumValues []string // Key specification KeyOpt ColumnKeyOption }
ColumnType represents a sql type in a CREATE TABLE statement All optional fields are nil if not specified
func (*ColumnType) Accept ¶
func (node *ColumnType) Accept(vis SQLAstVisitor) error
func (*ColumnType) DescribeType ¶
func (ct *ColumnType) DescribeType() string
DescribeType returns the abbreviated type information as required for describe table
func (*ColumnType) Format ¶
func (ct *ColumnType) Format(buf *TrackedBuffer)
Format returns a canonical string representation of the type and all relevant options
func (*ColumnType) SQLType ¶
func (ct *ColumnType) SQLType() querypb.Type
SQLType returns the sqltypes type code for the given column
type Columns ¶
type Columns []ColIdent
Columns represents an insert column list.
func (Columns) Accept ¶
func (node Columns) Accept(vis SQLAstVisitor) error
func (Columns) FindColumn ¶
FindColumn finds a column in the column list, returning the index if it exists or -1 otherwise
type CommentDirectives ¶
type CommentDirectives map[string]interface{}
CommentDirectives is the parsed representation for execution directives conveyed in query comments
func ExtractCommentDirectives ¶
func ExtractCommentDirectives(comments Comments) CommentDirectives
ExtractCommentDirectives parses the comment list for any execution directives of the form:
/*vt+ OPTION_ONE=1 OPTION_TWO OPTION_THREE=abcd */
It returns the map of the directive values or nil if there aren't any.
func (CommentDirectives) IsSet ¶
func (d CommentDirectives) IsSet(key string) bool
IsSet checks the directive map for the named directive and returns true if the directive is set and has a true/false or 0/1 value
type Comments ¶
type Comments [][]byte
Comments represents a list of comments.
func (Comments) Accept ¶
func (node Comments) Accept(vis SQLAstVisitor) error
type Commit ¶
type Commit struct{}
Commit represents a Commit statement.
func (*Commit) Accept ¶
func (node *Commit) Accept(vis SQLAstVisitor) error
type ComparisonExpr ¶
ComparisonExpr represents a two-value comparison expression.
func (*ComparisonExpr) Accept ¶
func (node *ComparisonExpr) Accept(vis SQLAstVisitor) error
func (*ComparisonExpr) Format ¶
func (node *ComparisonExpr) Format(buf *TrackedBuffer)
Format formats the node.
func (*ComparisonExpr) IsImpossible ¶
func (node *ComparisonExpr) IsImpossible() bool
IsImpossible returns true if the comparison in the expression can never evaluate to true. Note that this is not currently exhaustive to ALL impossible comparisons.
type ConstraintDefinition ¶
type ConstraintDefinition struct { Name string Details ConstraintInfo }
ConstraintDefinition describes a constraint in a CREATE TABLE statement
func (*ConstraintDefinition) Accept ¶
func (node *ConstraintDefinition) Accept(vis SQLAstVisitor) error
func (*ConstraintDefinition) Format ¶
func (c *ConstraintDefinition) Format(buf *TrackedBuffer)
Format formats the node.
type ConstraintInfo ¶
type ConstraintInfo interface { SQLNode // contains filtered or unexported methods }
ConstraintInfo details a constraint in a CREATE TABLE statement
type ConvertExpr ¶
type ConvertExpr struct { Expr Expr Type *ConvertType }
ConvertExpr represents a call to CONVERT(expr, type) or it's equivalent CAST(expr AS type). Both are rewritten to the former.
func (*ConvertExpr) Accept ¶
func (node *ConvertExpr) Accept(vis SQLAstVisitor) error
func (*ConvertExpr) Format ¶
func (node *ConvertExpr) Format(buf *TrackedBuffer)
Format formats the node.
type ConvertType ¶
ConvertType represents the type in call to CONVERT(expr, type)
func (*ConvertType) Accept ¶
func (node *ConvertType) Accept(vis SQLAstVisitor) error
func (*ConvertType) Format ¶
func (node *ConvertType) Format(buf *TrackedBuffer)
Format formats the node.
type ConvertUsingExpr ¶
ConvertUsingExpr represents a call to CONVERT(expr USING charset).
func (*ConvertUsingExpr) Accept ¶
func (node *ConvertUsingExpr) Accept(vis SQLAstVisitor) error
func (*ConvertUsingExpr) Format ¶
func (node *ConvertUsingExpr) Format(buf *TrackedBuffer)
Format formats the node.
type CurTimeFuncExpr ¶
type CurTimeFuncExpr struct { Name ColIdent Fsp Expr // fractional seconds precision, integer from 0 to 6 }
CurTimeFuncExpr represents the function and arguments for CURRENT DATE/TIME functions supported functions are documented in the grammar
func (*CurTimeFuncExpr) Accept ¶
func (node *CurTimeFuncExpr) Accept(vis SQLAstVisitor) error
func (*CurTimeFuncExpr) Format ¶
func (node *CurTimeFuncExpr) Format(buf *TrackedBuffer)
Format formats the node.
type Cursor ¶
type Cursor struct {
// contains filtered or unexported fields
}
A Cursor describes a node encountered during Apply. Information about the node and its parent is available from the Node and Parent methods.
type DBDDL ¶
type DBDDL struct { Action string DBName string IfExists bool IfNotExists bool Collate string Charset string }
DBDDL represents a CREATE, DROP, or ALTER database statement.
func (*DBDDL) Accept ¶
func (node *DBDDL) Accept(vis SQLAstVisitor) error
type DDL ¶
type DDL struct { Action string // FromTables is set if Action is RenameStr or DropStr. FromTables TableNames // ToTables is set if Action is RenameStr. ToTables TableNames // Table is set if Action is other than RenameStr or DropStr. Table TableName // The following fields are set if a DDL was fully analyzed. IfExists bool IfNotExists bool TableSpec *TableSpec OptLike *OptLike OrReplace bool PartitionSpec *PartitionSpec // VindexSpec is set for CreateVindexStr, DropVindexStr, AddColVindexStr, DropColVindexStr. VindexSpec *VindexSpec // VindexCols is set for AddColVindexStr. VindexCols []ColIdent // AutoIncSpec is set for AddAutoIncStr. AutoIncSpec *AutoIncSpec // SelectStatement is set for Create View. SelectStatement SelectStatement // Modifier is optional for Create View and Create Table. Modifier string }
DDL represents a CREATE, ALTER, DROP, RENAME, TRUNCATE or ANALYZE statement.
func (*DDL) Accept ¶
func (node *DDL) Accept(vis SQLAstVisitor) error
func (*DDL) AffectedTables ¶
func (node *DDL) AffectedTables() TableNames
AffectedTables returns the list table names affected by the DDL.
type Default ¶
type Default struct {
ColName string
}
Default represents a DEFAULT expression.
func (*Default) Accept ¶
func (node *Default) Accept(vis SQLAstVisitor) error
type Delete ¶
type Delete struct { Comments Comments Targets TableNames TableExprs TableExprs Partitions Partitions Where *Where OrderBy OrderBy Limit *Limit }
Delete represents a DELETE statement. If you add fields here, consider adding them to calls to validateUnshardedRoute.
func (*Delete) Accept ¶
func (node *Delete) Accept(vis SQLAstVisitor) error
type DescribeTable ¶
Statements
func (*DescribeTable) Accept ¶
func (node *DescribeTable) Accept(vis SQLAstVisitor) error
func (*DescribeTable) Format ¶
func (node *DescribeTable) Format(buf *TrackedBuffer)
Format formats the node.
type Exec ¶
type Exec struct { Await bool Comments Comments MethodName TableName ExecVarDefs []ExecVarDef OptExecPayload *ExecVarDef }
Exec represents an EXEC statement
func NewExec ¶
func NewExec(comments Comments, methodName TableName, execVarDefs []ExecVarDef, optExecPayload *ExecVarDef) *Exec
NewExec makes a new Exec.
func (*Exec) Accept ¶
func (node *Exec) Accept(vis SQLAstVisitor) error
func (*Exec) Format ¶
func (node *Exec) Format(buf *TrackedBuffer)
type ExecSubquery ¶
type ExecSubquery struct {
Exec *Exec
}
func (*ExecSubquery) Accept ¶
func (node *ExecSubquery) Accept(vis SQLAstVisitor) error
func (*ExecSubquery) Format ¶
func (node *ExecSubquery) Format(buf *TrackedBuffer)
type ExecVarDef ¶
func NewExecVarDef ¶
func NewExecVarDef(colIdent ColIdent, val Expr) ExecVarDef
NewExecVarDef makes a new ExecVarDef.
type ExistsExpr ¶
type ExistsExpr struct {
Subquery *Subquery
}
ExistsExpr represents an EXISTS expression.
func (*ExistsExpr) Accept ¶
func (node *ExistsExpr) Accept(vis SQLAstVisitor) error
func (*ExistsExpr) Format ¶
func (node *ExistsExpr) Format(buf *TrackedBuffer)
Format formats the node.
type Explain ¶
Explain represents an EXPLAIN statement
func (*Explain) Accept ¶
func (node *Explain) Accept(vis SQLAstVisitor) error
type Expr ¶
type Expr interface { SQLNode // contains filtered or unexported methods }
Expr represents an expression.
func ReplaceExpr ¶
ReplaceExpr finds the from expression from root and replaces it with to. If from matches root, then to is returned.
func SplitAndExpression ¶
SplitAndExpression breaks up the Expr into AND-separated conditions and appends them to filters. Outer parenthesis are removed. Precedence should be taken into account if expressions are recombined.
type Exprs ¶
type Exprs []Expr
Exprs represents a list of value expressions. It's not a valid expression because it's not parenthesized.
func (Exprs) Accept ¶
func (node Exprs) Accept(vis SQLAstVisitor) error
type ForeignKeyDefinition ¶
type ForeignKeyDefinition struct { Source Columns ReferencedTable TableName ReferencedColumns Columns OnDelete ReferenceAction OnUpdate ReferenceAction }
ForeignKeyDefinition describes a foreign key in a CREATE TABLE statement
func (*ForeignKeyDefinition) Accept ¶
func (node *ForeignKeyDefinition) Accept(vis SQLAstVisitor) error
func (*ForeignKeyDefinition) Format ¶
func (f *ForeignKeyDefinition) Format(buf *TrackedBuffer)
Format formats the node.
type FuncExpr ¶
type FuncExpr struct { Qualifier TableIdent Name ColIdent Distinct bool Exprs SelectExprs }
FuncExpr represents a function call.
func (*FuncExpr) Accept ¶
func (node *FuncExpr) Accept(vis SQLAstVisitor) error
func (*FuncExpr) IsAggregate ¶
IsAggregate returns true if the function is an aggregate.
type GroupBy ¶
type GroupBy []Expr
GroupBy represents a GROUP BY clause.
func (GroupBy) Accept ¶
func (node GroupBy) Accept(vis SQLAstVisitor) error
type GroupConcatExpr ¶
type GroupConcatExpr struct { Distinct string Exprs SelectExprs OrderBy OrderBy Separator string Limit *Limit }
GroupConcatExpr represents a call to GROUP_CONCAT
func (*GroupConcatExpr) Accept ¶
func (node *GroupConcatExpr) Accept(vis SQLAstVisitor) error
func (*GroupConcatExpr) Format ¶
func (node *GroupConcatExpr) Format(buf *TrackedBuffer)
Format formats the node
type IndexColumn ¶
IndexColumn describes a column in an index definition with optional length
type IndexDefinition ¶
type IndexDefinition struct { Info *IndexInfo Columns []*IndexColumn Options []*IndexOption }
IndexDefinition describes an index in a CREATE TABLE statement
func (*IndexDefinition) Accept ¶
func (node *IndexDefinition) Accept(vis SQLAstVisitor) error
func (*IndexDefinition) Format ¶
func (idx *IndexDefinition) Format(buf *TrackedBuffer)
Format formats the node.
type IndexHints ¶
IndexHints represents a list of index hints.
func (*IndexHints) Accept ¶
func (node *IndexHints) Accept(vis SQLAstVisitor) error
func (*IndexHints) Format ¶
func (node *IndexHints) Format(buf *TrackedBuffer)
Format formats the node.
type IndexInfo ¶
IndexInfo describes the name and type of an index in a CREATE TABLE statement
func (*IndexInfo) Accept ¶
func (node *IndexInfo) Accept(vis SQLAstVisitor) error
type IndexOption ¶
IndexOption is used for trailing options for indexes: COMMENT, KEY_BLOCK_SIZE, USING
type Insert ¶
type Insert struct { Action string Comments Comments Ignore string Table TableName Partitions Partitions Columns Columns Rows InsertRows OnDup OnDup }
Insert represents an INSERT or REPLACE statement. Per the MySQL docs, http://dev.mysql.com/doc/refman/5.7/en/replace.html Replace is the counterpart to `INSERT IGNORE`, and works exactly like a normal INSERT except if the row exists. In that case it first deletes the row and re-inserts with new values. For that reason we keep it as an Insert struct. Replaces are currently disallowed in sharded schemas because of the implications the deletion part may have on vindexes. If you add fields here, consider adding them to calls to validateUnshardedRoute.
func (*Insert) Accept ¶
func (node *Insert) Accept(vis SQLAstVisitor) error
type InsertRows ¶
type InsertRows interface { SQLNode // contains filtered or unexported methods }
InsertRows represents the rows for an INSERT statement.
type InsertValues ¶
InsertValues is a custom SQL encoder for the values of an insert statement.
func (InsertValues) EncodeSQL ¶
func (iv InsertValues) EncodeSQL(buf *strings.Builder)
EncodeSQL performs the SQL encoding for InsertValues.
type IntervalExpr ¶
IntervalExpr represents a date-time INTERVAL expression.
func (*IntervalExpr) Accept ¶
func (node *IntervalExpr) Accept(vis SQLAstVisitor) error
func (*IntervalExpr) Format ¶
func (node *IntervalExpr) Format(buf *TrackedBuffer)
Format formats the node.
type IsExpr ¶
IsExpr represents an IS ... or an IS NOT ... expression.
func (*IsExpr) Accept ¶
func (node *IsExpr) Accept(vis SQLAstVisitor) error
type IsolationLevel ¶
type IsolationLevel struct {
Level string
}
IsolationLevel is self-explanatory in this context
func (*IsolationLevel) Accept ¶
func (node *IsolationLevel) Accept(vis SQLAstVisitor) error
func (*IsolationLevel) Format ¶
func (node *IsolationLevel) Format(buf *TrackedBuffer)
Format formats the node.
type JoinCondition ¶
JoinCondition represents the join conditions (either a ON or USING clause) of a JoinTableExpr.
func (JoinCondition) Accept ¶
func (node JoinCondition) Accept(vis SQLAstVisitor) error
func (JoinCondition) Format ¶
func (node JoinCondition) Format(buf *TrackedBuffer)
Format formats the node.
type JoinTableExpr ¶
type JoinTableExpr struct { LeftExpr TableExpr Join string RightExpr TableExpr Condition JoinCondition }
JoinTableExpr represents a TableExpr that's a JOIN operation.
func (*JoinTableExpr) Accept ¶
func (node *JoinTableExpr) Accept(vis SQLAstVisitor) error
func (*JoinTableExpr) Format ¶
func (node *JoinTableExpr) Format(buf *TrackedBuffer)
Format formats the node.
type LengthScaleOption ¶
LengthScaleOption is used for types that have an optional length and scale
type Limit ¶
type Limit struct {
Offset, Rowcount Expr
}
Limit represents a LIMIT clause.
func (*Limit) Accept ¶
func (node *Limit) Accept(vis SQLAstVisitor) error
type ListArg ¶
type ListArg []byte
ListArg represents a named list argument.
func (ListArg) Accept ¶
func (node ListArg) Accept(vis SQLAstVisitor) error
type ListArgConcatamer ¶
type ListArgConcatamer []ListArg
ListArgConcatamer represents a concatamer string of apparent list arguments / postgres cast operators.
func (ListArgConcatamer) String ¶
func (lac ListArgConcatamer) String() string
type MarginComments ¶
MarginComments holds the leading and trailing comments that surround a query.
func SplitMarginComments ¶
func SplitMarginComments(sql string) (query string, comments MarginComments)
SplitMarginComments pulls out any leading or trailing comments from a raw sql query. This function also trims leading (if there's a comment) and trailing whitespace.
type MatchExpr ¶
type MatchExpr struct { Columns SelectExprs Expr Expr Option string }
MatchExpr represents a call to the MATCH function
func (*MatchExpr) Accept ¶
func (node *MatchExpr) Accept(vis SQLAstVisitor) error
func (*MatchExpr) Format ¶
func (node *MatchExpr) Format(buf *TrackedBuffer)
Format formats the node
type NativeQuery ¶
Purge represents a PURGE statement
func NewNativeQuery ¶
func NewNativeQuery(comments Comments, queryString string) *NativeQuery
NewNativeQuery makes a new NativeQuery.
func (*NativeQuery) Accept ¶
func (node *NativeQuery) Accept(vis SQLAstVisitor) error
func (*NativeQuery) Format ¶
func (node *NativeQuery) Format(buf *TrackedBuffer)
type Nextval ¶
type Nextval struct {
Expr Expr
}
Nextval defines the NEXT VALUE expression.
func (Nextval) Accept ¶
func (node Nextval) Accept(vis SQLAstVisitor) error
type NodeFormatter ¶
type NodeFormatter func(buf *TrackedBuffer, node SQLNode)
NodeFormatter defines the signature of a custom node formatter function that can be given to TrackedBuffer for code generation.
type NotExpr ¶
type NotExpr struct {
Expr Expr
}
NotExpr represents a NOT expression.
func (*NotExpr) Accept ¶
func (node *NotExpr) Accept(vis SQLAstVisitor) error
type NullVal ¶
type NullVal struct{}
NullVal represents a NULL value.
func (*NullVal) Accept ¶
func (node *NullVal) Accept(vis SQLAstVisitor) error
type OnDup ¶
type OnDup UpdateExprs
OnDup represents an ON DUPLICATE KEY clause.
func (OnDup) Accept ¶
func (node OnDup) Accept(vis SQLAstVisitor) error
type OptLike ¶
type OptLike struct {
LikeTable TableName
}
OptLike works for create table xxx like xxx
func (*OptLike) Accept ¶
func (node *OptLike) Accept(vis SQLAstVisitor) error
type OrExpr ¶
type OrExpr struct {
Left, Right Expr
}
OrExpr represents an OR expression.
func (*OrExpr) Accept ¶
func (node *OrExpr) Accept(vis SQLAstVisitor) error
type Order ¶
Order represents an ordering expression.
func (*Order) Accept ¶
func (node *Order) Accept(vis SQLAstVisitor) error
type OrderBy ¶
type OrderBy []*Order
OrderBy represents an ORDER By clause.
func (OrderBy) Accept ¶
func (node OrderBy) Accept(vis SQLAstVisitor) error
type OtherAdmin ¶
type OtherAdmin struct{}
OtherAdmin represents a misc statement that relies on ADMIN privileges, such as REPAIR, OPTIMIZE, or TRUNCATE statement. It should be used only as an indicator. It does not contain the full AST for the statement.
func (*OtherAdmin) Accept ¶
func (node *OtherAdmin) Accept(vis SQLAstVisitor) error
func (*OtherAdmin) Format ¶
func (node *OtherAdmin) Format(buf *TrackedBuffer)
Format formats the node.
type OtherRead ¶
type OtherRead struct{}
OtherRead represents a DESCRIBE, or EXPLAIN statement. It should be used only as an indicator. It does not contain the full AST for the statement.
func (*OtherRead) Accept ¶
func (node *OtherRead) Accept(vis SQLAstVisitor) error
func (*OtherRead) Format ¶
func (node *OtherRead) Format(buf *TrackedBuffer)
Format formats the node.
type ParenSelect ¶
type ParenSelect struct {
Select SelectStatement
}
ParenSelect is a parenthesized SELECT statement.
func (*ParenSelect) Accept ¶
func (node *ParenSelect) Accept(vis SQLAstVisitor) error
func (*ParenSelect) AddOrder ¶
func (node *ParenSelect) AddOrder(order *Order)
AddOrder adds an order by element
func (*ParenSelect) Format ¶
func (node *ParenSelect) Format(buf *TrackedBuffer)
Format formats the node.
func (*ParenSelect) SetLimit ¶
func (node *ParenSelect) SetLimit(limit *Limit)
SetLimit sets the limit clause
func (*ParenSelect) SetLock ¶
func (node *ParenSelect) SetLock(lock string)
SetLock sets the lock clause
type ParenTableExpr ¶
type ParenTableExpr struct {
Exprs TableExprs
}
ParenTableExpr represents a parenthesized list of TableExpr.
func (*ParenTableExpr) Accept ¶
func (node *ParenTableExpr) Accept(vis SQLAstVisitor) error
func (*ParenTableExpr) Format ¶
func (node *ParenTableExpr) Format(buf *TrackedBuffer)
Format formats the node.
type ParsedQuery ¶
type ParsedQuery struct { Query string // contains filtered or unexported fields }
ParsedQuery represents a parsed query where bind locations are precompued for fast substitutions.
func BuildParsedQuery ¶
func BuildParsedQuery(in string, vars ...interface{}) *ParsedQuery
BuildParsedQuery builds a ParsedQuery from the input.
func NewParsedQuery ¶
func NewParsedQuery(node SQLNode) *ParsedQuery
NewParsedQuery returns a ParsedQuery of the ast.
func (*ParsedQuery) Append ¶
func (pq *ParsedQuery) Append(buf *strings.Builder, bindVariables map[string]*querypb.BindVariable, extras map[string]Encodable) error
Append appends the generated query to the provided buffer.
func (*ParsedQuery) GenerateQuery ¶
func (pq *ParsedQuery) GenerateQuery(bindVariables map[string]*querypb.BindVariable, extras map[string]Encodable) (string, error)
GenerateQuery generates a query by substituting the specified bindVariables. The extras parameter specifies special parameters that can perform custom encoding.
func (*ParsedQuery) MarshalJSON ¶
func (pq *ParsedQuery) MarshalJSON() ([]byte, error)
MarshalJSON is a custom JSON marshaler for ParsedQuery. Note that any queries longer that 512 bytes will be truncated.
type PartitionDefinition ¶
PartitionDefinition describes a very minimal partition definition
func (*PartitionDefinition) Accept ¶
func (node *PartitionDefinition) Accept(vis SQLAstVisitor) error
func (*PartitionDefinition) Format ¶
func (node *PartitionDefinition) Format(buf *TrackedBuffer)
Format formats the node
type PartitionSpec ¶
type PartitionSpec struct { Action string Name ColIdent Definitions []*PartitionDefinition }
PartitionSpec describe partition actions (for alter and create)
func (*PartitionSpec) Accept ¶
func (node *PartitionSpec) Accept(vis SQLAstVisitor) error
func (*PartitionSpec) Format ¶
func (node *PartitionSpec) Format(buf *TrackedBuffer)
Format formats the node.
type Partitions ¶
type Partitions Columns
Partitions is a type alias for Columns so we can handle printing efficiently
func (Partitions) Accept ¶
func (node Partitions) Accept(vis SQLAstVisitor) error
func (Partitions) Format ¶
func (node Partitions) Format(buf *TrackedBuffer)
Format formats the node
type PositionedErr ¶
PositionedErr holds context related to parser errors
func (PositionedErr) Error ¶
func (p PositionedErr) Error() string
type Precendence ¶
type Precendence int
Precendence is used to know the precedence between operators, so we can introduce parens when needed in the String representation of the AST
const ( Syntactic Precendence = iota P1 P2 P3 P4 P5 P6 P7 P8 P9 P10 P11 P12 P13 P14 P15 P16 P17 )
type Purge ¶
Purge represents a PURGE statement
func (*Purge) Accept ¶
func (node *Purge) Accept(vis SQLAstVisitor) error
func (*Purge) Format ¶
func (node *Purge) Format(buf *TrackedBuffer)
type RangeCond ¶
RangeCond represents a BETWEEN or a NOT BETWEEN expression.
func (*RangeCond) Accept ¶
func (node *RangeCond) Accept(vis SQLAstVisitor) error
func (*RangeCond) Format ¶
func (node *RangeCond) Format(buf *TrackedBuffer)
Format formats the node.
type ReferenceAction ¶
type ReferenceAction int
ReferenceAction indicates the action takes by a referential constraint e.g. the `CASCADE` in a `FOREIGN KEY .. ON DELETE CASCADE` table definition.
const ( // DefaultAction indicates no action was explicitly specified. DefaultAction ReferenceAction = iota Restrict Cascade NoAction SetNull SetDefault )
These map to the SQL-defined reference actions. See https://dev.mysql.com/doc/refman/8.0/en/create-table-foreign-keys.html#foreign-keys-referential-actions
func (ReferenceAction) Accept ¶
func (node ReferenceAction) Accept(vis SQLAstVisitor) error
func (ReferenceAction) Format ¶
func (a ReferenceAction) Format(buf *TrackedBuffer)
Format formats the node.
type RefreshMaterializedView ¶
type RefreshMaterializedView struct { Concurrently bool ViewName TableName WithData bool ImplicitSelect SelectStatement // This is mutated during analysis. }
Statements
func (*RefreshMaterializedView) Accept ¶
func (node *RefreshMaterializedView) Accept(vis SQLAstVisitor) error
func (*RefreshMaterializedView) Format ¶
func (node *RefreshMaterializedView) Format(buf *TrackedBuffer)
type Registry ¶
Statements
func (*Registry) Accept ¶
func (node *Registry) Accept(vis SQLAstVisitor) error
type Release ¶
type Release struct {
Name ColIdent
}
Release represents a release savepoint statement.
func (*Release) Accept ¶
func (node *Release) Accept(vis SQLAstVisitor) error
type RewriteASTResult ¶
type RewriteASTResult struct { BindVarNeeds AST Statement // The rewritten AST }
RewriteASTResult contains the rewritten ast and meta information about it
func PrepareAST ¶
func PrepareAST(in Statement, bindVars map[string]*querypb.BindVariable, prefix string, parameterize bool) (*RewriteASTResult, error)
PrepareAST will normalize the query
func RewriteAST ¶
func RewriteAST(in Statement) (*RewriteASTResult, error)
RewriteAST rewrites the whole AST, replacing function calls and adding column aliases to queries
type Rollback ¶
type Rollback struct{}
Rollback represents a Rollback statement.
func (*Rollback) Accept ¶
func (node *Rollback) Accept(vis SQLAstVisitor) error
type SQLAstVisitor ¶
type SQLNode ¶
type SQLNode interface { Format(buf *TrackedBuffer) Accept(SQLAstVisitor) error }
SQLNode defines the interface for all nodes generated by the parser.
func Rewrite ¶
Rewrite traverses a syntax tree recursively, starting with root, and calling pre and post for each node as described below. Rewrite returns the syntax tree, possibly modified.
If pre is not nil, it is called for each node before the node's children are traversed (pre-order). If pre returns false, no children are traversed, and post is not called for that node.
If post is not nil, and a prior call of pre didn't return false, post is called for each node after its children are traversed (post-order). If post returns false, traversal is terminated and Apply returns immediately.
Only fields that refer to AST nodes are considered children; i.e., fields of basic types (strings, []byte, etc.) are ignored.
type SQLVal ¶
SQLVal represents a single value.
func (*SQLVal) Accept ¶
func (node *SQLVal) Accept(vis SQLAstVisitor) error
type SRollback ¶
type SRollback struct {
Name ColIdent
}
SRollback represents a rollback to savepoint statement.
func (*SRollback) Accept ¶
func (node *SRollback) Accept(vis SQLAstVisitor) error
func (*SRollback) Format ¶
func (node *SRollback) Format(buf *TrackedBuffer)
Format formats the node.
type Savepoint ¶
type Savepoint struct {
Name ColIdent
}
Savepoint represents a savepoint statement.
func (*Savepoint) Accept ¶
func (node *Savepoint) Accept(vis SQLAstVisitor) error
func (*Savepoint) Format ¶
func (node *Savepoint) Format(buf *TrackedBuffer)
Format formats the node.
type Select ¶
type Select struct { Cache *bool // a reference here so it can be nil Distinct bool StraightJoinHint bool SQLCalcFoundRows bool Comments Comments SelectExprs SelectExprs From TableExprs Where *Where GroupBy GroupBy Having *Where OrderBy OrderBy Limit *Limit Lock string }
Select represents a SELECT statement.
func NewSelect ¶
func NewSelect(comments Comments, exprs SelectExprs, selectOptions []string, from TableExprs, where *Where, groupBy GroupBy, having *Where) *Select
NewSelect is used to create a select statement
func (*Select) Accept ¶
func (node *Select) Accept(vis SQLAstVisitor) error
func (*Select) AddHaving ¶
AddHaving adds the boolean expression to the HAVING clause as an AND condition.
type SelectExpr ¶
type SelectExpr interface { SQLNode // contains filtered or unexported methods }
SelectExpr represents a SELECT expression.
type SelectExprs ¶
type SelectExprs []SelectExpr
SelectExprs represents SELECT expressions.
func (SelectExprs) Accept ¶
func (node SelectExprs) Accept(vis SQLAstVisitor) error
func (SelectExprs) Format ¶
func (node SelectExprs) Format(buf *TrackedBuffer)
Format formats the node.
type SelectStatement ¶
type SelectStatement interface { AddOrder(*Order) SetLimit(*Limit) SetLock(lock string) SQLNode // contains filtered or unexported methods }
SelectStatement any SELECT statement.
type Set ¶
Set represents a SET statement.
func (*Set) Accept ¶
func (node *Set) Accept(vis SQLAstVisitor) error
type SetExpr ¶
SetExpr represents a set expression.
func (*SetExpr) Accept ¶
func (node *SetExpr) Accept(vis SQLAstVisitor) error
type SetExprs ¶
type SetExprs []*SetExpr
SetExprs represents a list of set expressions.
func (SetExprs) Accept ¶
func (node SetExprs) Accept(vis SQLAstVisitor) error
type SetTransaction ¶
type SetTransaction struct { SQLNode Comments Comments Scope string Characteristics []Characteristic }
SetTransaction represents a SET TRANSACTION statement.
func (*SetTransaction) Accept ¶
func (node *SetTransaction) Accept(vis SQLAstVisitor) error
func (*SetTransaction) Format ¶
func (node *SetTransaction) Format(buf *TrackedBuffer)
Format formats the node.
type Show ¶
type Show struct { Extended string Type string OnTable TableName Table TableName ShowTablesOpt *ShowTablesOpt Scope string ShowCollationFilterOpt Expr Columns Columns Comments Comments }
Show represents a show statement.
func (*Show) Accept ¶
func (node *Show) Accept(vis SQLAstVisitor) error
func (*Show) HasOnTable ¶
HasOnTable returns true if the show statement has an "on" clause
type ShowFilter ¶
ShowFilter is show tables filter
func (*ShowFilter) Accept ¶
func (node *ShowFilter) Accept(vis SQLAstVisitor) error
func (*ShowFilter) Format ¶
func (node *ShowFilter) Format(buf *TrackedBuffer)
Format formats the node.
type ShowTablesOpt ¶
type ShowTablesOpt struct { Full string DbName string Filter *ShowFilter }
ShowTablesOpt is show tables option
type SimpleTableExpr ¶
type SimpleTableExpr interface { SQLNode // contains filtered or unexported methods }
SimpleTableExpr represents a simple table expression.
type Sleep ¶
type Sleep struct {
Duration *SQLVal
}
Statements
func (*Sleep) Accept ¶
func (node *Sleep) Accept(vis SQLAstVisitor) error
type StarExpr ¶
type StarExpr struct {
TableName TableName
}
StarExpr defines a '*' or 'table.*' expression.
func (*StarExpr) Accept ¶
func (node *StarExpr) Accept(vis SQLAstVisitor) error
type Statement ¶
type Statement interface { SQLNode // contains filtered or unexported methods }
Statement represents a statement.
func Parse ¶
Parse parses the SQL in full and returns a Statement, which is the AST representation of the query. If a DDL statement is partially parsed but still contains a syntax error, the error is ignored and the DDL is returned anyway.
func ParseNext ¶
ParseNext parses a single SQL statement from the tokenizer returning a Statement which is the AST representation of the query. The tokenizer will always read up to the end of the statement, allowing for the next call to ParseNext to parse any subsequent SQL statements. When there are no more statements to parse, a error of io.EOF is returned.
func ParseNextStrictDDL ¶
ParseNextStrictDDL is the same as ParseNext except it errors on partially parsed DDL statements.
func ParseStrictDDL ¶
ParseStrictDDL is the same as Parse except it errors on partially parsed DDL statements.
type StatementType ¶
type StatementType int
StatementType encodes the type of a SQL statement
const ( StmtSelect StatementType = iota StmtStream StmtInsert StmtReplace StmtUpdate StmtDelete StmtDDL StmtBegin StmtCommit StmtRollback StmtSet StmtShow StmtUse StmtOther StmtUnknown StmtComment StmtPriv StmtExplain )
These constants are used to identify the SQL statement type. Changing this list will require reviewing all calls to Preview.
func ASTToStatementType ¶
func ASTToStatementType(stmt Statement) StatementType
ASTToStatementType returns a StatementType from an AST stmt
func Preview ¶
func Preview(sql string) StatementType
Preview analyzes the beginning of the query using a simpler and faster textual comparison to identify the statement type.
func (StatementType) String ¶
func (s StatementType) String() string
type Stream ¶
type Stream struct { Comments Comments SelectExpr SelectExpr Table TableName }
Stream represents a SELECT statement.
func (*Stream) Accept ¶
func (node *Stream) Accept(vis SQLAstVisitor) error
type Subquery ¶
type Subquery struct {
Select SelectStatement
}
Subquery represents a subquery.
func (*Subquery) Accept ¶
func (node *Subquery) Accept(vis SQLAstVisitor) error
type SubstrExpr ¶
SubstrExpr represents a call to SubstrExpr(column, value_expression) or SubstrExpr(column, value_expression,value_expression) also supported syntax SubstrExpr(column from value_expression for value_expression). Additionally to column names, SubstrExpr is also supported for string values, e.g.: SubstrExpr('static string value', value_expression, value_expression) In this case StrVal will be set instead of Name.
func (*SubstrExpr) Accept ¶
func (node *SubstrExpr) Accept(vis SQLAstVisitor) error
func (*SubstrExpr) Format ¶
func (node *SubstrExpr) Format(buf *TrackedBuffer)
Format formats the node.
type TableExpr ¶
type TableExpr interface { SQLNode // contains filtered or unexported methods }
TableExpr represents a table expression.
type TableExprs ¶
type TableExprs []TableExpr
TableExprs represents a list of table expressions.
func (TableExprs) Accept ¶
func (node TableExprs) Accept(vis SQLAstVisitor) error
func (TableExprs) Format ¶
func (node TableExprs) Format(buf *TrackedBuffer)
Format formats the node.
type TableIdent ¶
type TableIdent struct {
// contains filtered or unexported fields
}
TableIdent is a case sensitive SQL identifier. It will be escaped with backquotes if necessary.
func GetTableName ¶
func GetTableName(node SimpleTableExpr) TableIdent
GetTableName returns the table name from the SimpleTableExpr only if it's a simple expression. Otherwise, it returns "".
func NewTableIdent ¶
func NewTableIdent(str string) TableIdent
NewTableIdent creates a new TableIdent.
func (TableIdent) Accept ¶
func (node TableIdent) Accept(vis SQLAstVisitor) error
func (TableIdent) CompliantName ¶
func (node TableIdent) CompliantName() string
CompliantName returns a compliant id name that can be used for a bind var.
func (TableIdent) Format ¶
func (node TableIdent) Format(buf *TrackedBuffer)
Format formats the node.
func (TableIdent) GetRawVal ¶
func (node TableIdent) GetRawVal() string
func (TableIdent) IsEmpty ¶
func (node TableIdent) IsEmpty() bool
IsEmpty returns true if TabIdent is empty.
func (TableIdent) MarshalJSON ¶
func (node TableIdent) MarshalJSON() ([]byte, error)
MarshalJSON marshals into JSON.
func (TableIdent) String ¶
func (node TableIdent) String() string
String returns the unescaped table name. It must not be used for SQL generation. Use sqlparser.String instead. The Stringer conformance is for usage in templates.
func (*TableIdent) UnmarshalJSON ¶
func (node *TableIdent) UnmarshalJSON(b []byte) error
UnmarshalJSON unmarshals from JSON.
type TableName ¶
type TableName struct {
Name, Qualifier, QualifierSecond, QualifierThird TableIdent
}
TableName represents a table name. Qualifier, if specified, represents a database or keyspace. TableName is a value struct whose fields are case sensitive. This means two TableName vars can be compared for equality and a TableName can also be used as key in a map.
func TableFromStatement ¶
TableFromStatement returns the qualified table name for the query. This works only for select statements.
func (TableName) Accept ¶
func (node TableName) Accept(vis SQLAstVisitor) error
func (TableName) ToViewName ¶
ToViewName returns a TableName acceptable for use as a VIEW. VIEW names are always lowercase, so ToViewName lowercasese the name. Databases are case-sensitive so Qualifier is left untouched.
type TableNames ¶
type TableNames []TableName
TableNames is a list of TableName.
func (TableNames) Accept ¶
func (node TableNames) Accept(vis SQLAstVisitor) error
func (TableNames) Format ¶
func (node TableNames) Format(buf *TrackedBuffer)
Format formats the node.
type TableSpec ¶
type TableSpec struct { Columns []*ColumnDefinition Indexes []*IndexDefinition Constraints []*ConstraintDefinition Options string }
TableSpec describes the structure of a table from a CREATE TABLE statement
func (*TableSpec) Accept ¶
func (node *TableSpec) Accept(vis SQLAstVisitor) error
func (*TableSpec) AddColumn ¶
func (ts *TableSpec) AddColumn(cd *ColumnDefinition)
AddColumn appends the given column to the list in the spec
func (*TableSpec) AddConstraint ¶
func (ts *TableSpec) AddConstraint(cd *ConstraintDefinition)
AddConstraint appends the given index to the list in the spec
func (*TableSpec) AddIndex ¶
func (ts *TableSpec) AddIndex(id *IndexDefinition)
AddIndex appends the given index to the list in the spec
type TableValuedFuncTableExpr ¶
type TableValuedFuncTableExpr struct { FuncExpr Expr As TableIdent }
TableValuedFuncTableExpr represents a call to a table-valued function.
func (*TableValuedFuncTableExpr) Accept ¶
func (node *TableValuedFuncTableExpr) Accept(vis SQLAstVisitor) error
func (*TableValuedFuncTableExpr) Format ¶
func (node *TableValuedFuncTableExpr) Format(buf *TrackedBuffer)
Format formats the node.
type TimestampFuncExpr ¶
TimestampFuncExpr represents the function and arguments for TIMESTAMP{ADD,DIFF} functions.
func (*TimestampFuncExpr) Accept ¶
func (node *TimestampFuncExpr) Accept(vis SQLAstVisitor) error
func (*TimestampFuncExpr) Format ¶
func (node *TimestampFuncExpr) Format(buf *TrackedBuffer)
Format formats the node.
type Tokenizer ¶
type Tokenizer struct { InStream io.Reader AllowComments bool SkipSpecialComments bool SkipToEnd bool Position int LastError error ParseTree Statement // contains filtered or unexported fields }
Tokenizer is the struct used to generate SQL tokens for the parser.
func NewStringTokenizer ¶
NewStringTokenizer creates a new Tokenizer for the sql string.
func NewTokenizer ¶
NewTokenizer creates a new Tokenizer reading a sql string from the io.Reader.
type TrackedBuffer ¶
TrackedBuffer is used to rebuild a query from the ast. bindLocations keeps track of locations in the buffer that use bind variables for efficient future substitutions. nodeFormatter is the formatting function the buffer will use to format a node. By default(nil), it's FormatNode. But you can supply a different formatting function if you want to generate a query that's different from the default.
func NewTrackedBuffer ¶
func NewTrackedBuffer(nodeFormatter NodeFormatter) *TrackedBuffer
NewTrackedBuffer creates a new TrackedBuffer.
func (*TrackedBuffer) AstPrintf ¶
func (buf *TrackedBuffer) AstPrintf(currentNode SQLNode, format string, values ...interface{})
func (*TrackedBuffer) HasBindVars ¶
func (buf *TrackedBuffer) HasBindVars() bool
HasBindVars returns true if the parsed query uses bind vars.
func (*TrackedBuffer) IsDelimitCols ¶
func (buf *TrackedBuffer) IsDelimitCols() bool
func (*TrackedBuffer) Myprintf ¶
func (buf *TrackedBuffer) Myprintf(format string, values ...interface{})
Myprintf mimics fmt.Fprintf(buf, ...), but limited to Node(%v), Node.Value(%s) and string(%s). It also allows a %a for a value argument, in which case it adds tracking info for future substitutions. It adds parens as needed to follow precedence rules when printing expressions
The name must be something other than the usual Printf() to avoid "go vet" warnings due to our custom format specifiers. *** THIS METHOD SHOULD NOT BE USED FROM ast.go. USE astPrintf INSTEAD ***
func (*TrackedBuffer) ParsedQuery ¶
func (buf *TrackedBuffer) ParsedQuery() *ParsedQuery
ParsedQuery returns a ParsedQuery that contains bind locations for easy substitution.
func (*TrackedBuffer) WithDelimitCols ¶
func (buf *TrackedBuffer) WithDelimitCols(isDelimitCols bool) *TrackedBuffer
func (*TrackedBuffer) WriteArg ¶
func (buf *TrackedBuffer) WriteArg(arg string)
WriteArg writes a value argument into the buffer along with tracking information for future substitutions. arg must contain the ":" or "::" prefix.
func (*TrackedBuffer) WriteNode ¶
func (buf *TrackedBuffer) WriteNode(node SQLNode) *TrackedBuffer
WriteNode function, initiates the writing of a single SQLNode tree by passing through to Myprintf with a default format string
type TupleEqualityList ¶
TupleEqualityList is for generating equality constraints for tables that have composite primary keys.
func (*TupleEqualityList) EncodeSQL ¶
func (tpl *TupleEqualityList) EncodeSQL(buf *strings.Builder)
EncodeSQL generates the where clause constraints for the tuple equality.
type UnaryCastConcatamerExpr ¶
type UnaryCastConcatamerExpr struct { CastConcatamer ListArgConcatamer Expr Expr }
UnaryCastConcatamerExpr represents an expression with a casting concatamer suffix.
func (*UnaryCastConcatamerExpr) Accept ¶
func (node *UnaryCastConcatamerExpr) Accept(vis SQLAstVisitor) error
func (*UnaryCastConcatamerExpr) Format ¶
func (node *UnaryCastConcatamerExpr) Format(buf *TrackedBuffer)
Format formats the node.
type UnaryExpr ¶
UnaryExpr represents a unary value expression.
func (*UnaryExpr) Accept ¶
func (node *UnaryExpr) Accept(vis SQLAstVisitor) error
func (*UnaryExpr) Format ¶
func (node *UnaryExpr) Format(buf *TrackedBuffer)
Format formats the node.
type Union ¶
type Union struct { FirstStatement SelectStatement UnionSelects []*UnionSelect OrderBy OrderBy Limit *Limit Lock string }
Union represents a UNION statement.
func (*Union) Accept ¶
func (node *Union) Accept(vis SQLAstVisitor) error
type UnionSelect ¶
type UnionSelect struct { Type string Statement SelectStatement }
UnionSelect represents union type and select statement after first select statement.
func (*UnionSelect) Accept ¶
func (node *UnionSelect) Accept(vis SQLAstVisitor) error
func (*UnionSelect) Format ¶
func (node *UnionSelect) Format(buf *TrackedBuffer)
Format formats the node.
type Update ¶
type Update struct { Action string Comments Comments Ignore string TableExprs TableExprs Exprs UpdateExprs From TableExprs Where *Where OrderBy OrderBy Limit *Limit }
Update represents an UPDATE statement. If you add fields here, consider adding them to calls to validateUnshardedRoute.
func (*Update) Accept ¶
func (node *Update) Accept(vis SQLAstVisitor) error
type UpdateExpr ¶
UpdateExpr represents an update expression.
func (*UpdateExpr) Accept ¶
func (node *UpdateExpr) Accept(vis SQLAstVisitor) error
func (*UpdateExpr) Format ¶
func (node *UpdateExpr) Format(buf *TrackedBuffer)
Format formats the node.
type UpdateExprs ¶
type UpdateExprs []*UpdateExpr
UpdateExprs represents a list of update expressions.
func (UpdateExprs) Accept ¶
func (node UpdateExprs) Accept(vis SQLAstVisitor) error
func (UpdateExprs) Format ¶
func (node UpdateExprs) Format(buf *TrackedBuffer)
Format formats the node.
type Use ¶
type Use struct {
DBName TableIdent
}
Use represents a use statement.
func (*Use) Accept ¶
func (node *Use) Accept(vis SQLAstVisitor) error
type ValTuple ¶
type ValTuple Exprs
ValTuple represents a tuple of actual values.
func (ValTuple) Accept ¶
func (node ValTuple) Accept(vis SQLAstVisitor) error
type Values ¶
type Values []ValTuple
Values represents a VALUES clause.
func (Values) Accept ¶
func (node Values) Accept(vis SQLAstVisitor) error
type ValuesFuncExpr ¶
type ValuesFuncExpr struct {
Name *ColName
}
ValuesFuncExpr represents a function call.
func (*ValuesFuncExpr) Accept ¶
func (node *ValuesFuncExpr) Accept(vis SQLAstVisitor) error
func (*ValuesFuncExpr) Format ¶
func (node *ValuesFuncExpr) Format(buf *TrackedBuffer)
Format formats the node.
type VindexParam ¶
VindexParam defines a key/value parameter for a CREATE VINDEX statement
func (VindexParam) Accept ¶
func (node VindexParam) Accept(vis SQLAstVisitor) error
func (VindexParam) Format ¶
func (node VindexParam) Format(buf *TrackedBuffer)
Format formats the node.
type VindexSpec ¶
type VindexSpec struct { Name ColIdent Type ColIdent Params []VindexParam }
VindexSpec defines a vindex for a CREATE VINDEX or DROP VINDEX statement
func (*VindexSpec) Accept ¶
func (node *VindexSpec) Accept(vis SQLAstVisitor) error
func (*VindexSpec) Format ¶
func (node *VindexSpec) Format(buf *TrackedBuffer)
Format formats the node. The "CREATE VINDEX" preamble was formatted in the containing DDL node Format, so this just prints the type, any parameters, and optionally the owner
func (*VindexSpec) ParseParams ¶
func (node *VindexSpec) ParseParams() (string, map[string]string)
ParseParams parses the vindex parameter list, pulling out the special-case "owner" parameter
type Visit ¶
Visit defines the signature of a function that can be used to visit all nodes of a parse tree.
type When ¶
When represents a WHEN sub-expression.
func (*When) Accept ¶
func (node *When) Accept(vis SQLAstVisitor) error
Source Files ¶
- analyzer.go
- ast.go
- ast_funcs.go
- comments.go
- constants.go
- encodable.go
- expression_converter.go
- expression_rewriting.go
- external_visitor.go
- fuzz.go
- impossible_query.go
- like_filter.go
- normalizer.go
- parsed_query.go
- parser.go
- precedence.go
- random_expr.go
- redact_query.go
- rewriter.go
- rewriter_api.go
- set_normalizer.go
- sql.y
- token.go
- tracked_buffer.go
- truncate_query.go
Directories ¶
Path | Synopsis |
---|---|
Package visitorgen is responsible for taking the ast.go of Vitess and and producing visitor infrastructure for it.
|
Package visitorgen is responsible for taking the ast.go of Vitess and and producing visitor infrastructure for it. |