package yb

Mouse Melon logoGet desktop application:
View/edit binary Protocol Buffers messages

message AppStatusPB

wire_protocol.proto:52

Error status returned by any RPC method. Every RPC method which could generate an application-level error should have this (or a more complex error result) as an optional field in its response. This maps to yb::Status in C++.

Used in: PgsqlResponsePB, ServerEntryPB, cdc.CDCErrorPB, consensus.ConsensusErrorPB, consensus.PerOpErrorPB, master.DeleteUniverseReplicationResponsePB, master.GetTabletLocationsResponsePB.Error, master.IndexStatusPB, master.IsAlterXClusterReplicationDoneResponsePB, master.IsCreateXClusterReplicationDoneResponsePB, master.IsSetupNamespaceReplicationWithBootstrapDoneResponsePB, master.IsSetupUniverseReplicationDoneResponsePB, master.ListSnapshotRestorationsResponsePB, master.MasterErrorPB, master.ReportedTabletPB, master.SysXClusterOutboundReplicationGroupEntryPB.NamespaceInfoPB, master.SysXClusterOutboundReplicationGroupEntryPB.TargetUniverseInfoPB, master.YsqlMajorCatalogUpgradeInfoPB, stateful_service.GetEchoCountResponsePB, stateful_service.GetEchoResponsePB, stateful_service.IncreaseMutationCountersResponsePB, stateful_service.PgCronGetLastMinuteResponsePB, stateful_service.PgCronSetLastMinuteResponsePB, tablet.TransactionStatePB, tserver.AbortTransactionRequestPB, tserver.EndRemoteBootstrapSessionRequestPB, tserver.GetTransactionStatusResponsePB, tserver.PgAcquireAdvisoryLockResponsePB, tserver.PgAcquireObjectLockResponsePB, tserver.PgActiveSessionHistoryResponsePB, tserver.PgAlterDatabaseResponsePB, tserver.PgAlterTableResponsePB, tserver.PgBackfillIndexResponsePB, tserver.PgCancelTransactionResponsePB, tserver.PgCheckIfPitrActiveResponsePB, tserver.PgClearExportedTxnSnapshotsResponsePB, tserver.PgCreateDatabaseResponsePB, tserver.PgCreateReplicationSlotResponsePB, tserver.PgCreateSequencesDataTableResponsePB, tserver.PgCreateTableResponsePB, tserver.PgCreateTablegroupResponsePB, tserver.PgCronGetLastMinuteResponsePB, tserver.PgCronSetLastMinuteResponsePB, tserver.PgDeleteDBSequencesResponsePB, tserver.PgDeleteSequenceTupleResponsePB, tserver.PgDropDatabaseResponsePB, tserver.PgDropReplicationSlotResponsePB, tserver.PgDropTableResponsePB, tserver.PgDropTablegroupResponsePB, tserver.PgExportTxnSnapshotResponsePB, tserver.PgFetchDataResponsePB, tserver.PgFetchSequenceTupleResponsePB, tserver.PgFinishTransactionResponsePB, tserver.PgGetActiveTransactionListResponsePB, tserver.PgGetCatalogMasterVersionResponsePB, tserver.PgGetDatabaseInfoResponsePB, tserver.PgGetIndexBackfillProgressResponsePB, tserver.PgGetLockStatusResponsePB, tserver.PgGetNewObjectIdResponsePB, tserver.PgGetReplicationSlotResponsePB, tserver.PgGetTableDiskSizeResponsePB, tserver.PgGetTableKeyRangesResponsePB, tserver.PgGetTablePartitionListResponsePB, tserver.PgGetTserverCatalogMessageListsResponsePB, tserver.PgGetTserverCatalogVersionInfoResponsePB, tserver.PgGetXClusterRoleResponsePB, tserver.PgHeartbeatResponsePB, tserver.PgImportTxnSnapshotResponsePB, tserver.PgInsertSequenceTupleResponsePB, tserver.PgIsInitDbDoneResponsePB, tserver.PgIsObjectPartOfXReplResponsePB, tserver.PgListClonesResponsePB, tserver.PgListLiveTabletServersResponsePB, tserver.PgListReplicationSlotsResponsePB, tserver.PgOpenTableResponsePB, tserver.PgPerformResponsePB, tserver.PgPollVectorIndexReadyResponsePB, tserver.PgReadSequenceTupleResponsePB, tserver.PgReleaseAdvisoryLockResponsePB, tserver.PgReserveOidsResponsePB, tserver.PgRollbackToSubTransactionResponsePB, tserver.PgServersMetricsResponsePB, tserver.PgSetTserverCatalogMessageListResponsePB, tserver.PgTabletServerCountResponsePB, tserver.PgTabletsMetadataResponsePB, tserver.PgTruncateTableResponsePB, tserver.PgUpdateSequenceTupleResponsePB, tserver.PgValidatePlacementResponsePB, tserver.PgWaitForBackendsCatalogVersionResponsePB, tserver.PgYCQLStatementStatsResponsePB, tserver.RemoteBootstrapErrorPB, tserver.TabletServerErrorPB, tserver.WriteResponsePB.PerRowErrorPB

enum AppStatusPB.ErrorCode

wire_protocol.proto:53

Used in: AppStatusPB

message AshAuxDataPB

common.proto:730

Some optional/additional fields that is collected in addition to the wait statement Depending on the wait-state we may choose to persist at most one of these into the yb_active_universe_history.wait_event_aux field.

Used in: WaitStateInfoPB

message AshMetadataPB

common.proto:699

