roachpb

package
v1.0.5 Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: Aug 17, 2017 License: Apache-2.0 Imports: 32 Imported by: 0

Documentation

Overview

Package roachpb is a generated protocol buffer package.

It is generated from these files:

cockroach/pkg/roachpb/api.proto
cockroach/pkg/roachpb/app_stats.proto
cockroach/pkg/roachpb/data.proto
cockroach/pkg/roachpb/errors.proto
cockroach/pkg/roachpb/internal.proto
cockroach/pkg/roachpb/internal_raft.proto
cockroach/pkg/roachpb/metadata.proto

It has these top-level messages:

RangeInfo
ResponseHeader
GetRequest
GetResponse
PutRequest
PutResponse
ConditionalPutRequest
ConditionalPutResponse
InitPutRequest
InitPutResponse
IncrementRequest
IncrementResponse
DeleteRequest
DeleteResponse
DeleteRangeRequest
DeleteRangeResponse
ScanRequest
ScanResponse
ReverseScanRequest
ReverseScanResponse
CheckConsistencyRequest
CheckConsistencyResponse
BeginTransactionRequest
BeginTransactionResponse
EndTransactionRequest
EndTransactionResponse
AdminSplitRequest
AdminSplitResponse
AdminMergeRequest
AdminMergeResponse
AdminTransferLeaseRequest
AdminTransferLeaseResponse
AdminChangeReplicasRequest
AdminChangeReplicasResponse
RangeLookupRequest
RangeLookupResponse
HeartbeatTxnRequest
HeartbeatTxnResponse
GCRequest
GCResponse
PushTxnRequest
PushTxnResponse
QueryTxnRequest
QueryTxnResponse
ResolveIntentRequest
ResolveIntentResponse
ResolveIntentRangeRequest
NoopResponse
NoopRequest
ResolveIntentRangeResponse
MergeRequest
MergeResponse
TruncateLogRequest
TruncateLogResponse
RequestLeaseRequest
TransferLeaseRequest
LeaseInfoRequest
LeaseInfoResponse
RequestLeaseResponse
ComputeChecksumRequest
ComputeChecksumResponse
DeprecatedVerifyChecksumRequest
DeprecatedVerifyChecksumResponse
ExportStorage
WriteBatchRequest
WriteBatchResponse
ExportRequest
ExportResponse
ImportRequest
ImportResponse
AdminScatterRequest
AdminScatterResponse
RequestUnion
ResponseUnion
Header
BatchRequest
BatchResponse
StatementStatistics
NumericStat
Span
Value
KeyValue
StoreIdent
SplitTrigger
MergeTrigger
ChangeReplicasTrigger
ModifiedSpanTrigger
InternalCommitTrigger
ObservedTimestamp
Transaction
Intent
Lease
AbortCacheEntry
NotLeaseHolderError
NodeUnavailableError
RangeNotFoundError
RangeKeyMismatchError
ReadWithinUncertaintyIntervalError
TransactionAbortedError
TransactionPushError
TransactionRetryError
TransactionReplayError
TransactionStatusError
WriteIntentError
WriteTooOldError
OpRequiresTxnError
ConditionFailedError
LeaseRejectedError
SendError
AmbiguousResultError
RaftGroupDeletedError
ReplicaCorruptionError
ReplicaTooOldError
StoreNotFoundError
ErrorDetail
ErrPosition
Error
UnhandledRetryableError
HandledRetryableTxnError
InternalTimeSeriesData
InternalTimeSeriesSample
RaftTruncatedState
RaftTombstone
RaftSnapshotData
Attributes
ReplicationTarget
ReplicaDescriptor
ReplicaIdent
RangeDescriptor
StoreCapacity
NodeDescriptor
StoreDescriptor
StoreDeadReplicas
Locality
Tier

Index

Constants

View Source
const (
	// MinUserPriority is the minimum allowed user priority.
	MinUserPriority = 0.001
	// UnspecifiedUserPriority means NormalUserPriority.
	UnspecifiedUserPriority = 0
	// NormalUserPriority is set to 1, meaning ops run through the database
	// are all given equal weight when a random priority is chosen. This can
	// be set specifically via client.NewDBWithPriority().
	NormalUserPriority = 1
	// MaxUserPriority is the maximum allowed user priority.
	MaxUserPriority = 1000
)
View Source
const (
	// MinTxnPriority is the minimum allowed txn priority.
	MinTxnPriority = 0
	// MaxTxnPriority is the maximum allowed txn priority.
	MaxTxnPriority = math.MaxInt32
)

Variables

View Source
var (
	ErrInvalidLengthApi = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowApi   = fmt.Errorf("proto: integer overflow")
)
View Source
var (
	ErrInvalidLengthAppStats = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowAppStats   = fmt.Errorf("proto: integer overflow")
)
View Source
var (
	// RKeyMin is a minimum key value which sorts before all other keys.
	RKeyMin = RKey("")
	// KeyMin is a minimum key value which sorts before all other keys.
	KeyMin = Key(RKeyMin)
	// RKeyMax is a maximum key value which sorts after all other keys.
	RKeyMax = RKey{0xff, 0xff}
	// KeyMax is a maximum key value which sorts after all other keys.
	KeyMax = Key(RKeyMax)

	// PrettyPrintKey prints a key in human readable format. It's
	// implemented in package git.com/cockroachdb/cockroach/keys to avoid
	// package circle import.
	PrettyPrintKey func(key Key) string

	// PrettyPrintRange prints a key range in human readable format. It's
	// implemented in package git.com/cockroachdb/cockroach/keys to avoid
	// package circle import.
	PrettyPrintRange func(start, end Key, maxChars int) string
)
View Source
var (
	ErrInvalidLengthData = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowData   = fmt.Errorf("proto: integer overflow")
)
View Source
var (
	ErrInvalidLengthErrors = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowErrors   = fmt.Errorf("proto: integer overflow")
)
View Source
var (
	ErrInvalidLengthInternal = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowInternal   = fmt.Errorf("proto: integer overflow")
)
View Source
var (
	ErrInvalidLengthInternalRaft = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowInternalRaft   = fmt.Errorf("proto: integer overflow")
)
View Source
var (
	ErrInvalidLengthMetadata = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowMetadata   = fmt.Errorf("proto: integer overflow")
)
View Source
var ExportStorageProvider_name = map[int32]string{
	0: "Unknown",
	1: "LocalFile",
	2: "Http",
	3: "S3",
	4: "GoogleCloud",
	5: "Azure",
}
View Source
var ExportStorageProvider_value = map[string]int32{
	"Unknown":     0,
	"LocalFile":   1,
	"Http":        2,
	"S3":          3,
	"GoogleCloud": 4,
	"Azure":       5,
}
View Source
var PushTxnType_name = map[int32]string{
	0: "PUSH_TIMESTAMP",
	1: "PUSH_ABORT",
	2: "PUSH_TOUCH",
	3: "PUSH_QUERY",
}
View Source
var PushTxnType_value = map[string]int32{
	"PUSH_TIMESTAMP": 0,
	"PUSH_ABORT":     1,
	"PUSH_TOUCH":     2,
	"PUSH_QUERY":     3,
}
View Source
var ReadConsistencyType_name = map[int32]string{
	0: "CONSISTENT",
	1: "CONSENSUS",
	2: "INCONSISTENT",
}
View Source
var ReadConsistencyType_value = map[string]int32{
	"CONSISTENT":   0,
	"CONSENSUS":    1,
	"INCONSISTENT": 2,
}
View Source
var ReplicaChangeType_name = map[int32]string{
	0: "ADD_REPLICA",
	1: "REMOVE_REPLICA",
}
View Source
var ReplicaChangeType_value = map[string]int32{
	"ADD_REPLICA":    0,
	"REMOVE_REPLICA": 1,
}
View Source
var TransactionRestart_name = map[int32]string{
	0: "NONE",
	1: "BACKOFF",
	2: "IMMEDIATE",
}
View Source
var TransactionRestart_value = map[string]int32{
	"NONE":      0,
	"BACKOFF":   1,
	"IMMEDIATE": 2,
}
View Source
var TransactionRetryReason_name = map[int32]string{
	0: "RETRY_REASON_UNKNOWN",
	1: "RETRY_WRITE_TOO_OLD",
	2: "RETRY_DELETE_RANGE",
	3: "RETRY_SERIALIZABLE",
	4: "RETRY_POSSIBLE_REPLAY",
}
View Source
var TransactionRetryReason_value = map[string]int32{
	"RETRY_REASON_UNKNOWN":  0,
	"RETRY_WRITE_TOO_OLD":   1,
	"RETRY_DELETE_RANGE":    2,
	"RETRY_SERIALIZABLE":    3,
	"RETRY_POSSIBLE_REPLAY": 4,
}
View Source
var TransactionStatus_name = map[int32]string{
	0: "PENDING",
	1: "COMMITTED",
	2: "ABORTED",
}
View Source
var TransactionStatus_value = map[string]int32{
	"PENDING":   0,
	"COMMITTED": 1,
	"ABORTED":   2,
}
View Source
var ValueType_name = map[int32]string{
	0:   "UNKNOWN",
	7:   "NULL",
	1:   "INT",
	2:   "FLOAT",
	3:   "BYTES",
	8:   "DELIMITED_BYTES",
	4:   "TIME",
	5:   "DECIMAL",
	9:   "DELIMITED_DECIMAL",
	6:   "DURATION",
	10:  "TUPLE",
	100: "TIMESERIES",
}
View Source
var ValueType_value = map[string]int32{
	"UNKNOWN":           0,
	"NULL":              7,
	"INT":               1,
	"FLOAT":             2,
	"BYTES":             3,
	"DELIMITED_BYTES":   8,
	"TIME":              4,
	"DECIMAL":           5,
	"DELIMITED_DECIMAL": 9,
	"DURATION":          6,
	"TUPLE":             10,
	"TIMESERIES":        100,
}

