package
25.1.0+incompatible
Repository: https://github.com/cockroachdb/cockroach.git
Documentation: pkg.go.dev

# Packages

# Functions

BinaryOp evaluates a tree.BinaryEvalOp.
Cbrt returns the cube root of x.
ComparisonExprWithSubOperator evaluates a comparison expression that has sub-operator (which are ANY, SOME, and ALL).
ConvertLikeToRegexp compiles the specified LIKE pattern as an equivalent regular expression.
DecimalCbrt returns the cube root of x.
DecimalSqrt returns the square root of x.
DecimalToInexactDTimestamp is the inverse of TimestampToDecimal.
DecimalToInexactDTimestampTZ is the inverse of TimestampToDecimal.
Expr evaluates a TypedExpr into a Datum.
GetFuncGenerator is used to construct a ValueGenerator from a FuncExpr.
GetRoutineGenerator is used to construct a ValueGenerator from a FuncExpr.
IntPow computes the value of x^y.
IsConst returns whether the expression is constant.
IsVar returns true if the expression's value can vary during plan execution.
LikeEscape converts a like pattern to a regexp pattern.
MakeTestingEvalContext returns an EvalContext that includes a MemoryMonitor.
MakeTestingEvalContextWithMon returns an EvalContext with the given MemoryMonitor.
MatchLikeEscape matches 'unescaped' with 'pattern' using custom escape character 'escape' which must be either empty (which disables the escape mechanism) or a single unicode character.
NewCallbackValueGenerator creates a new CallbackValueGenerator.
NewTestingEvalContext is a convenience version of MakeTestingEvalContext that returns a pointer.
NewUnsupportedTypeChecker returns a new tree.UnsupportedTypeChecker that can be used to check whether a type is allowed by the current cluster version.
ParseDOid parses and returns an Oid family datum.
PerformAssignmentCast performs an assignment cast from the provided Datum to the specified type.
PerformCast performs a cast from the provided Datum to the specified types.T.
PerformCastNoTruncate performs an explicit cast, but returns an error if the value doesn't fit in the required type.
PickFromTuple picks the greatest (or least value) from a tuple.
PopulateDatumWithJSON is used for the json to record function family, like json_populate_record.
PopulateRecordWithJSON is used for the json to record function family, like json_populate_record.
ReType ensures that the given expression evaluates to the requested type, wrapping the expression in a cast if necessary.
SimilarEscape converts a SQL:2008 regexp pattern to POSIX style, so it can be used by our regexp engine.
SimilarPattern converts a SQL regexp 'pattern' to a POSIX regexp 'pattern' using custom escape token 'escape' which must be either empty (which disables the escape mechanism) or a single unicode character.
SimilarToEscape checks if 'unescaped' is SIMILAR TO 'pattern' using custom escape token 'escape' which must be either empty (which disables the escape mechanism) or a single unicode character.
Sqrt returns the square root of x.
TimestampToDecimal converts the logical timestamp into a decimal value with the number of nanoseconds in the integer part and the logical counter in the decimal part.
TimestampToDecimalDatum is the same as TimestampToDecimal, but returns a datum.
TimestampToInexactDTimestamp converts the logical timestamp into an inexact DTimestamp by dropping the logical counter and using the wall time at the microsecond precision.
UnaryOp will evaluate a tree.UnaryEvalOp on a Datum into another Datum.
UnwrapDatum returns the base Datum type for a provided datum, stripping an *DOidWrapper if present.

# Constants

HasNoPrivilege means no privileges are granted.
HasPrivilege means at least one of the specified privileges is granted.
ObjectNotFound means the object that privileges are being checked on was not found.

# Variables

# Structs

AsOfSystemTime represents the result from the evaluation of AS OF SYSTEM TIME clause.
CallbackValueGenerator is a ValueGenerator that calls a supplied callback for producing the values.
Context defines the context in which to evaluate an expression, allowing the retrieval of state such as the node ID or statement start time.
HasPrivilegeSpecifier specifies an object to lookup privilege for.
PeerGroupsIndicesHelper computes peer groups using the given PeerGroupChecker.
RNGFactory is a simple wrapper to preserve the RNG throughout the session.
TestingKnobs contains test knobs.
ULIDEntropyFactory is a simple wrapper to preserve the ULID entropy throughout the session.
WindowFrameRangeOps allows for looking up an implementation of binary operators necessary for RANGE mode of framing.
WindowFrameRun contains the runtime state of window frame during calculations.