Used in: QLReadRequestPB, QLWriteRequestPB, WaitStateInfoPB, master.AcquireObjectLocksGlobalRequestPB, master.ReleaseObjectLocksGlobalRequestPB, tserver.AbortTransactionRequestPB, tserver.AcquireObjectLockRequestPB, tserver.BeginRemoteBootstrapSessionRequestPB, tserver.FetchDataRequestPB, tserver.PgAcquireAdvisoryLockRequestPB, tserver.PgAcquireObjectLockRequestPB, tserver.PgAlterDatabaseRequestPB, tserver.PgAlterTableRequestPB, tserver.PgBackfillIndexRequestPB, tserver.PgCancelTransactionRequestPB, tserver.PgCheckIfPitrActiveRequestPB, tserver.PgClearExportedTxnSnapshotsRequestPB, tserver.PgCreateDatabaseRequestPB, tserver.PgCreateReplicationSlotRequestPB, tserver.PgCreateTableRequestPB, tserver.PgCreateTablegroupRequestPB, tserver.PgCronGetLastMinuteRequestPB, tserver.PgCronSetLastMinuteRequestPB, tserver.PgDeleteDBSequencesRequestPB, tserver.PgDeleteSequenceTupleRequestPB, tserver.PgDropDatabaseRequestPB, tserver.PgDropReplicationSlotRequestPB, tserver.PgDropTableRequestPB, tserver.PgDropTablegroupRequestPB, tserver.PgExportTxnSnapshotRequestPB, tserver.PgFetchSequenceTupleRequestPB, tserver.PgFinishTransactionRequestPB, tserver.PgGetActiveTransactionListRequestPB, tserver.PgGetIndexBackfillProgressRequestPB, tserver.PgGetLockStatusRequestPB, tserver.PgGetNewObjectIdRequestPB, tserver.PgGetReplicationSlotRequestPB, tserver.PgGetTableDiskSizeRequestPB, tserver.PgGetTableKeyRangesRequestPB, tserver.PgGetTablePartitionListRequestPB, tserver.PgGetTserverCatalogMessageListsRequestPB, tserver.PgGetTserverCatalogVersionInfoRequestPB, tserver.PgGetXClusterRoleRequestPB, tserver.PgImportTxnSnapshotRequestPB, tserver.PgInsertSequenceTupleRequestPB, tserver.PgIsObjectPartOfXReplRequestPB, tserver.PgListClonesRequestPB, tserver.PgListLiveTabletServersRequestPB, tserver.PgListReplicationSlotsRequestPB, tserver.PgOpenTableRequestPB, tserver.PgPerformOptionsPB, tserver.PgPollVectorIndexReadyRequestPB, tserver.PgReadSequenceTupleRequestPB, tserver.PgReleaseAdvisoryLockRequestPB, tserver.PgReserveOidsRequestPB, tserver.PgRollbackToSubTransactionRequestPB, tserver.PgServersMetricsRequestPB, tserver.PgSetTserverCatalogMessageListRequestPB, tserver.PgTabletServerCountRequestPB, tserver.PgTabletsMetadataRequestPB, tserver.PgTruncateTableRequestPB, tserver.PgUpdateSequenceTupleRequestPB, tserver.PgValidatePlacementRequestPB, tserver.PgWaitForBackendsCatalogVersionRequestPB, tserver.PgYCQLStatementStatsRequestPB, tserver.ReadRequestPB, tserver.ReleaseObjectLockRequestPB, tserver.UpdateTransactionRequestPB, tserver.WriteRequestPB

message AutoFlagsConfigPB

wire_protocol.proto:171

Used in: consensus.ReplicateMsg, master.GetAutoFlagsConfigResponsePB, master.TSHeartbeatResponsePB, master.ValidateAutoFlagsConfigRequestPB

message BlockIdPB

fs.proto:106

Used in: BlockRecordPB

message BlockRecordPB

fs.proto:124

An element found in a container metadata file of the log-backed block storage implementation. Each one tracks the existence (creation) or non-existence (deletion) of a particular block. They are written sequentially, with subsequent messages taking precedence over earlier ones (e.g. "CREATE foo" followed by "DELETE foo" means that block foo does not exist).

enum BlockRecordType

fs.proto:111

The kind of record.

Used in: BlockRecordPB

enum CDCSDKDynamicTablesOption

common_types.proto:188

Used in: CDCSDKStreamCreateOptionsPB

enum CDCSDKSnapshotOption

common_types.proto:182

CDC SDK Consistent Snapshot Options

Used in: cdc.CreateCDCStreamRequestPB, master.CDCSDKStreamEntryPB, master.CDCStreamInfoPB, master.CreateCDCStreamRequestPB

message CDCSDKStreamCreateOptionsPB

common.proto:750

This message should be used for specifying stream creation options for CDCSDK streams.

Used in: cdc.CreateCDCStreamRequestPB, master.CreateCDCStreamRequestPB

message ChildTransactionDataPB

common.proto:476

For clarification of field meaning see comments of appropriate fields in YBTransaction::Impl

Used in: QLWriteRequestPB

message ChildTransactionResultPB

common.proto:497

For clarification of field meaning see comments of appropriate fields in YBTransaction::Impl

Used in: QLResponsePB

message CloudInfoListPB

common_net.proto:30

Used in: ReplicationInfoPB, master.SetPreferredZonesRequestPB

message CloudInfoPB

common_net.proto:24

Used in: CloudInfoListPB, PlacementBlockPB, ReplicationInfoPB, ServerRegistrationPB, consensus.RaftPeerPB, consensus.StartRemoteBootstrapRequestPB, master.GetTransactionStatusTabletsRequestPB, master.SetPreferredZonesRequestPB, master.StatefulServiceInfoPB, master.TSInfoPB, tserver.StartRemoteSnapshotTransferRequestPB

message ColocatedTableIdentifierPB

common.proto:113

Used in: SchemaPB

message ColumnSchemaPB

common.proto:86

TODO: Differentiate between the schema attributes that are only relevant to the server (e.g., encoding and compression) and those that also matter to the client.

Used in: QLResponsePB, SchemaPB, master.AlterTableRequestPB.AddColumn

message ContainerSupHeaderPB

pb_util.proto:46

Supplemental protobuf container header, after the main header (see pb_util.h for details).

message DatumMessagePB

common.proto:644

Used in: cdc.RowMessage

message DeletePlanPB

common.proto:626

Used in: ExplainPlanPB

message DeletedColumnPB

common.proto:504

Used in: tablet.RaftGroupReplicaSuperBlockPB, tablet.TableInfoPB

enum DocDbBlocksSamplingMethod

common.proto:764

See ql_rocksdb_storage.cc for details on each method.

Used in: PgsqlSamplingStatePB

message ExplainPlanPB

common.proto:595

message GetTabletKeyRangesEmbeddedRequestPB

pgsql_protocol.proto:406

TODO(get_table_key_ranges): deprecate after/if separate GetTabletKeyRanges RPC to the tablet leader is used.

Used in: PgsqlReadRequestPB

message HistogramSnapshotPB

histogram.proto:39

Captures the state of an Histogram.

Used in: HistogramSnapshotsListPB

message HistogramSnapshotsListPB

histogram.proto:63

message HostPortPB

common_net.proto:19

Used in: AshMetadataPB, QLReadRequestPB, ServerRegistrationPB, cdc.CDCTabletPB.ReplicaPB, cdc.GetChangesResponsePB, cdc.ProducerEntryPB, consensus.RaftPeerPB, consensus.StartRemoteBootstrapRequestPB, master.AddNamespaceToXClusterReplicationRequestPB, master.AlterUniverseReplicationRequestPB, master.BlacklistPB, master.CreateXClusterReplicationRequestPB, master.IsAlterXClusterReplicationDoneRequestPB, master.IsCreateXClusterReplicationDoneRequestPB, master.SetupNamespaceReplicationWithBootstrapRequestPB, master.SetupUniverseReplicationRequestPB, master.StatefulServiceInfoPB, master.SysUniverseReplicationBootstrapEntryPB, master.SysUniverseReplicationEntryPB, master.TSInfoPB, master.XClusterDeleteOutboundReplicationGroupRequestPB, master.XClusterRemoveNamespaceFromOutboundReplicationGroupRequestPB, server.ServerStatusPB, tserver.GetPgSocketDirResponsePB, tserver.StartRemoteSnapshotTransferRequestPB

message IndexInfoPB

common.proto:230