Functions

func BytesNext

func BytesNext(b []byte) []byte

BytesNext returns the next possible byte slice, using the extra capacity of the provided slice if possible, and if not, appending an \x00.

func ConsultsTimestampCache

func ConsultsTimestampCache(args Request) bool

ConsultsTimestampCache returns whether the command must consult the timestamp cache to determine whether a mutation is safe at a proposed timestamp or needs to move to a higher timestamp to avoid re-writing history.

func ErrorUnexpectedlySet

func ErrorUnexpectedlySet(culprit, response interface{}) string

ErrorUnexpectedlySet creates a string to panic with when a response (typically a roachpb.BatchResponse) unexpectedly has Error set in its response header.

func IsRange

func IsRange(args Request) bool

IsRange returns true if the command is range-based and must include a start and an end key.

func IsReadOnly

func IsReadOnly(args Request) bool

IsReadOnly returns true iff the request is read-only.

func IsTransactionWrite

func IsTransactionWrite(args Request) bool

IsTransactionWrite returns true if the request produces write intents when used within a transaction.

func MakePriority

func MakePriority(userPriority UserPriority) int32

MakePriority generates a random priority value, biased by the specified userPriority. If userPriority=100, the random priority will be 100x more likely to be greater than if userPriority=1. If userPriority = 0.1, the random priority will be 1/10th as likely to be greater than if userPriority=NormalUserPriority ( = 1). Balance is achieved when userPriority=NormalUserPriority, in which case the priority chosen is unbiased.

If userPriority is less than or equal to MinUserPriority, returns MinTxnPriority; if greater than or equal to MaxUserPriority, returns MaxTxnPriority. If userPriority is 0, returns NormalUserPriority.

func RegisterExternalServer

func RegisterExternalServer(s *grpc.Server, srv ExternalServer)

func RegisterInternalServer

func RegisterInternalServer(s *grpc.Server, srv InternalServer)

func TxnIDEqual

func TxnIDEqual(a, b *uuid.UUID) bool

TxnIDEqual returns whether the transaction IDs are equal.

func UpdatesTimestampCache

func UpdatesTimestampCache(args Request) bool

UpdatesTimestampCache returns whether the command must update the timestamp cache in order to set a low water mark for the timestamp at which mutations to overlapping key(s) can write such that they don't re-write history.

Types

type AbortCacheEntry

type AbortCacheEntry struct {
	// The key of the associated transaction.
	Key Key `protobuf:"bytes,1,opt,name=key,casttype=Key" json:"key,omitempty"`
	// The candidate commit timestamp the transaction record held at the time
	// it was aborted.
	Timestamp cockroach_util_hlc.Timestamp `protobuf:"bytes,2,opt,name=timestamp" json:"timestamp"`
	// The priority of the transaction.
	Priority int32 `protobuf:"varint,3,opt,name=priority" json:"priority"`
}

AbortCacheEntry contains information about a transaction which has been aborted. It's written to a range's abort cache if the range may have contained intents of the aborted txn. In the event that the same transaction attempts to read keys it may have written previously, this entry informs the transaction that it has aborted and must start fresh with an updated priority.

func NewPopulatedAbortCacheEntry

func NewPopulatedAbortCacheEntry(r randyData, easy bool) *AbortCacheEntry

func (*AbortCacheEntry) Descriptor

func (*AbortCacheEntry) Descriptor() ([]byte, []int)

func (*AbortCacheEntry) Marshal

func (m *AbortCacheEntry) Marshal() (dAtA []byte, err error)

func (*AbortCacheEntry) MarshalTo

func (m *AbortCacheEntry) MarshalTo(dAtA []byte) (int, error)

func (*AbortCacheEntry) ProtoMessage

func (*AbortCacheEntry) ProtoMessage()

func (*AbortCacheEntry) Reset

func (m *AbortCacheEntry) Reset()

func (*AbortCacheEntry) Size

func (m *AbortCacheEntry) Size() (n int)

func (*AbortCacheEntry) String

func (m *AbortCacheEntry) String() string

func (*AbortCacheEntry) Unmarshal

func (m *AbortCacheEntry) Unmarshal(dAtA []byte) error

type AdminChangeReplicasRequest

type AdminChangeReplicasRequest struct {
	Span       `protobuf:"bytes,1,opt,name=header,embedded=header" json:"header"`
	ChangeType ReplicaChangeType   `protobuf:"varint,2,opt,name=change_type,json=changeType,enum=cockroach.roachpb.ReplicaChangeType" json:"change_type"`
	Targets    []ReplicationTarget `protobuf:"bytes,3,rep,name=targets" json:"targets"`
}

An AdminChangeReplicasRequest is the argument to the AdminChangeReplicas() method. A change replicas operation allows adding or removing a set of replicas for a range.

func (*AdminChangeReplicasRequest) Descriptor

func (*AdminChangeReplicasRequest) Descriptor() ([]byte, []int)

func (*AdminChangeReplicasRequest) Marshal

func (m *AdminChangeReplicasRequest) Marshal() (dAtA []byte, err error)

func (*AdminChangeReplicasRequest) MarshalTo

func (m *AdminChangeReplicasRequest) MarshalTo(dAtA []byte) (int, error)

func (*AdminChangeReplicasRequest) Method

Method implements the Request interface.

func (*AdminChangeReplicasRequest) ProtoMessage

func (*AdminChangeReplicasRequest) ProtoMessage()

func (*AdminChangeReplicasRequest) Reset

func (m *AdminChangeReplicasRequest) Reset()

func (*AdminChangeReplicasRequest) ShallowCopy

func (acrr *AdminChangeReplicasRequest) ShallowCopy() Request

ShallowCopy implements the Request interface.

func (*AdminChangeReplicasRequest) Size

func (m *AdminChangeReplicasRequest) Size() (n int)

func (*AdminChangeReplicasRequest) String

func (m *AdminChangeReplicasRequest) String() string

func (*AdminChangeReplicasRequest) Unmarshal

func (m *AdminChangeReplicasRequest) Unmarshal(dAtA []byte) error

type AdminChangeReplicasResponse

type AdminChangeReplicasResponse struct {
	ResponseHeader `protobuf:"bytes,1,opt,name=header,embedded=header" json:"header"`
}

func (*AdminChangeReplicasResponse) Descriptor

func (*AdminChangeReplicasResponse) Descriptor() ([]byte, []int)

func (*AdminChangeReplicasResponse) Marshal

func (m *AdminChangeReplicasResponse) Marshal() (dAtA []byte, err error)

func (*AdminChangeReplicasResponse) MarshalTo

func (m *AdminChangeReplicasResponse) MarshalTo(dAtA []byte) (int, error)

func (*AdminChangeReplicasResponse) ProtoMessage

func (*AdminChangeReplicasResponse) ProtoMessage()

func (*AdminChangeReplicasResponse) Reset

func (m *AdminChangeReplicasResponse) Reset()

func (*AdminChangeReplicasResponse) Size

func (m *AdminChangeReplicasResponse) Size() (n int)

func (*AdminChangeReplicasResponse) String

func (m *AdminChangeReplicasResponse) String() string

func (*AdminChangeReplicasResponse) Unmarshal

func (m *AdminChangeReplicasResponse) Unmarshal(dAtA []byte) error

type AdminMergeRequest

type AdminMergeRequest struct {
	Span `protobuf:"bytes,1,opt,name=header,embedded=header" json:"header"`
}

An AdminMergeRequest is the argument to the AdminMerge() method. A merge is performed by calling AdminMerge on the left-hand range of two consecutive ranges (i.e. the range which contains keys which sort first). This range will be the subsuming range and the right hand range will be subsumed. After the merge operation, the subsumed range will no longer exist and the subsuming range will now encompass all keys from its original start key to the end key of the subsumed range. If AdminMerge is called on the final range in the key space, it is a noop.

func (*AdminMergeRequest) Descriptor

func (*AdminMergeRequest) Descriptor() ([]byte, []int)

func (*AdminMergeRequest) Marshal

func (m *AdminMergeRequest) Marshal() (dAtA []byte, err error)

func (*AdminMergeRequest) MarshalTo

func (m *AdminMergeRequest) MarshalTo(dAtA []byte) (int, error)

func (*AdminMergeRequest) Method

func (*AdminMergeRequest) Method() Method

Method implements the Request interface.

func (*AdminMergeRequest) ProtoMessage

