sessiondatapb

package
v0.0.4 Latest Latest
Warning

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

Go to latest
Published: Mar 20, 2022 License: Apache-2.0 Imports: 15 Imported by: 0

Documentation

Index

Constants

View Source
const (
	// NormalName is the external session setting string value to use to mean
	// Normal QoS level.
	NormalName = "regular"

	// UserHighName is the external session setting string value to use to mean
	// UserHigh QoS level.
	UserHighName = "critical"

	// UserLowName is the external session setting string value to use to mean
	// UserLow QoS level.
	UserLowName = "background"

	// SystemHighName is the string value to display indicating a SystemHigh
	// QoS level.
	SystemHighName = "maximum"

	// SystemLowName is the string value to display indicating a SystemLow
	// QoS level.
	SystemLowName = "minimum"

	// TTLLowName is the string value to display indicating a TTLLow QoS level.
	TTLLowName = "ttl_low"

	// LockingName is the string value to display indicating a Locking QoS level.
	LockingName = "locking"
)

Variables

View Source
var (
	ErrInvalidLengthLocalOnlySessionData        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowLocalOnlySessionData          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupLocalOnlySessionData = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrInvalidLengthSessionData        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowSessionData          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupSessionData = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrInvalidLengthSessionMigration        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowSessionMigration          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupSessionMigration = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrInvalidLengthSessionRevivalToken        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowSessionRevivalToken          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupSessionRevivalToken = fmt.Errorf("proto: unexpected end of group")
)
View Source
var VectorizeExecMode_name = map[int32]string{
	0: "VectorizeUnset",
	2: "VectorizeOn",
	3: "VectorizeExperimentalAlways",
	4: "VectorizeOff",
}
View Source
var VectorizeExecMode_value = map[string]int32{
	"VectorizeUnset":              0,
	"VectorizeOn":                 2,
	"VectorizeExperimentalAlways": 3,
	"VectorizeOff":                4,
}

Functions

This section is empty.

Types

type DataConversionConfig

type DataConversionConfig struct {
	// BytesEncodeFormat indicates how to encode byte arrays when converting to
	// string.
	BytesEncodeFormat lex.BytesEncodeFormat `` /* 166-byte string literal not displayed */
	// ExtraFloatDigits indicates the number of digits beyond the standard number
	// to use for float conversions.This must be set to a value between -15 and
	// 3, inclusive.
	ExtraFloatDigits int32 `protobuf:"varint,2,opt,name=extra_float_digits,json=extraFloatDigits,proto3" json:"extra_float_digits,omitempty"`
	// IntervalStyle indicates the style to parse and display intervals as.
	IntervalStyle duration.IntervalStyle `` /* 144-byte string literal not displayed */
	// DateStyle indicates the style to parse and display dates as.
	DateStyle pgdate.DateStyle `protobuf:"bytes,4,opt,name=date_style,json=dateStyle,proto3" json:"date_style"`
}

DataConversionConfig contains the parameters that influence the output of certain data types as strings or bytes.

func (*DataConversionConfig) Descriptor

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

func (DataConversionConfig) GetFloatPrec

func (c DataConversionConfig) GetFloatPrec() int

GetFloatPrec computes a precision suitable for a call to strconv.FormatFloat() or for use with '%.*g' in a printf-like function.

func (*DataConversionConfig) Marshal

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

func (*DataConversionConfig) MarshalTo

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

func (*DataConversionConfig) MarshalToSizedBuffer

func (m *DataConversionConfig) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*DataConversionConfig) ProtoMessage

func (*DataConversionConfig) ProtoMessage()

func (*DataConversionConfig) Reset

func (m *DataConversionConfig) Reset()

func (*DataConversionConfig) Size

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

func (*DataConversionConfig) String

func (m *DataConversionConfig) String() string

func (*DataConversionConfig) Unmarshal

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

func (*DataConversionConfig) XXX_DiscardUnknown

func (m *DataConversionConfig) XXX_DiscardUnknown()

func (*DataConversionConfig) XXX_Marshal

func (m *DataConversionConfig) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*DataConversionConfig) XXX_Merge

func (m *DataConversionConfig) XXX_Merge(src proto.Message)

func (*DataConversionConfig) XXX_Size

func (m *DataConversionConfig) XXX_Size() int

func (*DataConversionConfig) XXX_Unmarshal

func (m *DataConversionConfig) XXX_Unmarshal(b []byte) error

type DistSQLExecMode

type DistSQLExecMode int64

DistSQLExecMode controls if and when the Executor distributes queries. Since 2.1, we run everything through the DistSQL infrastructure, and these settings control whether to use a distributed plan, or use a plan that only involves local DistSQL processors.

const (
	// DistSQLOff means that we never distribute queries.
	DistSQLOff DistSQLExecMode = iota
	// DistSQLAuto means that we automatically decide on a case-by-case basis if
	// we distribute queries.
	DistSQLAuto
	// DistSQLOn means that we distribute queries that are supported.
	DistSQLOn
	// DistSQLAlways means that we only distribute; unsupported queries fail.
	DistSQLAlways
)

func DistSQLExecModeFromString

func DistSQLExecModeFromString(val string) (_ DistSQLExecMode, ok bool)

DistSQLExecModeFromString converts a string into a DistSQLExecMode

func (DistSQLExecMode) String

func (m DistSQLExecMode) String() string

type ExperimentalDistSQLPlanningMode

type ExperimentalDistSQLPlanningMode int64

ExperimentalDistSQLPlanningMode controls if and when the opt-driven DistSQL planning is used to create physical plans.

const (
	// ExperimentalDistSQLPlanningOff means that we always use the old path of
	// going from opt.Expr to planNodes and then to processor specs.
	ExperimentalDistSQLPlanningOff ExperimentalDistSQLPlanningMode = iota
	// ExperimentalDistSQLPlanningOn means that we will attempt to use the new
	// path for performing DistSQL planning in the optimizer, and if that
	// doesn't succeed for some reason, we will fallback to the old path.
	ExperimentalDistSQLPlanningOn
	// ExperimentalDistSQLPlanningAlways means that we will only use the new path,
	// and if it fails for any reason, the query will fail as well.
	ExperimentalDistSQLPlanningAlways
)

func ExperimentalDistSQLPlanningModeFromString