This message contains the metadata of a secondary index of a table. It maps the index::columns to the expressions of table::columns. Notes on where to find metadata of an INDEX. - Each INDEX is represented by IndexInfo and IndexTable. IndexInfoPB contains the definitions of the INDEX. IndexTable contains duplicate user-data for quick access. - The IndexInfoPB is stored in the Catalog::Table being indexed. - The TablePropertiesPB is kept in Catalog::IndexTable. Internally, Catalog::IndexTable is just the same as any Catalog::Table.

Used in: master.BackfillJobPB, master.CreateTableRequestPB, master.GetTableSchemaResponsePB, master.SysTablesEntryPB, tablet.ChangeMetadataRequestPB, tablet.CloneTabletRequestPB, tablet.RaftGroupReplicaSuperBlockPB, tablet.TableInfoPB, tserver.BackfillIndexRequestPB, tserver.CreateTabletRequestPB, tserver.TableMetadataPB, tserver.TabletSnapshotOpRequestPB

message IndexInfoPB.IndexColumnPB

common.proto:256

Index column mapping. "colexpr" is used to compute the value of this column in an INDEX. - When a table is indexed by expressions, we create internal/hidden columns to store the index value, and "value_expr" specifies the indexing expression. - As of 07/2019, only QLJsonColumnOperationsPB is allowed for "colexpr". - In the current index design & implementation, expression can only reference ONE column. Example: Example for scalar index TABLE (a, b, c) INDEX (c) -> INDEX is a table whose column 'c' is referencing TABLE(c) colexpr = ref to "c" column_id. Example for JSON index TABLE (a, b, j) INDEX (j->>'b') -> INDEX is a table whose column 'j->>b' is referencing to TABLE(j) colexpr = j->'b'

Used in: IndexInfoPB

message IndexInfoPB.WherePredicateSpecPB

common.proto:277

Used in: IndexInfoPB

enum IndexPermissions

common_types.proto:50

Indexes when created or deleted go through a series of steps to add a) delete, b) write and c) read permissions one by one. Backfill is done before the READ_WRITE_AND_DELETE state. If the backfill succeeds, the read permission is granted. If not, the given permissions are removed one by one, and the index will be deleted when it is unused. If the backfill is successfully complete, the index will be in READ_WRITE_AND_DELETE state, and remain so until the user deletes it. If an Index is dropped, it will move from READ_WRITE_AND_DELETE state throu the WRITE_AND_DELETE_WHILE_REMOVING and DELETE_ONLY_WHILE_REMOVING states to INDEX_UNUSED.

Used in: IndexInfoPB

message InsertPlanPB

common.proto:613

Used in: ExplainPlanPB

message InstanceMetadataPB

fs.proto:44

When any server initializes a new filesystem (eg a new node is created in the cluster), it creates this structure and stores it persistently.

enum InvolvedTabletMetadataState

common.proto:482

Used in: TransactionInvolvedTabletPB

enum IsolationLevel

transaction.proto:21

Used in: TransactionMetadataPB

enum JsonOperatorPB

common_types.proto:86

Used in: QLJsonOperationPB

message LockInfoPB

transaction.proto:132

Used in: TabletLockInfoPB.TransactionLockInfoPB, TabletLockInfoPB.WaiterInfoPB

enum LockMode

transaction.proto:125

Used in: LockInfoPB

message NodeInstancePB

wire_protocol.proto:111

Uniquely identify a particular instance of a particular server in the cluster.

Used in: ServerEntryPB, consensus.GetNodeInstanceResponsePB, master.GetMasterRegistrationResponsePB, master.ListLiveTabletServersResponsePB.Entry, master.ListTabletServersResponsePB.Entry, master.RefreshYsqlLeaseRequestPB, master.TSHeartbeatResponsePB, master.TSInformationPB, master.TSToMasterCommonPB, server.ServerStatusPB

message OpIdPB

opid.proto:41

An id for a generic state machine operation. Composed of the leaders' term plus the index of the operation in that term, e.g., the <index>th operation of the <term>th leader.

Used in: rocksdb.NewFilePB, rocksdb.VersionEditPB, PostApplyTransactionMetadataPB, cdc.CDCCheckpointPB, cdc.GetLatestEntryOpIdResponsePB, cdc.UpdateCdcReplicatedIndexRequestPB, consensus.ConsensusRequestPB, consensus.ConsensusStatusPB, consensus.GetLastOpIdResponsePB, consensus.OperationStatusPB, consensus.PerOpErrorPB, consensus.ReplicateMsg, consensus.ReplicatedRetryableRequestRangePB, consensus.RunLeaderElectionRequestPB, consensus.TabletBootstrapStatePB, docdb.ApplyTransactionStatePB, docdb.ConsensusFrontierPB, log.LogEntryBatchPB, tablet.RaftGroupReplicaSuperBlockPB, tablet.TableInfoPB, tserver.ChangeMetadataResponsePB, tserver.CreateTabletResponsePB, tserver.RegisterLogAnchorRequestPB, tserver.UpdateLogAnchorRequestPB

enum OrderMode

common.proto:298

The possible order modes for clients. Clients specify these in new scan requests. Ordered scans are fault-tolerant, and can be retried elsewhere in the case of tablet server failure. However, ordered scans impose additional overhead since the tablet server needs to sort the result rows.

message PartitionPB

common.proto:381

The serialized format of a YB table partition.

Used in: cdc.CDCRecordPB, master.CreateTableRequestPB, master.SysTabletsEntryPB, master.TabletLocationsPB, tablet.RaftGroupReplicaSuperBlockPB, tablet.TabletStatusPB, tserver.CreateTabletRequestPB

message PartitionSchemaPB

common.proto:306

The serialized format of a YB table partition schema.

Used in: master.CreateTableRequestPB, master.GetTableSchemaResponsePB, master.SysTablesEntryPB, tablet.CloneTabletRequestPB, tablet.RaftGroupReplicaSuperBlockPB, tablet.TableInfoPB, tserver.CreateTabletRequestPB, tserver.ListTabletsResponsePB.StatusAndSchemaPB

message PartitionSchemaPB.ColumnIdentifierPB

common.proto:311

A column identifier for partition schemas. In general, the name will be used when a client creates the table since column IDs are assigned by the master. All other uses of partition schemas will use the numeric column ID.

Used in: HashBucketSchemaPB, RangeSchemaPB

message PartitionSchemaPB.HashBucketSchemaPB

common.proto:344

Used in: PartitionSchemaPB

enum PartitionSchemaPB.HashBucketSchemaPB.HashAlgorithm

common.proto:359

Used in: HashBucketSchemaPB

enum PartitionSchemaPB.HashSchema

common.proto:371

Used in: PartitionSchemaPB

message PartitionSchemaPB.RangeSchemaPB

common.proto:330

Used in: PartitionSchemaPB

message PartitionSchemaPB.RangeSplitPB

common.proto:318

Used in: RangeSchemaPB

message PathInstanceMetadataPB

fs.proto:92