func (*AdminMergeRequest) ProtoMessage()

func (*AdminMergeRequest) Reset

func (m *AdminMergeRequest) Reset()

func (*AdminMergeRequest) ShallowCopy

func (amr *AdminMergeRequest) ShallowCopy() Request

ShallowCopy implements the Request interface.

func (*AdminMergeRequest) Size

func (m *AdminMergeRequest) Size() (n int)

func (*AdminMergeRequest) String

func (m *AdminMergeRequest) String() string

func (*AdminMergeRequest) Unmarshal

func (m *AdminMergeRequest) Unmarshal(dAtA []byte) error

type AdminMergeResponse

type AdminMergeResponse struct {
	ResponseHeader `protobuf:"bytes,1,opt,name=header,embedded=header" json:"header"`
}

An AdminMergeResponse is the return value from the AdminMerge() method.

func (*AdminMergeResponse) Descriptor

func (*AdminMergeResponse) Descriptor() ([]byte, []int)

func (*AdminMergeResponse) Marshal

func (m *AdminMergeResponse) Marshal() (dAtA []byte, err error)

func (*AdminMergeResponse) MarshalTo

func (m *AdminMergeResponse) MarshalTo(dAtA []byte) (int, error)

func (*AdminMergeResponse) ProtoMessage

func (*AdminMergeResponse) ProtoMessage()

func (*AdminMergeResponse) Reset

func (m *AdminMergeResponse) Reset()

func (*AdminMergeResponse) Size

func (m *AdminMergeResponse) Size() (n int)

func (*AdminMergeResponse) String

func (m *AdminMergeResponse) String() string

func (*AdminMergeResponse) Unmarshal

func (m *AdminMergeResponse) Unmarshal(dAtA []byte) error

type AdminScatterRequest

type AdminScatterRequest struct {
	Span `protobuf:"bytes,1,opt,name=header,embedded=header" json:"header"`
}

AdminScatterRequest is the argument to the AdminScatter() method, which moves replicas and leaseholders for a selection of ranges. Scatter is best-effort; ranges that cannot be moved will include an error detail in the response and won't fail the request.

func (*AdminScatterRequest) Descriptor

func (*AdminScatterRequest) Descriptor() ([]byte, []int)

func (*AdminScatterRequest) Marshal

func (m *AdminScatterRequest) Marshal() (dAtA []byte, err error)

func (*AdminScatterRequest) MarshalTo

func (m *AdminScatterRequest) MarshalTo(dAtA []byte) (int, error)

func (*AdminScatterRequest) Method

func (*AdminScatterRequest) Method() Method

Method implements the Request interface.

func (*AdminScatterRequest) ProtoMessage

func (*AdminScatterRequest) ProtoMessage()

func (*AdminScatterRequest) Reset

func (m *AdminScatterRequest) Reset()

func (*AdminScatterRequest) ShallowCopy

func (r *AdminScatterRequest) ShallowCopy() Request

ShallowCopy implements the Request interface.

func (*AdminScatterRequest) Size

func (m *AdminScatterRequest) Size() (n int)

func (*AdminScatterRequest) String

func (m *AdminScatterRequest) String() string

func (*AdminScatterRequest) Unmarshal

func (m *AdminScatterRequest) Unmarshal(dAtA []byte) error

type AdminScatterResponse

type AdminScatterResponse struct {
	ResponseHeader `protobuf:"bytes,1,opt,name=header,embedded=header" json:"header"`
	Ranges         []AdminScatterResponse_Range `protobuf:"bytes,2,rep,name=ranges" json:"ranges"`
}

ScatterResponse is the response to a Scatter() operation.

func (*AdminScatterResponse) Descriptor

func (*AdminScatterResponse) Descriptor() ([]byte, []int)

func (*AdminScatterResponse) Marshal

func (m *AdminScatterResponse) Marshal() (dAtA []byte, err error)

func (*AdminScatterResponse) MarshalTo

func (m *AdminScatterResponse) MarshalTo(dAtA []byte) (int, error)

func (*AdminScatterResponse) ProtoMessage

func (*AdminScatterResponse) ProtoMessage()

func (*AdminScatterResponse) Reset

func (m *AdminScatterResponse) Reset()

func (*AdminScatterResponse) Size

func (m *AdminScatterResponse) Size() (n int)

func (*AdminScatterResponse) String

func (m *AdminScatterResponse) String() string

func (*AdminScatterResponse) Unmarshal

func (m *AdminScatterResponse) Unmarshal(dAtA []byte) error

type AdminScatterResponse_Range

type AdminScatterResponse_Range struct {
	Span Span `protobuf:"bytes,1,opt,name=span" json:"span"`
	// Error will be nil if this range was successfully scattered.
	Error *Error `protobuf:"bytes,2,opt,name=error" json:"error,omitempty"`
}

func (*AdminScatterResponse_Range) Descriptor

func (*AdminScatterResponse_Range) Descriptor() ([]byte, []int)

func (*AdminScatterResponse_Range) Marshal

func (m *AdminScatterResponse_Range) Marshal() (dAtA []byte, err error)

func (*AdminScatterResponse_Range) MarshalTo

func (m *AdminScatterResponse_Range) MarshalTo(dAtA []byte) (int, error)

func (*AdminScatterResponse_Range) ProtoMessage

func (*AdminScatterResponse_Range) ProtoMessage()

func (*AdminScatterResponse_Range) Reset

func (m *AdminScatterResponse_Range) Reset()

func (*AdminScatterResponse_Range) Size

func (m *AdminScatterResponse_Range) Size() (n int)

func (*AdminScatterResponse_Range) String

func (m *AdminScatterResponse_Range) String() string

func (*AdminScatterResponse_Range) Unmarshal

func (m *AdminScatterResponse_Range) Unmarshal(dAtA []byte) error

type AdminSplitRequest

type AdminSplitRequest struct {
	Span     `protobuf:"bytes,1,opt,name=header,embedded=header" json:"header"`
	SplitKey Key `protobuf:"bytes,2,opt,name=split_key,json=splitKey,casttype=Key" json:"split_key,omitempty"`
}

An AdminSplitRequest is the argument to the AdminSplit() method. The existing range which contains header.key is split by split_key. If split_key is not specified, then this method will determine a split key that is roughly halfway through the range. The existing range is resized to cover only its start key to the split key. The new range created by the split starts at the split key and extends to the original range's end key. If split_key is known, header.key should also be set to split_key.

New range IDs for each of the split range's replica and a new Raft ID are generated by the operation. Split requests are done in the context of a distributed transaction which updates range addressing records, range metadata and finally, provides a commit trigger to update bookkeeping and instantiate the new range on commit.

The new range contains range replicas located on the same stores; no range data is moved during this operation. The split can be thought of as a mostly logical operation, though some other metadata (e.g. sequence cache and range stats must be copied or recomputed).

func (*AdminSplitRequest) Descriptor

func (*AdminSplitRequest) Descriptor() ([]byte, []int)

func (*AdminSplitRequest) Marshal

func (m *AdminSplitRequest) Marshal() (dAtA []byte, err error)

func (*AdminSplitRequest) MarshalTo

func (m *AdminSplitRequest) MarshalTo(dAtA []byte) (int, error)

func (*AdminSplitRequest) Method

func (*AdminSplitRequest) Method() Method

Method implements the Request interface.

func (*AdminSplitRequest) ProtoMessage

func (*AdminSplitRequest) ProtoMessage()

func (*AdminSplitRequest) Reset

func (m *AdminSplitRequest) Reset()

func (*AdminSplitRequest) ShallowCopy

func (asr *AdminSplitRequest) ShallowCopy() Request

ShallowCopy implements the Request interface.

func (*AdminSplitRequest) Size

func (m *AdminSplitRequest) Size() (n int)

func (*AdminSplitRequest) String

func (m *AdminSplitRequest) String() string

func (*AdminSplitRequest) Unmarshal

func (m *AdminSplitRequest) Unmarshal(dAtA []byte) error

type AdminSplitResponse

type AdminSplitResponse struct {
	ResponseHeader `protobuf:"bytes,1,opt,name=header,embedded=header" json:"header"`
}

An AdminSplitResponse is the return value from the AdminSplit() method.

func (*AdminSplitResponse) Descriptor

func (*AdminSplitResponse) Descriptor() ([]byte, []int)

func (*AdminSplitResponse) Marshal

func (m *AdminSplitResponse) Marshal() (dAtA []byte, err error)

func (*AdminSplitResponse) MarshalTo

func (m *AdminSplitResponse) MarshalTo(dAtA []byte) (int, error)

func (*AdminSplitResponse) ProtoMessage

func (*AdminSplitResponse) ProtoMessage()

func (*AdminSplitResponse) Reset

func (m *AdminSplitResponse) Reset()

func (*AdminSplitResponse) Size

func (m *AdminSplitResponse) Size() (n int)

func (*AdminSplitResponse) String

func (m *AdminSplitResponse) String() string

func (*AdminSplitResponse) Unmarshal

func (m *AdminSplitResponse) Unmarshal(dAtA []byte) error

type AdminTransferLeaseRequest

