Versions in this module Expand all Collapse all v1 v1.0.3 Jul 6, 2017 v1.0.2 Jun 7, 2017 v1.0.1 May 18, 2017 Changes in this version + const CheckFKs + const CodeRangeUnavailable + const DescriptorTableSchema + const EventLogTableSchema + const FamilyHeuristicTargetBytes + const JobsTableSchema + const LeaseTableSchema + const NamespaceTableSchema + const PrimaryKeyIndexName + const RangeEventTableSchema + const RowUpdaterDefault + const RowUpdaterOnlyColumns + const SettingsTableSchema + const SizeOfDatum + const SizeOfDatums + const SkipFKs + const UITableSchema + const UsersTableSchema + const ZonesTableSchema + var ColumnType_Kind_name = map[int32]string + var ColumnType_Kind_value = map[string]int32 + var ConstraintValidity_name = map[int32]string + var ConstraintValidity_value = map[string]int32 + var DatumEncoding_name = map[int32]string + var DatumEncoding_value = map[string]int32 + var DefaultSearchPath = parser.SearchPath + var DescriptorMutation_Direction_name = map[int32]string + var DescriptorMutation_Direction_value = map[string]int32 + var DescriptorMutation_State_name = map[int32]string + var DescriptorMutation_State_value = map[string]int32 + var DescriptorTable = TableDescriptor + var ErrDescriptorNotFound = errors.New("descriptor not found") + var ErrIntOverflowPrivilege = fmt.Errorf("proto: integer overflow") + var ErrIntOverflowStructured = fmt.Errorf("proto: integer overflow") + var ErrInvalidLengthPrivilege = fmt.Errorf("proto: negative length found during unmarshaling") + var ErrInvalidLengthStructured = fmt.Errorf("proto: negative length found during unmarshaling") + var ErrMissingColumns = errors.New("table must contain at least 1 column") + var ErrMissingPrimaryKey = errors.New("table must contain a primary key") + var EventLogTable = TableDescriptor + var IndexDescriptor_Direction_name = map[int32]string + var IndexDescriptor_Direction_value = map[string]int32 + var JobsTable = TableDescriptor + var LeaseTable = TableDescriptor + var NamespaceTable = TableDescriptor + var RangeEventTable = TableDescriptor + var SettingsTable = TableDescriptor + var SystemAllowedPrivileges = map[ID]privilege.Lists + var SystemDB = DatabaseDescriptor + var TableDescriptor_State_name = map[int32]string + var TableDescriptor_State_value = map[string]int32 + var UITable = TableDescriptor + var UsersTable = TableDescriptor + var ZonesTable = TableDescriptor + func CheckColumnType(col ColumnDescriptor, typ parser.Type, pmap *parser.PlaceholderInfo) error + func CheckValueWidth(col ColumnDescriptor, val parser.Datum) error + func ColIDtoRowIndexFromCols(cols []ColumnDescriptor) map[ColumnID]int + func ColumnsSelectors(cols []ColumnDescriptor) parser.SelectExprs + func CompareDatums(ordering ColumnOrdering, evalCtx *parser.EvalContext, lhs, rhs parser.Datums) int + func ConvertBatchError(tableDesc *TableDescriptor, b *client.Batch) error + func DecodeIndexKey(a *DatumAlloc, desc *TableDescriptor, indexID IndexID, vals []EncDatum, ...) ([]byte, bool, error) + func DecodeKeyVals(a *DatumAlloc, vals []EncDatum, directions []encoding.Direction, key []byte) ([]byte, error) + func DecodeTableIDIndexID(key []byte) ([]byte, ID, IndexID, error) + func DecodeTableKey(a *DatumAlloc, valType parser.Type, key []byte, dir encoding.Direction) (parser.Datum, []byte, error) + func DecodeTableValue(a *DatumAlloc, valType parser.Type, b []byte) (parser.Datum, []byte, error) + func EncDatumRowToDatums(datums parser.Datums, row EncDatumRow, da *DatumAlloc) error + func EncodeColumns(columnIDs []ColumnID, directions directions, colMap map[ColumnID]int, ...) (key []byte, containsNull bool, err error) + func EncodeDatum(b []byte, d parser.Datum) ([]byte, error) + func EncodeDatums(b []byte, d parser.Datums) ([]byte, error) + func EncodeIndexKey(tableDesc *TableDescriptor, index *IndexDescriptor, colMap map[ColumnID]int, ...) (key []byte, containsNull bool, err error) + func EncodePartialIndexKey(tableDesc *TableDescriptor, index *IndexDescriptor, numCols int, ...) (key []byte, containsNull bool, err error) + func EncodeSecondaryIndexes(tableDesc *TableDescriptor, indexes []IndexDescriptor, colMap map[ColumnID]int, ...) error + func EncodeTableKey(b []byte, val parser.Datum, dir encoding.Direction) ([]byte, error) + func EncodeTableValue(appendTo []byte, colID ColumnID, val parser.Datum) ([]byte, error) + func ExtractIndexKey(a *DatumAlloc, tableDesc *TableDescriptor, entry client.KeyValue) (roachpb.Key, error) + func FixedOffsetTimeZoneToLocation(offset int, origRepr string) *time.Location + func HasCompositeKeyEncoding(kind ColumnType_Kind) bool + func IsPermanentSchemaChangeError(err error) bool + func IsReservedID(id ID) bool + func IsSystemConfigID(id ID) bool + func IsUndefinedDatabaseError(err error) bool + func IsUndefinedTableError(err error) bool + func IsUniquenessConstraintViolationError(err error) bool + func MakeAllDescsMetadataKey() roachpb.Key + func MakeColumnDefDescs(d *parser.ColumnTableDef, searchPath parser.SearchPath, ...) (*ColumnDescriptor, *IndexDescriptor, error) + func MakeDefaultExprs(cols []ColumnDescriptor, parse *parser.Parser, evalCtx *parser.EvalContext) ([]parser.TypedExpr, error) + func MakeDescMetadataKey(descID ID) roachpb.Key + func MakeIndexKeyPrefix(desc *TableDescriptor, indexID IndexID) []byte + func MakeKeyFromEncDatums(values EncDatumRow, tableDesc *TableDescriptor, index *IndexDescriptor, ...) (roachpb.Key, error) + func MakeNameMetadataKey(parentID ID, name string) roachpb.Key + func MakePrimaryIndexKey(desc *TableDescriptor, vals ...interface{}) (roachpb.Key, error) + func MakeZoneKey(id ID) roachpb.Key + func MarshalColumnValue(col ColumnDescriptor, val parser.Datum) (roachpb.Value, error) + func NewDatabaseAlreadyExistsError(name string) error + func NewDependentObjectError(msg string) error + func NewDependentObjectErrorWithHint(msg string, hint string) error + func NewInvalidSchemaDefinitionError(err error) error + func NewNonNullViolationError(columnName string) error + func NewRangeUnavailableError(rangeID roachpb.RangeID, origErr error, nodeIDs ...roachpb.NodeID) error + func NewRelationAlreadyExistsError(name string) error + func NewRetryError(cause error) error + func NewStatementCompletionUnknownError(err *roachpb.AmbiguousResultError) error + func NewSyntaxError(msg string) error + func NewTransactionAbortedError(customMsg string) error + func NewTransactionCommittedError() error + func NewUndefinedDatabaseError(name string) error + func NewUndefinedTableError(name string) error + func NewUndefinedViewError(name string) error + func NewUniquenessConstraintViolationError(index *IndexDescriptor, vals []parser.Datum) error + func NewWindowingError(in string) error + func NewWrongObjectTypeError(name, desiredObjType string) error + func ParseFixedOffsetTimeZone(location string) (offset int, origRepr string, success bool) + func PrettyKey(key roachpb.Key, skip int) string + func PrettySpan(span roachpb.Span, skip int) string + func PrettySpans(spans []roachpb.Span, skip int) string + func RandCollationLocale(rng *rand.Rand) *string + func RandDatum(rng *rand.Rand, typ ColumnType, null bool) parser.Datum + func RandEncDatumSlices(rng *rand.Rand, numSets, numValsPerSet int) [][]EncDatum + func RunFilter(filter parser.TypedExpr, evalCtx *parser.EvalContext) (bool, error) + func SanitizeVarFreeExpr(expr parser.Expr, expectedType parser.Type, context string, ...) (parser.TypedExpr, error) + func SetKVBatchSize(val int64) func() + func SystemDesiredPrivileges(id ID) privilege.List + func TimeZoneStringToLocation(location string) (*time.Location, error) + func UnmarshalColumnValue(a *DatumAlloc, typ ColumnType, value *roachpb.Value) (parser.Datum, error) + type ColTypeInfo struct + func ColTypeInfoFromColTypes(colTypes []ColumnType) ColTypeInfo + func ColTypeInfoFromResCols(resCols ResultColumns) ColTypeInfo + func (ti ColTypeInfo) NumColumns() int + func (ti ColTypeInfo) Type(idx int) parser.Type + type ColumnDescriptor struct + DefaultExpr *string + Hidden bool + ID ColumnID + Name string + Nullable bool + Type ColumnType + func (*ColumnDescriptor) Descriptor() ([]byte, []int) + func (*ColumnDescriptor) ProtoMessage() + func (m *ColumnDescriptor) Marshal() (dAtA []byte, err error) + func (m *ColumnDescriptor) MarshalTo(dAtA []byte) (int, error) + func (m *ColumnDescriptor) Reset() + func (m *ColumnDescriptor) Size() (n int) + func (m *ColumnDescriptor) String() string + func (m *ColumnDescriptor) Unmarshal(dAtA []byte) error + type ColumnFamilyDescriptor struct + ColumnIDs []ColumnID + ColumnNames []string + DefaultColumnID ColumnID + ID FamilyID + Name string + func (*ColumnFamilyDescriptor) Descriptor() ([]byte, []int) + func (*ColumnFamilyDescriptor) ProtoMessage() + func (m *ColumnFamilyDescriptor) Marshal() (dAtA []byte, err error) + func (m *ColumnFamilyDescriptor) MarshalTo(dAtA []byte) (int, error) + func (m *ColumnFamilyDescriptor) Reset() + func (m *ColumnFamilyDescriptor) Size() (n int) + func (m *ColumnFamilyDescriptor) String() string + func (m *ColumnFamilyDescriptor) Unmarshal(dAtA []byte) error + type ColumnID parser.ColumnID + type ColumnOrderInfo struct + ColIdx int + Direction encoding.Direction + type ColumnOrdering []ColumnOrderInfo + func (a ColumnOrdering) IsPrefixOf(b ColumnOrdering) bool + type ColumnType struct + ArrayDimensions []int32 + Kind ColumnType_Kind + Locale *string + Precision int32 + Width int32 + func DatumTypeToColumnType(ptyp parser.Type) ColumnType + func RandColumnType(rng *rand.Rand) ColumnType + func (*ColumnType) Descriptor() ([]byte, []int) + func (*ColumnType) ProtoMessage() + func (c *ColumnType) MaxCharacterLength() (int32, bool) + func (c *ColumnType) MaxOctetLength() (int32, bool) + func (c *ColumnType) NumericPrecision() (int32, bool) + func (c *ColumnType) NumericScale() (int32, bool) + func (c *ColumnType) SQLString() string + func (c *ColumnType) ToDatumType() parser.Type + func (m *ColumnType) Marshal() (dAtA []byte, err error) + func (m *ColumnType) MarshalTo(dAtA []byte) (int, error) + func (m *ColumnType) Reset() + func (m *ColumnType) Size() (n int) + func (m *ColumnType) String() string + func (m *ColumnType) Unmarshal(dAtA []byte) error + type ColumnType_Kind int32 + const ColumnType_BOOL + const ColumnType_BYTES + const ColumnType_COLLATEDSTRING + const ColumnType_DATE + const ColumnType_DECIMAL + const ColumnType_FLOAT + const ColumnType_INT + const ColumnType_INT2VECTOR + const ColumnType_INTERVAL + const ColumnType_INT_ARRAY + const ColumnType_NAME + const ColumnType_NULL + const ColumnType_OID + const ColumnType_STRING + const ColumnType_TIMESTAMP + const ColumnType_TIMESTAMPTZ + func (ColumnType_Kind) EnumDescriptor() ([]byte, []int) + func (x *ColumnType_Kind) UnmarshalJSON(data []byte) error + func (x ColumnType_Kind) Enum() *ColumnType_Kind + func (x ColumnType_Kind) String() string + type ConstraintDetail struct + CheckConstraint *TableDescriptor_CheckConstraint + Columns []string + Details string + FK *ForeignKeyReference + Index *IndexDescriptor + Kind ConstraintType + ReferencedIndex *IndexDescriptor + ReferencedTable *TableDescriptor + Unvalidated bool + type ConstraintType string + const ConstraintTypeCheck + const ConstraintTypeFK + const ConstraintTypePK + const ConstraintTypeUnique + type ConstraintValidity int32 + const ConstraintValidity_Unvalidated + const ConstraintValidity_Validated + func (ConstraintValidity) EnumDescriptor() ([]byte, []int) + func (x *ConstraintValidity) UnmarshalJSON(data []byte) error + func (x ConstraintValidity) Enum() *ConstraintValidity + func (x ConstraintValidity) String() string + type DatabaseDescriptor struct + ID ID + Name string + Privileges *PrivilegeDescriptor + func GetDatabaseDescFromID(ctx context.Context, txn *client.Txn, id ID) (*DatabaseDescriptor, error) + func (*DatabaseDescriptor) Descriptor() ([]byte, []int) + func (*DatabaseDescriptor) ProtoMessage() + func (desc *DatabaseDescriptor) SetID(id ID) + func (desc *DatabaseDescriptor) SetName(name string) + func (desc *DatabaseDescriptor) TypeName() string + func (desc *DatabaseDescriptor) Validate() error + func (m *DatabaseDescriptor) GetID() ID + func (m *DatabaseDescriptor) GetName() string + func (m *DatabaseDescriptor) GetPrivileges() *PrivilegeDescriptor + func (m *DatabaseDescriptor) Marshal() (dAtA []byte, err error) + func (m *DatabaseDescriptor) MarshalTo(dAtA []byte) (int, error) + func (m *DatabaseDescriptor) Reset() + func (m *DatabaseDescriptor) Size() (n int) + func (m *DatabaseDescriptor) String() string + func (m *DatabaseDescriptor) Unmarshal(dAtA []byte) error + type DatumAlloc struct + func (a *DatumAlloc) NewDBytes(v parser.DBytes) *parser.DBytes + func (a *DatumAlloc) NewDDate(v parser.DDate) *parser.DDate + func (a *DatumAlloc) NewDDecimal(v parser.DDecimal) *parser.DDecimal + func (a *DatumAlloc) NewDFloat(v parser.DFloat) *parser.DFloat + func (a *DatumAlloc) NewDInt(v parser.DInt) *parser.DInt + func (a *DatumAlloc) NewDInterval(v parser.DInterval) *parser.DInterval + func (a *DatumAlloc) NewDName(v parser.DString) parser.Datum + func (a *DatumAlloc) NewDOid(v parser.DOid) parser.Datum + func (a *DatumAlloc) NewDString(v parser.DString) *parser.DString + func (a *DatumAlloc) NewDTimestamp(v parser.DTimestamp) *parser.DTimestamp + func (a *DatumAlloc) NewDTimestampTZ(v parser.DTimestampTZ) *parser.DTimestampTZ + type DatumEncoding int32 + const DatumEncoding_ASCENDING_KEY + const DatumEncoding_DESCENDING_KEY + const DatumEncoding_VALUE + func RandDatumEncoding(rng *rand.Rand) DatumEncoding + func (DatumEncoding) EnumDescriptor() ([]byte, []int) + func (x *DatumEncoding) UnmarshalJSON(data []byte) error + func (x DatumEncoding) Enum() *DatumEncoding + func (x DatumEncoding) String() string + type Descriptor struct + Union isDescriptor_Union + func WrapDescriptor(descriptor DescriptorProto) *Descriptor + func (*Descriptor) Descriptor() ([]byte, []int) + func (*Descriptor) ProtoMessage() + func (*Descriptor) XXX_OneofFuncs() (func(msg proto.Message, b *proto.Buffer) error, ...) + func (desc *Descriptor) GetID() ID + func (desc *Descriptor) GetName() string + func (m *Descriptor) GetDatabase() *DatabaseDescriptor + func (m *Descriptor) GetTable() *TableDescriptor + func (m *Descriptor) GetUnion() isDescriptor_Union + func (m *Descriptor) Marshal() (dAtA []byte, err error) + func (m *Descriptor) MarshalTo(dAtA []byte) (int, error) + func (m *Descriptor) Reset() + func (m *Descriptor) Size() (n int) + func (m *Descriptor) String() string + func (m *Descriptor) Unmarshal(dAtA []byte) error + type DescriptorKey interface + Key func() roachpb.Key + Name func() string + type DescriptorMutation struct + Descriptor_ isDescriptorMutation_Descriptor_ + Direction DescriptorMutation_Direction + MutationID MutationID + ResumeSpans []cockroach_roachpb1.Span + State DescriptorMutation_State + func (*DescriptorMutation) Descriptor() ([]byte, []int) + func (*DescriptorMutation) ProtoMessage() + func (*DescriptorMutation) XXX_OneofFuncs() (func(msg proto.Message, b *proto.Buffer) error, ...) + func (m *DescriptorMutation) GetColumn() *ColumnDescriptor + func (m *DescriptorMutation) GetDescriptor_() isDescriptorMutation_Descriptor_ + func (m *DescriptorMutation) GetIndex() *IndexDescriptor + func (m *DescriptorMutation) Marshal() (dAtA []byte, err error) + func (m *DescriptorMutation) MarshalTo(dAtA []byte) (int, error) + func (m *DescriptorMutation) Reset() + func (m *DescriptorMutation) Size() (n int) + func (m *DescriptorMutation) String() string + func (m *DescriptorMutation) Unmarshal(dAtA []byte) error + type DescriptorMutation_Column struct + Column *ColumnDescriptor + func (m *DescriptorMutation_Column) MarshalTo(dAtA []byte) (int, error) + func (m *DescriptorMutation_Column) Size() (n int) + type DescriptorMutation_Direction int32 + const DescriptorMutation_ADD + const DescriptorMutation_DROP + const DescriptorMutation_NONE + func (DescriptorMutation_Direction) EnumDescriptor() ([]byte, []int) + func (x *DescriptorMutation_Direction) UnmarshalJSON(data []byte) error + func (x DescriptorMutation_Direction) Enum() *DescriptorMutation_Direction + func (x DescriptorMutation_Direction) String() string + type DescriptorMutation_Index struct + Index *IndexDescriptor + func (m *DescriptorMutation_Index) MarshalTo(dAtA []byte) (int, error) + func (m *DescriptorMutation_Index) Size() (n int) + type DescriptorMutation_State int32 + const DescriptorMutation_DELETE_ONLY + const DescriptorMutation_UNKNOWN + const DescriptorMutation_WRITE_ONLY + func (DescriptorMutation_State) EnumDescriptor() ([]byte, []int) + func (x *DescriptorMutation_State) UnmarshalJSON(data []byte) error + func (x DescriptorMutation_State) Enum() *DescriptorMutation_State + func (x DescriptorMutation_State) String() string + type DescriptorProto interface + GetID func() ID + GetName func() string + GetPrivileges func() *PrivilegeDescriptor + SetID func(ID) + SetName func(string) + TypeName func() string + type DescriptorStatus int + const DescriptorAbsent + const DescriptorActive + const DescriptorIncomplete + type DescriptorVersion uint32 + type Descriptor_Database struct + Database *DatabaseDescriptor + func (m *Descriptor_Database) MarshalTo(dAtA []byte) (int, error) + func (m *Descriptor_Database) Size() (n int) + type Descriptor_Table struct + Table *TableDescriptor + func (m *Descriptor_Table) MarshalTo(dAtA []byte) (int, error) + func (m *Descriptor_Table) Size() (n int) + type EncDatum struct + Datum parser.Datum + Type ColumnType + func DatumToEncDatum(ctyp ColumnType, d parser.Datum) EncDatum + func EncDatumFromBuffer(typ ColumnType, enc DatumEncoding, buf []byte) (EncDatum, []byte, error) + func EncDatumFromEncoded(typ ColumnType, enc DatumEncoding, encoded []byte) EncDatum + func MakeEncodedKeyVals(desc *TableDescriptor, columnIDs []ColumnID) ([]EncDatum, error) + func RandEncDatum(rng *rand.Rand) EncDatum + func RandEncDatumSlice(rng *rand.Rand, numVals int) []EncDatum + func (ed *EncDatum) Compare(a *DatumAlloc, evalCtx *parser.EvalContext, rhs *EncDatum) (int, error) + func (ed *EncDatum) Encode(a *DatumAlloc, enc DatumEncoding, appendTo []byte) ([]byte, error) + func (ed *EncDatum) Encoding() (DatumEncoding, bool) + func (ed *EncDatum) EnsureDecoded(a *DatumAlloc) error + func (ed *EncDatum) IsNull() bool + func (ed *EncDatum) IsUnset() bool + func (ed *EncDatum) String() string + func (ed *EncDatum) UnsetDatum() + type EncDatumRow []EncDatum + func (r EncDatumRow) Compare(a *DatumAlloc, ordering ColumnOrdering, evalCtx *parser.EvalContext, ...) (int, error) + func (r EncDatumRow) CompareToDatums(a *DatumAlloc, ordering ColumnOrdering, evalCtx *parser.EvalContext, ...) (int, error) + func (r EncDatumRow) String() string + type EncDatumRowAlloc struct + func (a *EncDatumRowAlloc) AllocRow(cols int) EncDatumRow + func (a *EncDatumRowAlloc) CopyRow(row EncDatumRow) EncDatumRow + type EncDatumRows []EncDatumRow + func (r EncDatumRows) String() string + type FKCheck int + const CheckDeletes + const CheckInserts + const CheckUpdates + type FamilyID uint32 + type FkSpanCollector interface + CollectSpans func() (reads roachpb.Spans, writes roachpb.Spans) + type ForeignKeyReference struct + Index IndexID + Name string + SharedPrefixLen int32 + Table ID + Validity ConstraintValidity + func (*ForeignKeyReference) Descriptor() ([]byte, []int) + func (*ForeignKeyReference) ProtoMessage() + func (f ForeignKeyReference) IsSet() bool + func (m *ForeignKeyReference) Marshal() (dAtA []byte, err error) + func (m *ForeignKeyReference) MarshalTo(dAtA []byte) (int, error) + func (m *ForeignKeyReference) Reset() + func (m *ForeignKeyReference) Size() (n int) + func (m *ForeignKeyReference) String() string + func (m *ForeignKeyReference) Unmarshal(dAtA []byte) error + type FormatVersion uint32 + const BaseFormatVersion + const FamilyFormatVersion + const InterleavedFormatVersion + func (i FormatVersion) String() string + type ID parser.ID + type IDs []ID + func (ids IDs) Len() int + func (ids IDs) Less(i, j int) bool + func (ids IDs) Swap(i, j int) + type IndexDescriptor struct + ColumnDirections []IndexDescriptor_Direction + ColumnIDs []ColumnID + ColumnNames []string + CompositeColumnIDs []ColumnID + ExtraColumnIDs []ColumnID + ForeignKey ForeignKeyReference + ID IndexID + Interleave InterleaveDescriptor + InterleavedBy []ForeignKeyReference + Name string + ReferencedBy []ForeignKeyReference + StoreColumnIDs []ColumnID + StoreColumnNames []string + Unique bool + func (*IndexDescriptor) Descriptor() ([]byte, []int) + func (*IndexDescriptor) ProtoMessage() + func (desc *IndexDescriptor) ContainsColumnID(colID ColumnID) bool + func (desc *IndexDescriptor) FillColumns(elems parser.IndexElemList) error + func (desc *IndexDescriptor) FullColumnIDs() ([]ColumnID, []encoding.Direction) + func (desc *IndexDescriptor) HasOldStoredColumns() bool + func (desc *IndexDescriptor) RunOverAllColumns(fn func(id ColumnID) error) error + func (m *IndexDescriptor) Marshal() (dAtA []byte, err error) + func (m *IndexDescriptor) MarshalTo(dAtA []byte) (int, error) + func (m *IndexDescriptor) Reset() + func (m *IndexDescriptor) Size() (n int) + func (m *IndexDescriptor) String() string + func (m *IndexDescriptor) Unmarshal(dAtA []byte) error + type IndexDescriptor_Direction int32 + const IndexDescriptor_ASC + const IndexDescriptor_DESC + func (IndexDescriptor_Direction) EnumDescriptor() ([]byte, []int) + func (dir IndexDescriptor_Direction) ToEncodingDirection() (encoding.Direction, error) + func (x *IndexDescriptor_Direction) UnmarshalJSON(data []byte) error + func (x IndexDescriptor_Direction) Enum() *IndexDescriptor_Direction + func (x IndexDescriptor_Direction) String() string + type IndexEntry struct + Key roachpb.Key + Value roachpb.Value + func EncodeSecondaryIndex(tableDesc *TableDescriptor, secondaryIndex *IndexDescriptor, ...) (IndexEntry, error) + type IndexID parser.IndexID + func DecodeIndexKeyPrefix(a *DatumAlloc, desc *TableDescriptor, key []byte) (indexID IndexID, remaining []byte, err error) + type InterleaveDescriptor struct + Ancestors []InterleaveDescriptor_Ancestor + func (*InterleaveDescriptor) Descriptor() ([]byte, []int) + func (*InterleaveDescriptor) ProtoMessage() + func (m *InterleaveDescriptor) Marshal() (dAtA []byte, err error) + func (m *InterleaveDescriptor) MarshalTo(dAtA []byte) (int, error) + func (m *InterleaveDescriptor) Reset() + func (m *InterleaveDescriptor) Size() (n int) + func (m *InterleaveDescriptor) String() string + func (m *InterleaveDescriptor) Unmarshal(dAtA []byte) error + type InterleaveDescriptor_Ancestor struct + IndexID IndexID + SharedPrefixLen uint32 + TableID ID + func (*InterleaveDescriptor_Ancestor) Descriptor() ([]byte, []int) + func (*InterleaveDescriptor_Ancestor) ProtoMessage() + func (m *InterleaveDescriptor_Ancestor) Marshal() (dAtA []byte, err error) + func (m *InterleaveDescriptor_Ancestor) MarshalTo(dAtA []byte) (int, error) + func (m *InterleaveDescriptor_Ancestor) Reset() + func (m *InterleaveDescriptor_Ancestor) Size() (n int) + func (m *InterleaveDescriptor_Ancestor) String() string + func (m *InterleaveDescriptor_Ancestor) Unmarshal(dAtA []byte) error + type MetadataSchema struct + func MakeMetadataSchema() MetadataSchema + func (ms *MetadataSchema) AddConfigDescriptor(parentID ID, desc DescriptorProto) + func (ms *MetadataSchema) AddDescriptor(parentID ID, desc DescriptorProto) + func (ms MetadataSchema) GetInitialValues() []roachpb.KeyValue + func (ms MetadataSchema) InitialRangeCount() int + func (ms MetadataSchema) SystemConfigDescriptorCount() int + func (ms MetadataSchema) SystemDescriptorCount() int + type MutationID uint32 + const InvalidMutationID + type PrivilegeDescriptor struct + Users []UserPrivileges + func NewDefaultPrivilegeDescriptor() *PrivilegeDescriptor + func NewPrivilegeDescriptor(user string, priv privilege.List) *PrivilegeDescriptor + func (*PrivilegeDescriptor) Descriptor() ([]byte, []int) + func (*PrivilegeDescriptor) ProtoMessage() + func (m *PrivilegeDescriptor) Marshal() (dAtA []byte, err error) + func (m *PrivilegeDescriptor) MarshalTo(dAtA []byte) (int, error) + func (m *PrivilegeDescriptor) Reset() + func (m *PrivilegeDescriptor) Size() (n int) + func (m *PrivilegeDescriptor) String() string + func (m *PrivilegeDescriptor) Unmarshal(dAtA []byte) error + func (p *PrivilegeDescriptor) Grant(user string, privList privilege.List) + func (p *PrivilegeDescriptor) Revoke(user string, privList privilege.List) + func (p PrivilegeDescriptor) AnyPrivilege(user string) bool + func (p PrivilegeDescriptor) CheckPrivilege(user string, priv privilege.Kind) bool + func (p PrivilegeDescriptor) Show() []UserPrivilegeString + func (p PrivilegeDescriptor) Validate(id ID) error + type ResultColumn struct + Hidden bool + Name string + Omitted bool + Typ parser.Type + type ResultColumns []ResultColumn + func ResultColumnsFromColDescs(colDescs []ColumnDescriptor) ResultColumns + type RowContainer struct + func MakeRowContainer(acc mon.BoundAccount, ti ColTypeInfo, rowCapacity int) RowContainer + func NewRowContainer(acc mon.BoundAccount, ti ColTypeInfo, rowCapacity int) *RowContainer + func (c *RowContainer) AddRow(ctx context.Context, row parser.Datums) (parser.Datums, error) + func (c *RowContainer) At(i int) parser.Datums + func (c *RowContainer) Clear(ctx context.Context) + func (c *RowContainer) Close(ctx context.Context) + func (c *RowContainer) Len() int + func (c *RowContainer) PopFirst() + func (c *RowContainer) Replace(ctx context.Context, i int, newRow parser.Datums) error + func (c *RowContainer) Swap(i, j int) + type RowDeleter struct + FetchColIDtoRowIndex map[ColumnID]int + FetchCols []ColumnDescriptor + Fks fkDeleteHelper + Helper rowHelper + func MakeRowDeleter(txn *client.Txn, tableDesc *TableDescriptor, fkTables TableLookupsByID, ...) (RowDeleter, error) + func (rd *RowDeleter) DeleteIndexRow(ctx context.Context, b *client.Batch, idx *IndexDescriptor, ...) error + func (rd *RowDeleter) DeleteRow(ctx context.Context, b *client.Batch, values []parser.Datum) error + type RowFetcher struct + func (rf *RowFetcher) GetRangeInfo() []roachpb.RangeInfo + func (rf *RowFetcher) Init(desc *TableDescriptor, colIdxMap map[ColumnID]int, index *IndexDescriptor, ...) error + func (rf *RowFetcher) Key() roachpb.Key + func (rf *RowFetcher) NextKey(ctx context.Context) (rowDone bool, err error) + func (rf *RowFetcher) NextKeyDebug(ctx context.Context) (prettyKey string, prettyValue string, row EncDatumRow, err error) + func (rf *RowFetcher) NextRow(ctx context.Context) (EncDatumRow, error) + func (rf *RowFetcher) NextRowDecoded(ctx context.Context) (parser.Datums, error) + func (rf *RowFetcher) ProcessKV(kv client.KeyValue, debugStrings bool) (prettyKey string, prettyValue string, err error) + func (rf *RowFetcher) ReadIndexKey(k roachpb.Key) (remaining []byte, ok bool, err error) + func (rf *RowFetcher) StartScan(ctx context.Context, txn *client.Txn, spans roachpb.Spans, limitBatches bool, ...) error + type RowInserter struct + Fks fkInsertHelper + Helper rowHelper + InsertColIDtoRowIndex map[ColumnID]int + InsertCols []ColumnDescriptor + func MakeRowInserter(txn *client.Txn, tableDesc *TableDescriptor, fkTables TableLookupsByID, ...) (RowInserter, error) + func (ri *RowInserter) InsertRow(ctx context.Context, b puter, values []parser.Datum, ignoreConflicts bool) error + type RowUpdater struct + FetchColIDtoRowIndex map[ColumnID]int + FetchCols []ColumnDescriptor + Fks fkUpdateHelper + Helper rowHelper + UpdateCols []ColumnDescriptor + func MakeRowUpdater(txn *client.Txn, tableDesc *TableDescriptor, fkTables TableLookupsByID, ...) (RowUpdater, error) + func (ru *RowUpdater) IsColumnOnlyUpdate() bool + func (ru *RowUpdater) UpdateRow(ctx context.Context, b *client.Batch, oldValues []parser.Datum, ...) ([]parser.Datum, error) + type TableDescriptor struct + Checks []*TableDescriptor_CheckConstraint + Columns []ColumnDescriptor + DependedOnBy []TableDescriptor_Reference + DependsOn []ID + Families []ColumnFamilyDescriptor + FormatVersion FormatVersion + ID ID + Indexes []IndexDescriptor + Lease *TableDescriptor_SchemaChangeLease + ModificationTime cockroach_util_hlc.Timestamp + Mutations []DescriptorMutation + Name string + NextColumnID ColumnID + NextFamilyID FamilyID + NextIndexID IndexID + NextMutationID MutationID + ParentID ID + PrimaryIndex IndexDescriptor + Privileges *PrivilegeDescriptor + Renames []TableDescriptor_RenameInfo + State TableDescriptor_State + UpVersion bool + Version DescriptorVersion + ViewQuery string + func GetTableDescFromID(ctx context.Context, txn *client.Txn, id ID) (*TableDescriptor, error) + func GetTableDescriptor(kvDB *client.DB, database string, table string) *TableDescriptor + func (*TableDescriptor) Descriptor() ([]byte, []int) + func (*TableDescriptor) ProtoMessage() + func (desc *TableDescriptor) AddColumn(col ColumnDescriptor) + func (desc *TableDescriptor) AddColumnMutation(c ColumnDescriptor, direction DescriptorMutation_Direction) + func (desc *TableDescriptor) AddColumnToFamilyMaybeCreate(col string, family string, create bool, ifNotExists bool) error + func (desc *TableDescriptor) AddFamily(fam ColumnFamilyDescriptor) + func (desc *TableDescriptor) AddIndex(idx IndexDescriptor, primary bool) error + func (desc *TableDescriptor) AddIndexMutation(idx IndexDescriptor, direction DescriptorMutation_Direction) + func (desc *TableDescriptor) Adding() bool + func (desc *TableDescriptor) AllIndexSpans() roachpb.Spans + func (desc *TableDescriptor) AllNonDropIndexes() []IndexDescriptor + func (desc *TableDescriptor) AllocateIDs() error + func (desc *TableDescriptor) Dropped() bool + func (desc *TableDescriptor) FinalizeMutation() (MutationID, error) + func (desc *TableDescriptor) FindActiveColumnByID(id ColumnID) (*ColumnDescriptor, error) + func (desc *TableDescriptor) FindActiveColumnByName(name parser.Name) (ColumnDescriptor, error) + func (desc *TableDescriptor) FindActiveColumnByNormalizedName(normName string) (ColumnDescriptor, error) + func (desc *TableDescriptor) FindActiveColumnsByNames(names parser.NameList) ([]ColumnDescriptor, error) + func (desc *TableDescriptor) FindColumnByID(id ColumnID) (*ColumnDescriptor, error) + func (desc *TableDescriptor) FindColumnByName(name parser.Name) (DescriptorStatus, int, error) + func (desc *TableDescriptor) FindColumnByNormalizedName(normName string) (DescriptorStatus, int, error) + func (desc *TableDescriptor) FindFamilyByID(id FamilyID) (*ColumnFamilyDescriptor, error) + func (desc *TableDescriptor) FindIndexByID(id IndexID) (*IndexDescriptor, error) + func (desc *TableDescriptor) FindIndexByName(name parser.Name) (DescriptorStatus, int, error) + func (desc *TableDescriptor) FindIndexByNormalizedName(normName string) (DescriptorStatus, int, error) + func (desc *TableDescriptor) ForeachNonDropIndex(f func(*IndexDescriptor) error) error + func (desc *TableDescriptor) IndexSpan(indexID IndexID) roachpb.Span + func (desc *TableDescriptor) InvalidateFKConstraints() + func (desc *TableDescriptor) IsEmpty() bool + func (desc *TableDescriptor) IsInterleaved() bool + func (desc *TableDescriptor) IsPhysicalTable() bool + func (desc *TableDescriptor) IsTable() bool + func (desc *TableDescriptor) IsView() bool + func (desc *TableDescriptor) IsVirtualTable() bool + func (desc *TableDescriptor) KeysPerRow(indexID IndexID) int + func (desc *TableDescriptor) MakeMutationComplete(m DescriptorMutation) + func (desc *TableDescriptor) MaybeUpgradeFormatVersion() bool + func (desc *TableDescriptor) PrimaryIndexSpan() roachpb.Span + func (desc *TableDescriptor) RemoveColumnFromFamily(colID ColumnID) + func (desc *TableDescriptor) RenameColumnNormalized(colID ColumnID, newColName string) + func (desc *TableDescriptor) Renamed() bool + func (desc *TableDescriptor) SetID(id ID) + func (desc *TableDescriptor) SetName(name string) + func (desc *TableDescriptor) SetUpVersion() error + func (desc *TableDescriptor) TableSpan() roachpb.Span + func (desc *TableDescriptor) TypeName() string + func (desc *TableDescriptor) Validate(ctx context.Context, txn *client.Txn) error + func (desc *TableDescriptor) ValidateTable() error + func (desc *TableDescriptor) VisibleColumns() []ColumnDescriptor + func (desc TableDescriptor) CheckUniqueConstraints() error + func (desc TableDescriptor) GetConstraintInfo(ctx context.Context, txn *client.Txn) (map[string]ConstraintDetail, error) + func (desc TableDescriptor) GetConstraintInfoWithLookup(tableLookup tableLookupFn) (map[string]ConstraintDetail, error) + func (desc TableDescriptor) GetDescMetadataKey() roachpb.Key + func (desc TableDescriptor) GetNameMetadataKey() roachpb.Key + func (m *TableDescriptor) GetChecks() []*TableDescriptor_CheckConstraint + func (m *TableDescriptor) GetColumns() []ColumnDescriptor + func (m *TableDescriptor) GetDependedOnBy() []TableDescriptor_Reference + func (m *TableDescriptor) GetDependsOn() []ID + func (m *TableDescriptor) GetFamilies() []ColumnFamilyDescriptor + func (m *TableDescriptor) GetFormatVersion() FormatVersion + func (m *TableDescriptor) GetID() ID + func (m *TableDescriptor) GetIndexes() []IndexDescriptor + func (m *TableDescriptor) GetLease() *TableDescriptor_SchemaChangeLease + func (m *TableDescriptor) GetModificationTime() cockroach_util_hlc.Timestamp + func (m *TableDescriptor) GetMutations() []DescriptorMutation + func (m *TableDescriptor) GetName() string + func (m *TableDescriptor) GetNextColumnID() ColumnID + func (m *TableDescriptor) GetNextFamilyID() FamilyID + func (m *TableDescriptor) GetNextIndexID() IndexID + func (m *TableDescriptor) GetNextMutationID() MutationID + func (m *TableDescriptor) GetParentID() ID + func (m *TableDescriptor) GetPrimaryIndex() IndexDescriptor + func (m *TableDescriptor) GetPrivileges() *PrivilegeDescriptor + func (m *TableDescriptor) GetRenames() []TableDescriptor_RenameInfo + func (m *TableDescriptor) GetState() TableDescriptor_State + func (m *TableDescriptor) GetUpVersion() bool + func (m *TableDescriptor) GetVersion() DescriptorVersion + func (m *TableDescriptor) GetViewQuery() string + func (m *TableDescriptor) Marshal() (dAtA []byte, err error) + func (m *TableDescriptor) MarshalTo(dAtA []byte) (int, error) + func (m *TableDescriptor) Reset() + func (m *TableDescriptor) Size() (n int) + func (m *TableDescriptor) String() string + func (m *TableDescriptor) Unmarshal(dAtA []byte) error + type TableDescriptor_CheckConstraint struct + Expr string + Name string + Validity ConstraintValidity + func (*TableDescriptor_CheckConstraint) Descriptor() ([]byte, []int) + func (*TableDescriptor_CheckConstraint) ProtoMessage() + func (m *TableDescriptor_CheckConstraint) Marshal() (dAtA []byte, err error) + func (m *TableDescriptor_CheckConstraint) MarshalTo(dAtA []byte) (int, error) + func (m *TableDescriptor_CheckConstraint) Reset() + func (m *TableDescriptor_CheckConstraint) Size() (n int) + func (m *TableDescriptor_CheckConstraint) String() string + func (m *TableDescriptor_CheckConstraint) Unmarshal(dAtA []byte) error + type TableDescriptor_Reference struct + ColumnIDs []ColumnID + ID ID + IndexID IndexID + func (*TableDescriptor_Reference) Descriptor() ([]byte, []int) + func (*TableDescriptor_Reference) ProtoMessage() + func (m *TableDescriptor_Reference) Marshal() (dAtA []byte, err error) + func (m *TableDescriptor_Reference) MarshalTo(dAtA []byte) (int, error) + func (m *TableDescriptor_Reference) Reset() + func (m *TableDescriptor_Reference) Size() (n int) + func (m *TableDescriptor_Reference) String() string + func (m *TableDescriptor_Reference) Unmarshal(dAtA []byte) error + type TableDescriptor_RenameInfo struct + OldName string + OldParentID ID + func (*TableDescriptor_RenameInfo) Descriptor() ([]byte, []int) + func (*TableDescriptor_RenameInfo) ProtoMessage() + func (m *TableDescriptor_RenameInfo) Marshal() (dAtA []byte, err error) + func (m *TableDescriptor_RenameInfo) MarshalTo(dAtA []byte) (int, error) + func (m *TableDescriptor_RenameInfo) Reset() + func (m *TableDescriptor_RenameInfo) Size() (n int) + func (m *TableDescriptor_RenameInfo) String() string + func (m *TableDescriptor_RenameInfo) Unmarshal(dAtA []byte) error + type TableDescriptor_SchemaChangeLease struct + ExpirationTime int64 + NodeID github_com_cockroachdb_cockroach_pkg_roachpb.NodeID + func (*TableDescriptor_SchemaChangeLease) Descriptor() ([]byte, []int) + func (*TableDescriptor_SchemaChangeLease) ProtoMessage() + func (m *TableDescriptor_SchemaChangeLease) Marshal() (dAtA []byte, err error) + func (m *TableDescriptor_SchemaChangeLease) MarshalTo(dAtA []byte) (int, error) + func (m *TableDescriptor_SchemaChangeLease) Reset() + func (m *TableDescriptor_SchemaChangeLease) Size() (n int) + func (m *TableDescriptor_SchemaChangeLease) String() string + func (m *TableDescriptor_SchemaChangeLease) Unmarshal(dAtA []byte) error + type TableDescriptor_State int32 + const TableDescriptor_ADD + const TableDescriptor_DROP + const TableDescriptor_PUBLIC + func (TableDescriptor_State) EnumDescriptor() ([]byte, []int) + func (x *TableDescriptor_State) UnmarshalJSON(data []byte) error + func (x TableDescriptor_State) Enum() *TableDescriptor_State + func (x TableDescriptor_State) String() string + type TableLookup struct + IsAdding bool + Table *TableDescriptor + type TableLookupsByID map[ID]TableLookup + func TablesNeededForFKs(table TableDescriptor, usage FKCheck) TableLookupsByID + type UserPrivilegeString struct + Privileges []string + User string + func (u UserPrivilegeString) PrivilegeString() string + type UserPrivileges struct + Privileges uint32 + User string + func (*UserPrivileges) Descriptor() ([]byte, []int) + func (*UserPrivileges) ProtoMessage() + func (m *UserPrivileges) Marshal() (dAtA []byte, err error) + func (m *UserPrivileges) MarshalTo(dAtA []byte) (int, error) + func (m *UserPrivileges) Reset() + func (m *UserPrivileges) Size() (n int) + func (m *UserPrivileges) String() string + func (m *UserPrivileges) Unmarshal(dAtA []byte) error