A filesystem instance can contain multiple paths. One of these structures is persisted in each path when the filesystem instance is created.

message PathSetPB

fs.proto:80

Describes a collection of filesystem path instances and the membership of a particular instance in the collection. In a healthy filesystem (see below), a path instance can be referred to via its UUID's position in all_uuids instead of via the UUID itself. This is useful when there are many such references, as the position is much shorter than the UUID.

Used in: PathInstanceMetadataPB

enum PeerRole

common_types.proto:114

The possible roles for peers.

Used in: ServerEntryPB, master.CheckMasterTabletHealthResponsePB, master.GetMasterRegistrationResponsePB, master.TabletLocationsPB.ReplicaPB, tserver.CheckTserverTabletHealthResponsePB.TabletHealthPB

enum PermissionType

common_types.proto:29

Suffixed with PERMISSION, because Google does not allow same enum name CREATE

Used in: master.GrantRevokePermissionRequestPB, master.ResourcePermissionsPB

enum PersistentDataType

value.proto:100

To ensure compatibility between release versions, the numeric values of these datatypes cannot be changed once the types are implemented and released. Make sure this is in sync with YbcPgDataType in ybc_pg_typedefs.h.

Used in: QLTypePB, dockv.ColumnPackingPB

message PgDatumPB

common.proto:672

Used in: DatumMessagePB

message PgHnswIndexOptionsPB

common.proto:137

Used in: PgVectorIdxOptionsPB

message PgHnswReadOptionsPB

common.proto:157

Used in: PgVectorReadOptionsPB

enum PgReplicaIdentity

common_types.proto:195

Available replica identity modes for use in CDC

Used in: TablePropertiesPB, master.CDCStreamInfoPB, master.SysCDCStreamEntryPB

message PgTxnSnapshotPB

pgsql_protocol.proto:740

Used in: tserver.GetLocalPgTxnSnapshotResponsePB, tserver.PgExportTxnSnapshotRequestPB, tserver.PgImportTxnSnapshotResponsePB

enum PgVectorDistanceType

common.proto:123

Used in: PgVectorIdxOptionsPB

message PgVectorIdxOptionsPB

common.proto:143

Used in: IndexInfoPB, tserver.PgCreateTableRequestPB

enum PgVectorIndexType

common.proto:130

Used in: PgVectorIdxOptionsPB

message PgVectorReadOptionsPB

common.proto:161

Used in: PgsqlReadRequestPB

message PgsqlAdvisoryLockPB

pgsql_protocol.proto:717

Used in: PgsqlLockRequestPB

message PgsqlBCallPB

pgsql_protocol.proto:41

-------------------------------------------------------------------------------------------------- Expressions. -------------------------------------------------------------------------------------------------- Builtin call expression. There are 3 different calls. - Builtin operators such as '>', '<', '=', ... These operators can be executed anywhere. - Builtin functions such as Now(). These functions can be executed anywhere. - Server builtin functions. Only tablet servers can execute these functions. TODO(neil) Regular builtin operators. This message can be executed anywhere. - This is more efficient than builtin call as it avoids most overheads of calling builtin lib. - Merge the current condition operator execution with this. - To optimize certain operation (such as +), replace it builtin function with builtin op.

Used in: PgsqlExpressionPB

message PgsqlBackfillSpecPB

pgsql_protocol.proto:376

Given: master --chunk--> tserver --batch--> postgres --page--> tserver The backfill spec is updated and passed around for each batch and page.

message PgsqlBatchArgumentPB

pgsql_protocol.proto:76

This message defines an argument in a batch request from PgGate to DocDB. Instead of sending many requests of different arguments, a batch request would send one request that contains an array of independent arguments. DocDB will iterate the array to execute. DML_request(arg) [n] ---> DML_request ( PgsqlBatchArgument args[n] )

Used in: PgsqlReadRequestPB, PgsqlWriteRequestPB

message PgsqlColRefPB

pgsql_protocol.proto:115

Represents a column referenced by a PGSQL request. - column_id is a DocDB identifier of the column and used to locate a value within a row - attno is a Postgres identifier, must be specified if column is referenced by a PG expression - typid, typmod are needed to convert DocDB values to Postgres format (Datum and isnull pair). They must be specified if used in an expression evaluated by PGgate. - collid is for future collations support

Used in: PgsqlReadRequestPB, PgsqlWriteRequestPB

message PgsqlColumnRefsPB

pgsql_protocol.proto:105

-------------------------------------------------------------------------------------------------- Column messages. -------------------------------------------------------------------------------------------------- ColumnRefs is a list of columns to be read by DocDB before a PGSQL request can be executed. DEPRECATED, new code should use col_refs field of type PgsqlColRefPB instead

Used in: PgsqlReadRequestPB, PgsqlWriteRequestPB

message PgsqlColumnValuePB

pgsql_protocol.proto:126

ColumnValue is a value to be assigned to a table column by DocDB while executing a PGSQL request. Currently, this is used for SET clause. SET column-of-given-id = expr

Used in: PgsqlWriteRequestPB

message PgsqlConditionPB

pgsql_protocol.proto:47

A logical condition that evaluates to true/false. Used in the WHERE clause.

Used in: PgsqlExpressionPB

message PgsqlExpressionPB

pgsql_protocol.proto:58

An expression in a WHERE condition. - Bind values would be given by client and grouped into a repeated field that can be accessed by their indexes. - Alias values would be computed by server and grouped into repeated field that can be accessed by their indexes. - Code generator write indexes as ref. Executor deref indexes to get actual values.

Used in: PgsqlBCallPB, PgsqlBatchArgumentPB, PgsqlColumnValuePB, PgsqlConditionPB, PgsqlReadRequestPB, PgsqlWriteRequestPB

message PgsqlFetchSequenceParamsPB

pgsql_protocol.proto:191

Used in: PgsqlWriteRequestPB

message PgsqlLockRequestPB

pgsql_protocol.proto:722

Used in: tserver.WriteRequestPB

enum PgsqlLockRequestPB.PgsqlAdvisoryLockMode

pgsql_protocol.proto:723

Used in: PgsqlLockRequestPB

enum PgsqlMetricsCaptureType

pgsql_protocol.proto:399

Make sure this is in sync with YbcPgMetricsCaptureType in ybc_pg_typedefs.h.

Used in: PgsqlReadRequestPB

message PgsqlPagingStatePB

pgsql_protocol.proto:345

Paging state for continuing a read request. For a SELECT statement that returns many rows, the client may specify how many rows to return at most in each fetch. This paging state maintains the state for returning the next set of rows of the statement. This paging state is opaque to the client. When there should be more rows to return from the same tablet in the next fetch, "next_row_key" is populated in DocDB (PgsqlReadOperation) with the DocKey of the next row to read. We also embed a hybrid-time which is the clean snapshot time for read consistency. We also populate the "next_partition_key" for the next row, which is the hash code of the hash portion of the DocKey. This next partition key is needed by YBClient (Batcher) to locate the tablet to send the request to and it doesn't have access to the DocDB function to decode and extract from the DocKey. When we are done returning rows from the current tablet and the next fetch should continue in the next tablet (possible only for full-table query across tablets), "next_partition_key" is populated by the current tablet with its exclusive partition-end key, which is the start key of next tablet's partition. "next_row_key" is empty in this case which means we will start from the very beginning of the next tablet. (TODO: we need to return the clean snapshot time in this case also).