# Interfaces

AggregateFunc accumulates the result of a function of a Datum.
AliasAwareValueGenerator is a value generator that can inspect the alias with which it was invoked.
CatalogBuiltins is a set of methods which can be implemented using the lower-level descs.Collection for use in builtins.
ChangefeedState is used to track progress and checkpointing for sinkless/core changefeeds.
ClientNoticeSender is a limited interface to send notices to the client.
ConsistencyCheckRunner is an interface embedded in eval.Context used by crdb_internal.check_consistency.
DatabaseCatalog consists of functions that reference the session database and is to be used from Context.
DatabaseRegionConfig is a wrapper around multiregion.RegionConfig related methods which avoids a circular dependency between descpb and tree.
DeferredRoutineSender allows a nested routine to send the information needed for its own evaluation to a parent routine.
DescIDGenerator generates unique descriptor IDs.
GossipOperator is capable of manipulating the cluster's gossip network.
IndexedRow is a row with a corresponding index.
IndexedRows are rows with the corresponding indices.
IndexedVarContainer extends tree.IndexedVarContainer with the ability to evaluate the underlying expression.
IndexUsageStatsController is an interface embedded in EvalCtx which can be used by the builtins to reset index usage stats in the cluster.
InternalRows is an iterator interface that's exposed by the internal executor.
JobsProfiler is the interface used to fetch job specific execution details that may have been aggregated during a job's lifetime.
JoinTokenCreator is capable of creating and persisting join tokens, allowing SQL builtin functions to create join tokens.
PeerGroupChecker can check if a pair of row indices within a partition are in the same peer group.
Planner is a limited planner that can be used from EvalContext.
PreparedStatementState is a limited interface that exposes metadata about prepared statements.
PrivilegedAccessor gives access to certain queries that would otherwise require someone with RootUser access to query a given data source.
RangeProber is an interface embedded in eval.Context used by crdb_internal.probe_ranges.
RangeStatsFetcher is used to fetch RangeStats.
RegionOperator gives access to the current region, validation for all regions, and the ability to reset the zone configurations for tables or databases.
ReplicationStreamManager represents a collection of APIs that streaming replication supports on the production side.
SchemaTelemetryController is an interface embedded in EvalCtx which can be used by the builtins to create a job schedule for schema telemetry jobs.
SequenceOperators is used for various sql related functions that can be used from Context.
SessionAccessor is a limited interface to access session variables.
SQLStatsController is an interface embedded in EvalCtx which can be used by the builtins to reset SQL stats in the cluster.
StreamIngestManager represents a collection of APIs that streaming replication supports on the ingestion side.
StreamManagerFactory stores methods that return the streaming managers.
TenantOperator is capable of interacting with tenant state, allowing SQL builtin functions to create, configure, and destroy tenants.
TypeResolver is an interface for resolving types and type OIDs.
ValueGenerator is the interface provided by the value generator functions for SQL SRFs.
WindowFunc performs a computation on each row using data from a provided *WindowFrameRun.

# Type aliases

AggregateOverload is the concrete type for the tree.Overload.Aggregate field.
CastFunc is a function which cases a datum to a given type.
CompactEngineSpanFunc is used to compact an engine key span at the given (nodeID, storeID).
FnOverload is a function generally defined as a builtin.
FnWithExprsOverload is the concrete type for the tree.Overload.FnWithExprs field.
GeneratorOverload is the type of constructor functions for ValueGenerator objects.
GeneratorWithExprsOverload is an alternative constructor function type for ValueGenerators that gives implementations the ability to see the builtin's arguments before evaluation, as Exprs.
GetTableMetrics is used to retrieve sstable metrics on a key span (end-exclusive) at the given (nodeID, storeID).
HasAnyPrivilegeResult represents the non-error results of calling HasAnyPrivilege.
ScanStorageInternalKeysFunc is used to retrieve pebble metrics on a key span (end-exclusive) at the given (nodeID, storeID).
SetCompactionConcurrencyFunc is used to change the compaction concurrency of a store.
SQLFnOverload is the concrete type for the tree.Overload.SQLFn field.
StmtDiagnosticsRequestInsertFunc is an interface embedded in EvalCtx that can be used by the builtins to insert a statement diagnostics request.
WindowOverload is the type of constructor functions for WindowFunc objects.