type AdminTransferLeaseRequest struct {
	Span   `protobuf:"bytes,1,opt,name=header,embedded=header" json:"header"`
	Target StoreID `protobuf:"varint,2,opt,name=target,casttype=StoreID" json:"target"`
}

An AdminTransferLeaseRequest is the argument to the AdminTransferLease() method. A lease transfer allows an external entity to control the lease holder for a range. The target of the lease transfer needs to be a valid replica of the range.

func (*AdminTransferLeaseRequest) Descriptor

func (*AdminTransferLeaseRequest) Descriptor() ([]byte, []int)

func (*AdminTransferLeaseRequest) Marshal

func (m *AdminTransferLeaseRequest) Marshal() (dAtA []byte, err error)

func (*AdminTransferLeaseRequest) MarshalTo

func (m *AdminTransferLeaseRequest) MarshalTo(dAtA []byte) (int, error)

func (*AdminTransferLeaseRequest) Method

Method implements the Request interface.

func (*AdminTransferLeaseRequest) ProtoMessage

func (*AdminTransferLeaseRequest) ProtoMessage()

func (*AdminTransferLeaseRequest) Reset

func (m *AdminTransferLeaseRequest) Reset()

func (*AdminTransferLeaseRequest) ShallowCopy

func (atlr *AdminTransferLeaseRequest) ShallowCopy() Request

ShallowCopy implements the Request interface.

func (*AdminTransferLeaseRequest) Size

func (m *AdminTransferLeaseRequest) Size() (n int)

func (*AdminTransferLeaseRequest) String

func (m *AdminTransferLeaseRequest) String() string

func (*AdminTransferLeaseRequest) Unmarshal

func (m *AdminTransferLeaseRequest) Unmarshal(dAtA []byte) error

type AdminTransferLeaseResponse

type AdminTransferLeaseResponse struct {
	ResponseHeader `protobuf:"bytes,1,opt,name=header,embedded=header" json:"header"`
}

func (*AdminTransferLeaseResponse) Descriptor

func (*AdminTransferLeaseResponse) Descriptor() ([]byte, []int)

func (*AdminTransferLeaseResponse) Marshal

func (m *AdminTransferLeaseResponse) Marshal() (dAtA []byte, err error)

func (*AdminTransferLeaseResponse) MarshalTo

func (m *AdminTransferLeaseResponse) MarshalTo(dAtA []byte) (int, error)

func (*AdminTransferLeaseResponse) ProtoMessage

func (*AdminTransferLeaseResponse) ProtoMessage()

func (*AdminTransferLeaseResponse) Reset

func (m *AdminTransferLeaseResponse) Reset()

func (*AdminTransferLeaseResponse) Size

func (m *AdminTransferLeaseResponse) Size() (n int)

func (*AdminTransferLeaseResponse) String

func (m *AdminTransferLeaseResponse) String() string

func (*AdminTransferLeaseResponse) Unmarshal

func (m *AdminTransferLeaseResponse) Unmarshal(dAtA []byte) error

type AmbiguousResultError

type AmbiguousResultError struct {
	Message string `protobuf:"bytes,1,opt,name=message" json:"message"`
	// This can be set to give extra information about which error was converted
	// into an AmbiguousResultError. Useful for tests.
	WrappedErr *Error `protobuf:"bytes,2,opt,name=wrapped_err,json=wrappedErr" json:"wrapped_err,omitempty"`
}

An AmbiguousResultError indicates that a request may have succeeded or failed, but the response was not received and the final result is ambiguous.

func NewAmbiguousResultError

func NewAmbiguousResultError(msg string) *AmbiguousResultError

NewAmbiguousResultError initializes a new AmbiguousResultError with an explanatory message.

func (*AmbiguousResultError) Descriptor

func (*AmbiguousResultError) Descriptor() ([]byte, []int)

func (*AmbiguousResultError) Error

func (e *AmbiguousResultError) Error() string

func (*AmbiguousResultError) Marshal

func (m *AmbiguousResultError) Marshal() (dAtA []byte, err error)

func (*AmbiguousResultError) MarshalTo

func (m *AmbiguousResultError) MarshalTo(dAtA []byte) (int, error)

func (*AmbiguousResultError) ProtoMessage

func (*AmbiguousResultError) ProtoMessage()

func (*AmbiguousResultError) Reset

func (m *AmbiguousResultError) Reset()

func (*AmbiguousResultError) Size

func (m *AmbiguousResultError) Size() (n int)

func (*AmbiguousResultError) String

func (m *AmbiguousResultError) String() string

func (*AmbiguousResultError) Unmarshal

func (m *AmbiguousResultError) Unmarshal(dAtA []byte) error

type Attributes

type Attributes struct {
	Attrs []string `protobuf:"bytes,1,rep,name=attrs" json:"attrs,omitempty" yaml:"attrs,flow"`
}

Attributes specifies a list of arbitrary strings describing node topology, store type, and machine capabilities.

func (*Attributes) Descriptor

func (*Attributes) Descriptor() ([]byte, []int)

func (Attributes) IsSubset

func (a Attributes) IsSubset(b Attributes) bool

IsSubset returns whether attributes list a is a subset of attributes list b.

func (*Attributes) Marshal

func (m *Attributes) Marshal() (dAtA []byte, err error)

func (*Attributes) MarshalTo

func (m *Attributes) MarshalTo(dAtA []byte) (int, error)

func (*Attributes) ProtoMessage

func (*Attributes) ProtoMessage()

func (*Attributes) Reset

func (m *Attributes) Reset()

func (*Attributes) Size

func (m *Attributes) Size() (n int)

func (Attributes) SortedString

func (a Attributes) SortedString() string

SortedString returns a sorted, de-duplicated, comma-separated list of the attributes.

func (Attributes) String

func (a Attributes) String() string

func (*Attributes) Unmarshal

func (m *Attributes) Unmarshal(dAtA []byte) error

type BatchRequest

type BatchRequest struct {
	Header   `protobuf:"bytes,1,opt,name=header,embedded=header" json:"header"`
	Requests []RequestUnion `protobuf:"bytes,2,rep,name=requests" json:"requests"`
}

A BatchRequest contains one or more requests to be executed in parallel, or if applicable (based on write-only commands and range-locality), as a single update.

func (*BatchRequest) Add

func (ba *BatchRequest) Add(requests ...Request)

Add adds a request to the batch request. It's a convenience method; requests may also be added directly into the slice.

func (*BatchRequest) CreateReply

func (ba *BatchRequest) CreateReply() *BatchResponse

CreateReply creates replies for each of the contained requests, wrapped in a BatchResponse. The response objects are batch allocated to minimize allocation overhead.

func (*BatchRequest) Descriptor

func (*BatchRequest) Descriptor() ([]byte, []int)

func (*BatchRequest) GetArg

func (ba *BatchRequest) GetArg(method Method) (Request, bool)

GetArg returns a request of the given type if one is contained in the Batch. The request returned is the first of its kind, with the exception of EndTransaction, where it examines the very last request only.

func (*BatchRequest) GetPrevLeaseForLeaseRequest

func (ba *BatchRequest) GetPrevLeaseForLeaseRequest() *Lease

GetPrevLeaseForLeaseRequest returns the previous lease, at the time of proposal, for a request lease or transfer lease request. If the batch does not contain a single lease request, this method will panic.

func (*BatchRequest) GetUser

func (*BatchRequest) GetUser() string

GetUser implements security.RequestWithUser. KV messages are always sent by the node user.

func (*BatchRequest) IntentSpanIterate

func (ba *BatchRequest) IntentSpanIterate(br *BatchResponse, fn func(key, endKey Key))

IntentSpanIterate calls the passed method with the key ranges of the transactional writes contained in the batch. Usually the key spans contained in the requests are used, but when a response contains a ResumeSpan the ResumeSpan is subtracted from the request span to provide a more minimal span of keys affected by the request.

func (*BatchRequest) IsAdmin

func (ba *BatchRequest) IsAdmin() bool

IsAdmin returns true iff the BatchRequest contains an admin request.

func (*BatchRequest) IsLeaseRequest

func (ba *BatchRequest) IsLeaseRequest() bool

IsLeaseRequest returns whether the batch consists of a single RequestLease request. Note that TransferLease requests return false. RequestLease requests are special because they're the only type of requests a non-lease-holder can propose.

func (*BatchRequest) IsPossibleTransaction

func (ba *BatchRequest) IsPossibleTransaction() bool

IsPossibleTransaction returns true iff the BatchRequest contains requests that can be part of a transaction.

func (*BatchRequest) IsReadOnly

func (ba *BatchRequest) IsReadOnly() bool

IsReadOnly returns true if all requests within are read-only.

func (*BatchRequest) IsReverse

func (ba *BatchRequest) IsReverse() bool

IsReverse returns true iff the BatchRequest contains a reverse request.

func (*BatchRequest) IsSinglePushTxnRequest

func (ba *BatchRequest) IsSinglePushTxnRequest() bool

IsSinglePushTxnRequest returns true iff the batch contains a single request, and that request is for a PushTxn.

func (*BatchRequest) IsSingleRequest

func (ba *BatchRequest) IsSingleRequest() bool

