package
20.2.19+incompatible
Repository: https://github.com/cockroachdb/cockroach.git
Documentation: pkg.go.dev
# Packages
No description provided by the author
No description provided by the author
No description provided by the author
# Functions
BoolOrUnknownToSelOp plans an infrastructure necessary to convert a column of either Bool or Unknown type into a selection vector on the input batches.
EncDatumRowsToColVec converts one column from EncDatumRows to a column vector.
No description provided by the author
GetDatumToPhysicalFn returns a function for converting a datum of the given ColumnType to the corresponding Go type.
No description provided by the author
No description provided by the author
GetLikeOperator returns a selection operator which applies the specified LIKE pattern, or NOT LIKE if the negate argument is true.
GetLikeProjectionOperator returns a projection operator which projects the result of the specified LIKE pattern, or NOT LIKE if the negate argument is true.
GetProjectionLConstOperator returns the appropriate constant projection operator for the given left and right column types and operation.
GetProjectionOperator returns the appropriate projection operator for the given left and right column types and operation.
GetProjectionRConstOperator returns the appropriate constant projection operator for the given left and right column types and operation.
GetSelectionConstOperator returns the appropriate constant selection operator for the given left and right column types and comparison.
GetSelectionOperator returns the appropriate two column selection operator for the given left and right column types and comparison.
No description provided by the author
MakeHashJoinerSpec creates a specification for columnar hash join operator.
No description provided by the author
NewBatchSchemaSubsetEnforcer creates a new BatchSchemaSubsetEnforcer.
NewBufferOp returns a new bufferOp, initialized to buffer batches from the supplied input.
NewBuiltinFunctionOperator returns an operator that applies builtin functions.
NewCancelChecker creates a new CancelChecker.
NewCaseOp returns an operator that runs a case statement.
NewColumnarizer returns a new Columnarizer.
NewConstNullOp creates a new operator that produces a constant (untyped) NULL value at index outputIdx.
NewConstOp creates a new operator that produces a constant value constVal of type t at index outputIdx.
NewCountOp returns a new count operator that counts the rows in its input.
NewDefaultExprHelper returns an ExprHelper that takes advantage of an already well-typed expression in LocalExpr when set.
NewDeselectorOp creates a new deselector operator on the given input operator with the given column types.
NewExprHelper returns a new ExprHelper.
NewExternalHashJoiner returns a disk-backed hash joiner.
NewExternalSorter returns a disk-backed general sort operator.
NewFeedOperator returns a new feed operator.
NewHashAggregator creates a hash aggregator on the given grouping columns.
NewHashJoiner creates a new equality hash join operator on the left and right input tables.
NewHashRouter creates a new hash router that consumes coldata.Batches from input and hashes each row according to hashCols to one of the outputs returned as Operators.
NewInvariantsChecker creates a new invariantsChecker.
NewIsNullProjOp returns a new isNullProjOp.
NewIsNullSelOp returns a new isNullSelOp.
NewLimitOp returns a new limit operator with the given limit.
NewMaterializer creates a new Materializer processor which processes the columnar data coming from input to return it as rows.
NewMergeJoinOp returns a new merge join operator with the given spec that implements sort-merge join.
NewNoop returns a new noop Operator.
NewOffsetOp returns a new offset operator with the given offset.
NewOneInputDiskSpiller returns a new oneInputDiskSpiller.
NewOneInputNode returns an execinfra.OpNode with a single Operator input.
NewOrderedAggregator creates an ordered aggregator on the given grouping columns.
NewOrderedDistinct creates a new ordered distinct operator on the given input columns with the given types.
NewOrderedSynchronizer creates a new OrderedSynchronizer.
NewOrdinalityOp returns a new WITH ORDINALITY operator.
No description provided by the author
NewParallelUnorderedSynchronizer creates a new ParallelUnorderedSynchronizer.
NewRankOperator creates a new Operator that computes window functions RANK or DENSE_RANK (depending on the passed in windowFn).
NewRelativeRankOperator creates a new Operator that computes window functions PERCENT_RANK or CUME_DIST (depending on the passed in windowFn).
NewRowNumberOperator creates a new Operator that computes window function ROW_NUMBER.
NewSerialUnorderedSynchronizer creates a new SerialUnorderedSynchronizer.
NewSimpleProjectOp returns a new simpleProjectOp that applies a simple projection on the columns in its input batch, returning a new batch with only the columns in the projection slice, in order.
NewSingleTupleNoInputOp creates a new Operator which returns a batch of length 1 with no actual columns on the first call to Next() and zero-length batches on all consecutive calls.
NewSortChunks returns a new sort chunks operator, which sorts its input on the columns given in orderingCols.
NewSorter returns a new sort operator, which sorts its input on the columns given in orderingCols.
NewTopKSorter returns a new sort operator, which sorts its input on the columns given in orderingCols and returns the first K rows.
NewTupleProjOp creates a new tupleProjOp that projects newly-created tuples at position outputIdx taking the tuples' contents from corresponding values of the vectors at positions tupleContentsIdxs.
NewTwoInputDiskSpiller returns a new twoInputDiskSpiller.
NewUnorderedDistinct creates an unordered distinct on the given distinct columns.
NewVectorizedStatsCollector creates a new VectorizedStatsCollector which wraps 'op' that corresponds to a component with either ProcessorID or StreamID 'id' (with 'idTagKey' distinguishing between the two).
NewWindowPeerGrouper creates a new Operator that puts 'true' in outputColIdx'th column (which is appended if needed) for every tuple that is the first within its peer group.
NewWindowSortingPartitioner creates a new colexec.Operator that orders input first based on the partitionIdxs columns and second on ordCols (i.e.
NewZeroOp creates a new operator which just returns an empty batch.
NewZeroOpNoInput creates a new operator which just returns an empty batch and doesn't an input.
OrderedDistinctColsToOperators is a utility function that given an input and a slice of columns, creates a chain of distinct operators and returns the last distinct operator in that chain as well as its output column.
ProcessAggregations processes all aggregate functions specified in aggregations.
# Constants
DefaultExprDeserialization is the default way of handling expression deserialization in which case LocalExpr field is used if set.
DefaultVectorizeRowCountThreshold denotes the default row count threshold.
ForcedExprDeserialization is the way of handling expression deserialization in which case LocalExpr field is completely ignored and the serialized representation is always deserialized.
OperatorInitialized indicates that Init has already been called.
OperatorNotInitialized indicates that Init has not been called yet.
VecMaxOpenFDsLimit specifies the maximum number of open file descriptors that the vectorized engine can have (globally) for use of the temporary storage.
# Variables
TestNewColOperator is a test helper that's always aliased to builder.NewColOperator.
# Structs
BatchSchemaSubsetEnforcer is similar to vectorTypeEnforcer in its purpose, but it enforces that the subset of the columns of the non-zero length batch satisfies the desired schema.
No description provided by the author
No description provided by the author
CallbackCloser is a utility struct that implements the Closer interface by calling a provided callback.
CancelChecker is an Operator that checks whether query cancellation has occurred.
Columnarizer turns an execinfra.RowSource input into an Operator output, by reading the input in chunks of size coldata.BatchSize() and converting each chunk into a coldata.Batch column by column.
No description provided by the author
No description provided by the author
FeedOperator is used to feed an Operator chain with input by manually setting the next batch.
No description provided by the author
HashJoinerSpec is the specification for a hash join operator.
HashRouter hashes values according to provided hash columns and computes a destination for each row.
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
Materializer converts an Operator input into a execinfra.RowSource.
NewColOperatorArgs is a helper struct that encompasses all of the input arguments to NewColOperator call.
NewColOperatorResult is a helper struct that encompasses all of the return values of NewColOperator call.
OneInputNode is an execinfra.OpNode with a single Operator input.
OrderedSynchronizer receives rows from multiple inputs and produces a single stream of rows, ordered according to a set of columns.
ParallelUnorderedSynchronizer is an Operator that combines multiple Operator streams into one.
SerialUnorderedSynchronizer is an Operator that combines multiple Operator streams into one.
SynchronizerInput is a wrapper over a colexecbase.Operator that a synchronizer goroutine will be calling Next on.
No description provided by the author
VectorizedStatsCollector collects VectorizedStats on Operators.
# Interfaces
Closer is an object that releases resources when Close is called.
ExprHelper is a utility interface that helps with expression handling in the vectorized engine.
InternalMemoryOperator is an interface that operators which use internal memory need to implement.
NonExplainable is a marker interface which identifies an Operator that should be omitted from the output of EXPLAIN (VEC).
ResettableOperator is an Operator that can be reset.
# Type aliases
Closers is a slice of Closers.
ExprDeserialization describes how expression deserialization should be handled in the vectorized engine.
OperatorInitStatus indicates whether Init method has already been called on an Operator.