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

# Functions

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.
GenerateValuesSpec generates a ValuesCoreSpec that encodes the given rows.
GetConnForOutbox is a shared function between the rowexec and colexec outboxes.
GetLeafTxnFinalState returns the txn metadata from a transaction if it is present and the transaction is a leaf transaction.
GetTraceData returns the trace data.
GetWorkMemLimit returns the number of bytes determining the amount of RAM available to a single processor or operator.
LimitHint returns the limit hint to set for a KVFetcher based on the spec's limit hint and the PostProcessSpec.
MakeDistSQLMetrics instantiates the metrics holder for DistSQL monitoring.
MakeNoMetadataRowSource builds a NoMetadataRowSource.
MisplannedRanges queries the range cache for all the passed-in spans and returns the list of ranges whose leaseholder is not on the indicated node.
NewLimitedMonitor is a utility function used by processors to create a new limited memory monitor with the given name and start it.
NewMetadataTestReceiver creates a new MetadataTestReceiver.
NewMetadataTestSender creates a new MetadataTestSender.
NewMonitor is a utility function used by processors to create a new memory monitor with the given name and start it.
NewRepeatableRowSource creates a RepeatableRowSource with the given schema and rows.
NewTestDiskMonitor creates and starts a new disk monitor to be used in tests.
NewTestMemMonitor creates and starts a new memory monitor to be used in tests.
ProcessorSpan creates a child span for a processor (if we are doing any tracing).
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.
SendTraceData collects the tracing information from the ctx and pushes it to dst.

# 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.
MinAcceptedVersion is the oldest version that the server is compatible with.
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.
RowChannelBufSize is the default buffer size of a RowChannel.
Prettier aliases for execinfrapb.ScanVisibility values.
Prettier aliases for execinfrapb.ScanVisibility values.
StateDraining is the state in which the processor is forwarding metadata from its input and otherwise ignoring all rows.
StateExhausted is the state of a processor that has no more rows or metadata to produce.
StateRunning is the common state of a processor: it's producing rows for its consumer and forwarding metadata from its input.
StateTrailingMeta is the state in which the processor is outputting final metadata such as the tracing information or the LeafTxnFinalState.
StaticNodeID is the default Node ID to be used in tests.
Version identifies the distsql protocol version.

# Variables

SettingWorkMemBytes is a cluster setting that determines the maximum amount of RAM that a processor can use.

# Structs

DistSQLMetrics contains pointers to the metrics for monitoring DistSQL processing.
FlowCtx encompasses the configuration parameters needed for various flow components.
MetadataTestReceiver is a Processors that is complimentary to MetadataTestSender which checks that all metadata emitted by latter is received.
MetadataTestSender intersperses a metadata record after every row.
NoMetadataRowSource is a wrapper on top of a RowSource that automatically forwards metadata to a RowReceiver.
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.
RepeatableRowSource is a RowSource used in benchmarks to avoid having to reinitialize a new RowSource every time during multiple passes of the input.
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.
TestingKnobs are the testing knobs.

# Interfaces

Dialer is used for dialing based on node IDs.
DoesNotUseTxn is an interface implemented by some processors to mark that they do not use a txn.
IOReader is an operator that performs IO reads.
LocalProcessor is a RowSourcedProcessor that needs to be initialized with its post processing spec and output row receiver.
OpNode is an interface to operator-like structures with children.
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 rowexec 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.
ProcessorConstructor is a function that creates a Processor.