Versions in this module Expand all Collapse all v0 v0.6.1 Jun 12, 2020 Changes in this version + var DescribeSchema = sql.Schema + var EmptyTable = new(emptyTable) + var ErrAddForeignKeyDuplicateColumn = errors.NewKind("cannot have duplicates of columns in a foreign key: `%v`") + var ErrAlterTableNotSupported = errors.NewKind("table %s cannot be altered on database %s") + var ErrColumnNotFound = errors.NewKind("table %s does not have column %s") + var ErrCreateIndexDuplicateColumn = errors.NewKind("cannot have duplicates of columns in an index: `%v`") + var ErrCreateIndexMissingColumns = errors.NewKind("cannot create an index without columns") + var ErrCreateIndexNonExistentColumn = errors.NewKind("column `%v` does not exist in the table") + var ErrCreateTableNotSupported = errors.NewKind("tables cannot be created on database %s") + var ErrDeleteFromNotSupported = errors.NewKind("table doesn't support DELETE FROM") + var ErrDropTableNotSupported = errors.NewKind("tables cannot be dropped on database %s") + var ErrExprTypeNotIndexable = errors.NewKind("expression %q with type %s cannot be indexed") + var ErrForeignKeyMissingColumns = errors.NewKind("cannot create a foreign key without columns") + var ErrGroupBy = errors.NewKind("group by aggregation '%v' not supported") + var ErrIncompatibleDefaultType = errors.NewKind("incompatible type for default value") + var ErrIndexActionNotImplemented = errors.NewKind("alter table index action is not implemented: %v") + var ErrIndexNotAvailable = errors.NewKind("index %q is still not ready for usage and can't be deleted") + var ErrIndexNotFound = errors.NewKind("unable to find index %q on table %q of database %q") + var ErrIndexedTableAccessNotInitialized = errors.NewKind("IndexedTableAccess must be initialized before RowIter is called") + var ErrInsertIntoDuplicateColumn = errors.NewKind("duplicate column name %v") + var ErrInsertIntoIncompatibleTypes = errors.NewKind("cannot convert type %s to %s") + var ErrInsertIntoMismatchValueCount = errors.NewKind("number of values does not match number of columns provided") + var ErrInsertIntoNonNullableDefaultNullColumn = errors.NewKind("column name '%v' is non-nullable but attempted to set default value of null") + var ErrInsertIntoNonNullableProvidedNull = errors.NewKind("column name '%v' is non-nullable but attempted to set a value of null") + var ErrInsertIntoNonexistentColumn = errors.NewKind("invalid column name %v") + var ErrInsertIntoNotSupported = errors.NewKind("table doesn't support INSERT INTO") + var ErrInsertIntoUnsupportedValues = errors.NewKind("%T is unsupported for inserts") + var ErrInvalidIndexDriver = errors.NewKind("invalid driver index %q") + var ErrNoForeignKeySupport = errors.NewKind("the table does not support foreign key operations: %s") + var ErrNoIndexableTable = errors.NewKind("expected an IndexableTable, couldn't find one in %v") + var ErrNoIndexedTableAccess = errors.NewKind("expected an IndexedTableAccess, couldn't find one in %v") + var ErrNoPartitionable = errors.NewKind("no partitionable node found in exchange tree") + var ErrNotIndexable = errors.NewKind("the table is not indexable") + var ErrNotView = errors.NewKind("'%' is not VIEW") + var ErrNullDefault = errors.NewKind("column declared not null must have a non-null default value") + var ErrRenameTableNotSupported = errors.NewKind("tables cannot be renamed on database %s") + var ErrReplaceIntoNotSupported = errors.NewKind("table doesn't support REPLACE INTO") + var ErrTableCreatedNotFound = errors.NewKind("table was created but could not be found") + var ErrTableNotLockable = errors.NewKind("table %s is not lockable") + var ErrTableNotNameable = errors.NewKind("can't get name from table") + var ErrTableNotValid = errors.NewKind("table is not valid") + var ErrUnableSort = errors.NewKind("unable to sort") + var ErrUnresolvedTable = errors.NewKind("unresolved table") + var ErrUnsupportedFeature = errors.NewKind("unsupported feature: %s") + var ErrUpdateNotSupported = errors.NewKind("table doesn't support UPDATE") + var ErrUpdateUnexpectedSetResult = errors.NewKind("attempted to set field but expression returned %T") + var Nothing nothing + func Inspect(node sql.Node, f func(sql.Node) bool) + func InspectExpressions(node sql.Node, f func(sql.Expression) bool) + func IsBinary(node sql.Node) bool + func IsUnary(node sql.Node) bool + func NewShowCreateTable(db string, ctl *sql.Catalog, table sql.Node, isView bool) sql.Node + func NewShowIndexes(db sql.Database, table string, registry *sql.IndexRegistry) sql.Node + func NillaryWithChildren(node sql.Node, children ...sql.Node) (sql.Node, error) + func TransformExpressions(node sql.Node, f sql.TransformExprFunc) (sql.Node, error) + func TransformExpressionsUp(node sql.Node, f sql.TransformExprFunc) (sql.Node, error) + func TransformUp(node sql.Node, f sql.TransformNodeFunc) (sql.Node, error) + func Walk(v Visitor, node sql.Node) + func WalkExpressions(v sql.Visitor, node sql.Node) + type AddColumn struct + func NewAddColumn(db sql.Database, tableName string, column *sql.Column, order *sql.ColumnOrder) *AddColumn + func (*AddColumn) Schema() sql.Schema + func (a *AddColumn) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (a *AddColumn) String() string + func (a *AddColumn) WithChildren(children ...sql.Node) (sql.Node, error) + func (a *AddColumn) WithDatabase(db sql.Database) (sql.Node, error) + func (c *AddColumn) Children() []sql.Node + func (c *AddColumn) Database() sql.Database + func (c *AddColumn) Resolved() bool + type AlterForeignKey struct + Action ForeignKeyAction + FkDef *ForeignKeyDefinition + func NewAlterAddForeignKey(table sql.Node, fkDef *ForeignKeyDefinition) *AlterForeignKey + func NewAlterDropForeignKey(table sql.Node, fkDef *ForeignKeyDefinition) *AlterForeignKey + func (p *AlterForeignKey) Execute(ctx *sql.Context) error + func (p *AlterForeignKey) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (p *AlterForeignKey) WithChildren(children ...sql.Node) (sql.Node, error) + func (p AlterForeignKey) String() string + type AlterIndex struct + Action IndexAction + Columns []sql.IndexColumn + Comment string + Constraint sql.IndexConstraint + IndexName string + PreviousIndexName string + Table sql.Node + Using sql.IndexUsing + func NewAlterCreateIndex(table sql.Node, indexName string, using sql.IndexUsing, ...) *AlterIndex + func NewAlterDropIndex(table sql.Node, indexName string) *AlterIndex + func NewAlterRenameIndex(table sql.Node, fromIndexName, toIndexName string) *AlterIndex + func (p *AlterIndex) Children() []sql.Node + func (p *AlterIndex) Execute(ctx *sql.Context) error + func (p *AlterIndex) Resolved() bool + func (p *AlterIndex) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (p *AlterIndex) Schema() sql.Schema + func (p *AlterIndex) WithChildren(children ...sql.Node) (sql.Node, error) + func (p AlterIndex) String() string + type BinaryNode struct + Left sql.Node + Right sql.Node + func (n BinaryNode) Children() []sql.Node + func (n BinaryNode) Resolved() bool + type Commit struct + func NewCommit() *Commit + func (*Commit) Children() []sql.Node + func (*Commit) Resolved() bool + func (*Commit) RowIter(*sql.Context) (sql.RowIter, error) + func (*Commit) Schema() sql.Schema + func (*Commit) String() string + func (r *Commit) WithChildren(children ...sql.Node) (sql.Node, error) + type CreateIndex struct + Catalog *sql.Catalog + Config map[string]string + CurrentDatabase string + Driver string + Exprs []sql.Expression + Name string + Table sql.Node + func NewCreateIndex(name string, table sql.Node, exprs []sql.Expression, driver string, ...) *CreateIndex + func (c *CreateIndex) Children() []sql.Node + func (c *CreateIndex) Expressions() []sql.Expression + func (c *CreateIndex) Resolved() bool + func (c *CreateIndex) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (c *CreateIndex) Schema() sql.Schema + func (c *CreateIndex) String() string + func (c *CreateIndex) WithChildren(children ...sql.Node) (sql.Node, error) + func (c *CreateIndex) WithExpressions(exprs ...sql.Expression) (sql.Node, error) + type CreateTable struct + func NewCreateTable(db sql.Database, name string, schema sql.Schema, ifNotExists bool, ...) *CreateTable + func (*CreateTable) Schema() sql.Schema + func (c *CreateTable) Children() []sql.Node + func (c *CreateTable) Database() sql.Database + func (c *CreateTable) Resolved() bool + func (c *CreateTable) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (c *CreateTable) String() string + func (c *CreateTable) WithChildren(children ...sql.Node) (sql.Node, error) + func (c *CreateTable) WithDatabase(db sql.Database) (sql.Node, error) + type CreateView struct + Catalog *sql.Catalog + Columns []string + Definition *SubqueryAlias + IsReplace bool + Name string + func NewCreateView(database sql.Database, name string, columns []string, ...) *CreateView + func (cv *CreateView) Children() []sql.Node + func (cv *CreateView) Database() sql.Database + func (cv *CreateView) Resolved() bool + func (cv *CreateView) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (cv *CreateView) Schema() sql.Schema + func (cv *CreateView) String() string + func (cv *CreateView) View() sql.View + func (cv *CreateView) WithChildren(children ...sql.Node) (sql.Node, error) + func (cv *CreateView) WithDatabase(database sql.Database) (sql.Node, error) + type CrossJoin struct + func NewCrossJoin(left sql.Node, right sql.Node) *CrossJoin + func (p *CrossJoin) Resolved() bool + func (p *CrossJoin) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (p *CrossJoin) Schema() sql.Schema + func (p *CrossJoin) String() string + func (p *CrossJoin) WithChildren(children ...sql.Node) (sql.Node, error) + type DeleteFrom struct + func NewDeleteFrom(n sql.Node) *DeleteFrom + func (p *DeleteFrom) Children() []sql.Node + func (p *DeleteFrom) Execute(ctx *sql.Context) (int, error) + func (p *DeleteFrom) Resolved() bool + func (p *DeleteFrom) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (p *DeleteFrom) Schema() sql.Schema + func (p *DeleteFrom) WithChildren(children ...sql.Node) (sql.Node, error) + func (p DeleteFrom) String() string + type Describe struct + func NewDescribe(child sql.Node) *Describe + func (d *Describe) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (d *Describe) Schema() sql.Schema + func (d *Describe) WithChildren(children ...sql.Node) (sql.Node, error) + func (d Describe) String() string + type DescribeQuery struct + Format string + func NewDescribeQuery(format string, child sql.Node) *DescribeQuery + func (d *DescribeQuery) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (d *DescribeQuery) Schema() sql.Schema + func (d *DescribeQuery) String() string + func (d *DescribeQuery) WithChildren(children ...sql.Node) (sql.Node, error) + type Distinct struct + func NewDistinct(child sql.Node) *Distinct + func (d *Distinct) Resolved() bool + func (d *Distinct) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (d *Distinct) WithChildren(children ...sql.Node) (sql.Node, error) + func (d Distinct) String() string + type DropColumn struct + func NewDropColumn(db sql.Database, tableName string, column string) *DropColumn + func (*DropColumn) Schema() sql.Schema + func (c *DropColumn) Children() []sql.Node + func (c *DropColumn) Database() sql.Database + func (c *DropColumn) Resolved() bool + func (d *DropColumn) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (d *DropColumn) String() string + func (d *DropColumn) WithChildren(children ...sql.Node) (sql.Node, error) + func (d *DropColumn) WithDatabase(db sql.Database) (sql.Node, error) + type DropIndex struct + Catalog *sql.Catalog + CurrentDatabase string + Name string + Table sql.Node + func NewDropIndex(name string, table sql.Node) *DropIndex + func (d *DropIndex) Children() []sql.Node + func (d *DropIndex) Resolved() bool + func (d *DropIndex) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (d *DropIndex) Schema() sql.Schema + func (d *DropIndex) String() string + func (d *DropIndex) WithChildren(children ...sql.Node) (sql.Node, error) + type DropTable struct + func NewDropTable(db sql.Database, ifExists bool, tableNames ...string) *DropTable + func (*DropTable) Schema() sql.Schema + func (c *DropTable) Children() []sql.Node + func (c *DropTable) Database() sql.Database + func (c *DropTable) Resolved() bool + func (d *DropTable) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (d *DropTable) String() string + func (d *DropTable) WithChildren(children ...sql.Node) (sql.Node, error) + func (d *DropTable) WithDatabase(db sql.Database) (sql.Node, error) + type DropView struct + Catalog *sql.Catalog + func NewDropView(children []sql.Node, ifExists bool) *DropView + func (dvs *DropView) Children() []sql.Node + func (dvs *DropView) Resolved() bool + func (dvs *DropView) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (dvs *DropView) Schema() sql.Schema + func (dvs *DropView) String() string + func (dvs *DropView) WithChildren(children ...sql.Node) (sql.Node, error) + type Exchange struct + Parallelism int + func NewExchange(parallelism int, child sql.Node) *Exchange + func (e *Exchange) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (e *Exchange) String() string + func (e *Exchange) WithChildren(children ...sql.Node) (sql.Node, error) + type Filter struct + Expression sql.Expression + func NewFilter(expression sql.Expression, child sql.Node) *Filter + func (p *Filter) Expressions() []sql.Expression + func (p *Filter) Resolved() bool + func (p *Filter) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (p *Filter) String() string + func (p *Filter) WithChildren(children ...sql.Node) (sql.Node, error) + func (p *Filter) WithExpressions(exprs ...sql.Expression) (sql.Node, error) + type FilterIter struct + func NewFilterIter(ctx *sql.Context, cond sql.Expression, child sql.RowIter) *FilterIter + func (i *FilterIter) Close() error + func (i *FilterIter) Next() (sql.Row, error) + type ForeignKeyAction byte + const ForeignKeyAction_Add + const ForeignKeyAction_Drop + type ForeignKeyDefinition struct + Columns []string + Name string + OnDelete sql.ForeignKeyReferenceOption + OnUpdate sql.ForeignKeyReferenceOption + ReferencedColumns []string + ReferencedTable string + type Generate struct + Column *expression.GetField + func NewGenerate(child sql.Node, col *expression.GetField) *Generate + func (g *Generate) Expressions() []sql.Expression + func (g *Generate) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (g *Generate) Schema() sql.Schema + func (g *Generate) String() string + func (g *Generate) WithChildren(children ...sql.Node) (sql.Node, error) + func (g *Generate) WithExpressions(exprs ...sql.Expression) (sql.Node, error) + type GroupBy struct + Aggregate []sql.Expression + Grouping []sql.Expression + func NewGroupBy(aggregate []sql.Expression, grouping []sql.Expression, child sql.Node) *GroupBy + func (p *GroupBy) Expressions() []sql.Expression + func (p *GroupBy) Resolved() bool + func (p *GroupBy) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (p *GroupBy) Schema() sql.Schema + func (p *GroupBy) String() string + func (p *GroupBy) WithChildren(children ...sql.Node) (sql.Node, error) + func (p *GroupBy) WithExpressions(exprs ...sql.Expression) (sql.Node, error) + type Having struct + Cond sql.Expression + func NewHaving(cond sql.Expression, child sql.Node) *Having + func (h *Having) Expressions() []sql.Expression + func (h *Having) Resolved() bool + func (h *Having) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (h *Having) String() string + func (h *Having) WithChildren(children ...sql.Node) (sql.Node, error) + func (h *Having) WithExpressions(exprs ...sql.Expression) (sql.Node, error) + type IndexAction byte + const IndexAction_Create + const IndexAction_Drop + const IndexAction_Rename + type IndexedJoin struct + Cond sql.Expression + Index sql.Index + func NewIndexedJoin(primaryTable, indexedTable sql.Node, joinType JoinType, cond sql.Expression, ...) *IndexedJoin + func (ij *IndexedJoin) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (ij *IndexedJoin) Schema() sql.Schema + func (ij *IndexedJoin) String() string + func (ij *IndexedJoin) WithChildren(children ...sql.Node) (sql.Node, error) + type IndexedTableAccess struct + func NewIndexedTable(resolvedTable *ResolvedTable) *IndexedTableAccess + func (i *IndexedTableAccess) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (i *IndexedTableAccess) SetIndexLookup(ctx *sql.Context, lookup sql.IndexLookup) error + func (i *IndexedTableAccess) WithChildren(children ...sql.Node) (sql.Node, error) + type InnerJoin struct + Cond sql.Expression + func NewInnerJoin(left, right sql.Node, cond sql.Expression) *InnerJoin + func (j *InnerJoin) Expressions() []sql.Expression + func (j *InnerJoin) Resolved() bool + func (j *InnerJoin) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (j *InnerJoin) Schema() sql.Schema + func (j *InnerJoin) String() string + func (j *InnerJoin) WithChildren(children ...sql.Node) (sql.Node, error) + func (j *InnerJoin) WithExpressions(exprs ...sql.Expression) (sql.Node, error) + type InsertInto struct + ColumnNames []string + IsReplace bool + func NewInsertInto(dst, src sql.Node, isReplace bool, cols []string) *InsertInto + func (p *InsertInto) Execute(ctx *sql.Context) (int, error) + func (p *InsertInto) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (p *InsertInto) Schema() sql.Schema + func (p *InsertInto) WithChildren(children ...sql.Node) (sql.Node, error) + func (p InsertInto) String() string + type JoinType byte + const JoinTypeInner + const JoinTypeLeft + const JoinTypeRight + func (t JoinType) String() string + type LeftJoin struct + Cond sql.Expression + func NewLeftJoin(left, right sql.Node, cond sql.Expression) *LeftJoin + func (j *LeftJoin) Expressions() []sql.Expression + func (j *LeftJoin) Resolved() bool + func (j *LeftJoin) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (j *LeftJoin) Schema() sql.Schema + func (j *LeftJoin) String() string + func (j *LeftJoin) WithChildren(children ...sql.Node) (sql.Node, error) + func (j *LeftJoin) WithExpressions(exprs ...sql.Expression) (sql.Node, error) + type Limit struct + Limit int64 + func NewLimit(size int64, child sql.Node) *Limit + func (l *Limit) Resolved() bool + func (l *Limit) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (l *Limit) WithChildren(children ...sql.Node) (sql.Node, error) + func (l Limit) String() string + type LockTables struct + Catalog *sql.Catalog + Locks []*TableLock + func NewLockTables(locks []*TableLock) *LockTables + func (t *LockTables) Children() []sql.Node + func (t *LockTables) Resolved() bool + func (t *LockTables) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (t *LockTables) Schema() sql.Schema + func (t *LockTables) String() string + func (t *LockTables) WithChildren(children ...sql.Node) (sql.Node, error) + type ModifyColumn struct + func NewModifyColumn(db sql.Database, tableName string, columnName string, column *sql.Column, ...) *ModifyColumn + func (*ModifyColumn) Schema() sql.Schema + func (c *ModifyColumn) Children() []sql.Node + func (c *ModifyColumn) Database() sql.Database + func (c *ModifyColumn) Resolved() bool + func (m *ModifyColumn) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (m *ModifyColumn) String() string + func (m *ModifyColumn) WithChildren(children ...sql.Node) (sql.Node, error) + func (m *ModifyColumn) WithDatabase(db sql.Database) (sql.Node, error) + type NameAndSchema interface + Schema func() sql.Schema + type NamedNotifyFunc func(name string) + type NaturalJoin struct + func NewNaturalJoin(left, right sql.Node) *NaturalJoin + func (NaturalJoin) Resolved() bool + func (NaturalJoin) RowIter(*sql.Context) (sql.RowIter, error) + func (NaturalJoin) Schema() sql.Schema + func (j *NaturalJoin) WithChildren(children ...sql.Node) (sql.Node, error) + func (j NaturalJoin) String() string + type NotifyFunc func() + type NullOrdering byte + const NullsFirst + const NullsLast + type Offset struct + Offset int64 + func NewOffset(n int64, child sql.Node) *Offset + func (o *Offset) Resolved() bool + func (o *Offset) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (o *Offset) WithChildren(children ...sql.Node) (sql.Node, error) + func (o Offset) String() string + type OrderedDistinct struct + func NewOrderedDistinct(child sql.Node) *OrderedDistinct + func (d *OrderedDistinct) Resolved() bool + func (d *OrderedDistinct) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (d *OrderedDistinct) WithChildren(children ...sql.Node) (sql.Node, error) + func (d OrderedDistinct) String() string + type ProcessIndexableTable struct + OnPartitionDone NamedNotifyFunc + OnPartitionStart NamedNotifyFunc + OnRowNext NamedNotifyFunc + func NewProcessIndexableTable(t sql.DriverIndexableTable, ...) *ProcessIndexableTable + func (t *ProcessIndexableTable) IndexKeyValues(ctx *sql.Context, columns []string) (sql.PartitionIndexKeyValueIter, error) + func (t *ProcessIndexableTable) PartitionRows(ctx *sql.Context, p sql.Partition) (sql.RowIter, error) + func (t *ProcessIndexableTable) Underlying() sql.Table + type ProcessTable struct + OnPartitionDone NamedNotifyFunc + OnPartitionStart NamedNotifyFunc + OnRowNext NamedNotifyFunc + func NewProcessTable(t sql.Table, onPartitionDone, onPartitionStart, OnRowNext NamedNotifyFunc) *ProcessTable + func (t *ProcessTable) PartitionRows(ctx *sql.Context, p sql.Partition) (sql.RowIter, error) + func (t *ProcessTable) Underlying() sql.Table + type Project struct + Projections []sql.Expression + func NewProject(expressions []sql.Expression, child sql.Node) *Project + func (p *Project) Expressions() []sql.Expression + func (p *Project) Resolved() bool + func (p *Project) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (p *Project) Schema() sql.Schema + func (p *Project) String() string + func (p *Project) WithChildren(children ...sql.Node) (sql.Node, error) + func (p *Project) WithExpressions(exprs ...sql.Expression) (sql.Node, error) + type QueryProcess struct + Notify NotifyFunc + func NewQueryProcess(node sql.Node, notify NotifyFunc) *QueryProcess + func (p *QueryProcess) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (p *QueryProcess) String() string + func (p *QueryProcess) WithChildren(children ...sql.Node) (sql.Node, error) + type RenameColumn struct + func NewRenameColumn(db sql.Database, tableName string, columnName string, newColumnName string) *RenameColumn + func (*RenameColumn) Schema() sql.Schema + func (c *RenameColumn) Children() []sql.Node + func (c *RenameColumn) Database() sql.Database + func (c *RenameColumn) Resolved() bool + func (r *RenameColumn) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (r *RenameColumn) String() string + func (r *RenameColumn) WithChildren(children ...sql.Node) (sql.Node, error) + func (r *RenameColumn) WithDatabase(db sql.Database) (sql.Node, error) + type RenameTable struct + func NewRenameTable(db sql.Database, oldNames, newNames []string) *RenameTable + func (*RenameTable) Schema() sql.Schema + func (c *RenameTable) Children() []sql.Node + func (c *RenameTable) Database() sql.Database + func (c *RenameTable) Resolved() bool + func (r *RenameTable) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (r *RenameTable) String() string + func (r *RenameTable) WithChildren(children ...sql.Node) (sql.Node, error) + func (r *RenameTable) WithDatabase(db sql.Database) (sql.Node, error) + type ResolvedTable struct + func NewResolvedTable(table sql.Table) *ResolvedTable + func (*ResolvedTable) Children() []sql.Node + func (*ResolvedTable) Resolved() bool + func (t *ResolvedTable) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (t *ResolvedTable) WithChildren(children ...sql.Node) (sql.Node, error) + type RightJoin struct + Cond sql.Expression + func NewRightJoin(left, right sql.Node, cond sql.Expression) *RightJoin + func (j *RightJoin) Expressions() []sql.Expression + func (j *RightJoin) Resolved() bool + func (j *RightJoin) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (j *RightJoin) Schema() sql.Schema + func (j *RightJoin) String() string + func (j *RightJoin) WithChildren(children ...sql.Node) (sql.Node, error) + func (j *RightJoin) WithExpressions(exprs ...sql.Expression) (sql.Node, error) + type Rollback struct + func NewRollback() *Rollback + func (*Rollback) Children() []sql.Node + func (*Rollback) Resolved() bool + func (*Rollback) RowIter(*sql.Context) (sql.RowIter, error) + func (*Rollback) Schema() sql.Schema + func (*Rollback) String() string + func (r *Rollback) WithChildren(children ...sql.Node) (sql.Node, error) + type Set struct + Variables []SetVariable + func NewSet(vars ...SetVariable) *Set + func (s *Set) Children() []sql.Node + func (s *Set) Expressions() []sql.Expression + func (s *Set) Resolved() bool + func (s *Set) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (s *Set) Schema() sql.Schema + func (s *Set) String() string + func (s *Set) WithChildren(children ...sql.Node) (sql.Node, error) + func (s *Set) WithExpressions(exprs ...sql.Expression) (sql.Node, error) + type SetVariable struct + Name string + Value sql.Expression + type ShowColumns struct + Full bool + func NewShowColumns(full bool, child sql.Node) *ShowColumns + func (s *ShowColumns) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (s *ShowColumns) Schema() sql.Schema + func (s *ShowColumns) String() string + func (s *ShowColumns) WithChildren(children ...sql.Node) (sql.Node, error) + type ShowCreateDatabase struct + IfNotExists bool + func NewShowCreateDatabase(db sql.Database, ifNotExists bool) *ShowCreateDatabase + func (s *ShowCreateDatabase) Children() []sql.Node + func (s *ShowCreateDatabase) Database() sql.Database + func (s *ShowCreateDatabase) Resolved() bool + func (s *ShowCreateDatabase) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (s *ShowCreateDatabase) Schema() sql.Schema + func (s *ShowCreateDatabase) String() string + func (s *ShowCreateDatabase) WithChildren(children ...sql.Node) (sql.Node, error) + func (s *ShowCreateDatabase) WithDatabase(db sql.Database) (sql.Node, error) + type ShowCreateTable struct + Catalog *sql.Catalog + Database string + IsView bool + func (n *ShowCreateTable) Resolved() bool + func (n *ShowCreateTable) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (n *ShowCreateTable) Schema() sql.Schema + func (n *ShowCreateTable) String() string + func (n *ShowCreateTable) WithChildren(children ...sql.Node) (sql.Node, error) + type ShowDatabases struct + Catalog *sql.Catalog + func NewShowDatabases() *ShowDatabases + func (*ShowDatabases) Children() []sql.Node + func (*ShowDatabases) Schema() sql.Schema + func (p *ShowDatabases) Resolved() bool + func (p *ShowDatabases) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (p *ShowDatabases) WithChildren(children ...sql.Node) (sql.Node, error) + func (p ShowDatabases) String() string + type ShowIndexes struct + Registry *sql.IndexRegistry + Table string + func (n *ShowIndexes) Children() []sql.Node + func (n *ShowIndexes) Database() sql.Database + func (n *ShowIndexes) Resolved() bool + func (n *ShowIndexes) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (n *ShowIndexes) Schema() sql.Schema + func (n *ShowIndexes) String() string + func (n *ShowIndexes) WithChildren(children ...sql.Node) (sql.Node, error) + func (n *ShowIndexes) WithDatabase(db sql.Database) (sql.Node, error) + type ShowProcessList struct + Database string + func NewShowProcessList() *ShowProcessList + func (p *ShowProcessList) Children() []sql.Node + func (p *ShowProcessList) Resolved() bool + func (p *ShowProcessList) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (p *ShowProcessList) Schema() sql.Schema + func (p *ShowProcessList) String() string + func (p *ShowProcessList) WithChildren(children ...sql.Node) (sql.Node, error) + type ShowTableStatus struct + Catalog *sql.Catalog + Databases []string + func NewShowTableStatus(dbs ...string) *ShowTableStatus + func (s *ShowTableStatus) Children() []sql.Node + func (s *ShowTableStatus) Resolved() bool + func (s *ShowTableStatus) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (s *ShowTableStatus) Schema() sql.Schema + func (s *ShowTableStatus) String() string + func (s *ShowTableStatus) WithChildren(children ...sql.Node) (sql.Node, error) + type ShowTables struct + Full bool + func NewShowTables(database sql.Database, full bool) *ShowTables + func (*ShowTables) Children() []sql.Node + func (p *ShowTables) Database() sql.Database + func (p *ShowTables) Resolved() bool + func (p *ShowTables) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (p *ShowTables) Schema() sql.Schema + func (p *ShowTables) WithChildren(children ...sql.Node) (sql.Node, error) + func (p *ShowTables) WithDatabase(db sql.Database) (sql.Node, error) + func (p ShowTables) String() string + type ShowVariables struct + func NewShowVariables(config map[string]sql.TypedValue, like string) *ShowVariables + func (*ShowVariables) Children() []sql.Node + func (*ShowVariables) Schema() sql.Schema + func (sv *ShowVariables) Resolved() bool + func (sv *ShowVariables) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (sv *ShowVariables) String() string + func (sv *ShowVariables) WithChildren(children ...sql.Node) (sql.Node, error) + type ShowWarnings []*sql.Warning + func (ShowWarnings) Children() []sql.Node + func (ShowWarnings) Resolved() bool + func (ShowWarnings) Schema() sql.Schema + func (ShowWarnings) String() string + func (sw ShowWarnings) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (sw ShowWarnings) WithChildren(children ...sql.Node) (sql.Node, error) + type SingleDropView struct + func NewSingleDropView(database sql.Database, viewName string) *SingleDropView + func (dv *SingleDropView) Children() []sql.Node + func (dv *SingleDropView) Database() sql.Database + func (dv *SingleDropView) Resolved() bool + func (dv *SingleDropView) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (dv *SingleDropView) Schema() sql.Schema + func (dv *SingleDropView) String() string + func (dv *SingleDropView) WithChildren(children ...sql.Node) (sql.Node, error) + func (dv *SingleDropView) WithDatabase(database sql.Database) (sql.Node, error) + type Sort struct + SortFields []SortField + func NewSort(sortFields []SortField, child sql.Node) *Sort + func (s *Sort) Expressions() []sql.Expression + func (s *Sort) Resolved() bool + func (s *Sort) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (s *Sort) String() string + func (s *Sort) WithChildren(children ...sql.Node) (sql.Node, error) + func (s *Sort) WithExpressions(exprs ...sql.Expression) (sql.Node, error) + type SortField struct + Column sql.Expression + NullOrdering NullOrdering + Order SortOrder + type SortOrder byte + const Ascending + const Descending + func (s SortOrder) String() string + type SubqueryAlias struct + TextDefinition string + func NewSubqueryAlias(name, textDefinition string, node sql.Node) *SubqueryAlias + func (n *SubqueryAlias) AsView() sql.View + func (n *SubqueryAlias) Name() string + func (n *SubqueryAlias) Opaque() bool + func (n *SubqueryAlias) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (n *SubqueryAlias) Schema() sql.Schema + func (n *SubqueryAlias) WithChildren(children ...sql.Node) (sql.Node, error) + func (n SubqueryAlias) String() string + type TableAlias struct + func NewTableAlias(name string, node sql.Node) *TableAlias + func (t *TableAlias) Name() string + func (t *TableAlias) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (t *TableAlias) Schema() sql.Schema + func (t *TableAlias) WithChildren(children ...sql.Node) (sql.Node, error) + func (t TableAlias) String() string + type TableLock struct + Table sql.Node + Write bool + type UnaryNode struct + Child sql.Node + func (n *UnaryNode) Schema() sql.Schema + func (n UnaryNode) Children() []sql.Node + func (n UnaryNode) Resolved() bool + type Union struct + func NewUnion(left, right sql.Node) *Union + func (u *Union) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (u *Union) Schema() sql.Schema + func (u *Union) WithChildren(children ...sql.Node) (sql.Node, error) + func (u Union) String() string + type UnlockTables struct + Catalog *sql.Catalog + func NewUnlockTables() *UnlockTables + func (t *UnlockTables) Children() []sql.Node + func (t *UnlockTables) Resolved() bool + func (t *UnlockTables) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (t *UnlockTables) Schema() sql.Schema + func (t *UnlockTables) String() string + func (t *UnlockTables) WithChildren(children ...sql.Node) (sql.Node, error) + type UnresolvedTable struct + AsOf sql.Expression + Database string + func NewUnresolvedTable(name, db string) *UnresolvedTable + func NewUnresolvedTableAsOf(name, db string, asOf sql.Expression) *UnresolvedTable + func (*UnresolvedTable) Children() []sql.Node + func (*UnresolvedTable) Resolved() bool + func (*UnresolvedTable) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (*UnresolvedTable) Schema() sql.Schema + func (t *UnresolvedTable) Name() string + func (t *UnresolvedTable) WithAsOf(asOf sql.Expression) (*UnresolvedTable, error) + func (t *UnresolvedTable) WithChildren(children ...sql.Node) (sql.Node, error) + func (t *UnresolvedTable) WithDatabase(database string) (*UnresolvedTable, error) + func (t UnresolvedTable) String() string + type Update struct + UpdateExprs []sql.Expression + func NewUpdate(n sql.Node, updateExprs []sql.Expression) *Update + func (p *Update) Children() []sql.Node + func (p *Update) Execute(ctx *sql.Context) (int, int, error) + func (p *Update) Expressions() []sql.Expression + func (p *Update) Resolved() bool + func (p *Update) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (p *Update) Schema() sql.Schema + func (p *Update) WithChildren(children ...sql.Node) (sql.Node, error) + func (p *Update) WithExpressions(newExprs ...sql.Expression) (sql.Node, error) + func (p Update) String() string + type UpdateInfo struct + Matched int + Updated int + Warnings int + func (ui UpdateInfo) String() string + type Use struct + Catalog *sql.Catalog + func NewUse(db sql.Database) *Use + func (Use) Children() []sql.Node + func (Use) Schema() sql.Schema + func (u *Use) Database() sql.Database + func (u *Use) Resolved() bool + func (u *Use) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (u *Use) String() string + func (u *Use) WithChildren(children ...sql.Node) (sql.Node, error) + func (u *Use) WithDatabase(db sql.Database) (sql.Node, error) + type Values struct + ExpressionTuples [][]sql.Expression + func NewValues(tuples [][]sql.Expression) *Values + func (p *Values) Children() []sql.Node + func (p *Values) Expressions() []sql.Expression + func (p *Values) Resolved() bool + func (p *Values) RowIter(ctx *sql.Context) (sql.RowIter, error) + func (p *Values) Schema() sql.Schema + func (p *Values) String() string + func (p *Values) WithChildren(children ...sql.Node) (sql.Node, error) + func (p *Values) WithExpressions(exprs ...sql.Expression) (sql.Node, error) + type Visitor interface + Visit func(node sql.Node) Visitor