func ExperimentalDistSQLPlanningModeFromString(val string) (ExperimentalDistSQLPlanningMode, bool)

ExperimentalDistSQLPlanningModeFromString converts a string into a ExperimentalDistSQLPlanningMode. False is returned if the conversion was unsuccessful.

func (ExperimentalDistSQLPlanningMode) String

type LocalOnlySessionData

type LocalOnlySessionData struct {
	// SaveTablesPrefix indicates that a table should be created with the
	// given prefix for the output of each subexpression in a query. If
	// SaveTablesPrefix is empty, no tables are created.
	SaveTablesPrefix string `protobuf:"bytes,1,opt,name=save_tables_prefix,json=saveTablesPrefix,proto3" json:"save_tables_prefix,omitempty"`
	// OptimizerFKCascadesLimit is the maximum number of cascading operations that
	// are run for a single query.
	OptimizerFKCascadesLimit int64 `` /* 138-byte string literal not displayed */
	// StmtTimeout is the duration a query is permitted to run before it is
	// canceled by the session. If set to 0, there is no timeout.
	StmtTimeout time.Duration `protobuf:"varint,3,opt,name=stmt_timeout,json=stmtTimeout,proto3,casttype=time.Duration" json:"stmt_timeout,omitempty"`
	// IdleInSessionTimeout is the duration a session is permitted to idle before
	// the session is canceled. If set to 0, there is no timeout.
	IdleInSessionTimeout time.Duration `` /* 149-byte string literal not displayed */
	// IdleInTransactionSessionTimeout is the duration a session is permitted to
	// idle in a transaction before the session is canceled.
	// If set to 0, there is no timeout.
	IdleInTransactionSessionTimeout time.Duration `` /* 184-byte string literal not displayed */
	// NoticeDisplaySeverity indicates the level of Severity to send notices for the given
	// session. This should ideally be of type pgnotice.DisplaySeverity, but cannot be done
	// due to a circular dependency.
	NoticeDisplaySeverity uint32 `` /* 127-byte string literal not displayed */
	// ReorderJoinsLimit indicates the number of joins at which the optimizer should
	// stop attempting to reorder.
	ReorderJoinsLimit int64 `protobuf:"varint,7,opt,name=reorder_joins_limit,json=reorderJoinsLimit,proto3" json:"reorder_joins_limit,omitempty"`
	// DefaultTxnPriority indicates the default priority of newly created
	// transactions.
	// NOTE: we'd prefer to use tree.UserPriority here, but doing so would
	// introduce a package dependency cycle.
	DefaultTxnPriority int64 `protobuf:"varint,8,opt,name=default_txn_priority,json=defaultTxnPriority,proto3" json:"default_txn_priority,omitempty"`
	// DefaultTxnReadOnly indicates the default read-only status of newly
	// created transactions.
	DefaultTxnReadOnly bool `protobuf:"varint,9,opt,name=default_txn_read_only,json=defaultTxnReadOnly,proto3" json:"default_txn_read_only,omitempty"`
	// DefaultTxnUseFollowerReads indicates whether transactions should be
	// created by default using an AS OF SYSTEM TIME clause far enough in the
	// past to facilitate reads against followers. If true, transactions will
	// also default to being read-only.
	DefaultTxnUseFollowerReads bool `` /* 147-byte string literal not displayed */
	// PartiallyDistributedPlansDisabled indicates whether the partially
	// distributed plans produced by distSQLSpecExecFactory are disabled. It
	// should be set to 'true' only in tests that verify that the old and the
	// new factories return exactly the same physical plans.
	// TODO(yuzefovich): remove it when deleting old sql.execFactory.
	PartiallyDistributedPlansDisabled bool `` /* 166-byte string literal not displayed */
	// OptimizerUseHistograms indicates whether we should use histograms for
	// cardinality estimation in the optimizer.
	OptimizerUseHistograms bool `` /* 131-byte string literal not displayed */
	// OptimizerUseMultiColStats indicates whether we should use multi-column
	// statistics for cardinality estimation in the optimizer.
	OptimizerUseMultiColStats bool `` /* 144-byte string literal not displayed */
	// LocalityOptimizedSearch indicates that the optimizer will try to plan scans
	// and lookup joins in which local nodes (i.e., nodes in the gateway region)
	// are searched for matching rows before remote nodes, in the hope that the
	// execution engine can avoid visiting remote nodes.
	LocalityOptimizedSearch bool `` /* 134-byte string literal not displayed */
	// SafeUpdates causes errors when the client
	// sends syntax that may have unwanted side effects.
	SafeUpdates bool `protobuf:"varint,15,opt,name=safe_updates,json=safeUpdates,proto3" json:"safe_updates,omitempty"`
	// PreferLookupJoinsForFKs causes foreign key operations to prefer lookup
	// joins.
	PreferLookupJoinsForFKs bool `` /* 138-byte string literal not displayed */
	// ZigzagJoinEnabled indicates whether the optimizer should try and plan a
	// zigzag join.
	ZigzagJoinEnabled bool `protobuf:"varint,17,opt,name=zigzag_join_enabled,json=zigzagJoinEnabled,proto3" json:"zigzag_join_enabled,omitempty"`
	// RequireExplicitPrimaryKeys indicates whether CREATE TABLE statements should
	// error out if no primary key is provided.
	RequireExplicitPrimaryKeys bool `` /* 145-byte string literal not displayed */
	// ForceSavepointRestart overrides the default SAVEPOINT behavior
	// for compatibility with certain ORMs. When this flag is set,
	// the savepoint name will no longer be compared against the magic
	// identifier `cockroach_restart` in order use a restartable
	// transaction.
	ForceSavepointRestart bool `` /* 128-byte string literal not displayed */
	// AllowPrepareAsOptPlan must be set to allow use of
	//   PREPARE name AS OPT PLAN '...'
	AllowPrepareAsOptPlan bool `` /* 132-byte string literal not displayed */
	// TempTablesEnabled indicates whether temporary tables can be created or not.
	TempTablesEnabled bool `protobuf:"varint,21,opt,name=temp_tables_enabled,json=tempTablesEnabled,proto3" json:"temp_tables_enabled,omitempty"`
	// ImplicitPartitioningEnabled indicates whether implicit column partitioning
	// can be created.
	ImplicitColumnPartitioningEnabled bool `` /* 166-byte string literal not displayed */
	// OverrideMultiRegionZoneConfigEnabled indicates whether zone configurations can be
	// modified for multi-region databases and tables/indexes/partitions.
	OverrideMultiRegionZoneConfigEnabled bool `` /* 179-byte string literal not displayed */
	// DisallowFullTableScans indicates whether queries that plan full table scans
	// should be rejected.
	DisallowFullTableScans bool `` /* 133-byte string literal not displayed */
	// ImplicitSelectForUpdate is true if FOR UPDATE locking may be used during
	// the row-fetch phase of mutation statements.
	ImplicitSelectForUpdate bool `` /* 136-byte string literal not displayed */
	// InsertFastPath is true if the fast path for insert (with VALUES input) may
	// be used.
	InsertFastPath bool `protobuf:"varint,28,opt,name=insert_fast_path,json=insertFastPath,proto3" json:"insert_fast_path,omitempty"`
	// AlterColumnTypeGeneralEnabled is true if ALTER TABLE ... ALTER COLUMN ...
	// TYPE x may be used for general conversions requiring online schema change/
	AlterColumnTypeGeneralEnabled bool `` /* 156-byte string literal not displayed */
	// SynchronousCommit is a dummy setting for the synchronous_commit var.
	SynchronousCommit bool `protobuf:"varint,30,opt,name=synchronous_commit,json=synchronousCommit,proto3" json:"synchronous_commit,omitempty"`
	// EnableSeqScan is a dummy setting for the enable_seqscan var.
	EnableSeqScan bool `protobuf:"varint,31,opt,name=enable_seq_scan,json=enableSeqScan,proto3" json:"enable_seq_scan,omitempty"`
	// EnableUniqueWithoutIndexConstraints indicates whether creating unique
	// constraints without an index is allowed.
	// TODO(rytaft): remove this once unique without index constraints are fully
	// supported.
	EnableUniqueWithoutIndexConstraints bool `` /* 174-byte string literal not displayed */
	// StubCatalogTablesEnabled allows queries against virtual
	// tables that are not yet implemented.
	StubCatalogTablesEnabled bool `` /* 139-byte string literal not displayed */
	// ExperimentalComputedColumnRewrites allows automatic rewriting of computed
	// column expressions in CREATE TABLE and ALTER TABLE statements. See the
	// experimentalComputedColumnRewrites cluster setting for a description of the
	// format.
	ExperimentalComputedColumnRewrites string `` /* 168-byte string literal not displayed */
	// EnableStreamReplication indicates whether to allow setting up a replication
	// stream.
	EnableStreamReplication bool `` /* 134-byte string literal not displayed */
	// ResultsBufferSize specifies the size at which the pgwire results buffer
	// will self-flush.
	ResultsBufferSize int64 `protobuf:"varint,38,opt,name=results_buffer_size,json=resultsBufferSize,proto3" json:"results_buffer_size,omitempty"`
	// PropagateInputOrdering indicates that when planning a subquery or CTE, the
	// inner ordering should be propagated to the outer scope if the outer scope
	// is unordered. PropagateInputOrdering is currently experimental.
	PropagateInputOrdering bool `` /* 131-byte string literal not displayed */
	// ExperimentalDistSQLPlanningMode indicates whether the experimental
	// DistSQL planning driven by the optimizer is enabled.
	ExperimentalDistSQLPlanningMode ExperimentalDistSQLPlanningMode `` /* 201-byte string literal not displayed */
	// DistSQLMode indicates whether to run queries using the distributed
	// execution engine.
	DistSQLMode DistSQLExecMode `protobuf:"varint,41,opt,name=dist_sql_mode,json=distSqlMode,proto3,casttype=DistSQLExecMode" json:"dist_sql_mode,omitempty"`
	// SerialNormalizationMode indicates how to handle the SERIAL pseudo-type.
	SerialNormalizationMode SerialNormalizationMode `` /* 167-byte string literal not displayed */
	// NewSchemaChangerMode indicates whether to use the new schema changer.
	NewSchemaChangerMode NewSchemaChangerMode `` /* 157-byte string literal not displayed */
	// SequenceCache stores sequence values which have been cached using the
	// CACHE sequence option.
	SequenceCache SequenceCache `` /* 213-byte string literal not displayed */
	// PlacementEnabled indicates whether PLACEMENT can be used or not.
	PlacementEnabled bool `protobuf:"varint,45,opt,name=placement_enabled,json=placementEnabled,proto3" json:"placement_enabled,omitempty"`
	// SessionUserProto is the name of the user which has performed a SET ROLE
	// command. In other words, it is the name of the user which originally
	// established the connection before SET ROLE was first performed.
	// This is only populated when SET ROLE is used, otherwise the session_user
	// is the same as the UserProto in SessionData.
	//SessionUserProto github_com_cockroachdb_cockroach_pkg_security.SQLUsernameProto `protobuf:"bytes,46,opt,name=session_user_proto,json=sessionUserProto,proto3,casttype=sqlfmt/cockroach/pkg/security.SQLUsernameProto" json:"session_user_proto,omitempty"`
	// TxnRowsWrittenLog is the threshold for the number of rows written by a SQL
	// transaction which - once exceeded - will trigger a logging event to SQL_PERF
	// (or SQL_INTERNAL_PERF for internal transactions); 0 means disabled.
	TxnRowsWrittenLog int64 `protobuf:"varint,47,opt,name=txn_rows_written_log,json=txnRowsWrittenLog,proto3" json:"txn_rows_written_log,omitempty"`
	// TxnRowsWrittenErr is the limit for the number of rows written by a SQL
	// transaction which - once exceeded - will fail the transaction (or will
	// trigger a logging event to SQL_INTERNAL_PERF for internal transactions); 0
	// means disabled.
	TxnRowsWrittenErr int64 `protobuf:"varint,48,opt,name=txn_rows_written_err,json=txnRowsWrittenErr,proto3" json:"txn_rows_written_err,omitempty"`
	// TxnRowsReadLog is the threshold for the number of rows read by a SQL
	// transaction which - once exceeded - will trigger a logging event to SQL_PERF
	// (or SQL_INTERNAL_PERF for internal transactions); 0 means disabled.
	TxnRowsReadLog int64 `protobuf:"varint,49,opt,name=txn_rows_read_log,json=txnRowsReadLog,proto3" json:"txn_rows_read_log,omitempty"`
	// TxnRowsReadErr is the limit for the number of rows read by a SQL
	// transaction which - once exceeded - will fail the transaction (or will
	// trigger a logging event to SQL_INTERNAL_PERF for internal transactions); 0
	// means disabled.
	TxnRowsReadErr int64 `protobuf:"varint,50,opt,name=txn_rows_read_err,json=txnRowsReadErr,proto3" json:"txn_rows_read_err,omitempty"`
	// AutoRehomingEnabled indicates whether or not REGIONAL BY ROW tables should
	// have a rehoming ON UPDATE clause added to them.
	AutoRehomingEnabled bool `protobuf:"varint,51,opt,name=auto_rehoming_enabled,json=autoRehomingEnabled,proto3" json:"auto_rehoming_enabled,omitempty"`
	// IsSuperuser returns whether the user is a "superuser", which is defined
	// to be a user with an admin role.
	IsSuperuser bool `protobuf:"varint,52,opt,name=is_superuser,json=isSuperuser,proto3" json:"is_superuser,omitempty"`
	// LargeFullScanRows is the estimated row count at which a full scan is
	// considered large, and worthy of logging and/or disabling depending on other
	// settings.
	LargeFullScanRows float64 `protobuf:"fixed64,53,opt,name=large_full_scan_rows,json=largeFullScanRows,proto3" json:"large_full_scan_rows,omitempty"`
	// InjectRetryErrorsEnabled causes statements inside an explicit
	// transaction to return a transaction retry error. It is intended for
	// developers to test their app's retry logic.
	InjectRetryErrorsEnabled bool `` /* 139-byte string literal not displayed */
	// NullOrderedLast controls whether NULL is ordered last. We default to
	// NULLS FIRST for ascending order by default, whereas postgres defaults
	// to NULLS LAST.
	NullOrderedLast bool `protobuf:"varint,55,opt,name=null_ordered_last,json=nullOrderedLast,proto3" json:"null_ordered_last,omitempty"`
	// DisablePlanGists indicates whether we should disable automatic gists.
	DisablePlanGists bool `protobuf:"varint,56,opt,name=disable_plan_gists,json=disablePlanGists,proto3" json:"disable_plan_gists,omitempty"`
	// CustomOptions contains a map of all custom session settings.
	// These session variables have at least one period in their name.
	CustomOptions map[string]string `` /* 189-byte string literal not displayed */
	// IndexRecommendationsEnabled controls whether or not we display index
	// recommendations below the plan in EXPLAIN.
	IndexRecommendationsEnabled bool `` /* 146-byte string literal not displayed */
	// AvoidBuffering indicates that the returned data should not be
	// buffered by conn executor.  This is currently used by replication primitives
	// to ensure the data is flushed to the consumer immediately.
	AvoidBuffering bool `protobuf:"varint,59,opt,name=avoid_buffering,json=avoidBuffering,proto3" json:"avoid_buffering,omitempty"`
	// CheckFunctionBodies indicates whether functions are validated during
	// creation.
	CheckFunctionBodies bool `protobuf:"varint,60,opt,name=check_function_bodies,json=checkFunctionBodies,proto3" json:"check_function_bodies,omitempty"`
	// CostScansWithDefaultColSize is true when the optimizer should cost scans
	// and joins using the same default number of bytes per column instead of
	// column sizes from the AvgSize table statistic.
	CostScansWithDefaultColSize bool `` /* 152-byte string literal not displayed */
	// DefaultTxnQualityOfService indicates the default QoSLevel/WorkPriority of
	// newly created transactions.
	//DefaultTxnQualityOfService QoSLevel `protobuf:"varint,62,opt,name=default_txn_quality_of_service,json=defaultTxnQualityOfService,proto3,casttype=QoSLevel" json:"default_txn_quality_of_service,omitempty"`
	// OptSplitScanLimit indicates the maximum number of UNION ALL statements a
	// Scan may be split into during query optimization to avoid a sort.
	OptSplitScanLimit int32 `protobuf:"varint,63,opt,name=opt_split_scan_limit,json=optSplitScanLimit,proto3" json:"opt_split_scan_limit,omitempty"`
	// EnableSuperRegions is true when super region functionality is enabled.
	EnableSuperRegions bool `protobuf:"varint,64,opt,name=enable_super_regions,json=enableSuperRegions,proto3" json:"enable_super_regions,omitempty"`
	// OverrideAlterPrimaryRegionInSuperRegion is true when the user is allowed
	// to modify a primary region that is part of a super region.
	OverrideAlterPrimaryRegionInSuperRegion bool `` /* 190-byte string literal not displayed */
	// EnableImplicitTransactionForBatchStatements configures the handling of
	// multiple statements in a single query. If enabled, then an implicit
	// transaction is used when multiple statements are sent in a single query.
	// Setting this to false is a divergence from the pgwire protocol, but
	// matches the behavior of CockroachDB v21.2 and earlier.
	EnableImplicitTransactionForBatchStatements bool `` /* 200-byte string literal not displayed */
}

