Versions in this module Expand all Collapse all v1 v1.1.4 Jan 1, 2018 Changes in this version + const FlowFinished + const FlowNotStarted + const FlowRunning + var AggregatorSpec_Func_name = map[int32]string + var AggregatorSpec_Func_value = map[string]int32 + var AlgebraicSetOpSpec_SetOpType_name = map[int32]string + var AlgebraicSetOpSpec_SetOpType_value = map[string]int32 + var BackfillerSpec_Type_name = map[int32]string + var BackfillerSpec_Type_value = map[string]int32 + var ErrIntOverflowApi = fmt.Errorf("proto: integer overflow") + var ErrIntOverflowData = fmt.Errorf("proto: integer overflow") + var ErrIntOverflowProcessors = fmt.Errorf("proto: integer overflow") + var ErrInvalidLengthApi = fmt.Errorf("proto: negative length found during unmarshaling") + var ErrInvalidLengthData = fmt.Errorf("proto: negative length found during unmarshaling") + var ErrInvalidLengthProcessors = fmt.Errorf("proto: negative length found during unmarshaling") + var InputSyncSpec_Type_name = map[int32]string + var InputSyncSpec_Type_value = map[string]int32 + var JoinType_name = map[int32]string + var JoinType_value = map[string]int32 + var NewReadCSVProcessor func(*FlowCtx, ReadCSVSpec, RowReceiver) (Processor, error) + var NewSSTWriterProcessor func(*FlowCtx, SSTWriterSpec, RowSource, RowReceiver) (Processor, error) + var Ordering_Column_Direction_name = map[int32]string + var Ordering_Column_Direction_value = map[string]int32 + var OutputRouterSpec_Type_name = map[int32]string + var OutputRouterSpec_Type_value = map[string]int32 + var StreamEndpointSpec_Type_name = map[int32]string + var StreamEndpointSpec_Type_value = map[string]int32 + func ColumnMutationFilter(m sqlbase.DescriptorMutation) bool + func CompareEncDatumRowForMerge(lhs, rhs sqlbase.EncDatumRow, ...) (int, error) + func ConvertBackfillError(ctx context.Context, tableDesc *sqlbase.TableDescriptor, b *client.Batch) error + func DrainAndClose(ctx context.Context, dst RowReceiver, cause error, srcs ...RowSource) + func DrainAndForwardMetadata(ctx context.Context, src RowSource, dst RowReceiver) + func FlowVerIsCompatible(flowVer, minAcceptedVersion, serverVersion DistSQLVersion) bool + func GeneratePlanDiagram(flows map[roachpb.NodeID]FlowSpec, w io.Writer) error + func GeneratePlanDiagramWithURL(flows map[roachpb.NodeID]FlowSpec) (string, url.URL, error) + func GetAggregateInfo(fn AggregatorSpec_Func, inputTypes ...sqlbase.ColumnType) (aggregateConstructor func(*parser.EvalContext) parser.AggregateFunc, ...) + func GetResumeSpanIndexofMutationID(tableDesc *sqlbase.TableDescriptor, mutationIdx int) int + func GetResumeSpansFromJob(ctx context.Context, jobsRegistry *jobs.Registry, txn *client.Txn, jobID int64, ...) ([]roachpb.Span, error) + func IndexMutationFilter(m sqlbase.DescriptorMutation) bool + func ProcessInboundStream(ctx context.Context, stream DistSQL_FlowStreamServer, ...) error + func RegisterDistSQLServer(s *grpc.Server, srv DistSQLServer) + func SetResumeSpansInJob(ctx context.Context, spans []roachpb.Span, jobsRegistry *jobs.Registry, ...) error + func WriteResumeSpan(ctx context.Context, db *client.DB, id sqlbase.ID, origSpan roachpb.Span, ...) error + type AggregatorSpec struct + Aggregations []AggregatorSpec_Aggregation + GroupCols []uint32 + func (*AggregatorSpec) Descriptor() ([]byte, []int) + func (*AggregatorSpec) ProtoMessage() + func (m *AggregatorSpec) Marshal() (dAtA []byte, err error) + func (m *AggregatorSpec) MarshalTo(dAtA []byte) (int, error) + func (m *AggregatorSpec) Reset() + func (m *AggregatorSpec) Size() (n int) + func (m *AggregatorSpec) String() string + func (m *AggregatorSpec) Unmarshal(dAtA []byte) error + type AggregatorSpec_Aggregation struct + ColIdx []uint32 + ColIdx_1_0 *uint32 + Distinct bool + FilterColIdx *uint32 + Func AggregatorSpec_Func + func (*AggregatorSpec_Aggregation) Descriptor() ([]byte, []int) + func (*AggregatorSpec_Aggregation) ProtoMessage() + func (a AggregatorSpec_Aggregation) Equals(b AggregatorSpec_Aggregation) bool + func (m *AggregatorSpec_Aggregation) Marshal() (dAtA []byte, err error) + func (m *AggregatorSpec_Aggregation) MarshalTo(dAtA []byte) (int, error) + func (m *AggregatorSpec_Aggregation) Reset() + func (m *AggregatorSpec_Aggregation) Size() (n int) + func (m *AggregatorSpec_Aggregation) String() string + func (m *AggregatorSpec_Aggregation) Unmarshal(dAtA []byte) error + type AggregatorSpec_Func int32 + const AggregatorSpec_AVG + const AggregatorSpec_BOOL_AND + const AggregatorSpec_BOOL_OR + const AggregatorSpec_CONCAT_AGG + const AggregatorSpec_COUNT + const AggregatorSpec_COUNT_ROWS + const AggregatorSpec_IDENT + const AggregatorSpec_MAX + const AggregatorSpec_MIN + const AggregatorSpec_STDDEV + const AggregatorSpec_SUM + const AggregatorSpec_SUM_INT + const AggregatorSpec_VARIANCE + const AggregatorSpec_XOR_AGG + func (AggregatorSpec_Func) EnumDescriptor() ([]byte, []int) + func (x *AggregatorSpec_Func) UnmarshalJSON(data []byte) error + func (x AggregatorSpec_Func) Enum() *AggregatorSpec_Func + func (x AggregatorSpec_Func) String() string + type AlgebraicSetOpSpec struct + OpType AlgebraicSetOpSpec_SetOpType + Ordering Ordering + func (*AlgebraicSetOpSpec) Descriptor() ([]byte, []int) + func (*AlgebraicSetOpSpec) ProtoMessage() + func (m *AlgebraicSetOpSpec) Marshal() (dAtA []byte, err error) + func (m *AlgebraicSetOpSpec) MarshalTo(dAtA []byte) (int, error) + func (m *AlgebraicSetOpSpec) Reset() + func (m *AlgebraicSetOpSpec) Size() (n int) + func (m *AlgebraicSetOpSpec) String() string + func (m *AlgebraicSetOpSpec) Unmarshal(dAtA []byte) error + type AlgebraicSetOpSpec_SetOpType int32 + const AlgebraicSetOpSpec_Except_all + func (AlgebraicSetOpSpec_SetOpType) EnumDescriptor() ([]byte, []int) + func (x *AlgebraicSetOpSpec_SetOpType) UnmarshalJSON(data []byte) error + func (x AlgebraicSetOpSpec_SetOpType) Enum() *AlgebraicSetOpSpec_SetOpType + func (x AlgebraicSetOpSpec_SetOpType) String() string + type BackfillerSpec struct + ChunkSize int64 + Duration time.Duration + OtherTables []cockroach_sql_sqlbase1.TableDescriptor + ReadAsOf cockroach_util_hlc.Timestamp + Spans []TableReaderSpan + Table cockroach_sql_sqlbase1.TableDescriptor + Type BackfillerSpec_Type + func (*BackfillerSpec) Descriptor() ([]byte, []int) + func (*BackfillerSpec) ProtoMessage() + func (m *BackfillerSpec) Marshal() (dAtA []byte, err error) + func (m *BackfillerSpec) MarshalTo(dAtA []byte) (int, error) + func (m *BackfillerSpec) Reset() + func (m *BackfillerSpec) Size() (n int) + func (m *BackfillerSpec) String() string + func (m *BackfillerSpec) Unmarshal(dAtA []byte) error + type BackfillerSpec_Type int32 + const BackfillerSpec_Column + const BackfillerSpec_Index + const BackfillerSpec_Invalid + func (BackfillerSpec_Type) EnumDescriptor() ([]byte, []int) + func (x *BackfillerSpec_Type) UnmarshalJSON(data []byte) error + func (x BackfillerSpec_Type) Enum() *BackfillerSpec_Type + func (x BackfillerSpec_Type) String() string + type BufferedRecord struct + Meta ProducerMetadata + Row sqlbase.EncDatumRow + type CancellableRowReceiver interface + SetCancelled func() + type ConsumerHandshake struct + ConsumerScheduleDeadline *time.Time + ConsumerScheduled bool + MinAcceptedVersion DistSQLVersion + Version DistSQLVersion + func (*ConsumerHandshake) Descriptor() ([]byte, []int) + func (*ConsumerHandshake) ProtoMessage() + func (m *ConsumerHandshake) Marshal() (dAtA []byte, err error) + func (m *ConsumerHandshake) MarshalTo(dAtA []byte) (int, error) + func (m *ConsumerHandshake) Reset() + func (m *ConsumerHandshake) Size() (n int) + func (m *ConsumerHandshake) String() string + func (m *ConsumerHandshake) Unmarshal(dAtA []byte) error + type ConsumerSignal struct + DrainRequest *DrainRequest + Handshake *ConsumerHandshake + SetupFlowRequest *SetupFlowRequest + func (*ConsumerSignal) Descriptor() ([]byte, []int) + func (*ConsumerSignal) ProtoMessage() + func (m *ConsumerSignal) Marshal() (dAtA []byte, err error) + func (m *ConsumerSignal) MarshalTo(dAtA []byte) (int, error) + func (m *ConsumerSignal) Reset() + func (m *ConsumerSignal) Size() (n int) + func (m *ConsumerSignal) String() string + func (m *ConsumerSignal) Unmarshal(dAtA []byte) error + func (this *ConsumerSignal) GetValue() interface{} + func (this *ConsumerSignal) SetValue(value interface{}) bool + type ConsumerStatus uint32 + const ConsumerClosed + const DrainRequested + const NeedMoreRows + type DatumInfo struct + Encoding cockroach_sql_sqlbase2.DatumEncoding + Type cockroach_sql_sqlbase1.ColumnType + func (*DatumInfo) Descriptor() ([]byte, []int) + func (*DatumInfo) ProtoMessage() + func (m *DatumInfo) Marshal() (dAtA []byte, err error) + func (m *DatumInfo) MarshalTo(dAtA []byte) (int, error) + func (m *DatumInfo) Reset() + func (m *DatumInfo) Size() (n int) + func (m *DatumInfo) String() string + func (m *DatumInfo) Unmarshal(dAtA []byte) error + type DistSQLClient interface + FlowStream func(ctx context.Context, opts ...grpc.CallOption) (DistSQL_FlowStreamClient, error) + RunSyncFlow func(ctx context.Context, opts ...grpc.CallOption) (DistSQL_RunSyncFlowClient, error) + SetupFlow func(ctx context.Context, in *SetupFlowRequest, opts ...grpc.CallOption) (*SimpleResponse, error) + func NewDistSQLClient(cc *grpc.ClientConn) DistSQLClient + type DistSQLMetrics struct + CurBytesCount *metric.Counter + FlowsActive *metric.Gauge + FlowsTotal *metric.Counter + MaxBytesHist *metric.Histogram + QueriesActive *metric.Gauge + QueriesTotal *metric.Counter + func MakeDistSQLMetrics(histogramWindow time.Duration) DistSQLMetrics + func (DistSQLMetrics) MetricStruct() + func (m *DistSQLMetrics) FlowStart() + func (m *DistSQLMetrics) FlowStop() + func (m *DistSQLMetrics) QueryStart() + func (m *DistSQLMetrics) QueryStop() + type DistSQLServer interface + FlowStream func(DistSQL_FlowStreamServer) error + RunSyncFlow func(DistSQL_RunSyncFlowServer) error + SetupFlow func(context.Context, *SetupFlowRequest) (*SimpleResponse, error) + type DistSQLVersion uint32 + const Version + var MinAcceptedVersion DistSQLVersion = 6 + type DistSQLVersionGossipInfo struct + MinAcceptedVersion DistSQLVersion + Version DistSQLVersion + func (*DistSQLVersionGossipInfo) Descriptor() ([]byte, []int) + func (*DistSQLVersionGossipInfo) ProtoMessage() + func (m *DistSQLVersionGossipInfo) Marshal() (dAtA []byte, err error) + func (m *DistSQLVersionGossipInfo) MarshalTo(dAtA []byte) (int, error) + func (m *DistSQLVersionGossipInfo) Reset() + func (m *DistSQLVersionGossipInfo) Size() (n int) + func (m *DistSQLVersionGossipInfo) String() string + func (m *DistSQLVersionGossipInfo) Unmarshal(dAtA []byte) error + type DistSQL_FlowStreamClient interface + Recv func() (*ConsumerSignal, error) + Send func(*ProducerMessage) error + type DistSQL_FlowStreamServer interface + Recv func() (*ProducerMessage, error) + Send func(*ConsumerSignal) error + type DistSQL_RunSyncFlowClient interface + Recv func() (*ProducerMessage, error) + Send func(*ConsumerSignal) error + type DistSQL_RunSyncFlowServer interface + Recv func() (*ConsumerSignal, error) + Send func(*ProducerMessage) error + type DistinctSpec struct + DistinctColumns []uint32 + OrderedColumns []uint32 + func (*DistinctSpec) Descriptor() ([]byte, []int) + func (*DistinctSpec) ProtoMessage() + func (m *DistinctSpec) Marshal() (dAtA []byte, err error) + func (m *DistinctSpec) MarshalTo(dAtA []byte) (int, error) + func (m *DistinctSpec) Reset() + func (m *DistinctSpec) Size() (n int) + func (m *DistinctSpec) String() string + func (m *DistinctSpec) Unmarshal(dAtA []byte) error + type DrainRequest struct + func (*DrainRequest) Descriptor() ([]byte, []int) + func (*DrainRequest) ProtoMessage() + func (m *DrainRequest) Marshal() (dAtA []byte, err error) + func (m *DrainRequest) MarshalTo(dAtA []byte) (int, error) + func (m *DrainRequest) Reset() + func (m *DrainRequest) Size() (n int) + func (m *DrainRequest) String() string + func (m *DrainRequest) Unmarshal(dAtA []byte) error + type Error struct + Detail isError_Detail + func NewError(err error) *Error + func (*Error) Descriptor() ([]byte, []int) + func (*Error) ProtoMessage() + func (*Error) XXX_OneofFuncs() (func(msg proto.Message, b *proto.Buffer) error, ...) + func (e *Error) ErrorDetail() error + func (e *Error) String() string + func (m *Error) GetDetail() isError_Detail + func (m *Error) GetPGError() *cockroach_pgerror.Error + func (m *Error) GetRetryableTxnError() *cockroach_roachpb2.UnhandledRetryableError + func (m *Error) Marshal() (dAtA []byte, err error) + func (m *Error) MarshalTo(dAtA []byte) (int, error) + func (m *Error) Reset() + func (m *Error) Size() (n int) + func (m *Error) Unmarshal(dAtA []byte) error + type Error_PGError struct + PGError *cockroach_pgerror.Error + func (m *Error_PGError) MarshalTo(dAtA []byte) (int, error) + func (m *Error_PGError) Size() (n int) + type Error_RetryableTxnError struct + RetryableTxnError *cockroach_roachpb2.UnhandledRetryableError + func (m *Error_RetryableTxnError) MarshalTo(dAtA []byte) (int, error) + func (m *Error_RetryableTxnError) Size() (n int) + type EvalContext struct + ClusterTimestamp cockroach_util_hlc.Timestamp + Database string + Location string + SearchPath []string + StmtTimestampNanos int64 + TxnTimestampNanos int64 + User string + func MakeEvalContext(evalCtx parser.EvalContext) EvalContext + func (*EvalContext) Descriptor() ([]byte, []int) + func (*EvalContext) ProtoMessage() + func (m *EvalContext) Marshal() (dAtA []byte, err error) + func (m *EvalContext) MarshalTo(dAtA []byte) (int, error) + func (m *EvalContext) Reset() + func (m *EvalContext) Size() (n int) + func (m *EvalContext) String() string + func (m *EvalContext) Unmarshal(dAtA []byte) error + type Expression struct + Expr string + Version string + func (*Expression) Descriptor() ([]byte, []int) + func (*Expression) ProtoMessage() + func (m *Expression) Marshal() (dAtA []byte, err error) + func (m *Expression) MarshalTo(dAtA []byte) (int, error) + func (m *Expression) Reset() + func (m *Expression) Size() (n int) + func (m *Expression) String() string + func (m *Expression) Unmarshal(dAtA []byte) error + type Flow struct + func (f *Flow) Cleanup(ctx context.Context) + func (f *Flow) RunSync(ctx context.Context) + func (f *Flow) Start(ctx context.Context, doneFn func()) error + func (f *Flow) Wait() + type FlowCtx struct + EvalCtx parser.EvalContext + JobRegistry *jobs.Registry + Settings *cluster.Settings + TempStorage engine.Engine + type FlowID struct + type FlowSpec struct + FlowID FlowID + Gateway github_com_cockroachdb_cockroach_pkg_roachpb.NodeID + Processors []ProcessorSpec + func (*FlowSpec) Descriptor() ([]byte, []int) + func (*FlowSpec) ProtoMessage() + func (m *FlowSpec) Marshal() (dAtA []byte, err error) + func (m *FlowSpec) MarshalTo(dAtA []byte) (int, error) + func (m *FlowSpec) Reset() + func (m *FlowSpec) Size() (n int) + func (m *FlowSpec) String() string + func (m *FlowSpec) Unmarshal(dAtA []byte) error + type HashJoinerSpec struct + LeftEqColumns []uint32 + MergedColumns bool + OnExpr Expression + RightEqColumns []uint32 + Type JoinType + func (*HashJoinerSpec) Descriptor() ([]byte, []int) + func (*HashJoinerSpec) ProtoMessage() + func (m *HashJoinerSpec) Marshal() (dAtA []byte, err error) + func (m *HashJoinerSpec) MarshalTo(dAtA []byte) (int, error) + func (m *HashJoinerSpec) Reset() + func (m *HashJoinerSpec) Size() (n int) + func (m *HashJoinerSpec) String() string + func (m *HashJoinerSpec) Unmarshal(dAtA []byte) error + type InputSyncSpec struct + ColumnTypes []cockroach_sql_sqlbase1.ColumnType + Ordering Ordering + Streams []StreamEndpointSpec + Type InputSyncSpec_Type + func (*InputSyncSpec) Descriptor() ([]byte, []int) + func (*InputSyncSpec) ProtoMessage() + func (m *InputSyncSpec) Marshal() (dAtA []byte, err error) + func (m *InputSyncSpec) MarshalTo(dAtA []byte) (int, error) + func (m *InputSyncSpec) Reset() + func (m *InputSyncSpec) Size() (n int) + func (m *InputSyncSpec) String() string + func (m *InputSyncSpec) Unmarshal(dAtA []byte) error + type InputSyncSpec_Type int32 + const InputSyncSpec_ORDERED + const InputSyncSpec_UNORDERED + func (InputSyncSpec_Type) EnumDescriptor() ([]byte, []int) + func (x *InputSyncSpec_Type) UnmarshalJSON(data []byte) error + func (x InputSyncSpec_Type) Enum() *InputSyncSpec_Type + func (x InputSyncSpec_Type) String() string + type JoinReaderSpec struct + IndexIdx uint32 + Table cockroach_sql_sqlbase1.TableDescriptor + func (*JoinReaderSpec) Descriptor() ([]byte, []int) + func (*JoinReaderSpec) ProtoMessage() + func (m *JoinReaderSpec) Marshal() (dAtA []byte, err error) + func (m *JoinReaderSpec) MarshalTo(dAtA []byte) (int, error) + func (m *JoinReaderSpec) Reset() + func (m *JoinReaderSpec) Size() (n int) + func (m *JoinReaderSpec) String() string + func (m *JoinReaderSpec) Unmarshal(dAtA []byte) error + type JoinType int32 + const JoinType_FULL_OUTER + const JoinType_INNER + const JoinType_LEFT_OUTER + const JoinType_RIGHT_OUTER + func (JoinType) EnumDescriptor() ([]byte, []int) + func (x *JoinType) UnmarshalJSON(data []byte) error + func (x JoinType) Enum() *JoinType + func (x JoinType) String() string + type MergeJoinerSpec struct + LeftOrdering Ordering + OnExpr Expression + RightOrdering Ordering + Type JoinType + func (*MergeJoinerSpec) Descriptor() ([]byte, []int) + func (*MergeJoinerSpec) ProtoMessage() + func (m *MergeJoinerSpec) Marshal() (dAtA []byte, err error) + func (m *MergeJoinerSpec) MarshalTo(dAtA []byte) (int, error) + func (m *MergeJoinerSpec) Reset() + func (m *MergeJoinerSpec) Size() (n int) + func (m *MergeJoinerSpec) String() string + func (m *MergeJoinerSpec) Unmarshal(dAtA []byte) error + type MultiplexedRowChannel struct + func (mrc *MultiplexedRowChannel) ConsumerClosed() + func (mrc *MultiplexedRowChannel) ConsumerDone() + func (mrc *MultiplexedRowChannel) Init(numSenders int, types []sqlbase.ColumnType) + func (mrc *MultiplexedRowChannel) Next() (row sqlbase.EncDatumRow, meta ProducerMetadata) + func (mrc *MultiplexedRowChannel) ProducerDone() + func (mrc *MultiplexedRowChannel) Push(row sqlbase.EncDatumRow, meta ProducerMetadata) ConsumerStatus + func (mrc *MultiplexedRowChannel) Types() []sqlbase.ColumnType + type MutationFilter func(sqlbase.DescriptorMutation) bool + type NoMetadataRowSource struct + func MakeNoMetadataRowSource(src RowSource, sink RowReceiver) NoMetadataRowSource + func (rs *NoMetadataRowSource) NextRow() (sqlbase.EncDatumRow, error) + type NoopCoreSpec struct + func (*NoopCoreSpec) Descriptor() ([]byte, []int) + func (*NoopCoreSpec) ProtoMessage() + func (m *NoopCoreSpec) Marshal() (dAtA []byte, err error) + func (m *NoopCoreSpec) MarshalTo(dAtA []byte) (int, error) + func (m *NoopCoreSpec) Reset() + func (m *NoopCoreSpec) Size() (n int) + func (m *NoopCoreSpec) String() string + func (m *NoopCoreSpec) Unmarshal(dAtA []byte) error + type Ordering struct + Columns []Ordering_Column + func (*Ordering) Descriptor() ([]byte, []int) + func (*Ordering) ProtoMessage() + func (m *Ordering) Marshal() (dAtA []byte, err error) + func (m *Ordering) MarshalTo(dAtA []byte) (int, error) + func (m *Ordering) Reset() + func (m *Ordering) Size() (n int) + func (m *Ordering) String() string + func (m *Ordering) Unmarshal(dAtA []byte) error + type Ordering_Column struct + ColIdx uint32 + Direction Ordering_Column_Direction + func (*Ordering_Column) Descriptor() ([]byte, []int) + func (*Ordering_Column) ProtoMessage() + func (m *Ordering_Column) Marshal() (dAtA []byte, err error) + func (m *Ordering_Column) MarshalTo(dAtA []byte) (int, error) + func (m *Ordering_Column) Reset() + func (m *Ordering_Column) Size() (n int) + func (m *Ordering_Column) String() string + func (m *Ordering_Column) Unmarshal(dAtA []byte) error + type Ordering_Column_Direction int32 + const Ordering_Column_ASC + const Ordering_Column_DESC + func (Ordering_Column_Direction) EnumDescriptor() ([]byte, []int) + func (x *Ordering_Column_Direction) UnmarshalJSON(data []byte) error + func (x Ordering_Column_Direction) Enum() *Ordering_Column_Direction + func (x Ordering_Column_Direction) String() string + type OutputRouterSpec struct + HashColumns []uint32 + RangeRouterSpec OutputRouterSpec_RangeRouterSpec + Streams []StreamEndpointSpec + Type OutputRouterSpec_Type + func (*OutputRouterSpec) Descriptor() ([]byte, []int) + func (*OutputRouterSpec) ProtoMessage() + func (m *OutputRouterSpec) Marshal() (dAtA []byte, err error) + func (m *OutputRouterSpec) MarshalTo(dAtA []byte) (int, error) + func (m *OutputRouterSpec) Reset() + func (m *OutputRouterSpec) Size() (n int) + func (m *OutputRouterSpec) String() string + func (m *OutputRouterSpec) Unmarshal(dAtA []byte) error + type OutputRouterSpec_RangeRouterSpec struct + DefaultDest *int32 + Encodings []OutputRouterSpec_RangeRouterSpec_ColumnEncoding + Spans []OutputRouterSpec_RangeRouterSpec_Span + func (*OutputRouterSpec_RangeRouterSpec) Descriptor() ([]byte, []int) + func (*OutputRouterSpec_RangeRouterSpec) ProtoMessage() + func (m *OutputRouterSpec_RangeRouterSpec) Marshal() (dAtA []byte, err error) + func (m *OutputRouterSpec_RangeRouterSpec) MarshalTo(dAtA []byte) (int, error) + func (m *OutputRouterSpec_RangeRouterSpec) Reset() + func (m *OutputRouterSpec_RangeRouterSpec) Size() (n int) + func (m *OutputRouterSpec_RangeRouterSpec) String() string + func (m *OutputRouterSpec_RangeRouterSpec) Unmarshal(dAtA []byte) error + type OutputRouterSpec_RangeRouterSpec_ColumnEncoding struct + Column uint32 + Encoding cockroach_sql_sqlbase2.DatumEncoding + func (*OutputRouterSpec_RangeRouterSpec_ColumnEncoding) Descriptor() ([]byte, []int) + func (*OutputRouterSpec_RangeRouterSpec_ColumnEncoding) ProtoMessage() + func (m *OutputRouterSpec_RangeRouterSpec_ColumnEncoding) Marshal() (dAtA []byte, err error) + func (m *OutputRouterSpec_RangeRouterSpec_ColumnEncoding) MarshalTo(dAtA []byte) (int, error) + func (m *OutputRouterSpec_RangeRouterSpec_ColumnEncoding) Reset() + func (m *OutputRouterSpec_RangeRouterSpec_ColumnEncoding) Size() (n int) + func (m *OutputRouterSpec_RangeRouterSpec_ColumnEncoding) String() string + func (m *OutputRouterSpec_RangeRouterSpec_ColumnEncoding) Unmarshal(dAtA []byte) error + type OutputRouterSpec_RangeRouterSpec_Span struct + End []byte + Start []byte + func (*OutputRouterSpec_RangeRouterSpec_Span) Descriptor() ([]byte, []int) + func (*OutputRouterSpec_RangeRouterSpec_Span) ProtoMessage() + func (m *OutputRouterSpec_RangeRouterSpec_Span) Marshal() (dAtA []byte, err error) + func (m *OutputRouterSpec_RangeRouterSpec_Span) MarshalTo(dAtA []byte) (int, error) + func (m *OutputRouterSpec_RangeRouterSpec_Span) Reset() + func (m *OutputRouterSpec_RangeRouterSpec_Span) Size() (n int) + func (m *OutputRouterSpec_RangeRouterSpec_Span) String() string + func (m *OutputRouterSpec_RangeRouterSpec_Span) Unmarshal(dAtA []byte) error + type OutputRouterSpec_Type int32 + const OutputRouterSpec_BY_HASH + const OutputRouterSpec_BY_RANGE + const OutputRouterSpec_MIRROR + const OutputRouterSpec_PASS_THROUGH + func (OutputRouterSpec_Type) EnumDescriptor() ([]byte, []int) + func (x *OutputRouterSpec_Type) UnmarshalJSON(data []byte) error + func (x OutputRouterSpec_Type) Enum() *OutputRouterSpec_Type + func (x OutputRouterSpec_Type) String() string + type PostProcessSpec struct + Filter Expression + Limit uint64 + Offset uint64 + OutputColumns []uint32 + Projection bool + RenderExprs []Expression + func (*PostProcessSpec) Descriptor() ([]byte, []int) + func (*PostProcessSpec) ProtoMessage() + func (m *PostProcessSpec) Marshal() (dAtA []byte, err error) + func (m *PostProcessSpec) MarshalTo(dAtA []byte) (int, error) + func (m *PostProcessSpec) Reset() + func (m *PostProcessSpec) Size() (n int) + func (m *PostProcessSpec) String() string + func (m *PostProcessSpec) Unmarshal(dAtA []byte) error + type ProcOutputHelper struct + func (h *ProcOutputHelper) Close() + func (h *ProcOutputHelper) EmitRow(ctx context.Context, row sqlbase.EncDatumRow) (ConsumerStatus, error) + func (h *ProcOutputHelper) Init(post *PostProcessSpec, types []sqlbase.ColumnType, evalCtx *parser.EvalContext, ...) error + type Processor interface + OutputTypes func() []sqlbase.ColumnType + Run func(ctx context.Context, wg *sync.WaitGroup) + type ProcessorCoreUnion struct + Aggregator *AggregatorSpec + Backfiller *BackfillerSpec + Distinct *DistinctSpec + HashJoiner *HashJoinerSpec + JoinReader *JoinReaderSpec + MergeJoiner *MergeJoinerSpec + Noop *NoopCoreSpec + ReadCSV *ReadCSVSpec + SSTWriter *SSTWriterSpec + SetOp *AlgebraicSetOpSpec + Sorter *SorterSpec + TableReader *TableReaderSpec + Values *ValuesCoreSpec + func (*ProcessorCoreUnion) Descriptor() ([]byte, []int) + func (*ProcessorCoreUnion) ProtoMessage() + func (m *ProcessorCoreUnion) Marshal() (dAtA []byte, err error) + func (m *ProcessorCoreUnion) MarshalTo(dAtA []byte) (int, error) + func (m *ProcessorCoreUnion) Reset() + func (m *ProcessorCoreUnion) Size() (n int) + func (m *ProcessorCoreUnion) String() string + func (m *ProcessorCoreUnion) Unmarshal(dAtA []byte) error + func (this *ProcessorCoreUnion) GetValue() interface{} + func (this *ProcessorCoreUnion) SetValue(value interface{}) bool + type ProcessorSpec struct + Core ProcessorCoreUnion + Input []InputSyncSpec + Output []OutputRouterSpec + Post PostProcessSpec + StageID int32 + func (*ProcessorSpec) Descriptor() ([]byte, []int) + func (*ProcessorSpec) ProtoMessage() + func (m *ProcessorSpec) Marshal() (dAtA []byte, err error) + func (m *ProcessorSpec) MarshalTo(dAtA []byte) (int, error) + func (m *ProcessorSpec) Reset() + func (m *ProcessorSpec) Size() (n int) + func (m *ProcessorSpec) String() string + func (m *ProcessorSpec) Unmarshal(dAtA []byte) error + type ProducerData struct + Metadata []RemoteProducerMetadata + NumEmptyRows int32 + RawBytes []byte + func (*ProducerData) Descriptor() ([]byte, []int) + func (*ProducerData) ProtoMessage() + func (m *ProducerData) Marshal() (dAtA []byte, err error) + func (m *ProducerData) MarshalTo(dAtA []byte) (int, error) + func (m *ProducerData) Reset() + func (m *ProducerData) Size() (n int) + func (m *ProducerData) String() string + func (m *ProducerData) Unmarshal(dAtA []byte) error + type ProducerHeader struct + FlowID FlowID + StreamID StreamID + func (*ProducerHeader) Descriptor() ([]byte, []int) + func (*ProducerHeader) ProtoMessage() + func (m *ProducerHeader) Marshal() (dAtA []byte, err error) + func (m *ProducerHeader) MarshalTo(dAtA []byte) (int, error) + func (m *ProducerHeader) Reset() + func (m *ProducerHeader) Size() (n int) + func (m *ProducerHeader) String() string + func (m *ProducerHeader) Unmarshal(dAtA []byte) error + type ProducerMessage struct + Data ProducerData + Header *ProducerHeader + Typing []DatumInfo + func (*ProducerMessage) Descriptor() ([]byte, []int) + func (*ProducerMessage) ProtoMessage() + func (m *ProducerMessage) Marshal() (dAtA []byte, err error) + func (m *ProducerMessage) MarshalTo(dAtA []byte) (int, error) + func (m *ProducerMessage) Reset() + func (m *ProducerMessage) Size() (n int) + func (m *ProducerMessage) String() string + func (m *ProducerMessage) Unmarshal(dAtA []byte) error + type ProducerMetadata struct + Err error + Ranges []roachpb.RangeInfo + TraceData []tracing.RecordedSpan + func (meta ProducerMetadata) Empty() bool + type ReadCSVSpec struct + Options cockroach_roachpb1.CSVOptions + SampleSize int32 + TableDesc cockroach_sql_sqlbase1.TableDescriptor + Uri string + func (*ReadCSVSpec) Descriptor() ([]byte, []int) + func (*ReadCSVSpec) ProtoMessage() + func (m *ReadCSVSpec) Marshal() (dAtA []byte, err error) + func (m *ReadCSVSpec) MarshalTo(dAtA []byte) (int, error) + func (m *ReadCSVSpec) Reset() + func (m *ReadCSVSpec) Size() (n int) + func (m *ReadCSVSpec) String() string + func (m *ReadCSVSpec) Unmarshal(dAtA []byte) error + type RemoteProducerMetadata struct + Value isRemoteProducerMetadata_Value + func (*RemoteProducerMetadata) Descriptor() ([]byte, []int) + func (*RemoteProducerMetadata) ProtoMessage() + func (*RemoteProducerMetadata) XXX_OneofFuncs() (func(msg proto.Message, b *proto.Buffer) error, ...) + func (m *RemoteProducerMetadata) GetError() *Error + func (m *RemoteProducerMetadata) GetRangeInfo() *RemoteProducerMetadata_RangeInfos + func (m *RemoteProducerMetadata) GetTraceData() *RemoteProducerMetadata_TraceData + func (m *RemoteProducerMetadata) GetValue() isRemoteProducerMetadata_Value + func (m *RemoteProducerMetadata) Marshal() (dAtA []byte, err error) + func (m *RemoteProducerMetadata) MarshalTo(dAtA []byte) (int, error) + func (m *RemoteProducerMetadata) Reset() + func (m *RemoteProducerMetadata) Size() (n int) + func (m *RemoteProducerMetadata) String() string + func (m *RemoteProducerMetadata) Unmarshal(dAtA []byte) error + type RemoteProducerMetadata_Error struct + Error *Error + func (m *RemoteProducerMetadata_Error) MarshalTo(dAtA []byte) (int, error) + func (m *RemoteProducerMetadata_Error) Size() (n int) + type RemoteProducerMetadata_RangeInfo struct + RangeInfo *RemoteProducerMetadata_RangeInfos + func (m *RemoteProducerMetadata_RangeInfo) MarshalTo(dAtA []byte) (int, error) + func (m *RemoteProducerMetadata_RangeInfo) Size() (n int) + type RemoteProducerMetadata_RangeInfos struct + RangeInfo []cockroach_roachpb3.RangeInfo + func (*RemoteProducerMetadata_RangeInfos) Descriptor() ([]byte, []int) + func (*RemoteProducerMetadata_RangeInfos) ProtoMessage() + func (m *RemoteProducerMetadata_RangeInfos) Marshal() (dAtA []byte, err error) + func (m *RemoteProducerMetadata_RangeInfos) MarshalTo(dAtA []byte) (int, error) + func (m *RemoteProducerMetadata_RangeInfos) Reset() + func (m *RemoteProducerMetadata_RangeInfos) Size() (n int) + func (m *RemoteProducerMetadata_RangeInfos) String() string + func (m *RemoteProducerMetadata_RangeInfos) Unmarshal(dAtA []byte) error + type RemoteProducerMetadata_TraceData struct + CollectedSpans []cockroach_util_tracing.RecordedSpan + func (*RemoteProducerMetadata_TraceData) Descriptor() ([]byte, []int) + func (*RemoteProducerMetadata_TraceData) ProtoMessage() + func (m *RemoteProducerMetadata_TraceData) Marshal() (dAtA []byte, err error) + func (m *RemoteProducerMetadata_TraceData) MarshalTo(dAtA []byte) (int, error) + func (m *RemoteProducerMetadata_TraceData) Reset() + func (m *RemoteProducerMetadata_TraceData) Size() (n int) + func (m *RemoteProducerMetadata_TraceData) String() string + func (m *RemoteProducerMetadata_TraceData) Unmarshal(dAtA []byte) error + type RemoteProducerMetadata_TraceData_ struct + TraceData *RemoteProducerMetadata_TraceData + func (m *RemoteProducerMetadata_TraceData_) MarshalTo(dAtA []byte) (int, error) + func (m *RemoteProducerMetadata_TraceData_) Size() (n int) + type RepeatableRowSource struct + func NewRepeatableRowSource(types []sqlbase.ColumnType, rows sqlbase.EncDatumRows) *RepeatableRowSource + func (r *RepeatableRowSource) ConsumerClosed() + func (r *RepeatableRowSource) ConsumerDone() + func (r *RepeatableRowSource) Next() (sqlbase.EncDatumRow, ProducerMetadata) + func (r *RepeatableRowSource) Reset() + func (r *RepeatableRowSource) Types() []sqlbase.ColumnType + type RowBuffer struct + ConsumerStatus ConsumerStatus + Done bool + ProducerClosed bool + func NewRowBuffer(types []sqlbase.ColumnType, rows sqlbase.EncDatumRows, hooks RowBufferArgs) *RowBuffer + func (rb *RowBuffer) ConsumerClosed() + func (rb *RowBuffer) ConsumerDone() + func (rb *RowBuffer) Next() (sqlbase.EncDatumRow, ProducerMetadata) + func (rb *RowBuffer) ProducerDone() + func (rb *RowBuffer) Push(row sqlbase.EncDatumRow, meta ProducerMetadata) ConsumerStatus + func (rb *RowBuffer) Types() []sqlbase.ColumnType + type RowBufferArgs struct + AccumulateRowsWhileDraining bool + OnConsumerClosed func(*RowBuffer) + OnConsumerDone func(*RowBuffer) + OnNext func(*RowBuffer) (sqlbase.EncDatumRow, ProducerMetadata) + type RowChannel struct + C <-chan RowChannelMsg + func (rc *RowChannel) ConsumerClosed() + func (rc *RowChannel) ConsumerDone() + func (rc *RowChannel) Init(types []sqlbase.ColumnType) + func (rc *RowChannel) InitWithBufSize(types []sqlbase.ColumnType, chanBufSize int) + func (rc *RowChannel) Next() (sqlbase.EncDatumRow, ProducerMetadata) + func (rc *RowChannel) ProducerDone() + func (rc *RowChannel) Push(row sqlbase.EncDatumRow, meta ProducerMetadata) ConsumerStatus + func (rc *RowChannel) Types() []sqlbase.ColumnType + type RowChannelMsg struct + Meta ProducerMetadata + Row sqlbase.EncDatumRow + type RowDisposer struct + func (r *RowDisposer) ProducerDone() + func (r *RowDisposer) Push(row sqlbase.EncDatumRow, meta ProducerMetadata) ConsumerStatus + type RowReceiver interface + ProducerDone func() + Push func(row sqlbase.EncDatumRow, meta ProducerMetadata) ConsumerStatus + type RowSource interface + ConsumerClosed func() + ConsumerDone func() + Next func() (sqlbase.EncDatumRow, ProducerMetadata) + Types func() []sqlbase.ColumnType + type SSTWriterSpec struct + Destination string + Name string + WalltimeNanos int64 + func (*SSTWriterSpec) Descriptor() ([]byte, []int) + func (*SSTWriterSpec) ProtoMessage() + func (m *SSTWriterSpec) Marshal() (dAtA []byte, err error) + func (m *SSTWriterSpec) MarshalTo(dAtA []byte) (int, error) + func (m *SSTWriterSpec) Reset() + func (m *SSTWriterSpec) Size() (n int) + func (m *SSTWriterSpec) String() string + func (m *SSTWriterSpec) Unmarshal(dAtA []byte) error + type ServerConfig struct + ClusterID uuid.UUID + DB *client.DB + Extra1_0Compatibility bool + FlowDB *client.DB + Gossip *gossip.Gossip + JobRegistry *jobs.Registry + Metrics *DistSQLMetrics + NodeID *base.NodeIDContainer + ParentMemoryMonitor *mon.BytesMonitor + RPCContext *rpc.Context + Settings *cluster.Settings + Stopper *stop.Stopper + TempStorage engine.Engine + TempStorageMaxSizeBytes int64 + TestingKnobs TestingKnobs + type ServerImpl struct + func NewServer(ctx context.Context, cfg ServerConfig) *ServerImpl + func (ds *ServerImpl) FlowStream(stream DistSQL_FlowStreamServer) error + func (ds *ServerImpl) RunSyncFlow(stream DistSQL_RunSyncFlowServer) error + func (ds *ServerImpl) SetupFlow(ctx context.Context, req *SetupFlowRequest) (*SimpleResponse, error) + func (ds *ServerImpl) SetupSyncFlow(ctx context.Context, req *SetupFlowRequest, output RowReceiver) (context.Context, *Flow, error) + func (ds *ServerImpl) Start() + type SetupFlowRequest struct + EvalContext EvalContext + Flow FlowSpec + Txn cockroach_roachpb1.Transaction + Version DistSQLVersion + func (*SetupFlowRequest) Descriptor() ([]byte, []int) + func (*SetupFlowRequest) ProtoMessage() + func (m *SetupFlowRequest) Marshal() (dAtA []byte, err error) + func (m *SetupFlowRequest) MarshalTo(dAtA []byte) (int, error) + func (m *SetupFlowRequest) Reset() + func (m *SetupFlowRequest) Size() (n int) + func (m *SetupFlowRequest) String() string + func (m *SetupFlowRequest) Unmarshal(dAtA []byte) error + type SimpleResponse struct + Error *Error + func (*SimpleResponse) Descriptor() ([]byte, []int) + func (*SimpleResponse) ProtoMessage() + func (m *SimpleResponse) Marshal() (dAtA []byte, err error) + func (m *SimpleResponse) MarshalTo(dAtA []byte) (int, error) + func (m *SimpleResponse) Reset() + func (m *SimpleResponse) Size() (n int) + func (m *SimpleResponse) String() string + func (m *SimpleResponse) Unmarshal(dAtA []byte) error + type SorterSpec struct + OrderingMatchLen uint32 + OutputOrdering Ordering + func (*SorterSpec) Descriptor() ([]byte, []int) + func (*SorterSpec) ProtoMessage() + func (m *SorterSpec) Marshal() (dAtA []byte, err error) + func (m *SorterSpec) MarshalTo(dAtA []byte) (int, error) + func (m *SorterSpec) Reset() + func (m *SorterSpec) Size() (n int) + func (m *SorterSpec) String() string + func (m *SorterSpec) Unmarshal(dAtA []byte) error + type StreamDecoder struct + func (sd *StreamDecoder) AddMessage(msg *ProducerMessage) error + func (sd *StreamDecoder) GetRow(rowBuf sqlbase.EncDatumRow) (sqlbase.EncDatumRow, ProducerMetadata, error) + type StreamEncoder struct + func (se *StreamEncoder) AddMetadata(meta ProducerMetadata) + func (se *StreamEncoder) AddRow(row sqlbase.EncDatumRow) error + func (se *StreamEncoder) FormMessage(ctx context.Context) *ProducerMessage + type StreamEndpointSpec struct + StreamID StreamID + TargetAddr string + Type StreamEndpointSpec_Type + func (*StreamEndpointSpec) Descriptor() ([]byte, []int) + func (*StreamEndpointSpec) ProtoMessage() + func (m *StreamEndpointSpec) Marshal() (dAtA []byte, err error) + func (m *StreamEndpointSpec) MarshalTo(dAtA []byte) (int, error) + func (m *StreamEndpointSpec) Reset() + func (m *StreamEndpointSpec) Size() (n int) + func (m *StreamEndpointSpec) String() string + func (m *StreamEndpointSpec) Unmarshal(dAtA []byte) error + type StreamEndpointSpec_Type int32 + const StreamEndpointSpec_LOCAL + const StreamEndpointSpec_REMOTE + const StreamEndpointSpec_SYNC_RESPONSE + func (StreamEndpointSpec_Type) EnumDescriptor() ([]byte, []int) + func (x *StreamEndpointSpec_Type) UnmarshalJSON(data []byte) error + func (x StreamEndpointSpec_Type) Enum() *StreamEndpointSpec_Type + func (x StreamEndpointSpec_Type) String() string + type StreamID int + type TableReaderSpan struct + Span cockroach_roachpb1.Span + func (*TableReaderSpan) Descriptor() ([]byte, []int) + func (*TableReaderSpan) ProtoMessage() + func (m *TableReaderSpan) Marshal() (dAtA []byte, err error) + func (m *TableReaderSpan) MarshalTo(dAtA []byte) (int, error) + func (m *TableReaderSpan) Reset() + func (m *TableReaderSpan) Size() (n int) + func (m *TableReaderSpan) String() string + func (m *TableReaderSpan) Unmarshal(dAtA []byte) error + type TableReaderSpec struct + IndexIdx uint32 + LimitHint int64 + Reverse bool + Spans []TableReaderSpan + Table cockroach_sql_sqlbase1.TableDescriptor + func (*TableReaderSpec) Descriptor() ([]byte, []int) + func (*TableReaderSpec) ProtoMessage() + func (m *TableReaderSpec) Marshal() (dAtA []byte, err error) + func (m *TableReaderSpec) MarshalTo(dAtA []byte) (int, error) + func (m *TableReaderSpec) Reset() + func (m *TableReaderSpec) Size() (n int) + func (m *TableReaderSpec) String() string + func (m *TableReaderSpec) Unmarshal(dAtA []byte) error + type TestingKnobs struct + MemoryLimitBytes int64 + RunAfterBackfillChunk func() + RunBeforeBackfillChunk func(sp roachpb.Span) error + func (*TestingKnobs) ModuleTestingKnobs() + type ValuesCoreSpec struct + Columns []DatumInfo + RawBytes [][]byte + func (*ValuesCoreSpec) Descriptor() ([]byte, []int) + func (*ValuesCoreSpec) ProtoMessage() + func (m *ValuesCoreSpec) Marshal() (dAtA []byte, err error) + func (m *ValuesCoreSpec) MarshalTo(dAtA []byte) (int, error) + func (m *ValuesCoreSpec) Reset() + func (m *ValuesCoreSpec) Size() (n int) + func (m *ValuesCoreSpec) String() string + func (m *ValuesCoreSpec) Unmarshal(dAtA []byte) error