Versions in this module Expand all Collapse all v2 v2.11.4-hyn Aug 31, 2024 v2.11.3-hyn Aug 31, 2024 v2.11.2 Aug 31, 2024 Changes in this version + const StringConcatOperator + const StringNotRegexpLikeOperator + const StringRegexpLikeOperator + var CURRENT_ROW = frameExtentKeyword + var DateRangeExp = RangeExp[DateExpression] + var Int4RangeExp = RangeExp[Int4Expression] + var Int8RangeExp = RangeExp[Int8Expression] + var MINUS_INFINITY = String("-infinity") + var NULL = newNullLiteral() + var NumRangeExp = RangeExp[NumericExpression] + var PLUS_INFINITY = String("infinity") + var STAR = newStarLiteral() + var TsRangeExp = RangeExp[TimestampExpression] + var TstzRangeExp = RangeExp[TimestampzExpression] + var UNBOUNDED = Keyword("UNBOUNDED") + func AVG(numericExpression Expression) floatWindowExpression + func BIT_AND(integerExpression IntegerExpression) integerWindowExpression + func BIT_OR(integerExpression IntegerExpression) integerWindowExpression + func BOOL_AND(boolExpression BoolExpression) boolWindowExpression + func BOOL_OR(boolExpression BoolExpression) boolWindowExpression + func COUNT(expression Expression) integerWindowExpression + func CUME_DIST() floatWindowExpression + func DENSE_RANK() integerWindowExpression + func EVERY(boolExpression BoolExpression) boolWindowExpression + func FIRST_VALUE(value Expression) windowExpression + func FixedLiteral(value interface{}) *literalExpressionImpl + func LAG(expr Expression, offsetAndDefault ...interface{}) windowExpression + func LAST_VALUE(value Expression) windowExpression + func LEAD(expr Expression, offsetAndDefault ...interface{}) windowExpression + func LOWER_BOUND[T Expression](rangeExpression Range[T]) T + func Literal(value interface{}) *literalExpressionImpl + func MAXf(floatExpression FloatExpression) floatWindowExpression + func MAXi(integerExpression IntegerExpression) integerWindowExpression + func MINf(floatExpression FloatExpression) floatWindowExpression + func MINi(integerExpression IntegerExpression) integerWindowExpression + func NTH_VALUE(value Expression, nth int64) windowExpression + func NTILE(numOfBuckets int64) integerWindowExpression + func NewDateFunc(name string, expressions ...Expression) *dateFunc + func NewFloatWindowFunc(name string, expressions ...Expression) floatWindowExpression + func NewFunc(name string, expressions []Expression, parent Expression) *funcExpressionImpl + func NewRowLock(name string) func() RowLock + func NewSelectTable(selectStmt SerializerHasProjections, alias string) selectTableImpl + func NewTimeFunc(name string, expressions ...Expression) *timeFunc + func NewTimestampFunc(name string, expressions ...Expression) *timestampFunc + func OptionalOrDefaultString(defaultStr string, str ...string) string + func PERCENT_RANK() floatWindowExpression + func RANK() integerWindowExpression + func ROW_NUMBER() integerWindowExpression + func SUMf(floatExpression FloatExpression) floatWindowExpression + func SUMi(integerExpression IntegerExpression) integerWindowExpression + func Serialize(exp Serializer, statementType StatementType, out *SQLBuilder, ...) + func SerializeClauseList(statement StatementType, clauses []Serializer, out *SQLBuilder) + func SerializeColumnExpressionNames(columns []ColumnExpression, out *SQLBuilder) + func SerializeColumnExpressions(columns []ColumnExpression, statementType StatementType, out *SQLBuilder, ...) + func SerializeColumnNames(columns []Column, out *SQLBuilder) + func SerializeForOrderBy(exp Expression, statementType StatementType, out *SQLBuilder) + func SerializeForProjection(projection Projection, statementType StatementType, out *SQLBuilder) + func SerializeProjectionList(statement StatementType, projections []Projection, out *SQLBuilder) + func SetLoggerFunc(loggerFunc LoggerFunc) + func SetQueryLogger(loggerFunc QueryLoggerFunc) + func SetSubQuery(columnExpression ColumnExpression, subQuery SelectTable) + func SetTableName(columnExpression ColumnExpression, tableName string) + func UPPER_BOUND[T Expression](rangeExpression Range[T]) T + func UnwindRowsFromModels(columns []Column, data interface{}) [][]Serializer + func WITH(dialect Dialect, recursive bool, cte ...*CommonTableExpression) func(statement Statement) Statement + type BoolExpression interface + AND func(rhs BoolExpression) BoolExpression + EQ func(rhs BoolExpression) BoolExpression + IS_DISTINCT_FROM func(rhs BoolExpression) BoolExpression + IS_FALSE func() BoolExpression + IS_NOT_DISTINCT_FROM func(rhs BoolExpression) BoolExpression + IS_NOT_FALSE func() BoolExpression + IS_NOT_TRUE func() BoolExpression + IS_NOT_UNKNOWN func() BoolExpression + IS_TRUE func() BoolExpression + IS_UNKNOWN func() BoolExpression + NOT_EQ func(rhs BoolExpression) BoolExpression + OR func(rhs BoolExpression) BoolExpression + func AND(expressions ...BoolExpression) BoolExpression + func Bool(value bool) BoolExpression + func BoolExp(expression Expression) BoolExpression + func Contains(lhs Expression, rhs Expression) BoolExpression + func EXISTS(subQuery Expression) BoolExpression + func Eq(lhs, rhs Expression) BoolExpression + func Gt(lhs, rhs Expression) BoolExpression + func GtEq(lhs, rhs Expression) BoolExpression + func IS_EMPTY[T Expression](rangeExpression Range[T]) BoolExpression + func IsDistinctFrom(lhs, rhs Expression) BoolExpression + func IsNotDistinctFrom(lhs, rhs Expression) BoolExpression + func LOWER_INC[T Expression](rangeExpression Range[T]) BoolExpression + func LOWER_INF[T Expression](rangeExpression Range[T]) BoolExpression + func Lt(lhs Expression, rhs Expression) BoolExpression + func LtEq(lhs, rhs Expression) BoolExpression + func NOT(exp BoolExpression) BoolExpression + func NewBetweenOperatorExpression(expression, min, max Expression, notBetween bool) BoolExpression + func NotEq(lhs, rhs Expression) BoolExpression + func OR(expressions ...BoolExpression) BoolExpression + func Overlap(lhs, rhs Expression) BoolExpression + func REGEXP_LIKE(stringExp StringExpression, pattern StringExpression, matchType ...string) BoolExpression + func RawBool(raw string, namedArgs ...map[string]interface{}) BoolExpression + func UPPER_INC[T Expression](rangeExpression Range[T]) BoolExpression + func UPPER_INF[T Expression](rangeExpression Range[T]) BoolExpression + type CaseOperator interface + ELSE func(els Expression) CaseOperator + THEN func(then Expression) CaseOperator + WHEN func(condition Expression) CaseOperator + func CASE(expression ...Expression) CaseOperator + type Cast interface + AS func(castType string) Expression + func NewCastImpl(expression Expression) Cast + type Clause interface + Serialize func(statementType StatementType, out *SQLBuilder, options ...SerializeOption) + type ClauseDelete struct + OptimizerHints optimizerHints + Table SerializerTable + func (d *ClauseDelete) Serialize(statementType StatementType, out *SQLBuilder, options ...SerializeOption) + type ClauseFetch struct + Count IntegerExpression + WithTies bool + func (o *ClauseFetch) Serialize(statementType StatementType, out *SQLBuilder, options ...SerializeOption) + type ClauseFor struct + Lock RowLock + func (f *ClauseFor) Serialize(statementType StatementType, out *SQLBuilder, options ...SerializeOption) + type ClauseFrom struct + Name string + Tables []Serializer + func (f *ClauseFrom) Serialize(statementType StatementType, out *SQLBuilder, options ...SerializeOption) + type ClauseGroupBy struct + List []GroupByClause + func (c *ClauseGroupBy) Serialize(statementType StatementType, out *SQLBuilder, options ...SerializeOption) + type ClauseHaving struct + Condition BoolExpression + func (c *ClauseHaving) Serialize(statementType StatementType, out *SQLBuilder, options ...SerializeOption) + type ClauseIn struct + LockMode string + func (i *ClauseIn) Serialize(statementType StatementType, out *SQLBuilder, options ...SerializeOption) + type ClauseInsert struct + Columns []Column + OptimizerHints optimizerHints + Table SerializerTable + func (i *ClauseInsert) GetColumns() []Column + func (i *ClauseInsert) Serialize(statementType StatementType, out *SQLBuilder, options ...SerializeOption) + type ClauseLimit struct + Count int64 + func (l *ClauseLimit) Serialize(statementType StatementType, out *SQLBuilder, options ...SerializeOption) + type ClauseOffset struct + Count IntegerExpression + func (o *ClauseOffset) Serialize(statementType StatementType, out *SQLBuilder, options ...SerializeOption) + type ClauseOptional struct + InNewLine bool + Name string + Show bool + func (d *ClauseOptional) Serialize(statementType StatementType, out *SQLBuilder, options ...SerializeOption) + type ClauseOrderBy struct + List []OrderByClause + SkipNewLine bool + func (o *ClauseOrderBy) Serialize(statementType StatementType, out *SQLBuilder, options ...SerializeOption) + type ClauseQuery struct + Query SerializerStatement + SkipSelectWrap bool + func (v *ClauseQuery) Serialize(statementType StatementType, out *SQLBuilder, options ...SerializeOption) + type ClauseReturning struct + ProjectionList []Projection + func (r *ClauseReturning) Serialize(statementType StatementType, out *SQLBuilder, options ...SerializeOption) + func (r ClauseReturning) Projections() ProjectionList + type ClauseSelect struct + Distinct bool + DistinctOnColumns []ColumnExpression + OptimizerHints optimizerHints + ProjectionList []Projection + func (s *ClauseSelect) Projections() ProjectionList + func (s *ClauseSelect) Serialize(statementType StatementType, out *SQLBuilder, options ...SerializeOption) + type ClauseSetStmtOperator struct + All bool + Limit ClauseLimit + Offset ClauseOffset + Operator string + OrderBy ClauseOrderBy + Selects []SerializerStatement + SkipSelectWrap bool + func (s *ClauseSetStmtOperator) Projections() ProjectionList + func (s *ClauseSetStmtOperator) Serialize(statementType StatementType, out *SQLBuilder, options ...SerializeOption) + type ClauseStatementBegin struct + Name string + Tables []SerializerTable + func (d *ClauseStatementBegin) Serialize(statementType StatementType, out *SQLBuilder, options ...SerializeOption) + type ClauseUpdate struct + OptimizerHints optimizerHints + Table SerializerTable + func (u *ClauseUpdate) Serialize(statementType StatementType, out *SQLBuilder, options ...SerializeOption) + type ClauseValues struct + As string + Rows [][]Serializer + func (v *ClauseValues) Serialize(statementType StatementType, out *SQLBuilder, options ...SerializeOption) + type ClauseValuesQuery struct + func (v *ClauseValuesQuery) Serialize(statementType StatementType, out *SQLBuilder, options ...SerializeOption) + type ClauseWhere struct + Condition BoolExpression + Mandatory bool + func (c *ClauseWhere) Serialize(statementType StatementType, out *SQLBuilder, options ...SerializeOption) + type ClauseWindow struct + Definitions []WindowDefinition + func (i *ClauseWindow) Serialize(statementType StatementType, out *SQLBuilder, options ...SerializeOption) + type ClauseWithProjections interface + Projections func() ProjectionList + type Column interface + Name func() string + TableName func() string + func UnwidColumnList(columns []Column) []Column + func UnwindColumns(column1 Column, columns ...Column) []Column + type ColumnAssigment interface + type ColumnBool interface + From func(subQuery SelectTable) ColumnBool + SET func(boolExp BoolExpression) ColumnAssigment + func BoolColumn(name string) ColumnBool + type ColumnDate interface + From func(subQuery SelectTable) ColumnDate + SET func(dateExp DateExpression) ColumnAssigment + func DateColumn(name string) ColumnDate + type ColumnExpression interface + type ColumnExpressionImpl struct + func NewColumnImpl(name string, tableName string, parent ColumnExpression) ColumnExpressionImpl + func (c *ColumnExpressionImpl) Name() string + func (c *ColumnExpressionImpl) TableName() string + type ColumnFloat interface + From func(subQuery SelectTable) ColumnFloat + SET func(floatExp FloatExpression) ColumnAssigment + func FloatColumn(name string) ColumnFloat + type ColumnInteger interface + From func(subQuery SelectTable) ColumnInteger + SET func(intExp IntegerExpression) ColumnAssigment + func IntegerColumn(name string) ColumnInteger + type ColumnList []ColumnExpression + func (cl ColumnList) As(tableAlias string) ProjectionList + func (cl ColumnList) Except(excludedColumns ...Column) ColumnList + func (cl ColumnList) Name() string + func (cl ColumnList) SET(expression Expression) ColumnAssigment + func (cl ColumnList) TableName() string + type ColumnRange interface + From func(subQuery SelectTable) ColumnRange[T] + SET func(rangeExp Range[T]) ColumnAssigment + func RangeColumn[T Expression](name string) ColumnRange[T] + type ColumnSerializer interface + type ColumnString interface + From func(subQuery SelectTable) ColumnString + SET func(stringExp StringExpression) ColumnAssigment + func StringColumn(name string) ColumnString + type ColumnTime interface + From func(subQuery SelectTable) ColumnTime + SET func(timeExp TimeExpression) ColumnAssigment + func TimeColumn(name string) ColumnTime + type ColumnTimestamp interface + From func(subQuery SelectTable) ColumnTimestamp + SET func(timestampExp TimestampExpression) ColumnAssigment + func TimestampColumn(name string) ColumnTimestamp + type ColumnTimestampz interface + From func(subQuery SelectTable) ColumnTimestampz + SET func(timestampzExp TimestampzExpression) ColumnAssigment + func TimestampzColumn(name string) ColumnTimestampz + type ColumnTimez interface + From func(subQuery SelectTable) ColumnTimez + SET func(timeExp TimezExpression) ColumnAssigment + func TimezColumn(name string) ColumnTimez + type CommonTableExpression struct + Columns []ColumnExpression + NotMaterialized bool + func CTE(name string, columns ...ColumnExpression) CommonTableExpression + func (c CommonTableExpression) AllColumns() ProjectionList + func (s CommonTableExpression) Alias() string + type DateExpression interface + ADD func(rhs Interval) TimestampExpression + BETWEEN func(min, max DateExpression) BoolExpression + EQ func(rhs DateExpression) BoolExpression + GT func(rhs DateExpression) BoolExpression + GT_EQ func(rhs DateExpression) BoolExpression + IS_DISTINCT_FROM func(rhs DateExpression) BoolExpression + IS_NOT_DISTINCT_FROM func(rhs DateExpression) BoolExpression + LT func(rhs DateExpression) BoolExpression + LT_EQ func(rhs DateExpression) BoolExpression + NOT_BETWEEN func(min, max DateExpression) BoolExpression + NOT_EQ func(rhs DateExpression) BoolExpression + SUB func(rhs Interval) TimestampExpression + func CURRENT_DATE() DateExpression + func Date(year int, month time.Month, day int) DateExpression + func DateExp(expression Expression) DateExpression + func DateT(t time.Time) DateExpression + func RawDate(raw string, namedArgs ...map[string]interface{}) DateExpression + func TO_DATE(dateStr, format StringExpression) DateExpression + type Dialect interface + AliasQuoteChar func() byte + ArgumentPlaceholder func() QueryPlaceholderFunc + FunctionSerializeOverride func(function string) SerializeOverride + IdentifierQuoteChar func() byte + IsReservedWord func(name string) bool + Name func() string + OperatorSerializeOverride func(operator string) SerializeOverride + PackageName func() string + SerializeOrderBy func() func(expression Expression, ascending, nullsFirst *bool) SerializerFunc + func NewDialect(params DialectParams) Dialect + type DialectParams struct + AliasQuoteChar byte + ArgumentPlaceholder QueryPlaceholderFunc + FunctionSerializeOverrides map[string]SerializeOverride + IdentifierQuoteChar byte + Name string + OperatorSerializeOverrides map[string]SerializeOverride + PackageName string + ReservedWords []string + SerializeOrderBy func(expression Expression, ascending, nullsFirst *bool) SerializerFunc + type Expression interface + AS func(alias string) Projection + ASC func() OrderByClause + DESC func() OrderByClause + IN func(expressions ...Expression) BoolExpression + IS_NOT_NULL func() BoolExpression + IS_NULL func() BoolExpression + NOT_IN func(expressions ...Expression) BoolExpression + func Add(lhs, rhs Serializer) Expression + func BinaryOperator(lhs Expression, rhs Expression, operator string) Expression + func BoolExpressionListToExpressionList(expressions []BoolExpression) []Expression + func COALESCE(value Expression, values ...Expression) Expression + func CustomExpression(parts ...Serializer) Expression + func DISTINCT(expr Expression) Expression + func Div(lhs, rhs Serializer) Expression + func EXTRACT(field string, from Expression) Expression + func Func(name string, expressions ...Expression) Expression + func GREATEST(value Expression, values ...Expression) Expression + func LEAST(value Expression, values ...Expression) Expression + func MAX(expression Expression) Expression + func MIN(expression Expression) Expression + func Mod(lhs, rhs Serializer) Expression + func Mul(lhs, rhs Serializer) Expression + func NULLIF(value1, value2 Expression) Expression + func NewBinaryOperatorExpression(lhs, rhs Serializer, operator string, additionalParam ...Expression) Expression + func OptionalOrDefaultExpression(defaultExpression Expression, expression ...Expression) Expression + func ROW(expressions ...Expression) Expression + func Raw(raw string, namedArgs ...map[string]interface{}) Expression + func RawWithParent(raw string, parent ...Expression) Expression + func SUM(expression Expression) Expression + func Sub(lhs, rhs Serializer) Expression + func WRAP(expression ...Expression) Expression + type ExpressionInterfaceImpl struct + Parent Expression + func (e *ExpressionInterfaceImpl) AS(alias string) Projection + func (e *ExpressionInterfaceImpl) ASC() OrderByClause + func (e *ExpressionInterfaceImpl) DESC() OrderByClause + func (e *ExpressionInterfaceImpl) IN(expressions ...Expression) BoolExpression + func (e *ExpressionInterfaceImpl) IS_NOT_NULL() BoolExpression + func (e *ExpressionInterfaceImpl) IS_NULL() BoolExpression + func (e *ExpressionInterfaceImpl) NOT_IN(expressions ...Expression) BoolExpression + func (e *ExpressionInterfaceImpl) NULLS_FIRST() OrderByClause + func (e *ExpressionInterfaceImpl) NULLS_LAST() OrderByClause + type ExpressionStatement interface + func NewExpressionStatementImpl(Dialect Dialect, statementType StatementType, parent ExpressionStatement, ...) ExpressionStatement + type FloatExpression interface + ADD func(rhs NumericExpression) FloatExpression + BETWEEN func(min, max FloatExpression) BoolExpression + DIV func(rhs NumericExpression) FloatExpression + EQ func(rhs FloatExpression) BoolExpression + GT func(rhs FloatExpression) BoolExpression + GT_EQ func(rhs FloatExpression) BoolExpression + IS_DISTINCT_FROM func(rhs FloatExpression) BoolExpression + IS_NOT_DISTINCT_FROM func(rhs FloatExpression) BoolExpression + LT func(rhs FloatExpression) BoolExpression + LT_EQ func(rhs FloatExpression) BoolExpression + MOD func(rhs NumericExpression) FloatExpression + MUL func(rhs NumericExpression) FloatExpression + NOT_BETWEEN func(min, max FloatExpression) BoolExpression + NOT_EQ func(rhs FloatExpression) BoolExpression + POW func(rhs NumericExpression) FloatExpression + SUB func(rhs NumericExpression) FloatExpression + func ABSf(floatExpression FloatExpression) FloatExpression + func CBRT(numericExpression NumericExpression) FloatExpression + func CEIL(floatExpression FloatExpression) FloatExpression + func Decimal(value string) FloatExpression + func FLOOR(floatExpression FloatExpression) FloatExpression + func Float(value float64) FloatExpression + func FloatExp(expression Expression) FloatExpression + func LN(floatExpression FloatExpression) FloatExpression + func LOG(floatExpression FloatExpression) FloatExpression + func NewFloatFunc(name string, expressions ...Expression) FloatExpression + func POW(base, exponent NumericExpression) FloatExpression + func POWER(base, exponent NumericExpression) FloatExpression + func ROUND(floatExpression FloatExpression, precision ...IntegerExpression) FloatExpression + func RawFloat(raw string, namedArgs ...map[string]interface{}) FloatExpression + func SIGN(floatExpression FloatExpression) FloatExpression + func SQRT(numericExpression NumericExpression) FloatExpression + func TO_NUMBER(floatStr, format StringExpression) FloatExpression + func TRUNC(floatExpression FloatExpression, precision ...IntegerExpression) FloatExpression + type FrameExtent interface + func FOLLOWING(offset Serializer) FrameExtent + func PRECEDING(offset Serializer) FrameExtent + type GroupByClause interface + func CUBE(expressions ...Expression) GroupByClause + func GROUPING_SETS(expressions ...Expression) GroupByClause + func ROLLUP(expressions ...Expression) GroupByClause + func WITH_ROLLUP(expressions ...Expression) GroupByClause + type HasProjections interface + type Int4Expression IntegerExpression + type Int8Expression IntegerExpression + type IntegerExpression interface + ADD func(rhs IntegerExpression) IntegerExpression + BETWEEN func(min, max IntegerExpression) BoolExpression + BIT_AND func(rhs IntegerExpression) IntegerExpression + BIT_OR func(rhs IntegerExpression) IntegerExpression + BIT_SHIFT_LEFT func(shift IntegerExpression) IntegerExpression + BIT_SHIFT_RIGHT func(shift IntegerExpression) IntegerExpression + BIT_XOR func(rhs IntegerExpression) IntegerExpression + DIV func(rhs IntegerExpression) IntegerExpression + EQ func(rhs IntegerExpression) BoolExpression + GT func(rhs IntegerExpression) BoolExpression + GT_EQ func(rhs IntegerExpression) BoolExpression + IS_DISTINCT_FROM func(rhs IntegerExpression) BoolExpression + IS_NOT_DISTINCT_FROM func(rhs IntegerExpression) BoolExpression + LT func(rhs IntegerExpression) BoolExpression + LT_EQ func(rhs IntegerExpression) BoolExpression + MOD func(rhs IntegerExpression) IntegerExpression + MUL func(rhs IntegerExpression) IntegerExpression + NOT_BETWEEN func(min, max IntegerExpression) BoolExpression + NOT_EQ func(rhs IntegerExpression) BoolExpression + POW func(rhs IntegerExpression) IntegerExpression + SUB func(rhs IntegerExpression) IntegerExpression + func ABSi(integerExpression IntegerExpression) IntegerExpression + func BIT_LENGTH(stringExpression StringExpression) IntegerExpression + func BIT_NOT(expr IntegerExpression) IntegerExpression + func CHAR_LENGTH(stringExpression StringExpression) IntegerExpression + func GROUPING(expressions ...Expression) IntegerExpression + func Int(value int64) IntegerExpression + func Int16(value int16) IntegerExpression + func Int32(value int32) IntegerExpression + func Int8(value int8) IntegerExpression + func IntExp(expression Expression) IntegerExpression + func OCTET_LENGTH(stringExpression StringExpression) IntegerExpression + func RawInt(raw string, namedArgs ...map[string]interface{}) IntegerExpression + func STRPOS(str, substring StringExpression) IntegerExpression + func Uint16(value uint16) IntegerExpression + func Uint32(value uint32) IntegerExpression + func Uint64(value uint64) IntegerExpression + func Uint8(value uint8) IntegerExpression + type Interval interface + type IntervalImpl struct + Value Serializer + func NewInterval(s Serializer) *IntervalImpl + type IsInterval interface + type IsIntervalImpl struct + type JoinTable SerializerTable + func NewJoinTable(lhs Serializer, rhs Serializer, joinType JoinType, onCondition BoolExpression) JoinTable + type JoinType int + const CrossJoin + const FullJoin + const InnerJoin + const LeftJoin + const RightJoin + type Keyword string + const DEFAULT + type KeywordClause struct + func (k KeywordClause) Serialize(statementType StatementType, out *SQLBuilder, options ...SerializeOption) + type ListSerializer struct + Separator string + Serializers []Serializer + type LiteralExpression interface + SetConstant func(constant bool) + Value func() interface{} + type LoggerFunc func(ctx context.Context, statement PrintableStatement) + type NumericExpression interface + type OptimizerHint string + type OrderByClause interface + NULLS_FIRST func() OrderByClause + NULLS_LAST func() OrderByClause + type OrderSetAggregateFunc struct + func MODE() *OrderSetAggregateFunc + func PERCENTILE_CONT(fraction FloatExpression) *OrderSetAggregateFunc + func PERCENTILE_DISC(fraction FloatExpression) *OrderSetAggregateFunc + func (p *OrderSetAggregateFunc) WITHIN_GROUP_ORDER_BY(orderBy OrderByClause) Expression + type PrintableStatement interface + DebugSql func() (query string) + Sql func() (query string, args []interface{}) + type Projection interface + func ColumnListToProjectionList(columns []ColumnExpression) []Projection + type ProjectionList []Projection + func (pl ProjectionList) As(tableAlias string) ProjectionList + func (pl ProjectionList) Except(toExclude ...Column) ProjectionList + type QueryInfo struct + Duration time.Duration + Err error + RowsProcessed int64 + Statement PrintableStatement + func (q QueryInfo) Caller() (file string, line int, function string) + type QueryLoggerFunc func(ctx context.Context, info QueryInfo) + type QueryPlaceholderFunc func(ord int) string + type Range interface + CONTAINS func(rhs T) BoolExpression + CONTAINS_RANGE func(rhs Range[T]) BoolExpression + DIFFERENCE func(rhs Range[T]) Range[T] + EQ func(rhs Range[T]) BoolExpression + GT func(rhs Range[T]) BoolExpression + GT_EQ func(rhs Range[T]) BoolExpression + INTERSECTION func(rhs Range[T]) Range[T] + IS_EMPTY func() BoolExpression + LOWER_BOUND func() T + LOWER_INC func() BoolExpression + LOWER_INF func() BoolExpression + LT func(rhs Range[T]) BoolExpression + LT_EQ func(rhs Range[T]) BoolExpression + NOT_EQ func(rhs Range[T]) BoolExpression + OVERLAP func(rhs Range[T]) BoolExpression + UNION func(rhs Range[T]) Range[T] + UPPER_BOUND func() T + UPPER_INC func() BoolExpression + UPPER_INF func() BoolExpression + func DateRange(lowTs, highTs DateExpression, bounds ...StringExpression) Range[DateExpression] + func Int4Range(lowNum, highNum IntegerExpression, bounds ...StringExpression) Range[Int4Expression] + func Int8Range(lowNum, highNum Int8Expression, bounds ...StringExpression) Range[Int8Expression] + func NumRange(lowNum, highNum NumericExpression, bounds ...StringExpression) Range[NumericExpression] + func RangeExp[T Expression](expression Expression) Range[T] + func RawRange[T Expression](raw string, namedArgs ...map[string]interface{}) Range[T] + func TsRange(lowTs, highTs TimestampExpression, bounds ...StringExpression) Range[TimestampExpression] + func TstzRange(lowTs, highTs TimestampzExpression, bounds ...StringExpression) Range[TimestampzExpression] + type RowLock interface + NOWAIT func() RowLock + OF func(...Table) RowLock + SKIP_LOCKED func() RowLock + type Rows struct + func (r *Rows) Scan(destination interface{}) error + type SQLBuilder struct + Args []interface{} + Buff bytes.Buffer + Debug bool + Dialect Dialect + func (s *SQLBuilder) DecreaseIdent(ident ...int) + func (s *SQLBuilder) IncreaseIdent(ident ...int) + func (s *SQLBuilder) NewLine() + func (s *SQLBuilder) WriteAlias(str string) + func (s *SQLBuilder) WriteByte(b byte) + func (s *SQLBuilder) WriteIdentifier(name string, alwaysQuote ...bool) + func (s *SQLBuilder) WriteProjections(statement StatementType, projections []Projection) + func (s *SQLBuilder) WriteString(str string) + type SelectTable interface + Alias func() string + AllColumns func() ProjectionList + func NewLateral(selectStmt SerializerStatement, alias string) SelectTable + type SerializeOption int + const Ident + const NoWrap + const ShortName + const SkipNewLine + func FallTrough(options []SerializeOption) []SerializeOption + func (s SerializeOption) WithFallTrough(options []SerializeOption) []SerializeOption + type SerializeOverride func(expressions ...Serializer) SerializerFunc + type Serializer interface + func ExpressionListToSerializerList(expressions []Expression) []Serializer + func NewSerializerClauseImpl(clauses ...Clause) Serializer + func ToSerializerValue(value interface{}) Serializer + func UnwindRowFromModel(columns []Column, data interface{}) []Serializer + func UnwindRowFromValues(value interface{}, values []interface{}) []Serializer + type SerializerFunc func(statement StatementType, out *SQLBuilder, options ...SerializeOption) + type SerializerHasProjections interface + type SerializerStatement interface + func NewStatementImpl(Dialect Dialect, statementType StatementType, parent SerializerStatement, ...) SerializerStatement + type SerializerTable interface + func NewTable(schemaName, name, alias string, columns ...ColumnExpression) SerializerTable + type SetClause struct + Columns []Column + Values []Serializer + func (s *SetClause) Serialize(statementType StatementType, out *SQLBuilder, options ...SerializeOption) + type SetClauseNew []ColumnAssigment + func (s SetClauseNew) Serialize(statementType StatementType, out *SQLBuilder, options ...SerializeOption) + type SetPair struct + Column ColumnSerializer + Value Serializer + type Statement interface + DebugSql func() (query string) + Exec func(db qrm.Executable) (sql.Result, error) + ExecContext func(ctx context.Context, db qrm.Executable) (sql.Result, error) + Query func(db qrm.Queryable, destination interface{}) error + QueryContext func(ctx context.Context, db qrm.Queryable, destination interface{}) error + Rows func(ctx context.Context, db qrm.Queryable) (*Rows, error) + Sql func() (query string, args []interface{}) + func RawStatement(dialect Dialect, rawQuery string, namedArgument ...map[string]interface{}) Statement + type StatementType string + const DeleteStatementType + const InsertStatementType + const LockStatementType + const SelectStatementType + const SetStatementType + const UnLockStatementType + const UpdateStatementType + const WithStatementType + type StringExpression interface + BETWEEN func(min, max StringExpression) BoolExpression + CONCAT func(rhs Expression) StringExpression + EQ func(rhs StringExpression) BoolExpression + GT func(rhs StringExpression) BoolExpression + GT_EQ func(rhs StringExpression) BoolExpression + IS_DISTINCT_FROM func(rhs StringExpression) BoolExpression + IS_NOT_DISTINCT_FROM func(rhs StringExpression) BoolExpression + LIKE func(pattern StringExpression) BoolExpression + LT func(rhs StringExpression) BoolExpression + LT_EQ func(rhs StringExpression) BoolExpression + NOT_BETWEEN func(min, max StringExpression) BoolExpression + NOT_EQ func(rhs StringExpression) BoolExpression + NOT_LIKE func(pattern StringExpression) BoolExpression + NOT_REGEXP_LIKE func(pattern StringExpression, caseSensitive ...bool) BoolExpression + REGEXP_LIKE func(pattern StringExpression, caseSensitive ...bool) BoolExpression + func BTRIM(stringExpression StringExpression, trimChars ...StringExpression) StringExpression + func CHR(integerExpression IntegerExpression) StringExpression + func CONCAT(expressions ...Expression) StringExpression + func CONCAT_WS(separator Expression, expressions ...Expression) StringExpression + func CONVERT(str StringExpression, srcEncoding StringExpression, ...) StringExpression + func CONVERT_FROM(str StringExpression, srcEncoding StringExpression) StringExpression + func CONVERT_TO(str StringExpression, toEncoding StringExpression) StringExpression + func DECODE(data StringExpression, format StringExpression) StringExpression + func ENCODE(data StringExpression, format StringExpression) StringExpression + func FORMAT(formatStr StringExpression, formatArgs ...Expression) StringExpression + func INITCAP(str StringExpression) StringExpression + func LEFT(str StringExpression, n IntegerExpression) StringExpression + func LENGTH(str StringExpression, encoding ...StringExpression) StringExpression + func LOWER(stringExpression StringExpression) StringExpression + func LPAD(str StringExpression, length IntegerExpression, text ...StringExpression) StringExpression + func LTRIM(str StringExpression, trimChars ...StringExpression) StringExpression + func MD5(stringExpression StringExpression) StringExpression + func NewEnumValue(name string) StringExpression + func NewStringFunc(name string, expressions ...Expression) StringExpression + func REPEAT(str StringExpression, n IntegerExpression) StringExpression + func REPLACE(text, from, to StringExpression) StringExpression + func REVERSE(stringExpression StringExpression) StringExpression + func RIGHT(str StringExpression, n IntegerExpression) StringExpression + func RPAD(str StringExpression, length IntegerExpression, text ...StringExpression) StringExpression + func RTRIM(str StringExpression, trimChars ...StringExpression) StringExpression + func RawString(raw string, namedArgs ...map[string]interface{}) StringExpression + func SUBSTR(str StringExpression, from IntegerExpression, count ...IntegerExpression) StringExpression + func String(value string) StringExpression + func StringExp(expression Expression) StringExpression + func TO_ASCII(str StringExpression, encoding ...StringExpression) StringExpression + func TO_CHAR(expression Expression, format StringExpression) StringExpression + func TO_HEX(number IntegerExpression) StringExpression + func UPPER(stringExpression StringExpression) StringExpression + func UUID(value fmt.Stringer) StringExpression + type Table interface + Alias func() string + SchemaName func() string + TableName func() string + type TimeExpression interface + ADD func(rhs Interval) TimeExpression + BETWEEN func(min, max TimeExpression) BoolExpression + EQ func(rhs TimeExpression) BoolExpression + GT func(rhs TimeExpression) BoolExpression + GT_EQ func(rhs TimeExpression) BoolExpression + IS_DISTINCT_FROM func(rhs TimeExpression) BoolExpression + IS_NOT_DISTINCT_FROM func(rhs TimeExpression) BoolExpression + LT func(rhs TimeExpression) BoolExpression + LT_EQ func(rhs TimeExpression) BoolExpression + NOT_BETWEEN func(min, max TimeExpression) BoolExpression + NOT_EQ func(rhs TimeExpression) BoolExpression + SUB func(rhs Interval) TimeExpression + func LOCALTIME(precision ...int) TimeExpression + func RawTime(raw string, namedArgs ...map[string]interface{}) TimeExpression + func Time(hour, minute, second int, nanoseconds ...time.Duration) TimeExpression + func TimeExp(expression Expression) TimeExpression + func TimeT(t time.Time) TimeExpression + type TimestampExpression interface + ADD func(rhs Interval) TimestampExpression + BETWEEN func(min, max TimestampExpression) BoolExpression + EQ func(rhs TimestampExpression) BoolExpression + GT func(rhs TimestampExpression) BoolExpression + GT_EQ func(rhs TimestampExpression) BoolExpression + IS_DISTINCT_FROM func(rhs TimestampExpression) BoolExpression + IS_NOT_DISTINCT_FROM func(rhs TimestampExpression) BoolExpression + LT func(rhs TimestampExpression) BoolExpression + LT_EQ func(rhs TimestampExpression) BoolExpression + NOT_BETWEEN func(min, max TimestampExpression) BoolExpression + NOT_EQ func(rhs TimestampExpression) BoolExpression + SUB func(rhs Interval) TimestampExpression + func LOCALTIMESTAMP(precision ...int) TimestampExpression + func RawTimestamp(raw string, namedArgs ...map[string]interface{}) TimestampExpression + func Timestamp(year int, month time.Month, day, hour, minute, second int, ...) TimestampExpression + func TimestampExp(expression Expression) TimestampExpression + func TimestampT(t time.Time) TimestampExpression + type TimestampzExpression interface + ADD func(rhs Interval) TimestampzExpression + BETWEEN func(min, max TimestampzExpression) BoolExpression + EQ func(rhs TimestampzExpression) BoolExpression + GT func(rhs TimestampzExpression) BoolExpression + GT_EQ func(rhs TimestampzExpression) BoolExpression + IS_DISTINCT_FROM func(rhs TimestampzExpression) BoolExpression + IS_NOT_DISTINCT_FROM func(rhs TimestampzExpression) BoolExpression + LT func(rhs TimestampzExpression) BoolExpression + LT_EQ func(rhs TimestampzExpression) BoolExpression + NOT_BETWEEN func(min, max TimestampzExpression) BoolExpression + NOT_EQ func(rhs TimestampzExpression) BoolExpression + SUB func(rhs Interval) TimestampzExpression + func CURRENT_TIMESTAMP(precision ...int) TimestampzExpression + func NOW() TimestampzExpression + func RawTimestampz(raw string, namedArgs ...map[string]interface{}) TimestampzExpression + func TO_TIMESTAMP(timestampzStr, format StringExpression) TimestampzExpression + func Timestampz(year int, month time.Month, day, hour, minute, second int, ...) TimestampzExpression + func TimestampzExp(expression Expression) TimestampzExpression + func TimestampzT(t time.Time) TimestampzExpression + type TimezExpression interface + ADD func(rhs Interval) TimezExpression + BETWEEN func(min, max TimezExpression) BoolExpression + EQ func(rhs TimezExpression) BoolExpression + GT func(rhs TimezExpression) BoolExpression + GT_EQ func(rhs TimezExpression) BoolExpression + IS_DISTINCT_FROM func(rhs TimezExpression) BoolExpression + IS_NOT_DISTINCT_FROM func(rhs TimezExpression) BoolExpression + LT func(rhs TimezExpression) BoolExpression + LT_EQ func(rhs TimezExpression) BoolExpression + NOT_BETWEEN func(min, max TimezExpression) BoolExpression + NOT_EQ func(rhs TimezExpression) BoolExpression + SUB func(rhs Interval) TimezExpression + func CURRENT_TIME(precision ...int) TimezExpression + func RawTimez(raw string, namedArgs ...map[string]interface{}) TimezExpression + func Timez(hour, minute, second int, nanoseconds time.Duration, timezone string) TimezExpression + func TimezExp(expression Expression) TimezExpression + func TimezT(t time.Time) TimezExpression + type Token string + type Window interface + GROUPS func(start FrameExtent, end ...FrameExtent) Window + ORDER_BY func(expr ...OrderByClause) Window + RANGE func(start FrameExtent, end ...FrameExtent) Window + ROWS func(start FrameExtent, end ...FrameExtent) Window + func ORDER_BY(expr ...OrderByClause) Window + func PARTITION_BY(exp Expression, exprs ...Expression) Window + func WindowName(name string) Window + type WindowDefinition struct + Name string + Window Window