IsSingleRequest returns true iff the BatchRequest contains a single request.

func (*BatchRequest) IsSingleSkipLeaseCheckRequest

func (ba *BatchRequest) IsSingleSkipLeaseCheckRequest() bool

IsSingleSkipLeaseCheckRequest returns true iff the batch contains a single request, and that request has the skipLeaseCheck flag set.

func (*BatchRequest) IsTransactionWrite

func (ba *BatchRequest) IsTransactionWrite() bool

IsTransactionWrite returns true iff the BatchRequest contains a txn write.

func (*BatchRequest) IsWrite

func (ba *BatchRequest) IsWrite() bool

IsWrite returns true iff the BatchRequest contains a write.

func (*BatchRequest) Marshal

func (m *BatchRequest) Marshal() (dAtA []byte, err error)

func (*BatchRequest) MarshalTo

func (m *BatchRequest) MarshalTo(dAtA []byte) (int, error)

func (*BatchRequest) Methods

func (ba *BatchRequest) Methods() []Method

Methods returns a slice of the contained methods.

func (*BatchRequest) ProtoMessage

func (*BatchRequest) ProtoMessage()

func (*BatchRequest) Reset

func (m *BatchRequest) Reset()

func (*BatchRequest) SetActiveTimestamp

func (ba *BatchRequest) SetActiveTimestamp(nowFn func() hlc.Timestamp) error

SetActiveTimestamp sets the correct timestamp at which the request is to be carried out. For transactional requests, ba.Timestamp must be zero initially and it will be set to txn.OrigTimestamp. For non-transactional requests, if no timestamp is specified, nowFn is used to create and set one.

func (*BatchRequest) SetNewRequest

func (ba *BatchRequest) SetNewRequest()

SetNewRequest increases the internal sequence counter of this batch request. The sequence counter is used for replay and reordering protection. At the Store, a sequence counter less than or equal to the last observed one incurs a transaction restart (if the request is transactional).

func (*BatchRequest) Size

func (m *BatchRequest) Size() (n int)

func (BatchRequest) Split

func (ba BatchRequest) Split(canSplitET bool) [][]RequestUnion

Split separates the requests contained in a batch so that each subset of requests can be executed by a Store (without changing order). In particular, Admin requests are always singled out and mutating requests separated from reads. The boolean parameter indicates whether EndTransaction should be special-cased: If false, an EndTransaction request will never be split into a new chunk (otherwise, it is treated according to its flags). This allows sending a whole transaction in a single Batch when addressing a single range.

func (BatchRequest) String

func (ba BatchRequest) String() string

String gives a brief summary of the contained requests and keys in the batch. TODO(tschottdorf): the key range is useful information, but requires `keys`. See #2198.

func (*BatchRequest) Summary

func (ba *BatchRequest) Summary() string

Summary prints a short summary of the requests in a batch.

func (*BatchRequest) Unmarshal

func (m *BatchRequest) Unmarshal(dAtA []byte) error

func (*BatchRequest) UpdateTxn

func (ba *BatchRequest) UpdateTxn(otherTxn *Transaction)

UpdateTxn updates the batch transaction from the supplied one in a copy-on-write fashion, i.e. without mutating an existing Transaction struct.

type BatchResponse

type BatchResponse struct {
	BatchResponse_Header `protobuf:"bytes,1,opt,name=header,embedded=header" json:"header"`
	Responses            []ResponseUnion `protobuf:"bytes,2,rep,name=responses" json:"responses"`
}

A BatchResponse contains one or more responses, one per request corresponding to the requests in the matching BatchRequest. The error in the response header is set to the first error from the slice of responses, if applicable.

func (*BatchResponse) Add

func (br *BatchResponse) Add(reply Response)

Add adds a response to the batch response. It's a convenience method; responses may also be added directly.

func (*BatchResponse) Combine

func (br *BatchResponse) Combine(otherBatch *BatchResponse) error

Combine implements the Combinable interface. It combines each slot of the given request into the corresponding slot of the base response. The number of slots must be equal and the respective slots must be combinable. On error, the receiver BatchResponse is in an invalid state. TODO(tschottdorf): write tests.

func (*BatchResponse) Descriptor

func (*BatchResponse) Descriptor() ([]byte, []int)

func (*BatchResponse) Marshal

func (m *BatchResponse) Marshal() (dAtA []byte, err error)

func (*BatchResponse) MarshalTo

func (m *BatchResponse) MarshalTo(dAtA []byte) (int, error)

func (*BatchResponse) ProtoMessage

func (*BatchResponse) ProtoMessage()

func (*BatchResponse) Reset

func (m *BatchResponse) Reset()

func (*BatchResponse) Size

func (m *BatchResponse) Size() (n int)

func (*BatchResponse) String

func (br *BatchResponse) String() string

func (*BatchResponse) Unmarshal

func (m *BatchResponse) Unmarshal(dAtA []byte) error

type BatchResponse_Header

type BatchResponse_Header struct {
	// error is non-nil if an error occurred.
	Error *Error `protobuf:"bytes,1,opt,name=error" json:"error,omitempty"`
	// timestamp is set only for non-transactional responses and denotes the
	// highest timestamp at which a command from the batch executed. At the
	// time of writing, it is used solely for informational purposes and tests.
	Timestamp cockroach_util_hlc.Timestamp `protobuf:"bytes,2,opt,name=Timestamp" json:"Timestamp"`
	// txn is non-nil if the request specified a non-nil
	// transaction. The transaction timestamp and/or priority may have
	// been updated, depending on the outcome of the request.
	Txn *Transaction `protobuf:"bytes,3,opt,name=txn" json:"txn,omitempty"`
	// collected_spans is a binary representation of the trace spans
	// generated during the execution of this request.
	CollectedSpans [][]byte `protobuf:"bytes,4,rep,name=collected_spans,json=collectedSpans" json:"collected_spans,omitempty"`
	// now is the current time at the node sending the response,
	// which can be used by the receiver to update its local HLC.
	Now cockroach_util_hlc.Timestamp `protobuf:"bytes,5,opt,name=now" json:"now"`
}

func (*BatchResponse_Header) Descriptor

func (*BatchResponse_Header) Descriptor() ([]byte, []int)

func (*BatchResponse_Header) Marshal

func (m *BatchResponse_Header) Marshal() (dAtA []byte, err error)

func (*BatchResponse_Header) MarshalTo

func (m *BatchResponse_Header) MarshalTo(dAtA []byte) (int, error)

func (*BatchResponse_Header) ProtoMessage

func (*BatchResponse_Header) ProtoMessage()

func (*BatchResponse_Header) Reset

func (m *BatchResponse_Header) Reset()

func (*BatchResponse_Header) Size

func (m *BatchResponse_Header) Size() (n int)

func (*BatchResponse_Header) String

func (m *BatchResponse_Header) String() string

func (*BatchResponse_Header) Unmarshal

func (m *BatchResponse_Header) Unmarshal(dAtA []byte) error

type BeginTransactionRequest

type BeginTransactionRequest struct {
	Span `protobuf:"bytes,1,opt,name=header,embedded=header" json:"header"`
}

A BeginTransactionRequest is the argument to the BeginTransaction() method.

func (*BeginTransactionRequest) Descriptor

func (*BeginTransactionRequest) Descriptor() ([]byte, []int)

func (*BeginTransactionRequest) Marshal

func (m *BeginTransactionRequest) Marshal() (dAtA []byte, err error)

func (*BeginTransactionRequest) MarshalTo

func (m *BeginTransactionRequest) MarshalTo(dAtA []byte) (int, error)

func (*BeginTransactionRequest) Method

func (*BeginTransactionRequest) Method() Method

Method implements the Request interface.

func (*BeginTransactionRequest) ProtoMessage

func (*BeginTransactionRequest) ProtoMessage()

func (*BeginTransactionRequest) Reset

func (m *BeginTransactionRequest) Reset()

func (*BeginTransactionRequest) ShallowCopy

func (btr *BeginTransactionRequest) ShallowCopy() Request

ShallowCopy implements the Request interface.

func (*BeginTransactionRequest) Size

func (m *BeginTransactionRequest) Size() (n int)

func (*BeginTransactionRequest) String

func (m *BeginTransactionRequest) String() string

func (*BeginTransactionRequest) Unmarshal

func (m *BeginTransactionRequest) Unmarshal(dAtA []byte) error

type BeginTransactionResponse

type BeginTransactionResponse struct {
	ResponseHeader `protobuf:"bytes,1,opt,name=header,embedded=header" json:"header"`
}

A BeginTransactionResponse is the return value from the BeginTransaction() method.

func (*BeginTransactionResponse) Descriptor

func (*BeginTransactionResponse) Descriptor() ([]byte, []int)

func (*BeginTransactionResponse) Marshal

func (m *BeginTransactionResponse) Marshal() (dAtA []byte, err error)

func (*BeginTransactionResponse) MarshalTo

func (m *BeginTransactionResponse) MarshalTo(dAtA []byte) (int, error)

func (*BeginTransactionResponse) ProtoMessage

func (*BeginTransactionResponse) ProtoMessage()

func (*BeginTransactionResponse) Reset