Used in: PgsqlReadRequestPB, PgsqlResponsePB

message PgsqlPartitionBound

pgsql_protocol.proto:144

Boundary value.

Used in: PgsqlReadRequestPB

message PgsqlRSColDescPB

pgsql_protocol.proto:133

PgsqlRSColDesc is the descriptor of a selected column in a ResultSet (RS), which can be any expression and not just table columns.

Used in: PgsqlRSRowDescPB

message PgsqlRSRowDescPB

pgsql_protocol.proto:139

Descriptor of a row in a resultset (RS).

Used in: PgsqlReadRequestPB, PgsqlWriteRequestPB

message PgsqlRandState

pgsql_protocol.proto:152

YB_TODO(upgrade): Handle in pg15 upgrade path.

Used in: PgsqlSamplingStatePB

message PgsqlReadRequestPB

pgsql_protocol.proto:415

TODO(neil) The protocol for select needs to be changed accordingly when we introduce and cache execution plan in tablet server.

Used in: tserver.PgPerformOpPB, tserver.ReadRequestPB

message PgsqlRequestCounterMetricPB

pgsql_protocol.proto:598

Used in: PgsqlRequestMetricsPB

message PgsqlRequestEventMetricPB

pgsql_protocol.proto:603

Used in: PgsqlRequestMetricsPB

message PgsqlRequestGaugeMetricPB

pgsql_protocol.proto:593

Used in: PgsqlRequestMetricsPB

message PgsqlRequestMetricsPB

pgsql_protocol.proto:609

Used in: PgsqlResponsePB

message PgsqlResponsePB

pgsql_protocol.proto:623

Response from tablet server for both read and write.

Used in: tserver.PgPerformResponsePB, tserver.ReadResponsePB, tserver.WriteResponsePB

enum PgsqlResponsePB.RequestStatus

pgsql_protocol.proto:627

Response status

Used in: PgsqlResponsePB

message PgsqlSampleBlockPB

pgsql_protocol.proto:157

Used in: PgsqlReadRequestPB

message PgsqlSamplingStatePB

pgsql_protocol.proto:163

Random sampling state

Used in: PgsqlReadRequestPB, PgsqlResponsePB

message PgsqlWriteRequestPB

pgsql_protocol.proto:204

Instruction.

Used in: tserver.PgPerformOpPB, tserver.WriteRequestPB

enum PgsqlWriteRequestPB.PgsqlStmtType

pgsql_protocol.proto:206

Statement types

Used in: PgsqlWriteRequestPB

message PlacementBlockPB

common_net.proto:37

This represents one instance of a placement constraint for a table. It is used to dictate what is the minimum number of expected replicas in a certain cloud/region/zone combo.

Used in: PlacementInfoPB

message PlacementInfoPB

common_net.proto:53

This keeps track of the set of PlacementBlockPBs defining the placement requirements for a certain table. This is used both in the on-disk storage in SysCatalog, as well as in the actual table creation calls and in the schema returned to client queries. This is tightly coupled with the overall num_replicas for a certain table, as we want to both be able to specify requirements, per placement block, but also for the overall RF factor of the table.

Used in: ReplicationInfoPB

message PostApplyTransactionMetadataPB

transaction.proto:117

message PromotedFlagInfoPB

wire_protocol.proto:157

Used in: PromotedFlagsPerProcessPB

message PromotedFlagsPerProcessPB

wire_protocol.proto:161

Used in: AutoFlagsConfigPB

message ProtoContainerTest2PB

proto_container_test2.proto:43

Arbitrary protobuf that has one PB dependency.

Used in: ProtoContainerTest3PB

message ProtoContainerTest3PB

proto_container_test3.proto:46

Arbitrary protobuf has two PB dependencies. dependency.

message ProtoContainerTestPB

proto_container_test.proto:37

Arbitrary protobuf to test writing a containerized protobuf.

Used in: ProtoContainerTest2PB, ProtoContainerTest3PB

message QLBCallPB

common.proto:577

Builtin call expression. There are 3 different calls. - Builtin operators such as '>', '<', '=', ... These operators can be executed anywhere. - Builtin functions such as Now(). These functions can be executed anywhere. - Server builtin functions. Only tablet servers can execute these functions. TODO(neil) Regular builtin operators. This message can be executed anywhere. - This is more efficient than builtin call as it avoids most overheads of calling builtin lib. - Merge the current condition operator execution with this. - To optimize certain operation (such as +), replace it builtin function with builtin op.

Used in: QLExpressionPB

enum QLClient

common_types.proto:107

Client type.

Used in: PgsqlLockRequestPB, PgsqlReadRequestPB, PgsqlWriteRequestPB, QLReadRequestPB, QLWriteRequestPB

message QLColumnValuePB

ql_protocol.proto:24

A column value, optionally with subscripts, e.g. m['x'] or l[2]['x']

Used in: QLWriteRequestPB

message QLConditionPB

common.proto:560

A logical condition that evaluates to true/false. Used in the WHERE clause.

Used in: QLExpressionPB

message QLExpressionPB

common.proto:544

An expression in a WHERE condition

Used in: IndexInfoPB.IndexColumnPB, IndexInfoPB.WherePredicateSpecPB, PgsqlAdvisoryLockPB, QLBCallPB, QLColumnValuePB, QLConditionPB, QLJsonOperationPB, QLReadRequestPB, QLSubscriptedColPB, QLTupleExpressionPB, QLWriteRequestPB

message QLJsonColumnOperationsPB

common.proto:528

Represents operations applied to a json column.

Used in: QLExpressionPB

message QLJsonOperationPB

common.proto:533

Used in: ColumnSchemaPB, QLColumnValuePB, QLJsonColumnOperationsPB

message QLMapValuePB

value.proto:26

Used in: QLValuePB

enum QLOperator

value.proto:144

Expression operators.

Used in: PgsqlConditionPB, QLConditionPB

message QLPagingStatePB

ql_protocol.proto:66

Used in: QLReadRequestPB, QLResponsePB

message QLRSColDescPB

ql_protocol.proto:209

QLRSColDesc is the descriptor of a SELECT'ed column in a ResultSet, which can be any expression and not just table columns.

Used in: QLRSRowDescPB

message QLRSRowDescPB

ql_protocol.proto:215

Descriptor of a row in a resultset.

Used in: QLReadRequestPB

message QLReadRequestPB

ql_protocol.proto:221

TODO(neil) The protocol for select needs to be changed accordingly when we introduce and cache execution plan in tablet server.

Used in: tserver.ReadRequestPB

message QLReferencedColumnsPB

ql_protocol.proto:127

These columns must be read by DocDB before a read or write request can be executed.

