package
19.1.0-rc.1+incompatible
Repository: https://github.com/dchenk/cockroach.git
Documentation: pkg.go.dev

# Functions

CompareEncDatumRowForMerge EncDatumRow compares two EncDatumRows for merging.
CreateWindowerSpecFunc creates a WindowerSpec_Func based on the function name or returns an error if unknown function name is provided.
DrainAndClose is a version of DrainAndForwardMetadata that drains multiple sources.
DrainAndForwardMetadata calls src.ConsumerDone() (thus asking src for draining metadata) and then forwards all the metadata to dst.
FlowVerIsCompatible checks a flow's version is compatible with this node's DistSQL version.
GetAggregateInfo returns the aggregate constructor and the return type for the given aggregate function when applied on the given type.
GetResumeSpans returns a ResumeSpanList from a job.
GetWindowFunctionInfo returns windowFunc constructor and the return type when given fn is applied to given inputTypes.
MakeDistSQLMetrics instantiates the metrics holder for DistSQL monitoring.
MakeNoMetadataRowSource builds a NoMetadataRowSource.
NewDistinct instantiates a new Distinct processor.
NewInputStatCollector creates a new InputStatCollector that wraps the given input.
NewMonitor is a utility function used by processors to create a new memory monitor with the given name and start it.
NewRowBuffer creates a RowBuffer with the given schema and initial rows.
NewServer instantiates a DistSQLServer.
ProcessInboundStream receives rows from a DistSQL_FlowStreamServer and sends them to a RowReceiver.
Run reads records from the source and outputs them to the receiver, properly draining the source of metadata and closing both the source and receiver.
SetResumeSpansInJob addeds a list of resume spans into a job details field.
WriteResumeSpan writes a checkpoint for the backfill work on origSpan.

# Constants

ConsumerClosed indicates that the consumer will not process any more data rows or metadata.
DrainRequested indicates that the consumer will not process any more data rows, but will accept trailing metadata from the producer.
Flow status indicators.
Flow status indicators.
Flow status indicators.
MinAcceptedVersion is the oldest version that the server is compatible with; see above.
NeedMoreRows indicates that the consumer is still expecting more rows.
NoExplain represents that metadata test processors are planned for all queries except EXPLAIN (DISTSQL) statements.
Off represents that no metadata test processors are planned.
On represents that metadata test processors are planned for all queries.
ParallelScanResultThreshold is the number of results up to which, if the maximum number of results returned by a scan is known, the table reader disables batch limits in the dist sender.
StateRunning is the common state of a processor: it's producing rows for its consumer and forwarding metadata from its input.
SubqueryExecModeAllRows indicates that the subquery is an argument to an ARRAY constructor.
SubqueryExecModeAllRowsNormalized indicates that the subquery is an argument to IN, ANY, SOME, or ALL.
SubqueryExecModeExists indicates that the subquery is an argument to EXISTS.
SubqueryExecModeOneRow indicates that the subquery is an argument to another function.
SubqueryExecModeUnknown is the default value, and is only used to indicate a subquery that was improperly initialized.
Version identifies the distsqlrun protocol version.

# Variables

No description provided by the author
No description provided by the author
NewChangeAggregatorProcessor is externally implemented.
NewChangeFrontierProcessor is externally implemented.
NewCSVWriterProcessor is externally implemented.
NewReadImportDataProcessor is externally implemented and registered by ccl/sqlccl/csv.go.
NewSSTWriterProcessor is externally implemented and registered by ccl/sqlccl/csv.go.
SampleAggregatorProgressInterval is the frequency at which the SampleAggregator processor will report progress.
SamplerProgressInterval corresponds to the number of input rows after which the sampler will report progress by pushing a metadata record.
ScrubTypes is the schema for TableReaders that are doing a SCRUB check.
SubqueryExecModeNames maps SubqueryExecMode values to human readable strings for EXPLAIN queries.

# Structs

AggregatorStats are the stats collected during an aggregator run.
BufferedRecord represents a row or metadata record that has been buffered inside a RowBuffer.
Distinct is the physical processor implementation of the DISTINCT relational operator.
DistinctStats are the stats collected during a distinct run.
DistSQLMetrics contains pointers to the metrics for monitoring DistSQL processing.
Flow represents a flow which consists of processors and streams.
FlowCtx encompasses the contexts needed for various flow components.
HashJoinerStats are the stats collected during a hashJoiner run.
InputStatCollector wraps a RowSource and collects stats from it.
InputStats represents the stats collected from an input.
JoinReaderStats are the stats collected during a joinReader run.
LocalState carries information that is required to set up a flow with wrapped planNodes.
MergeJoinerStats are the stats collected during a mergeJoiner run.
NoMetadataRowSource is a wrapper on top of a RowSource that automatically forwards metadata to a RowReceiver.
OutboxStats are the stats collected by an outbox.
ProcessorBase is supposed to be embedded by Processors.
ProcOutputHelper is a helper type that performs filtering and projection on the output of a processor.
ProcStateOpts contains fields used by the ProcessorBase's family of functions that deal with draining and trailing metadata: the ProcessorBase implements generic useful functionality that needs to call back into the Processor.
ProducerMetadata represents a metadata record flowing through a DistSQL flow.
RouterOutputStats are the stats collected by a single router output stream.
RowBuffer is an implementation of RowReceiver that buffers (accumulates) results in memory, as well as an implementation of RowSource that returns records from a record buffer.
RowBufferArgs contains testing-oriented parameters for a RowBuffer.
RowChannel is a thin layer over a RowChannelMsg channel, which can be used to transfer rows between goroutines.
RowChannelMsg is the message used in the channels that implement local physical streams (i.e.
ServerConfig encompasses the configuration required to create a DistSQLServer.
ServerImpl implements the server for the distributed SQL APIs.
SortedDistinct is a specialized distinct that can be used when all of the distinct columns are also ordered.
SorterStats are the stats collected during a sorter run.
StreamDecoder converts a sequence of ProducerMessage to rows and metadata records.
StreamEncoder converts EncDatum rows into a sequence of ProducerMessage.
TableReaderStats are the stats collected during a tableReader run.
TestingKnobs are the testing knobs.
WindowerStats are the stats collected during a windower run.

# Interfaces

LocalProcessor is a RowSourcedProcessor that needs to be initialized with its post processing spec and output row receiver.
Processor is a common interface implemented by all processors, used by the higher-level flow orchestration code.
Releasable is an interface for objects than can be Released back into a memory pool when finished.
RowReceiver is any component of a flow that receives rows from another component.
RowSource is any component of a flow that produces rows that can be consumed by another component.
RowSourcedProcessor is the union of RowSource and Processor.
RuntimeStats is an interface through which the distsqlrun layer can get information about runtime statistics.

# Type aliases

ConsumerStatus is the type returned by RowReceiver.Push(), informing a producer of a consumer's state.
MetadataTestLevel represents the types of queries where metadata test processors are planned.
SubqueryExecMode is an enum to indicate the type of a subquery.