func (m *BeginTransactionResponse) Reset()

func (*BeginTransactionResponse) Size

func (m *BeginTransactionResponse) Size() (n int)

func (*BeginTransactionResponse) String

func (m *BeginTransactionResponse) String() string

func (*BeginTransactionResponse) Unmarshal

func (m *BeginTransactionResponse) Unmarshal(dAtA []byte) error

type ChangeReplicasTrigger

type ChangeReplicasTrigger struct {
	ChangeType ReplicaChangeType `protobuf:"varint,1,opt,name=change_type,json=changeType,enum=cockroach.roachpb.ReplicaChangeType" json:"change_type"`
	// The replica being modified.
	Replica ReplicaDescriptor `protobuf:"bytes,2,opt,name=replica" json:"replica"`
	// The new replica list with this change applied.
	UpdatedReplicas []ReplicaDescriptor `protobuf:"bytes,3,rep,name=updated_replicas,json=updatedReplicas" json:"updated_replicas"`
	NextReplicaID   ReplicaID           `protobuf:"varint,4,opt,name=next_replica_id,json=nextReplicaId,casttype=ReplicaID" json:"next_replica_id"`
}

func (*ChangeReplicasTrigger) Descriptor

func (*ChangeReplicasTrigger) Descriptor() ([]byte, []int)

func (*ChangeReplicasTrigger) Marshal

func (m *ChangeReplicasTrigger) Marshal() (dAtA []byte, err error)

func (*ChangeReplicasTrigger) MarshalTo

func (m *ChangeReplicasTrigger) MarshalTo(dAtA []byte) (int, error)

func (*ChangeReplicasTrigger) ProtoMessage

func (*ChangeReplicasTrigger) ProtoMessage()

func (*ChangeReplicasTrigger) Reset

func (m *ChangeReplicasTrigger) Reset()

func (*ChangeReplicasTrigger) Size

func (m *ChangeReplicasTrigger) Size() (n int)

func (*ChangeReplicasTrigger) String

func (m *ChangeReplicasTrigger) String() string

func (*ChangeReplicasTrigger) Unmarshal

func (m *ChangeReplicasTrigger) Unmarshal(dAtA []byte) error

type CheckConsistencyRequest

type CheckConsistencyRequest struct {
	Span `protobuf:"bytes,1,opt,name=header,embedded=header" json:"header"`
	// log a diff of inconsistencies if such inconsistencies are found.
	WithDiff bool `protobuf:"varint,2,opt,name=with_diff,json=withDiff" json:"with_diff"`
}

A CheckConsistencyRequest is the argument to the CheckConsistency() method. It specifies the start and end keys for a span of ranges to which a consistency check should be applied. A consistency check on a range involves running a ComputeChecksum on the range followed by a storage.CollectChecksum.

func (*CheckConsistencyRequest) Descriptor

func (*CheckConsistencyRequest) Descriptor() ([]byte, []int)

func (*CheckConsistencyRequest) Marshal

func (m *CheckConsistencyRequest) Marshal() (dAtA []byte, err error)

func (*CheckConsistencyRequest) MarshalTo

func (m *CheckConsistencyRequest) MarshalTo(dAtA []byte) (int, error)

func (*CheckConsistencyRequest) Method

func (*CheckConsistencyRequest) Method() Method

Method implements the Request interface.

func (*CheckConsistencyRequest) ProtoMessage

func (*CheckConsistencyRequest) ProtoMessage()

func (*CheckConsistencyRequest) Reset

func (m *CheckConsistencyRequest) Reset()

func (*CheckConsistencyRequest) ShallowCopy

func (ccr *CheckConsistencyRequest) ShallowCopy() Request

ShallowCopy implements the Request interface.

func (*CheckConsistencyRequest) Size

func (m *CheckConsistencyRequest) Size() (n int)

func (*CheckConsistencyRequest) String

func (m *CheckConsistencyRequest) String() string

func (*CheckConsistencyRequest) Unmarshal

func (m *CheckConsistencyRequest) Unmarshal(dAtA []byte) error

type CheckConsistencyResponse

type CheckConsistencyResponse struct {
	ResponseHeader `protobuf:"bytes,1,opt,name=header,embedded=header" json:"header"`
}

A CheckConsistencyResponse is the return value from the CheckConsistency() method. If a replica finds itself to be inconsistent with its lease holder it will panic.

func (*CheckConsistencyResponse) Descriptor

func (*CheckConsistencyResponse) Descriptor() ([]byte, []int)

func (*CheckConsistencyResponse) Marshal

func (m *CheckConsistencyResponse) Marshal() (dAtA []byte, err error)

func (*CheckConsistencyResponse) MarshalTo

func (m *CheckConsistencyResponse) MarshalTo(dAtA []byte) (int, error)

func (*CheckConsistencyResponse) ProtoMessage

func (*CheckConsistencyResponse) ProtoMessage()

func (*CheckConsistencyResponse) Reset

func (m *CheckConsistencyResponse) Reset()

func (*CheckConsistencyResponse) Size

func (m *CheckConsistencyResponse) Size() (n int)

func (*CheckConsistencyResponse) String

func (m *CheckConsistencyResponse) String() string

func (*CheckConsistencyResponse) Unmarshal

func (m *CheckConsistencyResponse) Unmarshal(dAtA []byte) error

type ComputeChecksumRequest

type ComputeChecksumRequest struct {
	Span `protobuf:"bytes,1,opt,name=header,embedded=header" json:"header"`
	// The version used to pick the checksum method. It allows us to use a
	// consistent checksumming method across replicas.
	Version uint32 `protobuf:"varint,2,opt,name=version" json:"version"`
	// A unique identifier to match a future storage.CollectChecksumRequest with
	// this request.
	ChecksumID github_com_cockroachdb_cockroach_pkg_util_uuid.UUID `` /* 137-byte string literal not displayed */
	// Compute a checksum along with a snapshot of the entire range, that will be
	// used in logging a diff during checksum verification.
	Snapshot bool `protobuf:"varint,4,opt,name=snapshot" json:"snapshot"`
}

A ComputeChecksumRequest is arguments to the ComputeChecksum() method, to start computing the checksum for the specified range at the snapshot for this request command. A response is returned without the checksum. The computed checksum is retrieved via a storage.CollectChecksumRequest.

func (*ComputeChecksumRequest) Descriptor

func (*ComputeChecksumRequest) Descriptor() ([]byte, []int)

func (*ComputeChecksumRequest) Marshal

func (m *ComputeChecksumRequest) Marshal() (dAtA []byte, err error)

func (*ComputeChecksumRequest) MarshalTo

func (m *ComputeChecksumRequest) MarshalTo(dAtA []byte) (int, error)

func (*ComputeChecksumRequest) Method

func (*ComputeChecksumRequest) Method() Method

Method implements the Request interface.

func (*ComputeChecksumRequest) ProtoMessage

func (*ComputeChecksumRequest) ProtoMessage()

func (*ComputeChecksumRequest) Reset

func (m *ComputeChecksumRequest) Reset()

func (*ComputeChecksumRequest) ShallowCopy

func (ccr *ComputeChecksumRequest) ShallowCopy() Request

ShallowCopy implements the Request interface.

func (*ComputeChecksumRequest) Size

func (m *ComputeChecksumRequest) Size() (n int)

func (*ComputeChecksumRequest) String

func (m *ComputeChecksumRequest) String() string

func (*ComputeChecksumRequest) Unmarshal

func (m *ComputeChecksumRequest) Unmarshal(dAtA []byte) error

type ComputeChecksumResponse

type ComputeChecksumResponse struct {
	ResponseHeader `protobuf:"bytes,1,opt,name=header,embedded=header" json:"header"`
}

A ComputeChecksumResponse is the response to a ComputeChecksum() operation.

func (*ComputeChecksumResponse) Descriptor

func (*ComputeChecksumResponse) Descriptor() ([]byte, []int)

func (*ComputeChecksumResponse) Marshal

func (m *ComputeChecksumResponse) Marshal() (dAtA []byte, err error)

func (*ComputeChecksumResponse) MarshalTo

func (m *ComputeChecksumResponse) MarshalTo(dAtA []byte) (int, error)

func (*ComputeChecksumResponse) ProtoMessage

func (*ComputeChecksumResponse) ProtoMessage()

func (*ComputeChecksumResponse) Reset

func (m *ComputeChecksumResponse) Reset()

func (*ComputeChecksumResponse) Size

func (m *ComputeChecksumResponse) Size() (n int)

func (*ComputeChecksumResponse) String

func (m *ComputeChecksumResponse) String() string

func (*ComputeChecksumResponse) Unmarshal

func (m *ComputeChecksumResponse) Unmarshal(dAtA []byte) error

type ConditionFailedError

type ConditionFailedError struct {
	ActualValue *Value `protobuf:"bytes,1,opt,name=actual_value,json=actualValue" json:"actual_value,omitempty"`
}

A ConditionFailedError indicates that the expected value of a ConditionalPutRequest was not found, either because it was missing or was not equal. The error will contain the actual value found.

func (*ConditionFailedError) Descriptor

func (*ConditionFailedError) Descriptor() ([]byte, []int)

