package
19.2.12+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
No description provided by the author

# Functions

EstimateBatchSizeBytes returns an estimated amount of bytes needed to store a batch in memory that has column types vecTypes.
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.
NewBatchBuffer creates a new BatchBuffer.
NewBoolVecToSelOp is the operator form of boolVecToSelOp.
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.
NewCoalescerOp creates a new coalescer operator on the given input operator with the given column types.
NewColOperator creates a new columnar operator according to the given spec.
NewColumnarizer returns a new Columnarizer.
NewCountOp returns a new count operator that counts the rows in its input.
NewDeselectorOp creates a new deselector operator on the given input operator with the given column coltypes.
NewEqHashJoinerOp creates a new equality hash join operator on the left and right input tables.
NewHashAggregator creates a hash aggregator on the given grouping columns.
NewHashRouter creates a new hash router that consumes coldata.Batches from input and hashes each row according to hashCols to one of numOutputs outputs.
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.
NewOneInputNode returns an execinfra.OpNode with a single Operator input.
NewOrderedAggregator creates an ordered aggregator on the given grouping columns.
NewOrderedSynchronizer creates a new OrderedSynchronizer.
NewOrdinalityOp returns a new WITH ORDINALITY operator.
NewParallelUnorderedSynchronizer creates a new ParallelUnorderedSynchronizer.
NewRandomDataOp creates a new RandomDataOp.
NewRankOperator creates a new exec.Operator that computes window function RANK or DENSE_RANK.
NewRepeatableBatchSource returns a new Operator initialized to return its input batch forever (including the selection vector if batch comes with it).
NewRowNumberOperator creates a new exec.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.
NewVectorizedStatsCollector creates a new VectorizedStatsCollector which wraps op that corresponds to a processor with ProcessorID id.
NewWindowSortingPartitioner creates a new exec.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.
PhysicalTypeColElemToDatum converts an element in a colvec to a datum of semtype ct.
RandomBatch returns a batch with a capacity of capacity and a number of random elements equal to length (capacity if length is 0).
RandomVec populates vec with n random values of typ, setting each value to null with a probability of nullProbability.

# Constants

DefaultVectorizeRowCountThreshold denotes the default row count threshold.
OperatorInitialized indicates that Init has already been called.
OperatorNotInitialized indicates that Init has not been called yet.

# Structs

BatchBuffer exposes a buffer of coldata.Batches through an Operator interface.
CallbackOperator is a testing utility struct that delegates Next calls to a callback provided by the user.
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.
HashRouter hashes values according to provided hash columns and computes a destination for each row.
Materializer converts an Operator input into a execinfra.RowSource.
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.
RandomDataOp is an operator that generates random data according to RandomDataOpArgs.
RandomDataOpArgs are arguments passed in to RandomDataOp.
RepeatableBatchSource is an Operator that returns the same batch forever.
SerialUnorderedSynchronizer is an Operator that combines multiple Operator streams into one.
VectorizedStatsCollector collects VectorizedStats on Operators.
ZeroInputNode is an execinfra.OpNode with no inputs.

# Interfaces

NonExplainable is a marker interface which identifies an Operator that should be omitted from the output of EXPLAIN (VEC).
Operator is a column vector operator that produces a Batch as output.
StaticMemoryOperator is an interface that streaming operators can implement if they are able to declare their memory usage upfront.

# Type aliases

OperatorInitStatus indicates whether Init method has already been called on an Operator.