Used in: QLReadRequestPB, QLWriteRequestPB

message QLResponsePB

ql_protocol.proto:302

Used in: tserver.ReadResponsePB, tserver.WriteResponsePB

enum QLResponsePB.QLStatus

ql_protocol.proto:305

Response status

Used in: QLResponsePB

message QLSelectRowCounterPB

ql_protocol.proto:54

Paging state for continuing a read request. For a SELECT statement that returns many rows, the client may specify how many rows to return at most in each fetch. This paging state maintains the state for returning the next set of rows of the statement. This paging state is opaque to the client. When there should be more rows to return from the same tablet in the next fetch, "next_row_key" is populated in DocDB (QLReadOperation) with the DocKey of the next row to read. We also embed a hybrid-time which is the clean snapshot time for read consistency. We also populate the "next_partition_key" for the next row, which is the hash code of the hash portion of the DocKey. This next partition key is needed by YBClient (Batcher) to locate the tablet to send the request to and it doesn't have access to the DocDB function to decode and extract from the DocKey. When we are done returning rows from the current tablet and the next fetch should continue in the next tablet (possible only for full-table query across tablets), "next_partition_key" is populated by the current tablet with its exclusive partition-end key, which is the start key of next tablet's partition. "next_row_key" is empty in this case which means we will start from the very beginning of the next tablet. (TODO: we need to return the clean snapshot time in this case also). RowCounter message. - These state variables are exchanged between users and CQL server when query result is paged. - DocDB does not use these.

Used in: QLPagingStatePB

message QLSeqValuePB

value.proto:22

Sequence of values used to represent Lists, Sets and Tuples

Used in: QLValuePB

message QLSubscriptedColPB

common.proto:522

Reference to a subcolumn, e.g. m['x'] or l[2]['x']

Used in: QLExpressionPB

message QLTupleExpressionPB

common.proto:539

Tuple expression in LHS of IN operation (in future for =, >, < too).

Used in: PgsqlExpressionPB, QLExpressionPB

message QLTypePB

common.proto:68

Used in: ColumnSchemaPB, DatumMessagePB, PgsqlRSColDescPB, QLRSColDescPB, cdc.CDCSDKColumnInfoPB, master.CreateUDTypeRequestPB, master.SysUDTypeEntryPB, master.UDTypeInfoPB

message QLTypePB.UDTypeInfo

common.proto:73

Fields for user-defined types

Used in: QLTypePB

message QLValuePB

value.proto:48

A QL value

Used in: ColumnSchemaPB, DatumMessagePB, PgVectorReadOptionsPB, PgsqlExpressionPB, QLExpressionPB, QLMapValuePB, QLSeqValuePB, cdc.KeyValuePairPB, tserver.PgCreateColumnPB, tserver.PgCreateSplitBoundaryPB

enum QLVirtualValuePB

value.proto:36

-------------------------------------------------------------------------------------------------- YQL support. The following section is common for all query language. -------------------------------------------------------------------------------------------------- Represent system internal values.

Used in: QLValuePB

message QLWriteRequestPB

ql_protocol.proto:134

Used in: tserver.WriteRequestPB

enum QLWriteRequestPB.QLStmtType

ql_protocol.proto:137

Statement types

Used in: QLWriteRequestPB

message ReadHybridTimePB

common.proto:453

See ReadHybridTime for explation of this message.

Used in: ChildTransactionDataPB, ChildTransactionResultPB, PgsqlPagingStatePB, QLPagingStatePB, tserver.GetLocalPgTxnSnapshotResponsePB, tserver.PgPerformOptionsPB, tserver.PgPerformResponsePB, tserver.ReadRequestPB, tserver.ReadResponsePB, tserver.WriteRequestPB, tserver.WriteResponsePB

message RedisAddRequestPB

redis_protocol.proto:307

SADD

Used in: RedisWriteRequestPB

message RedisAppendRequestPB

redis_protocol.proto:257

APPEND

Used in: RedisWriteRequestPB

(message has no fields)

message RedisArrayPB

redis_protocol.proto:347

Used in: RedisResponsePB

message RedisCollectionGetRangeRequestPB

redis_protocol.proto:208

Used in: RedisReadRequestPB

enum RedisCollectionGetRangeRequestPB.GetRangeRequestType

redis_protocol.proto:210

Used in: RedisCollectionGetRangeRequestPB

enum RedisDataType

redis_protocol.proto:92

Used in: RedisKeyValuePB, RedisResponsePB

message RedisDelRequestPB

redis_protocol.proto:265

DEL, HDEL

Used in: RedisWriteRequestPB

(message has no fields)

message RedisExistsRequestPB

redis_protocol.proto:269

EXISTS, HEXISTS

Used in: RedisReadRequestPB

(message has no fields)

message RedisGetForRenameRequestPB

redis_protocol.proto:249

RENAME

Used in: RedisReadRequestPB

(message has no fields)

message RedisGetRangeRequestPB

redis_protocol.proto:278

GETRANGE

Used in: RedisReadRequestPB

message RedisGetRequestPB

redis_protocol.proto:181

GET, HGET, MGET, HMGET, HGETALL, SMEMBERS HKEYS, HKEYS, HLEN

Used in: RedisReadRequestPB

enum RedisGetRequestPB.GetRequestType

redis_protocol.proto:183

Used in: RedisGetRequestPB

message RedisGetSetRequestPB

redis_protocol.proto:253

GETSET

Used in: RedisWriteRequestPB

(message has no fields)

message RedisGetTtlRequestPB

redis_protocol.proto:237

TTL, PTTL

Used in: RedisReadRequestPB

message RedisIncrRequestPB

redis_protocol.proto:284

INCR, INCRBY, INCRBYFLOAT, HINCRBY, HINCRBYFLOAT, ZINCRBY, DECR, DECRBY, ZADD with incr option

Used in: RedisWriteRequestPB

message RedisIndexBoundPB

redis_protocol.proto:76

Used in: RedisIndexRangePB

message RedisIndexRangePB

redis_protocol.proto:71

Used in: RedisReadRequestPB

message RedisInsertRequestPB

redis_protocol.proto:296

LINSERT

Used in: RedisWriteRequestPB

message RedisKeyValuePB

redis_protocol.proto:142

- Even if just a key is needed, or there are multiple values, this is used. - In case of referring to an entity within a container, the type of the outer_key and the subkey or index of the inner entity is specified. - String : Set the key and value only (setting STRING type is optional as it is understood). - List : Set the key, index, and value. - Set : Set the key, and value (possibly multiple depending on the command). - Hash : Set key, subkey, value. - SortedSet : Set key, subkey, value (value is interpreted as score). - Timeseries: Set key, subkey, value (timestamp_subkey in RedisKeyValueSubKeyPB is interpreted as timestamp). - Value is not present in case of an append, get, exists, etc. For multiple inserts into a container, the subkey and value fields have one or more items.

Used in: RedisReadRequestPB, RedisWriteRequestPB

message RedisKeyValueSubKeyPB