func (*ConditionFailedError) Error

func (e *ConditionFailedError) Error() string

func (*ConditionFailedError) Marshal

func (m *ConditionFailedError) Marshal() (dAtA []byte, err error)

func (*ConditionFailedError) MarshalTo

func (m *ConditionFailedError) MarshalTo(dAtA []byte) (int, error)

func (*ConditionFailedError) ProtoMessage

func (*ConditionFailedError) ProtoMessage()

func (*ConditionFailedError) Reset

func (m *ConditionFailedError) Reset()

func (*ConditionFailedError) Size

func (m *ConditionFailedError) Size() (n int)

func (*ConditionFailedError) String

func (m *ConditionFailedError) String() string

func (*ConditionFailedError) Unmarshal

func (m *ConditionFailedError) Unmarshal(dAtA []byte) error

type ConditionalPutRequest

type ConditionalPutRequest struct {
	Span `protobuf:"bytes,1,opt,name=header,embedded=header" json:"header"`
	// The value to put.
	Value Value `protobuf:"bytes,2,opt,name=value" json:"value"`
	// Set exp_value.bytes empty to test for non-existence. Specify as nil
	// to indicate there should be no existing entry. This is different
	// from the expectation that the value exists but is empty.
	ExpValue *Value `protobuf:"bytes,3,opt,name=exp_value,json=expValue" json:"exp_value,omitempty"`
	// NOTE: For internal use only! Set to indicate that the put is
	// writing to virgin keyspace and no reads are necessary to
	// rationalize MVCC.
	Blind bool `protobuf:"varint,4,opt,name=blind" json:"blind"`
}

A ConditionalPutRequest is the argument to the ConditionalPut() method.

- Returns true and sets value if exp_value equals existing value. - If key doesn't exist and exp_value is nil, sets value. - If key exists, but value is empty and exp_value is not nil but empty, sets value. - Otherwise, returns error and the actual value of the key in the response.

func (*ConditionalPutRequest) Descriptor

func (*ConditionalPutRequest) Descriptor() ([]byte, []int)

func (*ConditionalPutRequest) Marshal

func (m *ConditionalPutRequest) Marshal() (dAtA []byte, err error)

func (*ConditionalPutRequest) MarshalTo

func (m *ConditionalPutRequest) MarshalTo(dAtA []byte) (int, error)

func (*ConditionalPutRequest) Method

func (*ConditionalPutRequest) Method() Method

Method implements the Request interface.

func (*ConditionalPutRequest) ProtoMessage

func (*ConditionalPutRequest) ProtoMessage()

func (*ConditionalPutRequest) Reset

func (m *ConditionalPutRequest) Reset()

func (*ConditionalPutRequest) ShallowCopy

func (cpr *ConditionalPutRequest) ShallowCopy() Request

ShallowCopy implements the Request interface.

func (*ConditionalPutRequest) Size

func (m *ConditionalPutRequest) Size() (n int)

func (*ConditionalPutRequest) String

func (m *ConditionalPutRequest) String() string

func (*ConditionalPutRequest) Unmarshal

func (m *ConditionalPutRequest) Unmarshal(dAtA []byte) error

type ConditionalPutResponse

type ConditionalPutResponse struct {
	ResponseHeader `protobuf:"bytes,1,opt,name=header,embedded=header" json:"header"`
}

A ConditionalPutResponse is the return value from the ConditionalPut() method.

func (*ConditionalPutResponse) Descriptor

func (*ConditionalPutResponse) Descriptor() ([]byte, []int)

func (*ConditionalPutResponse) Marshal

func (m *ConditionalPutResponse) Marshal() (dAtA []byte, err error)

func (*ConditionalPutResponse) MarshalTo

func (m *ConditionalPutResponse) MarshalTo(dAtA []byte) (int, error)

func (*ConditionalPutResponse) ProtoMessage

func (*ConditionalPutResponse) ProtoMessage()

func (*ConditionalPutResponse) Reset

func (m *ConditionalPutResponse) Reset()

func (*ConditionalPutResponse) Size

func (m *ConditionalPutResponse) Size() (n int)

func (*ConditionalPutResponse) String

func (m *ConditionalPutResponse) String() string

func (*ConditionalPutResponse) Unmarshal

func (m *ConditionalPutResponse) Unmarshal(dAtA []byte) error

type DeleteRangeRequest

type DeleteRangeRequest struct {
	Span `protobuf:"bytes,1,opt,name=header,embedded=header" json:"header"`
	// return the keys that are deleted in the response.
	ReturnKeys bool `protobuf:"varint,3,opt,name=return_keys,json=returnKeys" json:"return_keys"`
	// delete "inline" keys which are stored without MVCC timestamps. Note that
	// an "inline" DeleteRange will fail if it attempts to delete any keys which
	// contain timestamped (non-inline) values; this option should only be used on
	// keys which are known to store inline values, such as data in cockroach's
	// time series system.
	//
	// Similarly, attempts to delete keys with inline values will fail unless this
	// flag is set to true; the setting must match the data being deleted.
	//
	// Inline values cannot be deleted transactionally; a DeleteRange with
	// "inline" set to true will fail if it is executed within a transaction.
	Inline bool `protobuf:"varint,4,opt,name=inline" json:"inline"`
}

A DeleteRangeRequest is the argument to the DeleteRange() method. It specifies the range of keys to delete.

func (*DeleteRangeRequest) Descriptor

func (*DeleteRangeRequest) Descriptor() ([]byte, []int)

func (*DeleteRangeRequest) Marshal

func (m *DeleteRangeRequest) Marshal() (dAtA []byte, err error)

func (*DeleteRangeRequest) MarshalTo

func (m *DeleteRangeRequest) MarshalTo(dAtA []byte) (int, error)

func (*DeleteRangeRequest) Method

func (*DeleteRangeRequest) Method() Method

Method implements the Request interface.

func (*DeleteRangeRequest) ProtoMessage

func (*DeleteRangeRequest) ProtoMessage()

func (*DeleteRangeRequest) Reset

func (m *DeleteRangeRequest) Reset()

func (*DeleteRangeRequest) ShallowCopy

func (drr *DeleteRangeRequest) ShallowCopy() Request

ShallowCopy implements the Request interface.

func (*DeleteRangeRequest) Size

func (m *DeleteRangeRequest) Size() (n int)

func (*DeleteRangeRequest) String

func (m *DeleteRangeRequest) String() string

func (*DeleteRangeRequest) Unmarshal

func (m *DeleteRangeRequest) Unmarshal(dAtA []byte) error

type DeleteRangeResponse

type DeleteRangeResponse struct {
	ResponseHeader `protobuf:"bytes,1,opt,name=header,embedded=header" json:"header"`
	// All the deleted keys if return_keys is set.
	Keys []Key `protobuf:"bytes,2,rep,name=keys,casttype=Key" json:"keys,omitempty"`
}

A DeleteRangeResponse is the return value from the DeleteRange() method.

func (*DeleteRangeResponse) Descriptor

func (*DeleteRangeResponse) Descriptor() ([]byte, []int)

func (*DeleteRangeResponse) Marshal

func (m *DeleteRangeResponse) Marshal() (dAtA []byte, err error)

func (*DeleteRangeResponse) MarshalTo

func (m *DeleteRangeResponse) MarshalTo(dAtA []byte) (int, error)

func (*DeleteRangeResponse) ProtoMessage

func (*DeleteRangeResponse) ProtoMessage()

func (*DeleteRangeResponse) Reset

func (m *DeleteRangeResponse) Reset()

func (*DeleteRangeResponse) Size

func (m *DeleteRangeResponse) Size() (n int)

func (*DeleteRangeResponse) String

func (m *DeleteRangeResponse) String() string

func (*DeleteRangeResponse) Unmarshal

func (m *DeleteRangeResponse) Unmarshal(dAtA []byte) error

type DeleteRequest

type DeleteRequest struct {
	Span `protobuf:"bytes,1,opt,name=header,embedded=header" json:"header"`
}

A DeleteRequest is the argument to the Delete() method.

func (*DeleteRequest) Descriptor

func (*DeleteRequest) Descriptor() ([]byte, []int)

func (*DeleteRequest) Marshal

func (m *DeleteRequest) Marshal() (dAtA []byte, err error)

func (*DeleteRequest) MarshalTo

func (m *DeleteRequest) MarshalTo(dAtA []byte) (int, error)

func (*DeleteRequest) Method

func (*DeleteRequest) Method() Method

Method implements the Request interface.

func (*DeleteRequest) ProtoMessage

func (*DeleteRequest) ProtoMessage()

func (*DeleteRequest) Reset

func (m *DeleteRequest) Reset()

func (*DeleteRequest) ShallowCopy

func (dr *DeleteRequest) ShallowCopy() Request

ShallowCopy implements the Request interface.

func (*DeleteRequest) Size

func (m *DeleteRequest) Size() (n int)

func (*DeleteRequest) String

func (m *DeleteRequest) String() string

func (*DeleteRequest) Unmarshal

func (m *DeleteRequest) Unmarshal(dAtA []byte) error

type DeleteResponse