LocalOnlySessionData contains the serializable components of session parameters that only influence execution on the gateway nodes.

func (*LocalOnlySessionData) Descriptor

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

func (*LocalOnlySessionData) Marshal

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

func (*LocalOnlySessionData) MarshalTo

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

func (*LocalOnlySessionData) MarshalToSizedBuffer

func (m *LocalOnlySessionData) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*LocalOnlySessionData) ProtoMessage

func (*LocalOnlySessionData) ProtoMessage()

func (*LocalOnlySessionData) Reset

func (m *LocalOnlySessionData) Reset()

func (*LocalOnlySessionData) Size

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

func (*LocalOnlySessionData) String

func (m *LocalOnlySessionData) String() string

func (*LocalOnlySessionData) Unmarshal

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

func (*LocalOnlySessionData) XXX_DiscardUnknown

func (m *LocalOnlySessionData) XXX_DiscardUnknown()

func (*LocalOnlySessionData) XXX_Marshal

func (m *LocalOnlySessionData) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*LocalOnlySessionData) XXX_Merge

func (m *LocalOnlySessionData) XXX_Merge(src proto.Message)

func (*LocalOnlySessionData) XXX_Size

func (m *LocalOnlySessionData) XXX_Size() int

func (*LocalOnlySessionData) XXX_Unmarshal