redis_protocol.proto:120

Used in: RedisKeyValuePB, RedisSubKeyBoundPB

message RedisKeysRequestPB

redis_protocol.proto:243

KEYS

Used in: RedisReadRequestPB

message RedisNoOpRequestPB

redis_protocol.proto:224

No operation.

Used in: RedisWriteRequestPB

(message has no fields)

enum RedisOrder

redis_protocol.proto:109

This enum is used to specify the insertion position (Insert after or before index).

Used in: RedisInsertRequestPB

message RedisPopRequestPB

redis_protocol.proto:301

LPOP, RPOP, SPOP; blocking versions BLPOP etc. currently not supported.

Used in: RedisWriteRequestPB

message RedisPushRequestPB

redis_protocol.proto:290

RPUSH, RPUSHX, LPUSH, LPUSHX

Used in: RedisWriteRequestPB

message RedisReadRequestPB

redis_protocol.proto:46

Used in: tserver.ReadRequestPB

message RedisResponsePB

redis_protocol.proto:315

Used in: tserver.ReadResponsePB, tserver.WriteResponsePB

enum RedisResponsePB.RedisStatusCode

redis_protocol.proto:317

Used in: RedisResponsePB

message RedisSetRangeRequestPB

redis_protocol.proto:273

SETRANGE

Used in: RedisWriteRequestPB

message RedisSetRequestPB

redis_protocol.proto:172

SET, SETNX, SETXX, HSET, HSETNX, LSET, MSET, HMSET, MSETNX

Used in: RedisWriteRequestPB

message RedisSetTtlRequestPB

redis_protocol.proto:228

PERSIST, (P)EXPIRE, (P)EXPIREAT

Used in: RedisWriteRequestPB

enum RedisSide

redis_protocol.proto:103

This enum is used to specify the side of a list (For LPOP or RPOP etc.).

Used in: RedisPopRequestPB, RedisPushRequestPB

message RedisStrLenRequestPB

redis_protocol.proto:261

STRLEN, HSTRLEN

Used in: RedisReadRequestPB

(message has no fields)

message RedisSubKeyBoundPB

redis_protocol.proto:81

Wrapper for a subkey which denotes an upper/lower bound for a range request.

Used in: RedisSubKeyRangePB

enum RedisSubKeyBoundPB.InfinityType

redis_protocol.proto:82

Used in: RedisSubKeyBoundPB

message RedisSubKeyRangePB

redis_protocol.proto:66

Used in: RedisReadRequestPB

enum RedisWriteMode

redis_protocol.proto:114

Used in: RedisAddRequestPB, RedisSetRequestPB

message RedisWriteRequestPB

redis_protocol.proto:25

A single Redis request. Some user commands like MGET should be split into multiple of these.

Used in: tserver.WriteRequestPB

enum ReplicationErrorPb

common_types.proto:141

Used in: master.ReplicationStatusErrorPB, master.XClusterConsumerStreamTabletStatusPB

message ReplicationInfoPB

common_net.proto:62

Higher level structure to keep track of all types of replicas configured. This will have, at a minimum, the information about the replicas that are supposed to be active members of the raft configs, but can also include extra information, such as read only replicas.

Used in: master.AlterTableRequestPB, master.CreateTableRequestPB, master.CreateTransactionStatusTableRequestPB, master.GetTableSchemaResponsePB, master.ListTabletServersRequestPB, master.SysClusterConfigEntryPB, master.SysTablesEntryPB, master.ValidateReplicationInfoRequestPB, tserver.PgValidatePlacementRequestPB

enum ReplicationSlotLsnType

common.proto:686

The type of LSN type which will be used with the replication slot and stream metadata.

Used in: CDCSDKStreamCreateOptionsPB, master.CDCStreamInfoOptionsPB, master.SysCDCStreamEntryPB

enum ReplicationSlotOrderingMode

common.proto:693

The type of ordering mode to be used while using logical replication.

Used in: CDCSDKStreamCreateOptionsPB, master.CDCStreamInfoOptionsPB, master.SysCDCStreamEntryPB

enum ResourceType

common_types.proto:20

Used for Cassandra Roles and Permissions

Used in: master.GrantRevokePermissionRequestPB, master.ResourcePermissionsPB

enum RowMarkType

transaction.proto:59

This enum matches enum RowMarkType defined in src/include/nodes/plannodes.h. The exception is ROW_MARK_ABSENT, which signifies the absence of a row mark.

Used in: PgsqlReadRequestPB, docdb.KeyValueWriteBatchPB

message SchemaPB

common.proto:212

Used in: log.LogSegmentHeaderPB, master.CreateTableRequestPB, master.GetTableSchemaFromSysCatalogResponsePB, master.GetTableSchemaResponsePB, master.InsertHistoricalColocatedSchemaPackingRequestPB, master.InsertPackedSchemaForXClusterTargetRequestPB, master.SysTablesEntryPB, master.YsqlDdlTxnVerifierStatePB, tablet.ChangeMetadataRequestPB, tablet.CloneTabletRequestPB, tablet.RaftGroupReplicaSuperBlockPB, tablet.TableInfoPB, tserver.CreateTabletRequestPB, tserver.GetCompatibleSchemaVersionRequestPB, tserver.ListTabletsResponsePB.StatusAndSchemaPB, tserver.TableMetadataPB, tserver.TabletSnapshotOpRequestPB

message SelectPlanPB

common.proto:604

Used in: ExplainPlanPB

message ServerEntryPB

wire_protocol.proto:140

Used in: master.ListMastersResponsePB

message ServerRegistrationPB

wire_protocol.proto:129

RPC and HTTP addresses for each server, as well as cloud related information.

Used in: ServerEntryPB, consensus.GetNodeInstanceResponsePB, master.GetMasterRegistrationResponsePB, master.SysTabletServerEntryPB, master.TSRegistrationPB, tserver.BeginRemoteBootstrapSessionRequestPB

message SortedSetOptionsPB

redis_protocol.proto:159

Used in: RedisSetRequestPB

enum SortedSetOptionsPB.UpdateOptions

redis_protocol.proto:160

Used in: SortedSetOptionsPB

enum StatefulServiceKind

common_types.proto:174

Stateful services.

Used in: master.CreateTableRequestPB, master.GetStatefulServiceLocationRequestPB, master.SysTablesEntryPB, tablet.RaftGroupReplicaSuperBlockPB, tserver.CreateTabletRequestPB

message SubTransactionMetadataPB

transaction.proto:111

Used in: docdb.KeyValueWriteBatchPB, tserver.ReadRequestPB

message SubtxnSetPB

transaction.proto:101

Used in: SubTransactionMetadataPB, docdb.ApplyExternalTransactionPB, docdb.ApplyTransactionStatePB, tablet.TransactionStatePB, tserver.GetLockStatusRequestPB.TransactionInfoPB, tserver.GetOldTransactionsResponsePB.OldTransactionMetadataPB, tserver.GetTransactionStatusResponsePB, tserver.ProbeTransactionDeadlockRequestPB, tserver.UpdateTransactionWaitingForStatusRequestPB.BlockingTransaction