type DeleteResponse struct {
	ResponseHeader `protobuf:"bytes,1,opt,name=header,embedded=header" json:"header"`
}

A DeleteResponse is the return value from the Delete() method.

func (*DeleteResponse) Descriptor

func (*DeleteResponse) Descriptor() ([]byte, []int)

func (*DeleteResponse) Marshal

func (m *DeleteResponse) Marshal() (dAtA []byte, err error)

func (*DeleteResponse) MarshalTo

func (m *DeleteResponse) MarshalTo(dAtA []byte) (int, error)

func (*DeleteResponse) ProtoMessage

func (*DeleteResponse) ProtoMessage()

func (*DeleteResponse) Reset

func (m *DeleteResponse) Reset()

func (*DeleteResponse) Size

func (m *DeleteResponse) Size() (n int)

func (*DeleteResponse) String

func (m *DeleteResponse) String() string

func (*DeleteResponse) Unmarshal

func (m *DeleteResponse) Unmarshal(dAtA []byte) error

type DeprecatedVerifyChecksumRequest

type DeprecatedVerifyChecksumRequest struct {
	Span `protobuf:"bytes,1,opt,name=header,embedded=header" json:"header"`
}

func (*DeprecatedVerifyChecksumRequest) Descriptor

func (*DeprecatedVerifyChecksumRequest) Descriptor() ([]byte, []int)

func (*DeprecatedVerifyChecksumRequest) Marshal

func (m *DeprecatedVerifyChecksumRequest) Marshal() (dAtA []byte, err error)

func (*DeprecatedVerifyChecksumRequest) MarshalTo

func (m *DeprecatedVerifyChecksumRequest) MarshalTo(dAtA []byte) (int, error)

func (*DeprecatedVerifyChecksumRequest) Method

Method implements the Request interface.

func (*DeprecatedVerifyChecksumRequest) ProtoMessage

func (*DeprecatedVerifyChecksumRequest) ProtoMessage()

func (*DeprecatedVerifyChecksumRequest) Reset

func (*DeprecatedVerifyChecksumRequest) ShallowCopy

func (dvcr *DeprecatedVerifyChecksumRequest) ShallowCopy() Request

ShallowCopy implements the Request interface.

func (*DeprecatedVerifyChecksumRequest) Size

func (m *DeprecatedVerifyChecksumRequest) Size() (n int)

func (*DeprecatedVerifyChecksumRequest) String

func (*DeprecatedVerifyChecksumRequest) Unmarshal

func (m *DeprecatedVerifyChecksumRequest) Unmarshal(dAtA []byte) error

type DeprecatedVerifyChecksumResponse

type DeprecatedVerifyChecksumResponse struct {
	ResponseHeader `protobuf:"bytes,1,opt,name=header,embedded=header" json:"header"`
}

func (*DeprecatedVerifyChecksumResponse) Descriptor

func (*DeprecatedVerifyChecksumResponse) Descriptor() ([]byte, []int)

func (*DeprecatedVerifyChecksumResponse) Marshal

func (m *DeprecatedVerifyChecksumResponse) Marshal() (dAtA []byte, err error)

func (*DeprecatedVerifyChecksumResponse) MarshalTo

func (m *DeprecatedVerifyChecksumResponse) MarshalTo(dAtA []byte) (int, error)

func (*DeprecatedVerifyChecksumResponse) ProtoMessage

func (*DeprecatedVerifyChecksumResponse) ProtoMessage()

func (*DeprecatedVerifyChecksumResponse) Reset

func (*DeprecatedVerifyChecksumResponse) Size

func (m *DeprecatedVerifyChecksumResponse) Size() (n int)

func (*DeprecatedVerifyChecksumResponse) String

func (*DeprecatedVerifyChecksumResponse) Unmarshal

func (m *DeprecatedVerifyChecksumResponse) Unmarshal(dAtA []byte) error

type EndTransactionRequest

type EndTransactionRequest struct {
	Span `protobuf:"bytes,1,opt,name=header,embedded=header" json:"header"`
	// False to abort and rollback.
	Commit bool `protobuf:"varint,2,opt,name=commit" json:"commit"`
	// The deadline by which the transaction must commit, if present.
	Deadline *cockroach_util_hlc.Timestamp `protobuf:"bytes,3,opt,name=deadline" json:"deadline,omitempty"`
	// Optional commit triggers. Note that commit triggers are for
	// internal use only and will cause an error if requested through the
	// external-facing KV API.
	InternalCommitTrigger *InternalCommitTrigger `protobuf:"bytes,4,opt,name=internal_commit_trigger,json=internalCommitTrigger" json:"internal_commit_trigger,omitempty"`
	// List of intents written by the transaction.
	IntentSpans []Span `protobuf:"bytes,5,rep,name=intent_spans,json=intentSpans" json:"intent_spans"`
	// Requires that the transaction completes as a 1 phase commit. This
	// guarantees that all writes are to the same range and that no
	// intents are left in the event of an error.
	Require1PC bool `protobuf:"varint,6,opt,name=require_1pc,json=require1pc" json:"require_1pc"`
}

An EndTransactionRequest is the argument to the EndTransaction() method. It specifies whether to commit or roll back an extant transaction.

func (*EndTransactionRequest) Descriptor

func (*EndTransactionRequest) Descriptor() ([]byte, []int)

func (*EndTransactionRequest) Marshal

func (m *EndTransactionRequest) Marshal() (dAtA []byte, err error)

func (*EndTransactionRequest) MarshalTo

func (m *EndTransactionRequest) MarshalTo(dAtA []byte) (int, error)

func (*EndTransactionRequest) Method

func (*EndTransactionRequest) Method() Method

Method implements the Request interface.

func (*EndTransactionRequest) ProtoMessage

func (*EndTransactionRequest) ProtoMessage()

func (*EndTransactionRequest) Reset

func (m *EndTransactionRequest) Reset()

func (*EndTransactionRequest) ShallowCopy

func (etr *EndTransactionRequest) ShallowCopy() Request

ShallowCopy implements the Request interface.

func (*EndTransactionRequest) Size

func (m *EndTransactionRequest) Size() (n int)

func (*EndTransactionRequest) String

func (m *EndTransactionRequest) String() string

func (*EndTransactionRequest) Unmarshal

func (m *EndTransactionRequest) Unmarshal(dAtA []byte) error

type EndTransactionResponse

type EndTransactionResponse struct {
	ResponseHeader `protobuf:"bytes,1,opt,name=header,embedded=header" json:"header"`
	// True if the transaction committed on the one phase commit path.
	// This means that all writes which were part of the transaction
	// were written as a single, atomic write batch to just one range.
	OnePhaseCommit bool `protobuf:"varint,4,opt,name=one_phase_commit,json=onePhaseCommit" json:"one_phase_commit"`
}

An EndTransactionResponse is the return value from the EndTransaction() method. The final transaction record is returned as part of the response header. In particular, transaction status and timestamp will be updated to reflect final committed values. Clients may propagate the transaction timestamp as the final txn commit timestamp in order to preserve causal ordering between subsequent transactions.

func (*EndTransactionResponse) Descriptor

func (*EndTransactionResponse) Descriptor() ([]byte, []int)

func (*EndTransactionResponse) Marshal

func (m *EndTransactionResponse) Marshal() (dAtA []byte, err error)

func (*EndTransactionResponse) MarshalTo

func (m *EndTransactionResponse) MarshalTo(dAtA []byte) (int, error)

func (*EndTransactionResponse) ProtoMessage

func (*EndTransactionResponse) ProtoMessage()

func (*EndTransactionResponse) Reset

func (m *EndTransactionResponse) Reset()

func (*EndTransactionResponse) Size

func (m *EndTransactionResponse) Size() (n int)

func (*EndTransactionResponse) String

func (m *EndTransactionResponse) String() string

func (*EndTransactionResponse) Unmarshal

func (m *EndTransactionResponse) Unmarshal(dAtA []byte) error

type ErrPosition

type ErrPosition struct {
	Index int32 `protobuf:"varint,1,opt,name=index" json:"index"`
}

ErrPosition describes the position of an error in a Batch. A simple nullable primitive field would break compatibility with proto3, where primitive fields are no longer allowed to be nullable.

func (*ErrPosition) Descriptor

func (*ErrPosition) Descriptor() ([]byte, []int)

func (*ErrPosition) Marshal

func (m *ErrPosition) Marshal() (dAtA []byte, err error)

func (*ErrPosition) MarshalTo

func (m *ErrPosition) MarshalTo(dAtA []byte) (int, error)

func (*ErrPosition) ProtoMessage

func (*ErrPosition) ProtoMessage()

func (*ErrPosition) Reset

func (m *ErrPosition) Reset()

func (*ErrPosition) Size

func (m *ErrPosition) Size() (n int)

func (*ErrPosition) String

func (m *ErrPosition) String() string

func (*ErrPosition) Unmarshal

func (m *ErrPosition) Unmarshal(dAtA []byte) error

type Error

type Error struct {
	// message is a human-readable error message.
	Message string `protobuf:"bytes,1,opt,name=message" json:"message"`
	// If transaction_restart is not ABORT, the error condition may be handled by