func (m *LocalOnlySessionData) XXX_Unmarshal(b []byte) error

type MigratableSession

type MigratableSession struct {
	SessionData          SessionData                           `protobuf:"bytes,1,opt,name=session_data,json=sessionData,proto3" json:"session_data"`
	LocalOnlySessionData LocalOnlySessionData                  `protobuf:"bytes,2,opt,name=local_only_session_data,json=localOnlySessionData,proto3" json:"local_only_session_data"`
	PreparedStatements   []MigratableSession_PreparedStatement `protobuf:"bytes,3,rep,name=prepared_statements,json=preparedStatements,proto3" json:"prepared_statements"`
}

MigratableSession represents a serialization of a session that can be migrated between SQL sessions.

func (*MigratableSession) Descriptor

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

func (*MigratableSession) Marshal

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

func (*MigratableSession) MarshalTo

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

func (*MigratableSession) MarshalToSizedBuffer

func (m *MigratableSession) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MigratableSession) ProtoMessage

func (*MigratableSession) ProtoMessage()

func (*MigratableSession) Reset

func (m *MigratableSession) Reset()

func (*MigratableSession) Size

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

func (*MigratableSession) String

func (m *MigratableSession) String() string

func (*MigratableSession) Unmarshal

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

func (*MigratableSession) XXX_DiscardUnknown