message TServerDBCatalogMessageListInfo

common.proto:640

Used in: tserver.GetTserverCatalogMessageListsResponsePB, tserver.PgGetTserverCatalogMessageListsResponsePB, tserver.PgSetTserverCatalogMessageListRequestPB

message TServerDBCatalogVersionInfo

common.proto:635

Used in: tserver.GetTserverCatalogVersionInfoResponsePB, tserver.PgGetTserverCatalogVersionInfoResponsePB

enum TableLockType

transaction.proto:86

This enum matches enum table locks defined in src/include/storage/lockdefs.h. Table level lock conflict matrix. Source: https://www.postgresql.org/docs/15/explicit-locking.html#LOCKING-TABLES

Used in: docdb.ObjectLockPB, master.SysObjectLockEntryPB.LockTypesPB

message TablePropertiesPB

common.proto:170

Used in: SchemaPB, master.AlterTableRequestPB

enum TableType

common_types.proto:75

This must exactly match YBTableType in client.h. We have static_assert's in tablet-test.cc to verify this.

Used in: master.CreateTableRequestPB, master.DdlLogEntryPB, master.GetTableLocationsResponsePB, master.GetTableSchemaResponsePB, master.ListTablesResponsePB.TableInfo, master.SysTablesEntryPB, master.SysUniverseReplicationBootstrapEntryPB.TableDataPB, tablet.RaftGroupReplicaSuperBlockPB, tablet.TableInfoPB, tablet.TabletStatusPB, tserver.CreateTabletRequestPB

message TabletLockInfoPB

transaction.proto:159

Used in: tserver.GetLockStatusResponsePB, tserver.PgGetLockStatusResponsePB.NodeLockStatusResponsePB

message TabletLockInfoPB.TransactionLockInfoPB

transaction.proto:177

Lock info for a given transaction at this tablet.

Used in: TabletLockInfoPB

message TabletLockInfoPB.WaiterInfoPB

transaction.proto:166

Used in: TabletLockInfoPB, TransactionLockInfoPB

message TestObjectOptionalPB

proto_container_test2.proto:59

message TestObjectRepeatedPB

proto_container_test2.proto:53

message TestObjectRequiredPB

proto_container_test2.proto:47

enum TestPBEnum

proto_container_test.proto:57

message TestStringOptionalPB

proto_container_test.proto:53

Used in: TestObjectOptionalPB

message TestStringRepeatedPB

proto_container_test.proto:49

Used in: TestObjectRepeatedPB

message TestStringRequiredPB

proto_container_test.proto:45

Used in: TestObjectRequiredPB

message TransactionInvolvedTabletPB

common.proto:488

Used in: ChildTransactionResultPB

enum TransactionLocality

transaction.proto:52

Used in: TransactionMetadataPB

message TransactionMetadataPB

common.proto:426

Used in: ChildTransactionDataPB, docdb.KeyValueWriteBatchPB, master.AlterTableRequestPB, master.CreateNamespaceRequestPB, master.CreateTableRequestPB, master.CreateTablegroupRequestPB, master.DeleteTableRequestPB, master.DeleteTablegroupRequestPB, master.IsYsqlDdlVerificationDoneRequestPB, master.SysNamespaceEntryPB, master.SysTablesEntryPB, tablet.TransactionStatePB, tserver.ReadRequestPB

enum TransactionStatus

transaction.proto:28

Used in: tablet.TransactionStatePB, tserver.AbortTransactionResponsePB, tserver.GetTransactionStatusResponsePB

message TserverInstanceMetadataPB

fs.proto:65

Used in: InstanceMetadataPB

message TserverMetricsInfoPB

common.proto:758

Used in: tserver.GetMetricsResponsePB, tserver.PgServerMetricsInfoPB

message UnsignedIntSetTestPB

proto_container_test.proto:63

message UpdatePlanPB

common.proto:618

Used in: ExplainPlanPB

message VersionInfoPB

version_info.proto:39

Information about the build environment, configuration, etc.

Used in: master.SysTabletServerEntryPB, master.TSRegistrationPB, server.ServerStatusPB

enum WaitPolicy

common.proto:413

This enum matches enum LockWaitPolicy defined in src/include/nodes/lockoptions.h and applies only to explicit row-level locking policies. NOTE: WAIT_ERROR implies no-wait semantics in Postgres i.e., if a conflicting lock is held, fail self's transaction. However, in YSQL, the WAIT_ERROR enum maps to the Fail-on-Conflict conflict management policy (where we may fail other transactions depending on priority, as described in conflict_resolution.h). It doesn't map to no-wait semantics because they aren't yet supported by docdb. But, note that NOWAIT clause is supported for READ COMMITTED isolation level when no other isolation's transactions are active. YSQL acheives that without relying on no-wait semantics from the tserver. This is done by leveraging the fact that the Fail-on-Conflict policy for read committed transactions are effectively no-wait semantics because all read committed transactions have the same kHighest priority. TODO(concurrency-control): When NOWAIT support is to be extended for REPEATABLE READ and SERIALIZABLE isolation level, we would require using WAIT_ERROR to rightly mean the no-wait policy and another enum to represent the Fail-on-Conflict policy. YSQL specifies WaitPolicy explicitly only for reads via PgsqlReadRequestPB that take explicit row-level locks.

Used in: PgsqlReadRequestPB, docdb.KeyValueWriteBatchPB

message WaitStateInfoPB

common.proto:737

Represents the wait-state tracked for a given incoming rpc/request.

Used in: rpc.RpcCallInProgressPB, tserver.WaitStatesPB

message XClusterNamespaceInfoPB

common_types.proto:220

Information for a namespace currently/previously under automatic mode xCluster replication.

Used in: master.SysXClusterConfigEntryPB, master.TSHeartbeatResponsePB.XClusterHeartbeatInfo

enum XClusterNamespaceInfoPB.XClusterRole

common_types.proto:221

Used in: XClusterNamespaceInfoPB

enum XClusterReplicationType

common_types.proto:213

Used in: master.GetUniverseReplicationInfoResponsePB

enum YBConsistencyLevel

common_types.proto:91

Used in: TablePropertiesPB, tserver.ChecksumRequestPB, tserver.ReadRequestPB

enum YQLDatabase

common_types.proto:66

Client type.

Used in: cdc.CreateCDCStreamRequestPB, master.BootstrapProducerRequestPB, master.CreateNamespaceRequestPB, master.DeleteNamespaceRequestPB, master.ListNamespacesRequestPB, master.NamespaceIdentifierPB, master.SysCloneStatePB, master.SysNamespaceEntryPB, master.SysUniverseReplicationBootstrapEntryPB.NamespaceDataPB

enum YsqlSamplingAlgorithm

common.proto:772

See yb_sampling_algorithm flag description. Should be in sync with YbcSamplingAlgorithmEnum in GUC (ybc_util.h).

Used in: PgsqlSamplingStatePB