# Functions
AbortCacheKey returns a range-local key by Range ID for an abort cache entry, with detail specified by encoding the supplied transaction ID.
Addr returns the address for the key, used to lookup the range containing the key.
AddrUpperBound returns the address of an (exclusive) EndKey, used to lookup ranges containing the keys strictly smaller than that key.
DecodeAbortCacheKey decodes the provided abort cache entry, returning the transaction ID.
DecodeRangeIDKey parses a local range ID key into range ID, infix, suffix, and detail.
DecodeRangeKey decodes the range key into range start key, suffix and optional detail (may be nil).
DecodeTablePrefix validates that the given key has a table prefix, returning the remainder of the key (with the prefix removed) and the decoded descriptor ID of the table.
EnsureSafeSplitKey transforms an SQL table key such that it is a valid split key (i.e.
GetRowPrefixLength returns the length of the row prefix of the key.
IsLocal performs a cheap check that returns true iff a range-local key is passed, that is, a key for which `Addr` would return a non-identical RKey (or a decoding error).
LeaseAppliedIndexKey returns a system-local key for a lease applied index.
MakeFamilyKey returns the key for the family in the given row by appending to the passed key.
MakeRangeIDPrefix creates a range-local key prefix from rangeID for both replicated and unreplicated data.
MakeRangeIDPrefixBuf creates a new range ID prefix buf suitable for generating the various range ID local keys.
MakeRangeIDReplicatedPrefix creates a range-local key prefix from rangeID for all Raft replicated data.
MakeRangeIDUnreplicatedPrefix creates a range-local key prefix from rangeID for all unreplicated data.
MakeRangeKey creates a range-local key based on the range start key, metadata key suffix, and optional detail (e.g.
MakeRangeKeyPrefix creates a key prefix under which all range-local keys can be found.
MakeStoreKey creates a store-local key based on the metadata key suffix, and optional detail.
MakeTablePrefix returns the key prefix used for the table's data.
MassagePrettyPrintedSpanForTest does some transformations on pretty-printed spans and keys: - if dirs is not nil, replace all ints with their ones' complement for descendingly-encoded columns.
MetaReverseScanBounds returns the range [start,end) within which the desired meta record can be found by means of a reverse engine scan.
MetaScanBounds returns the range [start,end) within which the desired meta record can be found by means of an engine scan.
MustAddr calls Addr and panics on errors.
NewInvalidRangeMetaKeyError returns a new InvalidRangeMetaKeyError.
NodeLivenessKey returns the key for the node liveness record.
NodeStatusKey returns the key for accessing the node status for the specified node ID.
PrettyPrint prints the key in a human readable format:
Key's Format Key's Value /Local/..
PrettyPrintRange pretty prints a compact representation of a key range.
QueueLastProcessedKey returns a range-local key for last processed timestamps for the named queue.
RaftAppliedIndexKey returns a system-local key for a raft applied index.
RaftHardStateKey returns a system-local key for a Raft HardState.
RaftLastIndexKey returns a system-local key for the last index of the Raft log.
RaftLogKey returns a system-local key for a Raft log entry.
RaftLogPrefix returns the system-local prefix shared by all entries in a Raft log.
RaftTombstoneKey returns a system-local key for a raft tombstone.
RaftTruncatedStateKey returns a system-local key for a RaftTruncatedState.
Range returns a key range encompassing all the keys in the Batch.
RangeDescriptorKey returns a range-local key for the descriptor for the range with specified key.
RangeFrozenStatusKey returns a system-local key for the frozen status.
RangeLastGCKey returns a system-local key for last used GC threshold on the user keyspace.
RangeLastReplicaGCTimestampKey returns a range-local key for the range's last replica GC timestamp.
RangeLastVerificationTimestampKeyDeprecated returns a range-local key for the range's last verification timestamp.
RangeLeaseKey returns a system-local key for a range lease.
RangeMetaKey returns a range metadata (meta1, meta2) indexing key for the given key.
RangeStatsKey returns the key for accessing the MVCCStats struct for the specified Range ID.
RangeTxnSpanGCThresholdKey returns a system-local key for last used GC threshold on the txn span.
StoreClusterVersionKey returns a store-local key for the cluster version.
StoreGossipKey returns a store-local key for the gossip bootstrap metadata.
StoreIdentKey returns a store-local key for the store metadata.
StoreLastUpKey returns the key for the store's "last up" timestamp.
TransactionKey returns a transaction key based on the provided transaction key and ID.
UglyPrint is a partial right inverse to PrettyPrint: it takes a key formatted for human consumption and attempts to translate it into a roachpb.Key.
UserKey returns an ordinary key for the given range metadata (meta1, meta2) indexing key.
# Constants
Various IDs used by the structured data layer.
Various IDs used by the structured data layer.
Various IDs used by the structured data layer.
Reserved IDs for other system tables.
MaxReservedDescID is the maximum value of reserved descriptor IDs.
MaxSystemConfigDescID is the maximum system descriptor ID that will be gossiped as part of the SystemConfig.
Various IDs used by the structured data layer.
Various IDs used by the structured data layer.
Various IDs used by the structured data layer.
RootNamespaceID is the ID of the root namespace.
Various IDs used by the structured data layer.
SystemDatabaseID and following are the database/table IDs for objects in the system span.
Various IDs used by the structured data layer.
Various IDs used by the structured data layer.
Various IDs used by the structured data layer.
Various IDs used by the structured data layer.
VirtualDescriptorID is the ID used by all virtual descriptors.
Various IDs used by the structured data layer.
Various IDs used by the structured data layer.
# Variables
BootstrapVersion is the key at which clusters bootstrapped with a version > 1.0 persist the version at which they were bootstrapped.
DescIDGenerator is the global descriptor ID generator sequence used for table and namespace IDs.
LocalAbortCacheSuffix is the suffix for abort cache entries.
LocalLeaseAppliedIndexSuffix is the suffix for the applied lease index.
LocalMax is the end of the local key range.
LocalQueueLastProcessedSuffix is the suffix for replica queue state keys.
LocalRaftAppliedIndexSuffix is the suffix for the raft applied index.
LocalRaftHardStateSuffix is the Suffix for the raft HardState.
LocalRaftLastIndexSuffix is the suffix for raft's last index.
LocalRaftLogSuffix is the suffix for the raft log.
LocalRaftTombstoneSuffix is the suffix for the raft tombstone.
LocalRaftTruncatedStateSuffix is the suffix for the RaftTruncatedState.
LocalRangeDescriptorSuffix is the suffix for keys storing range descriptors.
LocalRangeFrozenStatusSuffix is the suffix for a frozen status.
LocalRangeIDPrefix is the prefix identifying per-range data indexed by Range ID.
LocalRangeLastGCSuffix is the suffix for the last GC.
LocalRangeLastReplicaGCTimestampSuffix is the suffix for a range's last replica GC timestamp (for GC of old replicas).
LocalRangeLastVerificationTimestampSuffixDeprecated is the suffix for a range's last verification timestamp (for checking integrity of on-disk data).
LocalRangeLeaseSuffix is the suffix for a range lease.
Constants for system-reserved keys in the KV map.
LocalRangePrefix is the prefix identifying per-range data indexed by range key (either start key, or some key in the range).
LocalRangeReplicaDestroyedErrorSuffix is the suffix for a range's replica destroyed error (for marking replicas as dead).
LocalRangeStatsSuffix is the suffix for range statistics.
LocalTransactionSuffix specifies the key suffix for transaction records.
LocalTxnSpanGCThresholdSuffix is the suffix for the last txn span GC's threshold.
MaxKey is the infinity marker which is larger than any other key.
Meta1KeyMax is the end of the range of the first level of key addressing.
Meta1Prefix is the first level of key addressing.
Meta2KeyMax is the end of the range of the second level of key addressing.
Meta2Prefix is the second level of key addressing.
MetaMax is the end of the range of addressing keys.
MetaMin is the start of the range of addressing keys.
MetaSpan holds all the addressing records.
MigrationKeyMax is the maximum value for any system migration key.
MigrationLease is the key that nodes must take a lease on in order to run system migrations on the cluster.
MigrationPrefix specifies the key prefix to store all migration details.
MinKey is a minimum key value which sorts before all other keys.
NodeIDGenerator is the global node ID generator sequence.
NodeLivenessKeyMax is the maximum value for any node liveness key.
NodeLivenessPrefix specifies the key prefix for the node liveness table.
NodeLivenessSpan holds the liveness records for nodes in the cluster.
NoSplitSpans describes the ranges that should never be split.
PrettyPrintTimeseriesKey is a hook for pretty printing a timeseries key.
RangeIDGenerator is the global range ID generator sequence.
StatusNodePrefix stores all status info for nodes.
StatusPrefix specifies the key prefix to store all status details.
StoreIDGenerator is the global store ID generator sequence.
SystemConfigSpan is the range of system objects which will be gossiped.
SystemConfigSplitKey is the key to split at immediately prior to the system config span.
SystemConfigTableDataMax is the end key of system config span.
Constants for system-reserved keys in the KV map.
SystemPrefix indicates the beginning of the key range for global, system data which are replicated across the cluster.
TableDataMin is the end of the range of table data keys.
TableDataMin is the start of the range of table data keys.
TimeseriesPrefix is the key prefix for all timeseries data.
UserTableDataMin is the start key of user structured data.
# Structs
InvalidRangeMetaKeyError indicates that a Range Metadata key is somehow invalid.
# Type aliases
RangeIDPrefixBuf provides methods for generating range ID local keys while avoiding an allocation on every key generated.