func (m *MigratableSession) XXX_DiscardUnknown()

func (*MigratableSession) XXX_Marshal

func (m *MigratableSession) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MigratableSession) XXX_Merge

func (m *MigratableSession) XXX_Merge(src proto.Message)

func (*MigratableSession) XXX_Size

func (m *MigratableSession) XXX_Size() int

func (*MigratableSession) XXX_Unmarshal

func (m *MigratableSession) XXX_Unmarshal(b []byte) error

type MigratableSession_PreparedStatement

type MigratableSession_PreparedStatement struct {
	Name                 string                      `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	PlaceholderTypeHints []github_com_lib_pq_oid.Oid `` /* 168-byte string literal not displayed */
	SQL                  string                      `protobuf:"bytes,3,opt,name=sql,proto3" json:"sql,omitempty"`
}

PreparedStatement represents a prepared statement in a migratable session.

func (*MigratableSession_PreparedStatement) Descriptor

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

func (*MigratableSession_PreparedStatement) Marshal

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

func (*MigratableSession_PreparedStatement) MarshalTo

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

func (*MigratableSession_PreparedStatement) MarshalToSizedBuffer

func (m *MigratableSession_PreparedStatement) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MigratableSession_PreparedStatement) ProtoMessage

func (*MigratableSession_PreparedStatement) ProtoMessage()

func (*MigratableSession_PreparedStatement) Reset

func (*MigratableSession_PreparedStatement) Size

func (*MigratableSession_PreparedStatement) String

func (*MigratableSession_PreparedStatement) Unmarshal

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

func (*MigratableSession_PreparedStatement) XXX_DiscardUnknown

func (m *MigratableSession_PreparedStatement) XXX_DiscardUnknown()

func (*MigratableSession_PreparedStatement) XXX_Marshal

func (m *MigratableSession_PreparedStatement) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MigratableSession_PreparedStatement) XXX_Merge

func (*MigratableSession_PreparedStatement) XXX_Size

func (*MigratableSession_PreparedStatement) XXX_Unmarshal

func (m *MigratableSession_PreparedStatement) XXX_Unmarshal(b []byte) error

type NewSchemaChangerMode

type NewSchemaChangerMode int64

NewSchemaChangerMode controls if and when the new schema changer (in sql/schemachanger) is in use.

const (
	// UseNewSchemaChangerOff means that we never use the new schema changer.
	UseNewSchemaChangerOff NewSchemaChangerMode = iota
	// UseNewSchemaChangerOn means that we use the new schema changer for
	// supported statements in implicit transactions, but fall back to the old
	// schema changer otherwise.
	UseNewSchemaChangerOn
	// UseNewSchemaChangerUnsafe means that we attempt to use the new schema
	// changer for implemented statements including ones which aren't production
	// ready. Used for testing/development.
	UseNewSchemaChangerUnsafe
	// UseNewSchemaChangerUnsafeAlways means that we attempt to use the new schema
	// changer for all statements and return errors for unsupported statements.
	// Used for testing/development.
	UseNewSchemaChangerUnsafeAlways
)

func NewSchemaChangerModeFromString

func NewSchemaChangerModeFromString(val string) (_ NewSchemaChangerMode, ok bool)

NewSchemaChangerModeFromString converts a string into a NewSchemaChangerMode

func (NewSchemaChangerMode) String

func (m NewSchemaChangerMode) String() string

type SequenceCache

type SequenceCache map[uint32]*SequenceCacheEntry

SequenceCache stores sequence values that have already been created in KV and are available to be given out as sequence numbers. Values for sequences are keyed by the descpb.ID of each sequence. These IDs are represented as uint32 to prevent an import cycle with the descpb package. The cache should only be accessed using the provided API.

The cache ensures that values are invalidated when new descriptor versions are seen. Note that new descriptor versions may not monotonically increase. For example, the sequence schema may be altered in a txn, so the cache sees a new version V and invalidates/repopulates itself. Then, the txn may get rolled back, so the cache will see version V-1 and invalidate/repopulate itself again.

func (SequenceCache) NextValue

func (sc SequenceCache) NextValue(
	seqID uint32, clientVersion uint32, fetchNextValues func() (int64, int64, int64, error),
) (int64, error)

NextValue fetches the next value in the sequence cache. If the values in the cache have all been given out or if the descriptor version has changed, then fetchNextValues() is used to repopulate the cache.

type SequenceCacheEntry

type SequenceCacheEntry struct {
	// CachedVersion stores the descpb.DescriptorVersion that cached values are associated with.
	// The version is checked to determine if cache needs to be invalidated. The version is stored as
	// a uint32 to prevent an import cycle with the descpb package.
	CachedVersion uint32 `protobuf:"varint,1,opt,name=cached_version,json=cachedVersion,proto3" json:"cached_version,omitempty"`
	// CurrentValue stores the present value of the sequence to be given out.
	CurrentValue int64 `protobuf:"varint,2,opt,name=current_value,json=currentValue,proto3" json:"current_value,omitempty"`
	// Increment stores the amount to Increment the currentVal by each time the
	// currentVal is used. This value corresponds to descpb.TableDescriptor_SequenceOpts.Increment.
	Increment int64 `protobuf:"varint,3,opt,name=increment,proto3" json:"increment,omitempty"`
	// NumValues represents the number of values to cache. The cache is considered
	// to be empty when NumValues is 0.
	NumValues int64 `protobuf:"varint,4,opt,name=num_values,json=numValues,proto3" json:"num_values,omitempty"`
}

SequenceCacheEntry is an entry in a SequenceCache.

func (*SequenceCacheEntry) Descriptor

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

func (*SequenceCacheEntry) Marshal

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

func (*SequenceCacheEntry) MarshalTo

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

func (*SequenceCacheEntry) MarshalToSizedBuffer

func (m *SequenceCacheEntry) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*SequenceCacheEntry) ProtoMessage

func (*SequenceCacheEntry) ProtoMessage()

func (*SequenceCacheEntry) Reset

func (m *SequenceCacheEntry) Reset()

func (*SequenceCacheEntry) Size

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

func (*SequenceCacheEntry) String

func (m *SequenceCacheEntry) String() string

func (*SequenceCacheEntry) Unmarshal

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

func (*SequenceCacheEntry) XXX_DiscardUnknown

func (m *SequenceCacheEntry) XXX_DiscardUnknown()

func (*SequenceCacheEntry) XXX_Marshal

func (m *SequenceCacheEntry) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*SequenceCacheEntry) XXX_Merge

func (m *SequenceCacheEntry) XXX_Merge(src proto.Message)

func (*SequenceCacheEntry) XXX_Size

func (m *SequenceCacheEntry) XXX_Size() int

func (*SequenceCacheEntry) XXX_Unmarshal

func (m *SequenceCacheEntry) XXX_Unmarshal(b []byte) error

type SequenceState

type SequenceState struct {
	Seqs []*SequenceState_Seq `protobuf:"bytes,1,rep,name=seqs,proto3" json:"seqs,omitempty"`
	// last_seq_incremented is the id of the last sequence incremented by the
	// session. This field is filled in iff seqs is not empty.
	LastSeqIncremented uint32 `protobuf:"varint,2,opt,name=last_seq_incremented,json=lastSeqIncremented,proto3" json:"last_seq_incremented,omitempty"`
}

SequenceState is used to marshall the sessiondata.SequenceState struct.

func (*SequenceState) Descriptor

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

func (*SequenceState) Marshal

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

func (*SequenceState) MarshalTo

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

func (*SequenceState) MarshalToSizedBuffer

func (m *SequenceState) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*SequenceState) ProtoMessage

func (*SequenceState) ProtoMessage()

func (*SequenceState) Reset

func (m *SequenceState) Reset()

func (*SequenceState) Size

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

func (*SequenceState) String

func (m *SequenceState) String() string

func (*SequenceState) Unmarshal

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

func (*SequenceState) XXX_DiscardUnknown

func (m *SequenceState) XXX_DiscardUnknown()

func (*SequenceState) XXX_Marshal

func (m *SequenceState) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*SequenceState) XXX_Merge

func (m *SequenceState) XXX_Merge(src proto.Message)

func (*SequenceState) XXX_Size

func (m *SequenceState) XXX_Size() int

func (*SequenceState) XXX_Unmarshal

func (m *SequenceState) XXX_Unmarshal(b []byte) error

type SequenceState_Seq

type SequenceState_Seq struct {
	SeqID     uint32 `protobuf:"varint,1,opt,name=seq_id,json=seqId,proto3" json:"seq_id,omitempty"`
	LatestVal int64  `protobuf:"varint,2,opt,name=latest_val,json=latestVal,proto3" json:"latest_val,omitempty"`
}

Seq represents the last value of one sequence modified by the session.

func (*SequenceState_Seq) Descriptor

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

func (*SequenceState_Seq) Marshal

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

func (*SequenceState_Seq) MarshalTo

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

func (*SequenceState_Seq) MarshalToSizedBuffer

func (m *SequenceState_Seq) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*SequenceState_Seq) ProtoMessage

func (*SequenceState_Seq) ProtoMessage()

func (*SequenceState_Seq) Reset

func (m *SequenceState_Seq) Reset()

func (*SequenceState_Seq) Size

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

func (*SequenceState_Seq) String

func (m *SequenceState_Seq) String() string

func (*SequenceState_Seq) Unmarshal

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

func (*SequenceState_Seq) XXX_DiscardUnknown

func (m *SequenceState_Seq) XXX_DiscardUnknown()

func (*SequenceState_Seq) XXX_Marshal

func (m *SequenceState_Seq) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*SequenceState_Seq) XXX_Merge

func (m *SequenceState_Seq) XXX_Merge(src proto.Message)

func (*SequenceState_Seq) XXX_Size

func (m *SequenceState_Seq) XXX_Size() int

func (*SequenceState_Seq) XXX_Unmarshal

func (m *SequenceState_Seq) XXX_Unmarshal(b []byte) error

type SerialNormalizationMode

type SerialNormalizationMode int64

SerialNormalizationMode controls if and when the Executor uses DistSQL. NB: The values of the enums must be stable across releases.

const (
	// SerialUsesRowID means use INT NOT NULL DEFAULT unique_rowid().
	SerialUsesRowID SerialNormalizationMode = 0
	// SerialUsesVirtualSequences means create a virtual sequence and
	// use INT NOT NULL DEFAULT nextval(...).
	SerialUsesVirtualSequences SerialNormalizationMode = 1
	// SerialUsesSQLSequences means create a regular SQL sequence and
	// use INT NOT NULL DEFAULT nextval(...). Each call to nextval()
	// is a distributed call to kv. This minimizes the size of gaps
	// between successive sequence numbers (which occur due to
	// node failures or errors), but the multiple kv calls
	// can impact performance negatively.
	SerialUsesSQLSequences SerialNormalizationMode = 2
	// SerialUsesCachedSQLSequences is identical to SerialUsesSQLSequences with
	// the exception that nodes can cache sequence values. This significantly
	// reduces contention and distributed calls to kv, which results in better
	// performance. Gaps between sequences may be larger as a result of cached
	// values being lost to errors and/or node failures.
	SerialUsesCachedSQLSequences SerialNormalizationMode = 3
	// SerialUsesUnorderedRowID means use INT NOT NULL DEFAULT unordered_unique_rowid().
	SerialUsesUnorderedRowID SerialNormalizationMode = 4
)

func SerialNormalizationModeFromString

func SerialNormalizationModeFromString(val string) (_ SerialNormalizationMode, ok bool)

SerialNormalizationModeFromString converts a string into a SerialNormalizationMode

func (SerialNormalizationMode) String

func (m SerialNormalizationMode) String() string

type SessionData

type SessionData struct {
	// Database indicates the "current" database for the purpose of resolving
	// names.
	Database string `protobuf:"bytes,1,opt,name=database,proto3" json:"database,omitempty"`
	// ApplicationName is the name of the application running the current
	// session. This can be used for logging and per-application statistics.
	ApplicationName string `protobuf:"bytes,2,opt,name=application_name,json=applicationName,proto3" json:"application_name,omitempty"`
	// User is the name of the user logged into the session.
	//UserProto github_com_cockroachdb_cockroach_pkg_security.SQLUsernameProto `protobuf:"bytes,3,opt,name=user_proto,json=userProto,proto3,casttype=sqlfmt/cockroach/pkg/security.SQLUsernameProto" json:"user_proto,omitempty"`
	// DataConversion gives access to the data conversion configuration.
	DataConversionConfig DataConversionConfig `protobuf:"bytes,4,opt,name=data_conversion_config,json=dataConversionConfig,proto3" json:"data_conversion_config"`
	// VectorizeMode indicates which kinds of queries to use vectorized execution
	// engine for.
	VectorizeMode VectorizeExecMode `` /* 152-byte string literal not displayed */
	// TestingVectorizeInjectPanics indicates whether random panics are injected
	// into the vectorized flow execution. The goal of such behavior is making
	// sure that errors that are propagated as panics in the vectorized engine
	// are caught in all scenarios.
	TestingVectorizeInjectPanics bool `` /* 150-byte string literal not displayed */
	// DefaultIntSize specifies the size in bits or bytes (preferred) of how a
	// "naked" INT type should be parsed.
	DefaultIntSize int32 `protobuf:"varint,7,opt,name=default_int_size,json=defaultIntSize,proto3" json:"default_int_size,omitempty"`
	// The name of the location according to whose current timezone we're going to
	// parse timestamps. Used to initialize sessiondata.SessionData.Location on
	// the remote nodes.
	//
	// Note that the current serialization of the time.Location objects as
	// strings has many drawbacks which could lead to unstable computation on the
	// remote nodes. See #36864 and
	// https://sqlfmt/cockroach/pull/55377#issuecomment-707794695
	// for more details.
	Location string `protobuf:"bytes,8,opt,name=location,proto3" json:"location,omitempty"`
	// SearchPath is a list of namespaces to search builtins in. Used to
	// initialize sessiondata.SessionData.SearchPath on the remote nodes.
	SearchPath          []string `protobuf:"bytes,9,rep,name=search_path,json=searchPath,proto3" json:"search_path,omitempty"`
	TemporarySchemaName string   `protobuf:"bytes,10,opt,name=temporary_schema_name,json=temporarySchemaName,proto3" json:"temporary_schema_name,omitempty"`
	// SeqState gives access to the SQL sequences that have been manipulated by
	// the session.
	SeqState SequenceState `protobuf:"bytes,11,opt,name=seq_state,json=seqState,proto3" json:"seq_state"`
	// WorkMemLimit determines how much RAM (in bytes) a single operation of a
	// single query can use before it has to spill to disk.
	WorkMemLimit int64 `protobuf:"varint,12,opt,name=WorkMemLimit,proto3" json:"WorkMemLimit,omitempty"`
	// IntervalStyleEnabled allows the setting of IntervalStyle to different
	// values.
	IntervalStyleEnabled bool `protobuf:"varint,13,opt,name=interval_style_enabled,json=intervalStyleEnabled,proto3" json:"interval_style_enabled,omitempty"`
	// DateStyleEnabled allows the setting of DateStyle to different
	// values.
	DateStyleEnabled bool `protobuf:"varint,14,opt,name=date_style_enabled,json=dateStyleEnabled,proto3" json:"date_style_enabled,omitempty"`
	// LockTimeout is the maximum amount of time that a query will wait while
	// attempting to acquire a lock on a key or while blocking on an existing
	// lock in order to perform a non-locking read on a key.
	LockTimeout time.Duration `protobuf:"bytes,15,opt,name=lock_timeout,json=lockTimeout,proto3,stdduration" json:"lock_timeout"`
	// Internal is true if this query came from InternalExecutor or an internal
	// planner.
	Internal bool `protobuf:"varint,16,opt,name=internal,proto3" json:"internal,omitempty"`
	// OnUpdateRehomeRowEnabled controls whether the ON UPDATE rehome_row()
	// will actually trigger on row updates.
	OnUpdateRehomeRowEnabled bool `` /* 141-byte string literal not displayed */
	// JoinReaderOrderingStrategyBatchSize is the size limit on the input rows to
	// the joinReader processor (when ordering is required to be maintained) to
	// construct a single lookup KV batch.
	JoinReaderOrderingStrategyBatchSize int64 `` /* 176-byte string literal not displayed */
	// ParallelizeMultiKeyLookupJoinsEnabled is true when the join reader should
	// parallelize lookup batches under all circumstances. Enabling this will
	// increase the speed of lookup joins when each input row might get multiple
	// looked up rows at the cost of increased memory usage.
	ParallelizeMultiKeyLookupJoinsEnabled bool `` /* 182-byte string literal not displayed */
}

SessionData contains session parameters that are easily serializable and are required to be propagated to the remote nodes for the correct execution of DistSQL flows.

func (*SessionData) Descriptor

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

func (*SessionData) Marshal

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

func (*SessionData) MarshalTo

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

func (*SessionData) MarshalToSizedBuffer

func (m *SessionData) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*SessionData) ProtoMessage

func (*SessionData) ProtoMessage()

func (*SessionData) Reset

func (m *SessionData) Reset()

func (*SessionData) Size

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

func (*SessionData) String

func (m *SessionData) String() string

func (*SessionData) Unmarshal

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

func (*SessionData) XXX_DiscardUnknown

func (m *SessionData) XXX_DiscardUnknown()

func (*SessionData) XXX_Marshal

func (m *SessionData) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*SessionData) XXX_Merge

func (m *SessionData) XXX_Merge(src proto.Message)

func (*SessionData) XXX_Size

func (m *SessionData) XXX_Size() int

func (*SessionData) XXX_Unmarshal

func (m *SessionData) XXX_Unmarshal(b []byte) error

type SessionRevivalToken

type SessionRevivalToken struct {
	// The payload to sign. This uses raw bytes so the data being signed is
	// deterministic and not dependent on the proto version.
	Payload []byte `protobuf:"bytes,1,opt,name=payload,proto3" json:"payload,omitempty"`
	// The signature of the payload, signed using the new signing key.
	Signature []byte `protobuf:"bytes,2,opt,name=signature,proto3" json:"signature,omitempty"`
}

SessionRevivalToken is an opaque piece of data that can be used to authenticate a new SQL session for the user who created this token.

func (*SessionRevivalToken) Descriptor

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

func (*SessionRevivalToken) Marshal

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

func (*SessionRevivalToken) MarshalTo

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

func (*SessionRevivalToken) MarshalToSizedBuffer

func (m *SessionRevivalToken) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*SessionRevivalToken) ProtoMessage

func (*SessionRevivalToken) ProtoMessage()

func (*SessionRevivalToken) Reset

func (m *SessionRevivalToken) Reset()

func (*SessionRevivalToken) Size

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

func (*SessionRevivalToken) String

func (m *SessionRevivalToken) String() string

func (*SessionRevivalToken) Unmarshal

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

func (*SessionRevivalToken) XXX_DiscardUnknown

func (m *SessionRevivalToken) XXX_DiscardUnknown()

func (*SessionRevivalToken) XXX_Marshal

func (m *SessionRevivalToken) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*SessionRevivalToken) XXX_Merge

func (m *SessionRevivalToken) XXX_Merge(src proto.Message)

func (*SessionRevivalToken) XXX_Size

func (m *SessionRevivalToken) XXX_Size() int

func (*SessionRevivalToken) XXX_Unmarshal

func (m *SessionRevivalToken) XXX_Unmarshal(b []byte) error

type SessionRevivalToken_Payload

type SessionRevivalToken_Payload struct {
	// The SQL user who can use this token to authenticate.
	User string `protobuf:"bytes,1,opt,name=user,proto3" json:"user,omitempty"`
	// The algorithm used to sign the payload. Can be either Ed25519 or RSA.
	Algorithm string `protobuf:"bytes,2,opt,name=algorithm,proto3" json:"algorithm,omitempty"`
	// The time that this token is no longer considered valid.
	ExpiresAt *types.Timestamp `protobuf:"bytes,3,opt,name=expires_at,json=expiresAt,proto3" json:"expires_at,omitempty"`
	// The time that this token was created.
	IssuedAt *types.Timestamp `protobuf:"bytes,4,opt,name=issued_at,json=issuedAt,proto3" json:"issued_at,omitempty"`
}

Payload is defined as a separate type so that it’s easier to sign.

func (*SessionRevivalToken_Payload) Descriptor

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

func (*SessionRevivalToken_Payload) Marshal

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

func (*SessionRevivalToken_Payload) MarshalTo

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

func (*SessionRevivalToken_Payload) MarshalToSizedBuffer

func (m *SessionRevivalToken_Payload) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*SessionRevivalToken_Payload) ProtoMessage

func (*SessionRevivalToken_Payload) ProtoMessage()

func (*SessionRevivalToken_Payload) Reset

func (m *SessionRevivalToken_Payload) Reset()

func (*SessionRevivalToken_Payload) Size

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

func (*SessionRevivalToken_Payload) String

func (m *SessionRevivalToken_Payload) String() string

func (*SessionRevivalToken_Payload) Unmarshal

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

func (*SessionRevivalToken_Payload) XXX_DiscardUnknown

func (m *SessionRevivalToken_Payload) XXX_DiscardUnknown()

func (*SessionRevivalToken_Payload) XXX_Marshal

func (m *SessionRevivalToken_Payload) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*SessionRevivalToken_Payload) XXX_Merge

func (m *SessionRevivalToken_Payload) XXX_Merge(src proto.Message)

func (*SessionRevivalToken_Payload) XXX_Size

func (m *SessionRevivalToken_Payload) XXX_Size() int

func (*SessionRevivalToken_Payload) XXX_Unmarshal

func (m *SessionRevivalToken_Payload) XXX_Unmarshal(b []byte) error

type VectorizeExecMode

type VectorizeExecMode int32

VectorizeExecMode controls if an when the Executor executes queries using the columnar execution engine.

const (
	// VectorizeUnset means the VectorizeExecMode wasn't explicitly set. Having
	// the first enum value as zero is required by proto3. This is mapped to
	// VectorizeOn.
	VectorizeUnset VectorizeExecMode = 0
	// VectorizeOn means that any supported queries will be run using the
	// columnar execution.
	VectorizeOn VectorizeExecMode = 2
	// VectorizeExperimentalAlways means that we attempt to vectorize all
	// queries; unsupported queries will fail. Mostly used for testing.
	VectorizeExperimentalAlways VectorizeExecMode = 3
	// VectorizeOff means that columnar execution is disabled.
	VectorizeOff VectorizeExecMode = 4
)

func VectorizeExecModeFromString

func VectorizeExecModeFromString(val string) (VectorizeExecMode, bool)

VectorizeExecModeFromString converts a string into a VectorizeExecMode. False is returned if the conversion was unsuccessful.

func (VectorizeExecMode) EnumDescriptor

func (VectorizeExecMode) EnumDescriptor() ([]byte, []int)

func (VectorizeExecMode) String

func (m VectorizeExecMode) String() string

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL