 Documentation
      ¶
      Documentation
      ¶
    
    
  
    
  
    Index ¶
- Constants
- func CoordinationOnAlterNode(t *Coordination, c *context.Context, call call, path string) func(error)
- func CoordinationOnClose(t *Coordination, c *context.Context, call call) func(error)
- func CoordinationOnCreateNode(t *Coordination, c *context.Context, call call, path string) func(error)
- func CoordinationOnDescribeNode(t *Coordination, c *context.Context, call call, path string) func(error)
- func CoordinationOnDropNode(t *Coordination, c *context.Context, call call, path string) func(error)
- func CoordinationOnNew(t *Coordination, c *context.Context, call call) func()
- func CoordinationOnSession(t *Coordination, c *context.Context, call call, path string) func(error)
- func CoordinationOnSessionClientTimeout(t *Coordination, lastGoodResponseTime time.Time, timeout time.Duration)
- func CoordinationOnSessionKeepAliveTimeout(t *Coordination, lastGoodResponseTime time.Time, timeout time.Duration)
- func CoordinationOnSessionReceive(t *Coordination) func(response *Ydb_Coordination.SessionResponse, _ error)
- func CoordinationOnSessionReceiveUnexpected(t *Coordination, response *Ydb_Coordination.SessionResponse)
- func CoordinationOnSessionSend(t *Coordination, request *Ydb_Coordination.SessionRequest) func(error)
- func CoordinationOnSessionServerError(t *Coordination, failure *Ydb_Coordination.SessionResponse_Failure)
- func CoordinationOnSessionServerExpire(t *Coordination, failure *Ydb_Coordination.SessionResponse_Failure)
- func CoordinationOnSessionStart(t *Coordination) func(error)
- func CoordinationOnSessionStartTimeout(t *Coordination, timeout time.Duration)
- func CoordinationOnSessionStarted(t *Coordination, sessionID uint64, expectedSessionID uint64)
- func CoordinationOnSessionStop(t *Coordination, sessionID uint64)
- func CoordinationOnSessionStopTimeout(t *Coordination, timeout time.Duration)
- func CoordinationOnSessionStopped(t *Coordination, sessionID uint64, expectedSessionID uint64)
- func CoordinationOnStreamNew(t *Coordination) func(error)
- func DatabaseSQLOnConnBegin(t *DatabaseSQL, c *context.Context, call call) func(tx tableTransactionInfo, _ error)
- func DatabaseSQLOnConnClose(t *DatabaseSQL, c *context.Context, call call) func(error)
- func DatabaseSQLOnConnExec(t *DatabaseSQL, c *context.Context, call call, query string, mode string, ...) func(error)
- func DatabaseSQLOnConnIsTableExists(t *DatabaseSQL, c *context.Context, call call, tableName string) func(exists bool, _ error)
- func DatabaseSQLOnConnPing(t *DatabaseSQL, c *context.Context, call call) func(error)
- func DatabaseSQLOnConnPrepare(t *DatabaseSQL, c *context.Context, call call, query string) func(error)
- func DatabaseSQLOnConnQuery(t *DatabaseSQL, c *context.Context, call call, query string, mode string, ...) func(error)
- func DatabaseSQLOnConnectorConnect(t *DatabaseSQL, c *context.Context, call call) func(_ error, session tableSessionInfo)
- func DatabaseSQLOnDoTx(t *DatabaseSQL, c *context.Context, call call, iD string, idempotent bool) func(error) func(attempts int, _ error)
- func DatabaseSQLOnStmtClose(t *DatabaseSQL, stmtContext *context.Context, call call) func(error)
- func DatabaseSQLOnStmtExec(t *DatabaseSQL, c *context.Context, call call, stmtContext context.Context, ...) func(error)
- func DatabaseSQLOnStmtQuery(t *DatabaseSQL, c *context.Context, call call, stmtContext context.Context, ...) func(error)
- func DatabaseSQLOnTxCommit(t *DatabaseSQL, c *context.Context, call call, tx tableTransactionInfo) func(error)
- func DatabaseSQLOnTxExec(t *DatabaseSQL, c *context.Context, call call, txContext context.Context, ...) func(error)
- func DatabaseSQLOnTxPrepare(t *DatabaseSQL, c *context.Context, call call, txContext context.Context, ...) func(error)
- func DatabaseSQLOnTxQuery(t *DatabaseSQL, c *context.Context, call call, txContext context.Context, ...) func(error)
- func DatabaseSQLOnTxRollback(t *DatabaseSQL, c *context.Context, call call, tx tableTransactionInfo) func(error)
- func DiscoveryOnDiscover(t *Discovery, c *context.Context, call call, address string, database string) func(location string, endpoints []EndpointInfo, _ error)
- func DiscoveryOnWhoAmI(t *Discovery, c *context.Context, call call) func(user string, groups []string, _ error)
- func DriverOnBalancerChooseEndpoint(t *Driver, c *context.Context, call call) func(endpoint EndpointInfo, _ error)
- func DriverOnBalancerClose(t *Driver, c *context.Context, call call) func(error)
- func DriverOnBalancerClusterDiscoveryAttempt(t *Driver, c *context.Context, call call, address string) func(error)
- func DriverOnBalancerInit(t *Driver, c *context.Context, call call, name string) func(error)
- func DriverOnBalancerUpdate(t *Driver, c *context.Context, call call, needLocalDC bool) ...
- func DriverOnClose(t *Driver, c *context.Context, call call) func(error)
- func DriverOnConnAllow(t *Driver, c *context.Context, call call, endpoint EndpointInfo, ...) func(state ConnState)
- func DriverOnConnBan(t *Driver, c *context.Context, call call, endpoint EndpointInfo, ...) func(state ConnState)
- func DriverOnConnClose(t *Driver, c *context.Context, call call, endpoint EndpointInfo) func(error)
- func DriverOnConnDial(t *Driver, c *context.Context, call call, endpoint EndpointInfo) func(error)
- func DriverOnConnInvoke(t *Driver, c *context.Context, call call, endpoint EndpointInfo, m Method) func(_ error, issues []Issue, opID string, state ConnState, ...)
- func DriverOnConnNewStream(t *Driver, c *context.Context, call call, endpoint EndpointInfo, m Method) func(_ error, state ConnState)
- func DriverOnConnPark(t *Driver, c *context.Context, call call, endpoint EndpointInfo) func(error)
- func DriverOnConnStateChange(t *Driver, c *context.Context, call call, endpoint EndpointInfo, ...) func(state ConnState)
- func DriverOnConnStreamCloseSend(t *Driver, c *context.Context, call call) func(error)
- func DriverOnConnStreamRecvMsg(t *Driver, c *context.Context, call call) func(error)
- func DriverOnConnStreamSendMsg(t *Driver, c *context.Context, call call) func(error)
- func DriverOnGetCredentials(t *Driver, c *context.Context, call call) func(token string, _ error)
- func DriverOnInit(t *Driver, c *context.Context, call call, endpoint string, database string, ...) func(error)
- func DriverOnPoolNew(t *Driver, c *context.Context, call call) func()
- func DriverOnPoolRelease(t *Driver, c *context.Context, call call) func(error)
- func DriverOnRepeaterWakeUp(t *Driver, c *context.Context, call call, name string, event string) func(error)
- func DriverOnResolve(t *Driver, call call, target string, resolved []string) func(error)
- func DriverOnWith(t *Driver, c *context.Context, call call, endpoint string, database string, ...) func(error)
- func QueryOnClose(t *Query, c *context.Context, call call) func(error)
- func QueryOnDo(t *Query, c *context.Context, call call) func(attempts int, _ error)
- func QueryOnDoTx(t *Query, c *context.Context, call call) func(attempts int, _ error)
- func QueryOnNew(t *Query, c *context.Context, call call) func()
- func QueryOnPoolChange(t *Query, limit int, index int, idle int, inUse int)
- func QueryOnPoolClose(t *Query, c *context.Context, call call) func(error)
- func QueryOnPoolGet(t *Query, c *context.Context, call call) func(error)
- func QueryOnPoolNew(t *Query, c *context.Context, call call) func(limit int)
- func QueryOnPoolPut(t *Query, c *context.Context, call call) func(error)
- func QueryOnPoolTry(t *Query, c *context.Context, call call) func(error)
- func QueryOnPoolWith(t *Query, c *context.Context, call call) func(_ error, attempts int)
- func QueryOnResultClose(t *Query, c *context.Context, call call) func(error)
- func QueryOnResultNew(t *Query, c *context.Context, call call) func(error)
- func QueryOnResultNextPart(t *Query, c *context.Context, call call) func(error)
- func QueryOnResultNextResultSet(t *Query, c *context.Context, call call) func(error)
- func QueryOnResultSetNextRow(t *Query, c *context.Context, call call) func(error)
- func QueryOnRowScan(t *Query, c *context.Context, call call) func(error)
- func QueryOnRowScanNamed(t *Query, c *context.Context, call call) func(error)
- func QueryOnRowScanStruct(t *Query, c *context.Context, call call) func(error)
- func QueryOnSessionAttach(t *Query, c *context.Context, call call, session querySessionInfo) func(error)
- func QueryOnSessionBegin(t *Query, c *context.Context, call call, session querySessionInfo) func(_ error, tx queryTransactionInfo)
- func QueryOnSessionCreate(t *Query, c *context.Context, call call) func(session querySessionInfo, _ error)
- func QueryOnSessionDelete(t *Query, c *context.Context, call call, session querySessionInfo) func(error)
- func QueryOnSessionExecute(t *Query, c *context.Context, call call, session querySessionInfo, ...) func(error)
- func QueryOnTxExecute(t *Query, c *context.Context, call call, session querySessionInfo, ...) func(error)
- func RetryOnRetry(t *Retry, c *context.Context, call call, label string, idempotent bool, ...) func(attempts int, _ error)
- func SchemeOnDescribePath(t *Scheme, c *context.Context, call call, path string) func(entryType string, _ error)
- func SchemeOnListDirectory(t *Scheme, c *context.Context, call call) func(error)
- func SchemeOnMakeDirectory(t *Scheme, c *context.Context, call call, path string) func(error)
- func SchemeOnModifyPermissions(t *Scheme, c *context.Context, call call, path string) func(error)
- func SchemeOnRemoveDirectory(t *Scheme, c *context.Context, call call, path string) func(error)
- func ScriptingOnClose(t *Scripting, c *context.Context, call call) func(error)
- func ScriptingOnExecute(t *Scripting, c *context.Context, call call, query string, ...) func(result scriptingResult, _ error)
- func ScriptingOnExplain(t *Scripting, c *context.Context, call call, query string) func(plan string, _ error)
- func ScriptingOnStreamExecute(t *Scripting, c *context.Context, call call, query string, ...) func(error) func(error)
- func TableOnClose(t *Table, c *context.Context, call call) func(error)
- func TableOnCreateSession(t *Table, c *context.Context, call call) func(session tableSessionInfo, attempts int, _ error)
- func TableOnDo(t *Table, c *context.Context, call call, label string, idempotent bool, ...) func(attempts int, _ error)
- func TableOnDoTx(t *Table, c *context.Context, call call, label string, idempotent bool, ...) func(attempts int, _ error)
- func TableOnInit(t *Table, c *context.Context, call call) func(limit int)
- func TableOnPoolGet(t *Table, c *context.Context, call call) func(session tableSessionInfo, attempts int, _ error)
- func TableOnPoolPut(t *Table, c *context.Context, call call, session tableSessionInfo) func(error)
- func TableOnPoolSessionAdd(t *Table, session tableSessionInfo)
- func TableOnPoolSessionRemove(t *Table, session tableSessionInfo)
- func TableOnPoolStateChange(t *Table, size int, event string)
- func TableOnPoolWait(t *Table, c *context.Context, call call) func(session tableSessionInfo, _ error)
- func TableOnSessionBulkUpsert(t *Table, c *context.Context, call call, session tableSessionInfo) func(error)
- func TableOnSessionDelete(t *Table, c *context.Context, call call, session tableSessionInfo) func(error)
- func TableOnSessionKeepAlive(t *Table, c *context.Context, call call, session tableSessionInfo) func(error)
- func TableOnSessionNew(t *Table, c *context.Context, call call) func(session tableSessionInfo, _ error)
- func TableOnSessionQueryExecute(t *Table, c *context.Context, call call, session tableSessionInfo, ...) func(tx tableTransactionInfo, prepared bool, result tableResult, _ error)
- func TableOnSessionQueryExplain(t *Table, c *context.Context, call call, session tableSessionInfo, ...) func(aST string, plan string, _ error)
- func TableOnSessionQueryPrepare(t *Table, c *context.Context, call call, session tableSessionInfo, ...) func(result tableDataQuery, _ error)
- func TableOnSessionQueryStreamExecute(t *Table, c *context.Context, call call, session tableSessionInfo, ...) func(error)
- func TableOnSessionQueryStreamRead(t *Table, c *context.Context, call call, session tableSessionInfo) func(error)
- func TableOnTxBegin(t *Table, c *context.Context, call call, session tableSessionInfo) func(tx tableTransactionInfo, _ error)
- func TableOnTxCommit(t *Table, c *context.Context, call call, session tableSessionInfo, ...) func(error)
- func TableOnTxExecute(t *Table, c *context.Context, call call, session tableSessionInfo, ...) func(result tableResult, _ error)
- func TableOnTxExecuteStatement(t *Table, c *context.Context, call call, session tableSessionInfo, ...) func(result tableResult, _ error)
- func TableOnTxRollback(t *Table, c *context.Context, call call, session tableSessionInfo, ...) func(error)
- func TopicOnReaderClose(t *Topic, readerConnectionID string, closeReason error) func(closeError error)
- func TopicOnReaderCommit(t *Topic, requestContext *context.Context, topic string, partitionID int64, ...) func(error)
- func TopicOnReaderCommittedNotify(t *Topic, readerConnectionID string, topic string, partitionID int64, ...)
- func TopicOnReaderError(t *Topic, readerConnectionID string, e error)
- func TopicOnReaderInit(t *Topic, preInitReaderConnectionID string, ...) func(readerConnectionID string, _ error)
- func TopicOnReaderPartitionReadStartResponse(t *Topic, readerConnectionID string, partitionContext *context.Context, ...) func(readOffset *int64, commitOffset *int64, _ error)
- func TopicOnReaderPartitionReadStopResponse(t *Topic, readerConnectionID string, partitionContext *context.Context, ...) func(error)
- func TopicOnReaderReadMessages(t *Topic, requestContext *context.Context, minCount int, maxCount int, ...) ...
- func TopicOnReaderReceiveDataResponse(t *Topic, readerConnectionID string, localBufferSizeAfterReceive int, ...) func(error)
- func TopicOnReaderReconnect(t *Topic, reason error) func(error)
- func TopicOnReaderReconnectRequest(t *Topic, reason error, wasSent bool)
- func TopicOnReaderSendCommitMessage(t *Topic, commitsInfo TopicReaderStreamSendCommitMessageStartMessageInfo) func(error)
- func TopicOnReaderSentDataRequest(t *Topic, readerConnectionID string, requestBytes int, ...)
- func TopicOnReaderStart(t *Topic, readerID int64, consumer string)
- func TopicOnReaderUnknownGrpcMessage(t *Topic, readerConnectionID string, e error)
- func TopicOnReaderUpdateToken(t *Topic, readerConnectionID string) func(tokenLen int, _ error) func(error)
- func TopicOnWriterClose(t *Topic, writerInstanceID string, reason error) func(error)
- func TopicOnWriterCompressMessages(t *Topic, writerInstanceID string, sessionID string, codec int32, ...) func(error)
- func TopicOnWriterInitStream(t *Topic, writerInstanceID string, topic string, producerID string) func(sessionID string, _ error)
- func TopicOnWriterReadUnknownGrpcMessage(t *Topic, writerInstanceID string, sessionID string, e error)
- func TopicOnWriterReconnect(t *Topic, writerInstanceID string, topic string, producerID string, ...) func(error)
- func TopicOnWriterSendMessages(t *Topic, writerInstanceID string, sessionID string, codec int32, ...) func(error)
- func WithDefaultDetails(defaultDetails Details) matchDetailsOption
- func WithPOSIXMatch() matchDetailsOption
- type ConnState
- type Coordination
- type CoordinationAlterNodeDoneInfo
- type CoordinationAlterNodeStartInfo
- type CoordinationCloseDoneInfo
- type CoordinationCloseStartInfo
- type CoordinationComposeOption
- type CoordinationCreateNodeDoneInfo
- type CoordinationCreateNodeStartInfo
- type CoordinationDescribeNodeDoneInfo
- type CoordinationDescribeNodeStartInfo
- type CoordinationDropNodeDoneInfo
- type CoordinationDropNodeStartInfo
- type CoordinationNewDoneInfo
- type CoordinationNewStartInfo
- type CoordinationSessionClientTimeoutInfo
- type CoordinationSessionDoneInfo
- type CoordinationSessionKeepAliveTimeoutInfo
- type CoordinationSessionReceiveDoneInfo
- type CoordinationSessionReceiveStartInfo
- type CoordinationSessionReceiveUnexpectedInfo
- type CoordinationSessionSendDoneInfo
- type CoordinationSessionSendStartInfo
- type CoordinationSessionServerErrorInfo
- type CoordinationSessionServerExpireInfo
- type CoordinationSessionStartDoneInfo
- type CoordinationSessionStartInfo
- type CoordinationSessionStartStartInfo
- type CoordinationSessionStartTimeoutInfo
- type CoordinationSessionStartedInfo
- type CoordinationSessionStopInfo
- type CoordinationSessionStopTimeoutInfo
- type CoordinationSessionStoppedInfo
- type CoordinationStreamNewDoneInfo
- type CoordinationStreamNewStartInfo
- type DatabaseSQL
- type DatabaseSQLComposeOption
- type DatabaseSQLConnBeginDoneInfo
- type DatabaseSQLConnBeginStartInfo
- type DatabaseSQLConnCloseDoneInfo
- type DatabaseSQLConnCloseStartInfo
- type DatabaseSQLConnExecDoneInfo
- type DatabaseSQLConnExecStartInfo
- type DatabaseSQLConnIsTableExistsDoneInfo
- type DatabaseSQLConnIsTableExistsStartInfo
- type DatabaseSQLConnPingDoneInfo
- type DatabaseSQLConnPingStartInfo
- type DatabaseSQLConnPrepareDoneInfo
- type DatabaseSQLConnPrepareStartInfo
- type DatabaseSQLConnQueryDoneInfo
- type DatabaseSQLConnQueryStartInfo
- type DatabaseSQLConnectorConnectDoneInfo
- type DatabaseSQLConnectorConnectStartInfo
- type DatabaseSQLDoTxDoneInfo
- type DatabaseSQLDoTxIntermediateInfo
- type DatabaseSQLDoTxStartInfo
- type DatabaseSQLStmtCloseDoneInfo
- type DatabaseSQLStmtCloseStartInfo
- type DatabaseSQLStmtExecDoneInfo
- type DatabaseSQLStmtExecStartInfo
- type DatabaseSQLStmtQueryDoneInfo
- type DatabaseSQLStmtQueryStartInfo
- type DatabaseSQLTxCommitDoneInfo
- type DatabaseSQLTxCommitStartInfo
- type DatabaseSQLTxExecDoneInfo
- type DatabaseSQLTxExecStartInfo
- type DatabaseSQLTxPrepareDoneInfo
- type DatabaseSQLTxPrepareStartInfo
- type DatabaseSQLTxQueryDoneInfo
- type DatabaseSQLTxQueryStartInfo
- type DatabaseSQLTxRollbackDoneInfo
- type DatabaseSQLTxRollbackStartInfo
- type Detailer
- type Details
- type Discovery
- type DiscoveryComposeOption
- type DiscoveryDiscoverDoneInfo
- type DiscoveryDiscoverStartInfo
- type DiscoveryWhoAmIDoneInfo
- type DiscoveryWhoAmIStartInfo
- type Driver
- type DriverBalancerChooseEndpointDoneInfo
- type DriverBalancerChooseEndpointStartInfo
- type DriverBalancerCloseDoneInfo
- type DriverBalancerCloseStartInfo
- type DriverBalancerClusterDiscoveryAttemptDoneInfo
- type DriverBalancerClusterDiscoveryAttemptStartInfo
- type DriverBalancerDialEntrypointDoneInfo
- type DriverBalancerDialEntrypointStartInfo
- type DriverBalancerInitDoneInfo
- type DriverBalancerInitStartInfo
- type DriverBalancerUpdateDoneInfo
- type DriverBalancerUpdateStartInfo
- type DriverCloseDoneInfo
- type DriverCloseStartInfo
- type DriverComposeOption
- type DriverConnAllowDoneInfo
- type DriverConnAllowStartInfo
- type DriverConnBanDoneInfo
- type DriverConnBanStartInfo
- type DriverConnCloseDoneInfo
- type DriverConnCloseStartInfo
- type DriverConnDialDoneInfo
- type DriverConnDialStartInfo
- type DriverConnInvokeDoneInfo
- type DriverConnInvokeStartInfo
- type DriverConnNewStreamDoneInfo
- type DriverConnNewStreamStartInfo
- type DriverConnParkDoneInfo
- type DriverConnParkStartInfo
- type DriverConnPoolNewDoneInfo
- type DriverConnPoolNewStartInfo
- type DriverConnPoolReleaseDoneInfo
- type DriverConnPoolReleaseStartInfo
- type DriverConnStateChangeDoneInfo
- type DriverConnStateChangeStartInfo
- type DriverConnStreamCloseSendDoneInfo
- type DriverConnStreamCloseSendStartInfo
- type DriverConnStreamRecvMsgDoneInfo
- type DriverConnStreamRecvMsgStartInfo
- type DriverConnStreamSendMsgDoneInfo
- type DriverConnStreamSendMsgStartInfo
- type DriverConnTakeDoneInfo
- type DriverConnTakeStartInfo
- type DriverGetCredentialsDoneInfo
- type DriverGetCredentialsStartInfo
- type DriverInitDoneInfo
- type DriverInitStartInfo
- type DriverNetCloseDoneInfo
- type DriverNetCloseStartInfo
- type DriverNetDialDoneInfo
- type DriverNetDialStartInfo
- type DriverNetReadDoneInfo
- type DriverNetReadStartInfo
- type DriverNetWriteDoneInfo
- type DriverNetWriteStartInfo
- type DriverRepeaterWakeUpDoneInfo
- type DriverRepeaterWakeUpStartInfo
- type DriverResolveDoneInfo
- type DriverResolveStartInfo
- type DriverWithDoneInfo
- type DriverWithStartInfo
- type EndpointInfo
- type Issue
- type Method
- type OnReadStreamUpdateTokenDoneInfo
- type OnReadUnknownGrpcMessageInfo
- type OnReadUpdateTokenMiddleTokenReceivedInfo
- type OnReadUpdateTokenStartInfo
- type Query
- type QueryCloseDoneInfo
- type QueryCloseStartInfo
- type QueryComposeOption
- type QueryDoDoneInfo
- type QueryDoStartInfo
- type QueryDoTxDoneInfo
- type QueryDoTxStartInfo
- type QueryNewDoneInfo
- type QueryNewStartInfo
- type QueryPoolChange
- type QueryPoolCloseDoneInfo
- type QueryPoolCloseStartInfo
- type QueryPoolGetDoneInfo
- type QueryPoolGetStartInfo
- type QueryPoolNewDoneInfo
- type QueryPoolNewStartInfo
- type QueryPoolPutDoneInfo
- type QueryPoolPutStartInfo
- type QueryPoolTryDoneInfo
- type QueryPoolTryStartInfo
- type QueryPoolWithDoneInfo
- type QueryPoolWithStartInfo
- type QueryResultCloseDoneInfo
- type QueryResultCloseStartInfo
- type QueryResultNewDoneInfo
- type QueryResultNewStartInfo
- type QueryResultNextPartDoneInfo
- type QueryResultNextPartStartInfo
- type QueryResultNextResultSetDoneInfo
- type QueryResultNextResultSetStartInfo
- type QueryResultSetNextRowDoneInfo
- type QueryResultSetNextRowStartInfo
- type QueryRowScanDoneInfo
- type QueryRowScanNamedDoneInfo
- type QueryRowScanNamedStartInfo
- type QueryRowScanStartInfo
- type QueryRowScanStructDoneInfo
- type QueryRowScanStructStartInfo
- type QuerySessionAttachDoneInfo
- type QuerySessionAttachStartInfo
- type QuerySessionBeginDoneInfo
- type QuerySessionBeginStartInfo
- type QuerySessionCreateDoneInfo
- type QuerySessionCreateStartInfo
- type QuerySessionDeleteDoneInfo
- type QuerySessionDeleteStartInfo
- type QuerySessionExecuteDoneInfo
- type QuerySessionExecuteStartInfo
- type QueryTxExecuteDoneInfo
- type QueryTxExecuteStartInfo
- type Ratelimiter
- type RatelimiterComposeOption
- type Retry
- type RetryComposeOption
- type RetryLoopDoneInfo
- type RetryLoopStartInfo
- type Scheme
- type SchemeComposeOption
- type SchemeDescribePathDoneInfo
- type SchemeDescribePathStartInfo
- type SchemeListDirectoryDoneInfo
- type SchemeListDirectoryStartInfo
- type SchemeMakeDirectoryDoneInfo
- type SchemeMakeDirectoryStartInfo
- type SchemeModifyPermissionsDoneInfo
- type SchemeModifyPermissionsStartInfo
- type SchemeRemoveDirectoryDoneInfo
- type SchemeRemoveDirectoryStartInfo
- type Scripting
- type ScriptingCloseDoneInfo
- type ScriptingCloseStartInfo
- type ScriptingComposeOption
- type ScriptingExecuteDoneInfo
- type ScriptingExecuteStartInfo
- type ScriptingExplainDoneInfo
- type ScriptingExplainStartInfo
- type ScriptingStreamExecuteDoneInfo
- type ScriptingStreamExecuteIntermediateInfo
- type ScriptingStreamExecuteStartInfo
- type Table
- type TableBulkUpsertDoneInfo
- type TableBulkUpsertStartInfo
- type TableCloseDoneInfo
- type TableCloseStartInfo
- type TableComposeOption
- type TableCreateSessionDoneInfo
- type TableCreateSessionStartInfo
- type TableDoDoneInfo
- type TableDoStartInfo
- type TableDoTxDoneInfo
- type TableDoTxStartInfo
- type TableExecuteDataQueryDoneInfo
- type TableExecuteDataQueryStartInfo
- type TableExplainQueryDoneInfo
- type TableExplainQueryStartInfo
- type TableInitDoneInfo
- type TableInitStartInfo
- type TableKeepAliveDoneInfo
- type TableKeepAliveStartInfo
- type TablePoolGetDoneInfo
- type TablePoolGetStartInfo
- type TablePoolPutDoneInfo
- type TablePoolPutStartInfo
- type TablePoolSessionAddInfo
- type TablePoolSessionCloseDoneInfo
- type TablePoolSessionCloseStartInfo
- type TablePoolSessionNewDoneInfo
- type TablePoolSessionNewStartInfo
- type TablePoolSessionRemoveInfo
- type TablePoolStateChangeInfo
- type TablePoolWaitDoneInfo
- type TablePoolWaitStartInfo
- type TablePrepareDataQueryDoneInfo
- type TablePrepareDataQueryStartInfo
- type TableSessionDeleteDoneInfo
- type TableSessionDeleteStartInfo
- type TableSessionNewDoneInfo
- type TableSessionNewStartInfo
- type TableSessionQueryStreamExecuteDoneInfo
- type TableSessionQueryStreamExecuteStartInfo
- type TableSessionQueryStreamReadDoneInfo
- type TableSessionQueryStreamReadStartInfo
- type TableTransactionExecuteDoneInfo
- type TableTransactionExecuteStartInfo
- type TableTransactionExecuteStatementDoneInfo
- type TableTransactionExecuteStatementStartInfo
- type TableTxBeginDoneInfo
- type TableTxBeginStartInfo
- type TableTxCommitDoneInfo
- type TableTxCommitStartInfo
- type TableTxRollbackDoneInfo
- type TableTxRollbackStartInfo
- type Topic
- type TopicComposeOption
- type TopicOnWriterReadUnknownGrpcMessageInfo
- type TopicReadStreamInitRequestInfo
- type TopicReaderCloseDoneInfo
- type TopicReaderCloseStartInfo
- type TopicReaderCommitDoneInfo
- type TopicReaderCommitStartInfo
- type TopicReaderCommittedNotifyInfo
- type TopicReaderDataResponseInfo
- type TopicReaderErrorInfo
- type TopicReaderInitDoneInfo
- type TopicReaderInitStartInfo
- type TopicReaderPartitionReadStartResponseDoneInfo
- type TopicReaderPartitionReadStartResponseStartInfo
- type TopicReaderPartitionReadStopResponseDoneInfo
- type TopicReaderPartitionReadStopResponseStartInfo
- type TopicReaderReadMessagesDoneInfo
- type TopicReaderReadMessagesStartInfo
- type TopicReaderReceiveDataResponseDoneInfo
- type TopicReaderReceiveDataResponseStartInfo
- type TopicReaderReconnectDoneInfo
- type TopicReaderReconnectRequestInfo
- type TopicReaderReconnectStartInfo
- type TopicReaderSendCommitMessageDoneInfo
- type TopicReaderSendCommitMessageStartInfo
- type TopicReaderSentDataRequestInfo
- type TopicReaderStartInfo
- type TopicReaderStreamCommitInfo
- type TopicReaderStreamSendCommitMessageStartMessageInfo
- type TopicWriterCloseDoneInfo
- type TopicWriterCloseStartInfo
- type TopicWriterCompressMessagesDoneInfo
- type TopicWriterCompressMessagesReason
- type TopicWriterCompressMessagesStartInfo
- type TopicWriterInitStreamDoneInfo
- type TopicWriterInitStreamStartInfo
- type TopicWriterReconnectDoneInfo
- type TopicWriterReconnectStartInfo
- type TopicWriterSendMessagesDoneInfo
- type TopicWriterSendMessagesStartInfo
Constants ¶
const ( // Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals TopicWriterCompressMessagesReasonCompressData = TopicWriterCompressMessagesReason("compress-on-send") // Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals TopicWriterCompressMessagesReasonCompressDataOnWriteReadData = TopicWriterCompressMessagesReason("compress-on-call-write") //nolint:lll // Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals TopicWriterCompressMessagesReasonCodecsMeasure = TopicWriterCompressMessagesReason("compress-on-codecs-measure") //nolint:lll )
Variables ¶
This section is empty.
Functions ¶
func CoordinationOnAlterNode ¶ added in v3.60.1
func CoordinationOnAlterNode(t *Coordination, c *context.Context, call call, path string) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func CoordinationOnClose ¶ added in v3.61.1
func CoordinationOnClose(t *Coordination, c *context.Context, call call) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func CoordinationOnCreateNode ¶ added in v3.60.1
func CoordinationOnCreateNode(t *Coordination, c *context.Context, call call, path string) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func CoordinationOnDescribeNode ¶ added in v3.60.1
func CoordinationOnDescribeNode(t *Coordination, c *context.Context, call call, path string) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func CoordinationOnDropNode ¶ added in v3.60.1
func CoordinationOnDropNode(t *Coordination, c *context.Context, call call, path string) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func CoordinationOnNew ¶ added in v3.60.1
func CoordinationOnNew(t *Coordination, c *context.Context, call call) func()
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func CoordinationOnSession ¶ added in v3.61.1
func CoordinationOnSession(t *Coordination, c *context.Context, call call, path string) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func CoordinationOnSessionClientTimeout ¶ added in v3.60.0
func CoordinationOnSessionClientTimeout(t *Coordination, lastGoodResponseTime time.Time, timeout time.Duration)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func CoordinationOnSessionKeepAliveTimeout ¶ added in v3.60.0
func CoordinationOnSessionKeepAliveTimeout(t *Coordination, lastGoodResponseTime time.Time, timeout time.Duration)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func CoordinationOnSessionReceive ¶ added in v3.60.0
func CoordinationOnSessionReceive(t *Coordination) func(response *Ydb_Coordination.SessionResponse, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func CoordinationOnSessionReceiveUnexpected ¶ added in v3.60.0
func CoordinationOnSessionReceiveUnexpected(t *Coordination, response *Ydb_Coordination.SessionResponse)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func CoordinationOnSessionSend ¶ added in v3.60.0
func CoordinationOnSessionSend(t *Coordination, request *Ydb_Coordination.SessionRequest) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func CoordinationOnSessionServerError ¶ added in v3.60.0
func CoordinationOnSessionServerError(t *Coordination, failure *Ydb_Coordination.SessionResponse_Failure)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func CoordinationOnSessionServerExpire ¶ added in v3.60.0
func CoordinationOnSessionServerExpire(t *Coordination, failure *Ydb_Coordination.SessionResponse_Failure)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func CoordinationOnSessionStart ¶ added in v3.60.0
func CoordinationOnSessionStart(t *Coordination) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func CoordinationOnSessionStartTimeout ¶ added in v3.60.0
func CoordinationOnSessionStartTimeout(t *Coordination, timeout time.Duration)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func CoordinationOnSessionStarted ¶ added in v3.60.0
func CoordinationOnSessionStarted(t *Coordination, sessionID uint64, expectedSessionID uint64)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func CoordinationOnSessionStop ¶ added in v3.60.0
func CoordinationOnSessionStop(t *Coordination, sessionID uint64)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func CoordinationOnSessionStopTimeout ¶ added in v3.60.0
func CoordinationOnSessionStopTimeout(t *Coordination, timeout time.Duration)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func CoordinationOnSessionStopped ¶ added in v3.60.0
func CoordinationOnSessionStopped(t *Coordination, sessionID uint64, expectedSessionID uint64)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func CoordinationOnStreamNew ¶ added in v3.60.0
func CoordinationOnStreamNew(t *Coordination) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DatabaseSQLOnConnBegin ¶ added in v3.34.0
func DatabaseSQLOnConnBegin(t *DatabaseSQL, c *context.Context, call call) func(tx tableTransactionInfo, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DatabaseSQLOnConnClose ¶ added in v3.34.0
func DatabaseSQLOnConnClose(t *DatabaseSQL, c *context.Context, call call) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DatabaseSQLOnConnExec ¶ added in v3.34.0
func DatabaseSQLOnConnExec(t *DatabaseSQL, c *context.Context, call call, query string, mode string, idempotent bool, idleTime time.Duration) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DatabaseSQLOnConnIsTableExists ¶ added in v3.54.2
func DatabaseSQLOnConnIsTableExists(t *DatabaseSQL, c *context.Context, call call, tableName string) func(exists bool, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DatabaseSQLOnConnPing ¶ added in v3.34.0
func DatabaseSQLOnConnPing(t *DatabaseSQL, c *context.Context, call call) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DatabaseSQLOnConnPrepare ¶ added in v3.34.0
func DatabaseSQLOnConnPrepare(t *DatabaseSQL, c *context.Context, call call, query string) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DatabaseSQLOnConnQuery ¶ added in v3.34.0
func DatabaseSQLOnConnQuery(t *DatabaseSQL, c *context.Context, call call, query string, mode string, idempotent bool, idleTime time.Duration) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DatabaseSQLOnConnectorConnect ¶ added in v3.34.0
func DatabaseSQLOnConnectorConnect(t *DatabaseSQL, c *context.Context, call call) func(_ error, session tableSessionInfo)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DatabaseSQLOnDoTx ¶ added in v3.34.0
func DatabaseSQLOnDoTx(t *DatabaseSQL, c *context.Context, call call, iD string, idempotent bool) func(error) func(attempts int, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DatabaseSQLOnStmtClose ¶ added in v3.34.0
func DatabaseSQLOnStmtClose(t *DatabaseSQL, stmtContext *context.Context, call call) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DatabaseSQLOnStmtExec ¶ added in v3.34.0
func DatabaseSQLOnStmtExec(t *DatabaseSQL, c *context.Context, call call, stmtContext context.Context, query string) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DatabaseSQLOnStmtQuery ¶ added in v3.34.0
func DatabaseSQLOnStmtQuery(t *DatabaseSQL, c *context.Context, call call, stmtContext context.Context, query string) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DatabaseSQLOnTxCommit ¶ added in v3.34.0
func DatabaseSQLOnTxCommit(t *DatabaseSQL, c *context.Context, call call, tx tableTransactionInfo) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DatabaseSQLOnTxExec ¶ added in v3.34.2
func DatabaseSQLOnTxExec(t *DatabaseSQL, c *context.Context, call call, txContext context.Context, tx tableTransactionInfo, query string) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DatabaseSQLOnTxPrepare ¶ added in v3.54.2
func DatabaseSQLOnTxPrepare(t *DatabaseSQL, c *context.Context, call call, txContext context.Context, tx tableTransactionInfo, query string) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DatabaseSQLOnTxQuery ¶ added in v3.34.2
func DatabaseSQLOnTxQuery(t *DatabaseSQL, c *context.Context, call call, txContext context.Context, tx tableTransactionInfo, query string) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DatabaseSQLOnTxRollback ¶ added in v3.34.0
func DatabaseSQLOnTxRollback(t *DatabaseSQL, c *context.Context, call call, tx tableTransactionInfo) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DiscoveryOnDiscover ¶ added in v3.10.0
func DiscoveryOnDiscover(t *Discovery, c *context.Context, call call, address string, database string) func(location string, endpoints []EndpointInfo, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DiscoveryOnWhoAmI ¶ added in v3.10.0
func DiscoveryOnWhoAmI(t *Discovery, c *context.Context, call call) func(user string, groups []string, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnBalancerChooseEndpoint ¶ added in v3.26.0
func DriverOnBalancerChooseEndpoint(t *Driver, c *context.Context, call call) func(endpoint EndpointInfo, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnBalancerClose ¶ added in v3.26.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnBalancerClusterDiscoveryAttempt ¶ added in v3.42.9
func DriverOnBalancerClusterDiscoveryAttempt(t *Driver, c *context.Context, call call, address string) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnBalancerInit ¶ added in v3.26.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnBalancerUpdate ¶ added in v3.26.0
func DriverOnBalancerUpdate(t *Driver, c *context.Context, call call, needLocalDC bool) func(endpoints []EndpointInfo, added []EndpointInfo, dropped []EndpointInfo, localDC string)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnClose ¶ added in v3.5.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnConnAllow ¶ added in v3.25.1
func DriverOnConnAllow(t *Driver, c *context.Context, call call, endpoint EndpointInfo, state ConnState) func(state ConnState)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnConnBan ¶ added in v3.25.1
func DriverOnConnBan(t *Driver, c *context.Context, call call, endpoint EndpointInfo, state ConnState, cause error) func(state ConnState)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnConnClose ¶ added in v3.12.1
func DriverOnConnClose(t *Driver, c *context.Context, call call, endpoint EndpointInfo) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnConnDial ¶ added in v3.42.12
func DriverOnConnDial(t *Driver, c *context.Context, call call, endpoint EndpointInfo) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnConnInvoke ¶
func DriverOnConnInvoke(t *Driver, c *context.Context, call call, endpoint EndpointInfo, m Method) func(_ error, issues []Issue, opID string, state ConnState, metadata map[string][]string)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnConnNewStream ¶
func DriverOnConnNewStream(t *Driver, c *context.Context, call call, endpoint EndpointInfo, m Method) func(_ error, state ConnState)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnConnPark ¶ added in v3.12.1
func DriverOnConnPark(t *Driver, c *context.Context, call call, endpoint EndpointInfo) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnConnStateChange ¶
func DriverOnConnStateChange(t *Driver, c *context.Context, call call, endpoint EndpointInfo, state ConnState) func(state ConnState)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnConnStreamCloseSend ¶ added in v3.58.1
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnConnStreamRecvMsg ¶ added in v3.58.1
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnConnStreamSendMsg ¶ added in v3.58.1
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnGetCredentials ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnInit ¶ added in v3.5.0
func DriverOnInit(t *Driver, c *context.Context, call call, endpoint string, database string, secure bool) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnPoolNew ¶ added in v3.54.2
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnPoolRelease ¶ added in v3.54.2
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnRepeaterWakeUp ¶ added in v3.11.13
func DriverOnRepeaterWakeUp(t *Driver, c *context.Context, call call, name string, event string) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnResolve ¶ added in v3.11.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnWith ¶ added in v3.54.3
func DriverOnWith(t *Driver, c *context.Context, call call, endpoint string, database string, secure bool) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnClose ¶ added in v3.58.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnDo ¶ added in v3.57.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnDoTx ¶ added in v3.57.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnNew ¶ added in v3.58.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnPoolChange ¶ added in v3.59.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnPoolClose ¶ added in v3.58.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnPoolGet ¶ added in v3.58.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnPoolNew ¶ added in v3.58.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnPoolPut ¶ added in v3.58.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnPoolTry ¶ added in v3.58.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnPoolWith ¶ added in v3.58.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnResultClose ¶ added in v3.58.2
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnResultNew ¶ added in v3.58.2
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnResultNextPart ¶ added in v3.58.2
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnResultNextResultSet ¶ added in v3.58.2
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnResultSetNextRow ¶ added in v3.58.2
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnRowScan ¶ added in v3.58.2
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnRowScanNamed ¶ added in v3.58.2
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnRowScanStruct ¶ added in v3.58.2
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnSessionAttach ¶ added in v3.58.0
func QueryOnSessionAttach(t *Query, c *context.Context, call call, session querySessionInfo) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnSessionBegin ¶ added in v3.58.2
func QueryOnSessionBegin(t *Query, c *context.Context, call call, session querySessionInfo) func(_ error, tx queryTransactionInfo)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnSessionCreate ¶ added in v3.58.0
func QueryOnSessionCreate(t *Query, c *context.Context, call call) func(session querySessionInfo, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnSessionDelete ¶ added in v3.58.0
func QueryOnSessionDelete(t *Query, c *context.Context, call call, session querySessionInfo) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnSessionExecute ¶ added in v3.58.1
func QueryOnSessionExecute(t *Query, c *context.Context, call call, session querySessionInfo, query string) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnTxExecute ¶ added in v3.59.0
func QueryOnTxExecute(t *Query, c *context.Context, call call, session querySessionInfo, tx queryTransactionInfo, query string) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func RetryOnRetry ¶
func RetryOnRetry(t *Retry, c *context.Context, call call, label string, idempotent bool, nestedCall bool) func(attempts int, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func SchemeOnDescribePath ¶ added in v3.54.2
func SchemeOnDescribePath(t *Scheme, c *context.Context, call call, path string) func(entryType string, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func SchemeOnListDirectory ¶ added in v3.54.2
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func SchemeOnMakeDirectory ¶ added in v3.54.2
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func SchemeOnModifyPermissions ¶ added in v3.54.2
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func SchemeOnRemoveDirectory ¶ added in v3.54.2
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func ScriptingOnClose ¶ added in v3.13.1
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func ScriptingOnExecute ¶ added in v3.10.0
func ScriptingOnExecute(t *Scripting, c *context.Context, call call, query string, parameters scriptingQueryParameters) func(result scriptingResult, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func ScriptingOnExplain ¶ added in v3.10.0
func ScriptingOnExplain(t *Scripting, c *context.Context, call call, query string) func(plan string, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func ScriptingOnStreamExecute ¶ added in v3.10.0
func ScriptingOnStreamExecute(t *Scripting, c *context.Context, call call, query string, parameters scriptingQueryParameters) func(error) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnClose ¶ added in v3.13.1
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnCreateSession ¶ added in v3.15.0
func TableOnCreateSession(t *Table, c *context.Context, call call) func(session tableSessionInfo, attempts int, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnDo ¶ added in v3.15.0
func TableOnDo(t *Table, c *context.Context, call call, label string, idempotent bool, nestedCall bool) func(attempts int, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnDoTx ¶ added in v3.15.0
func TableOnDoTx(t *Table, c *context.Context, call call, label string, idempotent bool, nestedCall bool) func(attempts int, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnInit ¶ added in v3.13.1
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnPoolGet ¶
func TableOnPoolGet(t *Table, c *context.Context, call call) func(session tableSessionInfo, attempts int, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnPoolPut ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnPoolSessionAdd ¶ added in v3.33.0
func TableOnPoolSessionAdd(t *Table, session tableSessionInfo)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnPoolSessionRemove ¶ added in v3.33.0
func TableOnPoolSessionRemove(t *Table, session tableSessionInfo)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnPoolStateChange ¶ added in v3.11.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnPoolWait ¶
func TableOnPoolWait(t *Table, c *context.Context, call call) func(session tableSessionInfo, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnSessionBulkUpsert ¶ added in v3.54.2
func TableOnSessionBulkUpsert(t *Table, c *context.Context, call call, session tableSessionInfo) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnSessionDelete ¶
func TableOnSessionDelete(t *Table, c *context.Context, call call, session tableSessionInfo) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnSessionKeepAlive ¶
func TableOnSessionKeepAlive(t *Table, c *context.Context, call call, session tableSessionInfo) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnSessionNew ¶
func TableOnSessionNew(t *Table, c *context.Context, call call) func(session tableSessionInfo, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnSessionQueryExecute ¶
func TableOnSessionQueryExecute(t *Table, c *context.Context, call call, session tableSessionInfo, query tableDataQuery, parameters tableQueryParameters, keepInCache bool) func(tx tableTransactionInfo, prepared bool, result tableResult, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnSessionQueryExplain ¶ added in v3.10.0
func TableOnSessionQueryExplain(t *Table, c *context.Context, call call, session tableSessionInfo, query string) func(aST string, plan string, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnSessionQueryPrepare ¶
func TableOnSessionQueryPrepare(t *Table, c *context.Context, call call, session tableSessionInfo, query string) func(result tableDataQuery, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnSessionQueryStreamExecute ¶
func TableOnSessionQueryStreamExecute(t *Table, c *context.Context, call call, session tableSessionInfo, query tableDataQuery, parameters tableQueryParameters) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnSessionQueryStreamRead ¶
func TableOnSessionQueryStreamRead(t *Table, c *context.Context, call call, session tableSessionInfo) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnTxBegin ¶ added in v3.59.0
func TableOnTxBegin(t *Table, c *context.Context, call call, session tableSessionInfo) func(tx tableTransactionInfo, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnTxCommit ¶ added in v3.59.0
func TableOnTxCommit(t *Table, c *context.Context, call call, session tableSessionInfo, tx tableTransactionInfo) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnTxExecute ¶ added in v3.59.0
func TableOnTxExecute(t *Table, c *context.Context, call call, session tableSessionInfo, tx tableTransactionInfo, query tableDataQuery, parameters tableQueryParameters) func(result tableResult, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnTxExecuteStatement ¶ added in v3.59.0
func TableOnTxExecuteStatement(t *Table, c *context.Context, call call, session tableSessionInfo, tx tableTransactionInfo, statementQuery tableDataQuery, parameters tableQueryParameters) func(result tableResult, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnTxRollback ¶ added in v3.59.0
func TableOnTxRollback(t *Table, c *context.Context, call call, session tableSessionInfo, tx tableTransactionInfo) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnReaderClose ¶ added in v3.32.0
func TopicOnReaderClose(t *Topic, readerConnectionID string, closeReason error) func(closeError error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnReaderCommit ¶ added in v3.32.0
func TopicOnReaderCommit(t *Topic, requestContext *context.Context, topic string, partitionID int64, partitionSessionID int64, startOffset int64, endOffset int64) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnReaderCommittedNotify ¶ added in v3.32.0
func TopicOnReaderCommittedNotify(t *Topic, readerConnectionID string, topic string, partitionID int64, partitionSessionID int64, committedOffset int64)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnReaderError ¶ added in v3.32.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnReaderInit ¶ added in v3.32.0
func TopicOnReaderInit(t *Topic, preInitReaderConnectionID string, initRequestInfo TopicReadStreamInitRequestInfo) func(readerConnectionID string, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnReaderPartitionReadStartResponse ¶ added in v3.32.0
func TopicOnReaderPartitionReadStartResponse(t *Topic, readerConnectionID string, partitionContext *context.Context, topic string, partitionID int64, partitionSessionID int64) func(readOffset *int64, commitOffset *int64, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnReaderPartitionReadStopResponse ¶ added in v3.32.0
func TopicOnReaderPartitionReadStopResponse(t *Topic, readerConnectionID string, partitionContext *context.Context, topic string, partitionID int64, partitionSessionID int64, committedOffset int64, graceful bool) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnReaderReadMessages ¶ added in v3.32.0
func TopicOnReaderReadMessages(t *Topic, requestContext *context.Context, minCount int, maxCount int, freeBufferCapacity int) func(messagesCount int, topic string, partitionID int64, partitionSessionID int64, offsetStart int64, offsetEnd int64, freeBufferCapacity int, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnReaderReceiveDataResponse ¶ added in v3.32.0
func TopicOnReaderReceiveDataResponse(t *Topic, readerConnectionID string, localBufferSizeAfterReceive int, dataResponse TopicReaderDataResponseInfo) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnReaderReconnect ¶ added in v3.32.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnReaderReconnectRequest ¶ added in v3.32.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnReaderSendCommitMessage ¶ added in v3.32.0
func TopicOnReaderSendCommitMessage(t *Topic, commitsInfo TopicReaderStreamSendCommitMessageStartMessageInfo) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnReaderSentDataRequest ¶ added in v3.32.0
func TopicOnReaderSentDataRequest(t *Topic, readerConnectionID string, requestBytes int, localBufferSizeAfterSent int)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnReaderStart ¶ added in v3.52.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnReaderUnknownGrpcMessage ¶ added in v3.32.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnReaderUpdateToken ¶ added in v3.32.0
func TopicOnReaderUpdateToken(t *Topic, readerConnectionID string) func(tokenLen int, _ error) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnWriterClose ¶ added in v3.38.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnWriterCompressMessages ¶ added in v3.38.0
func TopicOnWriterCompressMessages(t *Topic, writerInstanceID string, sessionID string, codec int32, firstSeqNo int64, messagesCount int, reason TopicWriterCompressMessagesReason) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnWriterInitStream ¶ added in v3.38.0
func TopicOnWriterInitStream(t *Topic, writerInstanceID string, topic string, producerID string) func(sessionID string, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnWriterReadUnknownGrpcMessage ¶ added in v3.38.0
func TopicOnWriterReadUnknownGrpcMessage(t *Topic, writerInstanceID string, sessionID string, e error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnWriterReconnect ¶ added in v3.38.0
func TopicOnWriterReconnect(t *Topic, writerInstanceID string, topic string, producerID string, attempt int) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnWriterSendMessages ¶ added in v3.38.0
func TopicOnWriterSendMessages(t *Topic, writerInstanceID string, sessionID string, codec int32, firstSeqNo int64, messagesCount int) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func WithDefaultDetails ¶ added in v3.11.0
func WithDefaultDetails(defaultDetails Details) matchDetailsOption
func WithPOSIXMatch ¶ added in v3.11.0
func WithPOSIXMatch() matchDetailsOption
Types ¶
type ConnState ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type Coordination ¶ added in v3.10.0
type Coordination struct {
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnNew func(CoordinationNewStartInfo) func(CoordinationNewDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnCreateNode func(CoordinationCreateNodeStartInfo) func(CoordinationCreateNodeDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnAlterNode func(CoordinationAlterNodeStartInfo) func(CoordinationAlterNodeDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnDropNode func(CoordinationDropNodeStartInfo) func(CoordinationDropNodeDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnDescribeNode func(CoordinationDescribeNodeStartInfo) func(CoordinationDescribeNodeDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnSession func(CoordinationSessionStartInfo) func(CoordinationSessionDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnClose func(CoordinationCloseStartInfo) func(CoordinationCloseDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnStreamNew func(CoordinationStreamNewStartInfo) func(CoordinationStreamNewDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnSessionStarted func(CoordinationSessionStartedInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnSessionStartTimeout func(CoordinationSessionStartTimeoutInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnSessionKeepAliveTimeout func(CoordinationSessionKeepAliveTimeoutInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnSessionStopped func(CoordinationSessionStoppedInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnSessionStopTimeout func(CoordinationSessionStopTimeoutInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnSessionClientTimeout func(CoordinationSessionClientTimeoutInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnSessionServerExpire func(CoordinationSessionServerExpireInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnSessionServerError func(CoordinationSessionServerErrorInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnSessionReceive func(CoordinationSessionReceiveStartInfo) func(CoordinationSessionReceiveDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnSessionReceiveUnexpected func(CoordinationSessionReceiveUnexpectedInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnSessionStop func(CoordinationSessionStopInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnSessionStart func(CoordinationSessionStartStartInfo) func(CoordinationSessionStartDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnSessionSend func(CoordinationSessionSendStartInfo) func(CoordinationSessionSendDoneInfo)
}
    Coordination specified trace of coordination client activity. gtrace:gen
func (*Coordination) Compose ¶ added in v3.10.0
func (t *Coordination) Compose(x *Coordination, opts ...CoordinationComposeOption) *Coordination
Compose returns a new Coordination which has functional fields composed both from t and x. Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationAlterNodeDoneInfo ¶ added in v3.60.1
type CoordinationAlterNodeDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationAlterNodeStartInfo ¶ added in v3.60.1
type CoordinationAlterNodeStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Path string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationCloseDoneInfo ¶ added in v3.61.1
type CoordinationCloseDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationCloseStartInfo ¶ added in v3.61.1
type CoordinationCloseStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationComposeOption ¶ added in v3.17.0
type CoordinationComposeOption func(o *coordinationComposeOptions)
CoordinationOption specified Coordination compose option Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func WithCoordinationPanicCallback ¶ added in v3.17.0
func WithCoordinationPanicCallback(cb func(e interface{})) CoordinationComposeOption
    WithCoordinationPanicCallback specified behavior on panic Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationCreateNodeDoneInfo ¶ added in v3.60.1
type CoordinationCreateNodeDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationCreateNodeStartInfo ¶ added in v3.60.1
type CoordinationCreateNodeStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Path string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationDescribeNodeDoneInfo ¶ added in v3.60.1
type CoordinationDescribeNodeDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationDescribeNodeStartInfo ¶ added in v3.60.1
type CoordinationDescribeNodeStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Path string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationDropNodeDoneInfo ¶ added in v3.60.1
type CoordinationDropNodeDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationDropNodeStartInfo ¶ added in v3.60.1
type CoordinationDropNodeStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Path string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationNewDoneInfo ¶ added in v3.60.1
type CoordinationNewDoneInfo struct{}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationNewStartInfo ¶ added in v3.60.1
type CoordinationNewStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionClientTimeoutInfo ¶ added in v3.60.0
type CoordinationSessionClientTimeoutInfo struct {
	LastGoodResponseTime time.Time
	Timeout              time.Duration
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionDoneInfo ¶ added in v3.61.1
type CoordinationSessionDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionKeepAliveTimeoutInfo ¶ added in v3.60.0
type CoordinationSessionKeepAliveTimeoutInfo struct {
	LastGoodResponseTime time.Time
	Timeout              time.Duration
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionReceiveDoneInfo ¶ added in v3.60.0
type CoordinationSessionReceiveDoneInfo struct {
	Response *Ydb_Coordination.SessionResponse
	Error    error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionReceiveStartInfo ¶ added in v3.60.0
type CoordinationSessionReceiveStartInfo struct{}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionReceiveUnexpectedInfo ¶ added in v3.60.0
type CoordinationSessionReceiveUnexpectedInfo struct {
	Response *Ydb_Coordination.SessionResponse
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionSendDoneInfo ¶ added in v3.60.0
type CoordinationSessionSendDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionSendStartInfo ¶ added in v3.60.0
type CoordinationSessionSendStartInfo struct {
	Request *Ydb_Coordination.SessionRequest
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionServerErrorInfo ¶ added in v3.60.0
type CoordinationSessionServerErrorInfo struct {
	Failure *Ydb_Coordination.SessionResponse_Failure
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionServerExpireInfo ¶ added in v3.60.0
type CoordinationSessionServerExpireInfo struct {
	Failure *Ydb_Coordination.SessionResponse_Failure
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionStartDoneInfo ¶ added in v3.60.0
type CoordinationSessionStartDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionStartInfo ¶ added in v3.61.1
type CoordinationSessionStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Path string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionStartStartInfo ¶ added in v3.60.0
type CoordinationSessionStartStartInfo struct{}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionStartTimeoutInfo ¶ added in v3.60.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionStartedInfo ¶ added in v3.60.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionStopInfo ¶ added in v3.60.0
type CoordinationSessionStopInfo struct {
	SessionID uint64
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionStopTimeoutInfo ¶ added in v3.60.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionStoppedInfo ¶ added in v3.60.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationStreamNewDoneInfo ¶ added in v3.60.0
type CoordinationStreamNewDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationStreamNewStartInfo ¶ added in v3.60.0
type CoordinationStreamNewStartInfo struct{}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQL ¶ added in v3.34.0
type DatabaseSQL struct {
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnConnectorConnect func(DatabaseSQLConnectorConnectStartInfo) func(DatabaseSQLConnectorConnectDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnConnPing func(DatabaseSQLConnPingStartInfo) func(DatabaseSQLConnPingDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnConnPrepare func(DatabaseSQLConnPrepareStartInfo) func(DatabaseSQLConnPrepareDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnConnClose func(DatabaseSQLConnCloseStartInfo) func(DatabaseSQLConnCloseDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnConnBegin func(DatabaseSQLConnBeginStartInfo) func(DatabaseSQLConnBeginDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnConnQuery func(DatabaseSQLConnQueryStartInfo) func(DatabaseSQLConnQueryDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnConnExec func(DatabaseSQLConnExecStartInfo) func(DatabaseSQLConnExecDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnConnIsTableExists func(DatabaseSQLConnIsTableExistsStartInfo) func(DatabaseSQLConnIsTableExistsDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnTxQuery func(DatabaseSQLTxQueryStartInfo) func(DatabaseSQLTxQueryDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnTxExec func(DatabaseSQLTxExecStartInfo) func(DatabaseSQLTxExecDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnTxPrepare func(DatabaseSQLTxPrepareStartInfo) func(DatabaseSQLTxPrepareDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnTxCommit func(DatabaseSQLTxCommitStartInfo) func(DatabaseSQLTxCommitDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnTxRollback func(DatabaseSQLTxRollbackStartInfo) func(DatabaseSQLTxRollbackDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnStmtQuery func(DatabaseSQLStmtQueryStartInfo) func(DatabaseSQLStmtQueryDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnStmtExec func(DatabaseSQLStmtExecStartInfo) func(DatabaseSQLStmtExecDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnStmtClose func(DatabaseSQLStmtCloseStartInfo) func(DatabaseSQLStmtCloseDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnDoTx func(DatabaseSQLDoTxStartInfo) func(DatabaseSQLDoTxIntermediateInfo) func(DatabaseSQLDoTxDoneInfo)
}
    DatabaseSQL specified trace of `database/sql` call activity. gtrace:gen Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func (*DatabaseSQL) Compose ¶ added in v3.34.0
func (t *DatabaseSQL) Compose(x *DatabaseSQL, opts ...DatabaseSQLComposeOption) *DatabaseSQL
Compose returns a new DatabaseSQL which has functional fields composed both from t and x. Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLComposeOption ¶ added in v3.34.0
type DatabaseSQLComposeOption func(o *databaseSQLComposeOptions)
DatabaseSQLOption specified DatabaseSQL compose option Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func WithDatabaseSQLPanicCallback ¶ added in v3.34.0
func WithDatabaseSQLPanicCallback(cb func(e interface{})) DatabaseSQLComposeOption
    WithDatabaseSQLPanicCallback specified behavior on panic Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLConnBeginDoneInfo ¶ added in v3.34.0
type DatabaseSQLConnBeginDoneInfo struct {
	Tx    tableTransactionInfo
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLConnBeginStartInfo ¶ added in v3.34.0
type DatabaseSQLConnBeginStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLConnCloseDoneInfo ¶ added in v3.34.0
type DatabaseSQLConnCloseDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLConnCloseStartInfo ¶ added in v3.34.0
type DatabaseSQLConnCloseStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLConnExecDoneInfo ¶ added in v3.34.0
type DatabaseSQLConnExecDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLConnExecStartInfo ¶ added in v3.34.0
type DatabaseSQLConnExecStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context    *context.Context
	Call       call
	Query      string
	Mode       string
	Idempotent bool
	IdleTime   time.Duration
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLConnIsTableExistsDoneInfo ¶ added in v3.54.2
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLConnIsTableExistsStartInfo ¶ added in v3.54.2
type DatabaseSQLConnIsTableExistsStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context   *context.Context
	Call      call
	TableName string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLConnPingDoneInfo ¶ added in v3.34.0
type DatabaseSQLConnPingDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLConnPingStartInfo ¶ added in v3.34.0
type DatabaseSQLConnPingStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLConnPrepareDoneInfo ¶ added in v3.34.0
type DatabaseSQLConnPrepareDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLConnPrepareStartInfo ¶ added in v3.34.0
type DatabaseSQLConnPrepareStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Query   string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLConnQueryDoneInfo ¶ added in v3.34.0
type DatabaseSQLConnQueryDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLConnQueryStartInfo ¶ added in v3.34.0
type DatabaseSQLConnQueryStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context    *context.Context
	Call       call
	Query      string
	Mode       string
	Idempotent bool
	IdleTime   time.Duration
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLConnectorConnectDoneInfo ¶ added in v3.34.0
type DatabaseSQLConnectorConnectDoneInfo struct {
	Error   error
	Session tableSessionInfo
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLConnectorConnectStartInfo ¶ added in v3.34.0
type DatabaseSQLConnectorConnectStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLDoTxDoneInfo ¶ added in v3.34.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLDoTxIntermediateInfo ¶ added in v3.34.0
type DatabaseSQLDoTxIntermediateInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLDoTxStartInfo ¶ added in v3.34.0
type DatabaseSQLDoTxStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context    *context.Context
	Call       call
	ID         string
	Idempotent bool
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLStmtCloseDoneInfo ¶ added in v3.34.0
type DatabaseSQLStmtCloseDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLStmtCloseStartInfo ¶ added in v3.34.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLStmtExecDoneInfo ¶ added in v3.34.0
type DatabaseSQLStmtExecDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLStmtExecStartInfo ¶ added in v3.34.0
type DatabaseSQLStmtExecStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context     *context.Context
	Call        call
	StmtContext context.Context //nolint:containedctx
	Query       string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLStmtQueryDoneInfo ¶ added in v3.34.0
type DatabaseSQLStmtQueryDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLStmtQueryStartInfo ¶ added in v3.34.0
type DatabaseSQLStmtQueryStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context     *context.Context
	Call        call
	StmtContext context.Context //nolint:containedctx
	Query       string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLTxCommitDoneInfo ¶ added in v3.34.0
type DatabaseSQLTxCommitDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLTxCommitStartInfo ¶ added in v3.34.0
type DatabaseSQLTxCommitStartInfo struct {
	// TxContext make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Tx      tableTransactionInfo
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLTxExecDoneInfo ¶ added in v3.34.2
type DatabaseSQLTxExecDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLTxExecStartInfo ¶ added in v3.34.2
type DatabaseSQLTxExecStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context   *context.Context
	Call      call
	TxContext context.Context //nolint:containedctx
	Tx        tableTransactionInfo
	Query     string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLTxPrepareDoneInfo ¶ added in v3.54.2
type DatabaseSQLTxPrepareDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLTxPrepareStartInfo ¶ added in v3.54.2
type DatabaseSQLTxPrepareStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context   *context.Context
	Call      call
	TxContext context.Context //nolint:containedctx
	Tx        tableTransactionInfo
	Query     string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLTxQueryDoneInfo ¶ added in v3.34.2
type DatabaseSQLTxQueryDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLTxQueryStartInfo ¶ added in v3.34.2
type DatabaseSQLTxQueryStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context   *context.Context
	Call      call
	TxContext context.Context //nolint:containedctx
	Tx        tableTransactionInfo
	Query     string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLTxRollbackDoneInfo ¶ added in v3.34.0
type DatabaseSQLTxRollbackDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLTxRollbackStartInfo ¶ added in v3.34.0
type DatabaseSQLTxRollbackStartInfo struct {
	// TxContext make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Tx      tableTransactionInfo
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type Details ¶ added in v3.2.1
type Details uint64
const ( DriverNetEvents Details = 1 << iota // for bitmask: 1, 2, 4, 8, 16, 32, ... DriverConnEvents DriverBalancerEvents DriverResolverEvents DriverRepeaterEvents DriverCredentialsEvents TableSessionLifeCycleEvents TableSessionQueryInvokeEvents TableSessionQueryStreamEvents TableSessionTransactionEvents TablePoolLifeCycleEvents TablePoolSessionLifeCycleEvents TablePoolAPIEvents QuerySessionEvents QueryResultEvents QueryTransactionEvents QueryPoolEvents TopicControlPlaneEvents TopicReaderCustomerEvents TopicReaderStreamLifeCycleEvents TopicReaderStreamEvents TopicReaderMessageEvents TopicReaderPartitionEvents TopicWriterStreamLifeCycleEvents TopicWriterStreamEvents DatabaseSQLConnectorEvents DatabaseSQLConnEvents DatabaseSQLTxEvents DatabaseSQLStmtEvents RetryEvents DiscoveryEvents SchemeEvents ScriptingEvents RatelimiterEvents CoordinationEvents DriverEvents = DriverConnEvents | DriverBalancerEvents | DriverResolverEvents | DriverRepeaterEvents | DriverCredentialsEvents TableEvents = TableSessionLifeCycleEvents | TableSessionQueryInvokeEvents | TableSessionQueryStreamEvents | TableSessionTransactionEvents | TablePoolLifeCycleEvents | TablePoolSessionLifeCycleEvents | TablePoolAPIEvents QueryEvents = QuerySessionEvents | QueryPoolEvents | QueryResultEvents | QueryTransactionEvents TablePoolEvents = TablePoolLifeCycleEvents | TablePoolSessionLifeCycleEvents | TablePoolAPIEvents TableSessionQueryEvents = TableSessionQueryInvokeEvents | TableSessionQueryStreamEvents TableSessionEvents = TableSessionLifeCycleEvents | TableSessionQueryEvents | TableSessionTransactionEvents TopicReaderEvents = TopicReaderCustomerEvents | TopicReaderStreamEvents | TopicReaderMessageEvents | TopicReaderPartitionEvents | TopicReaderStreamLifeCycleEvents TopicEvents = TopicControlPlaneEvents | TopicReaderEvents DatabaseSQLEvents = DatabaseSQLConnectorEvents | DatabaseSQLConnEvents | DatabaseSQLTxEvents | DatabaseSQLStmtEvents DetailsAll = ^Details(0) // All bits enabled )
func MatchDetails ¶ added in v3.11.0
type Discovery ¶ added in v3.10.0
type Discovery struct {
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnDiscover func(DiscoveryDiscoverStartInfo) func(DiscoveryDiscoverDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnWhoAmI func(DiscoveryWhoAmIStartInfo) func(DiscoveryWhoAmIDoneInfo)
}
    Discovery specified trace of discovery client activity. gtrace:gen Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func (*Discovery) Compose ¶ added in v3.10.0
func (t *Discovery) Compose(x *Discovery, opts ...DiscoveryComposeOption) *Discovery
Compose returns a new Discovery which has functional fields composed both from t and x. Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DiscoveryComposeOption ¶ added in v3.17.0
type DiscoveryComposeOption func(o *discoveryComposeOptions)
DiscoveryOption specified Discovery compose option Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func WithDiscoveryPanicCallback ¶ added in v3.17.0
func WithDiscoveryPanicCallback(cb func(e interface{})) DiscoveryComposeOption
    WithDiscoveryPanicCallback specified behavior on panic Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DiscoveryDiscoverDoneInfo ¶ added in v3.15.0
type DiscoveryDiscoverDoneInfo struct {
	Location  string
	Endpoints []EndpointInfo
	Error     error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DiscoveryDiscoverStartInfo ¶ added in v3.15.0
type DiscoveryDiscoverStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context  *context.Context
	Call     call
	Address  string
	Database string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DiscoveryWhoAmIDoneInfo ¶ added in v3.15.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DiscoveryWhoAmIStartInfo ¶ added in v3.15.0
type DiscoveryWhoAmIStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type Driver ¶
type Driver struct {
	// Driver runtime events
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnInit func(DriverInitStartInfo) func(DriverInitDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnWith func(DriverWithStartInfo) func(DriverWithDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnClose func(DriverCloseStartInfo) func(DriverCloseDoneInfo)
	// Pool of connections
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnPoolNew func(DriverConnPoolNewStartInfo) func(DriverConnPoolNewDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnPoolRelease func(DriverConnPoolReleaseStartInfo) func(DriverConnPoolReleaseDoneInfo)
	// Resolver events
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnResolve func(DriverResolveStartInfo) func(DriverResolveDoneInfo)
	// Conn events
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnConnStateChange func(DriverConnStateChangeStartInfo) func(DriverConnStateChangeDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnConnInvoke func(DriverConnInvokeStartInfo) func(DriverConnInvokeDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnConnNewStream func(DriverConnNewStreamStartInfo) func(DriverConnNewStreamDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnConnStreamRecvMsg func(DriverConnStreamRecvMsgStartInfo) func(DriverConnStreamRecvMsgDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnConnStreamSendMsg func(DriverConnStreamSendMsgStartInfo) func(DriverConnStreamSendMsgDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnConnStreamCloseSend func(DriverConnStreamCloseSendStartInfo) func(DriverConnStreamCloseSendDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnConnDial func(DriverConnDialStartInfo) func(DriverConnDialDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnConnBan func(DriverConnBanStartInfo) func(DriverConnBanDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnConnAllow func(DriverConnAllowStartInfo) func(DriverConnAllowDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnConnPark func(DriverConnParkStartInfo) func(DriverConnParkDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnConnClose func(DriverConnCloseStartInfo) func(DriverConnCloseDoneInfo)
	// Repeater events
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnRepeaterWakeUp func(DriverRepeaterWakeUpStartInfo) func(DriverRepeaterWakeUpDoneInfo)
	// Balancer events
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnBalancerInit func(DriverBalancerInitStartInfo) func(DriverBalancerInitDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnBalancerClose func(DriverBalancerCloseStartInfo) func(DriverBalancerCloseDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnBalancerChooseEndpoint func(
		DriverBalancerChooseEndpointStartInfo,
	) func(
		DriverBalancerChooseEndpointDoneInfo,
	)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnBalancerClusterDiscoveryAttempt func(
		DriverBalancerClusterDiscoveryAttemptStartInfo,
	) func(
		DriverBalancerClusterDiscoveryAttemptDoneInfo,
	)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnBalancerUpdate func(DriverBalancerUpdateStartInfo) func(DriverBalancerUpdateDoneInfo)
	// Credentials events
	OnGetCredentials func(DriverGetCredentialsStartInfo) func(DriverGetCredentialsDoneInfo)
}
    Driver specified trace of common driver activity. gtrace:gen Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func (*Driver) Compose ¶
func (t *Driver) Compose(x *Driver, opts ...DriverComposeOption) *Driver
Compose returns a new Driver which has functional fields composed both from t and x. Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverBalancerChooseEndpointDoneInfo ¶ added in v3.26.0
type DriverBalancerChooseEndpointDoneInfo struct {
	Endpoint EndpointInfo
	Error    error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverBalancerChooseEndpointStartInfo ¶ added in v3.26.0
type DriverBalancerChooseEndpointStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverBalancerCloseDoneInfo ¶ added in v3.26.0
type DriverBalancerCloseDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverBalancerCloseStartInfo ¶ added in v3.26.0
type DriverBalancerCloseStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverBalancerClusterDiscoveryAttemptDoneInfo ¶ added in v3.42.9
type DriverBalancerClusterDiscoveryAttemptDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverBalancerClusterDiscoveryAttemptStartInfo ¶ added in v3.42.9
type DriverBalancerClusterDiscoveryAttemptStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Address string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverBalancerDialEntrypointDoneInfo ¶ added in v3.42.9
type DriverBalancerDialEntrypointDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverBalancerDialEntrypointStartInfo ¶ added in v3.42.9
type DriverBalancerDialEntrypointStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Address string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverBalancerInitDoneInfo ¶ added in v3.26.0
type DriverBalancerInitDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverBalancerInitStartInfo ¶ added in v3.26.0
type DriverBalancerInitStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Name    string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverBalancerUpdateDoneInfo ¶ added in v3.26.0
type DriverBalancerUpdateDoneInfo struct {
	Endpoints []EndpointInfo
	Added     []EndpointInfo
	Dropped   []EndpointInfo
	LocalDC   string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverBalancerUpdateStartInfo ¶ added in v3.26.0
type DriverBalancerUpdateStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context     *context.Context
	Call        call
	NeedLocalDC bool
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverCloseDoneInfo ¶ added in v3.15.0
type DriverCloseDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverCloseStartInfo ¶ added in v3.15.0
type DriverCloseStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverComposeOption ¶ added in v3.17.0
type DriverComposeOption func(o *driverComposeOptions)
DriverOption specified Driver compose option Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func WithDriverPanicCallback ¶ added in v3.17.0
func WithDriverPanicCallback(cb func(e interface{})) DriverComposeOption
    WithDriverPanicCallback specified behavior on panic Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnAllowDoneInfo ¶ added in v3.25.1
type DriverConnAllowDoneInfo struct {
	State ConnState
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnAllowStartInfo ¶ added in v3.25.1
type DriverConnAllowStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context  *context.Context
	Call     call
	Endpoint EndpointInfo
	State    ConnState
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnBanDoneInfo ¶ added in v3.25.1
type DriverConnBanDoneInfo struct {
	State ConnState
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnBanStartInfo ¶ added in v3.25.1
type DriverConnBanStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context  *context.Context
	Call     call
	Endpoint EndpointInfo
	State    ConnState
	Cause    error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnCloseDoneInfo ¶ added in v3.15.0
type DriverConnCloseDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnCloseStartInfo ¶ added in v3.15.0
type DriverConnCloseStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context  *context.Context
	Call     call
	Endpoint EndpointInfo
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnDialDoneInfo ¶ added in v3.42.12
type DriverConnDialDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnDialStartInfo ¶ added in v3.42.12
type DriverConnDialStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context  *context.Context
	Call     call
	Endpoint EndpointInfo
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnInvokeDoneInfo ¶ added in v3.15.0
type DriverConnInvokeDoneInfo struct {
	Error    error
	Issues   []Issue
	OpID     string
	State    ConnState
	Metadata map[string][]string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnInvokeStartInfo ¶ added in v3.15.0
type DriverConnInvokeStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context  *context.Context
	Call     call
	Endpoint EndpointInfo
	Method   Method
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnNewStreamDoneInfo ¶ added in v3.15.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnNewStreamStartInfo ¶ added in v3.15.0
type DriverConnNewStreamStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context  *context.Context
	Call     call
	Endpoint EndpointInfo
	Method   Method
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnParkDoneInfo ¶ added in v3.15.0
type DriverConnParkDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnParkStartInfo ¶ added in v3.15.0
type DriverConnParkStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context  *context.Context
	Call     call
	Endpoint EndpointInfo
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnPoolNewDoneInfo ¶ added in v3.54.2
type DriverConnPoolNewDoneInfo struct{}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnPoolNewStartInfo ¶ added in v3.54.2
type DriverConnPoolNewStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnPoolReleaseDoneInfo ¶ added in v3.54.2
type DriverConnPoolReleaseDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnPoolReleaseStartInfo ¶ added in v3.54.2
type DriverConnPoolReleaseStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnStateChangeDoneInfo ¶ added in v3.15.0
type DriverConnStateChangeDoneInfo struct {
	State ConnState
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnStateChangeStartInfo ¶ added in v3.15.0
type DriverConnStateChangeStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context  *context.Context
	Call     call
	Endpoint EndpointInfo
	State    ConnState
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnStreamCloseSendDoneInfo ¶ added in v3.58.1
type DriverConnStreamCloseSendDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnStreamCloseSendStartInfo ¶ added in v3.58.1
type DriverConnStreamCloseSendStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnStreamRecvMsgDoneInfo ¶ added in v3.58.1
type DriverConnStreamRecvMsgDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnStreamRecvMsgStartInfo ¶ added in v3.58.1
type DriverConnStreamRecvMsgStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnStreamSendMsgDoneInfo ¶ added in v3.58.1
type DriverConnStreamSendMsgDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnStreamSendMsgStartInfo ¶ added in v3.58.1
type DriverConnStreamSendMsgStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnTakeDoneInfo ¶ added in v3.15.0
type DriverConnTakeDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnTakeStartInfo ¶ added in v3.15.0
type DriverConnTakeStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context  *context.Context
	Call     call
	Endpoint EndpointInfo
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverGetCredentialsDoneInfo ¶ added in v3.15.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverGetCredentialsStartInfo ¶ added in v3.15.0
type DriverGetCredentialsStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverInitDoneInfo ¶ added in v3.15.0
type DriverInitDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverInitStartInfo ¶ added in v3.15.0
type DriverInitStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context  *context.Context
	Call     call
	Endpoint string
	Database string
	Secure   bool
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverNetCloseDoneInfo ¶ added in v3.15.0
type DriverNetCloseDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverNetCloseStartInfo ¶ added in v3.15.0
type DriverNetCloseStartInfo struct {
	Call    call
	Address string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverNetDialDoneInfo ¶ added in v3.15.0
type DriverNetDialDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverNetDialStartInfo ¶ added in v3.15.0
type DriverNetDialStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Address string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverNetReadDoneInfo ¶ added in v3.15.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverNetReadStartInfo ¶ added in v3.15.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverNetWriteDoneInfo ¶ added in v3.15.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverNetWriteStartInfo ¶ added in v3.15.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverRepeaterWakeUpDoneInfo ¶ added in v3.25.0
type DriverRepeaterWakeUpDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverRepeaterWakeUpStartInfo ¶ added in v3.25.0
type DriverRepeaterWakeUpStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Name    string
	Event   string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverResolveDoneInfo ¶ added in v3.15.0
type DriverResolveDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverResolveStartInfo ¶ added in v3.15.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverWithDoneInfo ¶ added in v3.54.3
type DriverWithDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverWithStartInfo ¶ added in v3.54.3
type DriverWithStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context  *context.Context
	Call     call
	Endpoint string
	Database string
	Secure   bool
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type EndpointInfo ¶ added in v3.11.8
type EndpointInfo interface {
	fmt.Stringer
	NodeID() uint32
	Address() string
	Location() string
	LoadFactor() float32
	LastUpdated() time.Time
	// Deprecated: LocalDC check "local" by compare endpoint location with discovery "selflocation" field.
	// It work good only if connection url always point to local dc.
	// Will be removed after Oct 2024.
	// Read about versioning policy: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#deprecated
	LocalDC() bool
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type Issue ¶
Issue declare interface of operation error issues Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type Method ¶
type Method string
Method represents rpc method. Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func (Method) Name ¶
Name returns the rpc method name. Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func (Method) Service ¶
Service returns the rpc service name. Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func (Method) Split ¶
Split returns service name and method. Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type OnReadStreamUpdateTokenDoneInfo ¶ added in v3.32.0
type OnReadStreamUpdateTokenDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type OnReadUnknownGrpcMessageInfo ¶ added in v3.31.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type OnReadUpdateTokenMiddleTokenReceivedInfo ¶ added in v3.32.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type OnReadUpdateTokenStartInfo ¶ added in v3.32.0
type OnReadUpdateTokenStartInfo struct {
	ReaderConnectionID string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type Query ¶ added in v3.57.0
type Query struct {
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnNew func(QueryNewStartInfo) func(info QueryNewDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnClose func(QueryCloseStartInfo) func(info QueryCloseDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnPoolNew func(QueryPoolNewStartInfo) func(QueryPoolNewDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnPoolClose func(QueryPoolCloseStartInfo) func(QueryPoolCloseDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnPoolTry func(QueryPoolTryStartInfo) func(QueryPoolTryDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnPoolWith func(QueryPoolWithStartInfo) func(QueryPoolWithDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnPoolPut func(QueryPoolPutStartInfo) func(QueryPoolPutDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnPoolGet func(QueryPoolGetStartInfo) func(QueryPoolGetDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnPoolChange func(QueryPoolChange)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnDo func(QueryDoStartInfo) func(QueryDoDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnDoTx func(QueryDoTxStartInfo) func(QueryDoTxDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnSessionCreate func(QuerySessionCreateStartInfo) func(info QuerySessionCreateDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnSessionAttach func(QuerySessionAttachStartInfo) func(info QuerySessionAttachDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnSessionDelete func(QuerySessionDeleteStartInfo) func(info QuerySessionDeleteDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnSessionExecute func(QuerySessionExecuteStartInfo) func(info QuerySessionExecuteDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnSessionBegin        func(QuerySessionBeginStartInfo) func(info QuerySessionBeginDoneInfo)
	OnTxExecute           func(QueryTxExecuteStartInfo) func(info QueryTxExecuteDoneInfo)
	OnResultNew           func(QueryResultNewStartInfo) func(info QueryResultNewDoneInfo)
	OnResultNextPart      func(QueryResultNextPartStartInfo) func(info QueryResultNextPartDoneInfo)
	OnResultNextResultSet func(QueryResultNextResultSetStartInfo) func(info QueryResultNextResultSetDoneInfo)
	OnResultClose         func(QueryResultCloseStartInfo) func(info QueryResultCloseDoneInfo)
	OnResultSetNextRow    func(QueryResultSetNextRowStartInfo) func(info QueryResultSetNextRowDoneInfo)
	OnRowScan             func(QueryRowScanStartInfo) func(info QueryRowScanDoneInfo)
	OnRowScanNamed        func(QueryRowScanNamedStartInfo) func(info QueryRowScanNamedDoneInfo)
	OnRowScanStruct       func(QueryRowScanStructStartInfo) func(info QueryRowScanStructDoneInfo)
}
    Query specified trace of retry call activity. gtrace:gen Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func (*Query) Compose ¶ added in v3.57.0
func (t *Query) Compose(x *Query, opts ...QueryComposeOption) *Query
Compose returns a new Query which has functional fields composed both from t and x. Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryCloseDoneInfo ¶ added in v3.58.0
type QueryCloseDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryCloseStartInfo ¶ added in v3.58.0
type QueryCloseStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryComposeOption ¶ added in v3.57.0
type QueryComposeOption func(o *queryComposeOptions)
QueryOption specified Query compose option Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func WithQueryPanicCallback ¶ added in v3.57.0
func WithQueryPanicCallback(cb func(e interface{})) QueryComposeOption
    WithQueryPanicCallback specified behavior on panic Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryDoDoneInfo ¶ added in v3.57.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryDoStartInfo ¶ added in v3.57.0
type QueryDoStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryDoTxDoneInfo ¶ added in v3.57.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryDoTxStartInfo ¶ added in v3.57.0
type QueryDoTxStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryNewDoneInfo ¶ added in v3.58.0
type QueryNewDoneInfo struct{}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryNewStartInfo ¶ added in v3.58.0
type QueryNewStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryPoolChange ¶ added in v3.59.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryPoolCloseDoneInfo ¶ added in v3.58.0
type QueryPoolCloseDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryPoolCloseStartInfo ¶ added in v3.58.0
type QueryPoolCloseStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryPoolGetDoneInfo ¶ added in v3.58.0
type QueryPoolGetDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryPoolGetStartInfo ¶ added in v3.58.0
type QueryPoolGetStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryPoolNewDoneInfo ¶ added in v3.58.0
type QueryPoolNewDoneInfo struct {
	Limit int
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryPoolNewStartInfo ¶ added in v3.58.0
type QueryPoolNewStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryPoolPutDoneInfo ¶ added in v3.58.0
type QueryPoolPutDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryPoolPutStartInfo ¶ added in v3.58.0
type QueryPoolPutStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryPoolTryDoneInfo ¶ added in v3.58.0
type QueryPoolTryDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryPoolTryStartInfo ¶ added in v3.58.0
type QueryPoolTryStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryPoolWithDoneInfo ¶ added in v3.58.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryPoolWithStartInfo ¶ added in v3.58.0
type QueryPoolWithStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryResultCloseDoneInfo ¶ added in v3.58.2
type QueryResultCloseDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryResultCloseStartInfo ¶ added in v3.58.2
type QueryResultCloseStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryResultNewDoneInfo ¶ added in v3.58.2
type QueryResultNewDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryResultNewStartInfo ¶ added in v3.58.2
type QueryResultNewStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryResultNextPartDoneInfo ¶ added in v3.58.2
type QueryResultNextPartDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryResultNextPartStartInfo ¶ added in v3.58.2
type QueryResultNextPartStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryResultNextResultSetDoneInfo ¶ added in v3.58.2
type QueryResultNextResultSetDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryResultNextResultSetStartInfo ¶ added in v3.58.2
type QueryResultNextResultSetStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryResultSetNextRowDoneInfo ¶ added in v3.58.2
type QueryResultSetNextRowDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryResultSetNextRowStartInfo ¶ added in v3.58.2
type QueryResultSetNextRowStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryRowScanDoneInfo ¶ added in v3.58.2
type QueryRowScanDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryRowScanNamedDoneInfo ¶ added in v3.58.2
type QueryRowScanNamedDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryRowScanNamedStartInfo ¶ added in v3.58.2
type QueryRowScanNamedStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryRowScanStartInfo ¶ added in v3.58.2
type QueryRowScanStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryRowScanStructDoneInfo ¶ added in v3.58.2
type QueryRowScanStructDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryRowScanStructStartInfo ¶ added in v3.58.2
type QueryRowScanStructStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QuerySessionAttachDoneInfo ¶ added in v3.58.0
type QuerySessionAttachDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QuerySessionAttachStartInfo ¶ added in v3.58.0
type QuerySessionAttachStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Session querySessionInfo
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QuerySessionBeginDoneInfo ¶ added in v3.58.2
type QuerySessionBeginDoneInfo struct {
	Error error
	Tx    queryTransactionInfo
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QuerySessionBeginStartInfo ¶ added in v3.58.2
type QuerySessionBeginStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Session querySessionInfo
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QuerySessionCreateDoneInfo ¶ added in v3.58.0
type QuerySessionCreateDoneInfo struct {
	Session querySessionInfo
	Error   error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QuerySessionCreateStartInfo ¶ added in v3.58.0
type QuerySessionCreateStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QuerySessionDeleteDoneInfo ¶ added in v3.58.0
type QuerySessionDeleteDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QuerySessionDeleteStartInfo ¶ added in v3.58.0
type QuerySessionDeleteStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Session querySessionInfo
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QuerySessionExecuteDoneInfo ¶ added in v3.58.1
type QuerySessionExecuteDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QuerySessionExecuteStartInfo ¶ added in v3.58.1
type QuerySessionExecuteStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Session querySessionInfo
	Query   string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryTxExecuteDoneInfo ¶ added in v3.59.0
type QueryTxExecuteDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryTxExecuteStartInfo ¶ added in v3.59.0
type QueryTxExecuteStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Session querySessionInfo
	Tx      queryTransactionInfo
	Query   string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type Ratelimiter ¶ added in v3.10.0
type Ratelimiter struct{}
    Ratelimiter specified trace of ratelimiter client activity. gtrace:gen Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func (*Ratelimiter) Compose ¶ added in v3.10.0
func (t *Ratelimiter) Compose(x *Ratelimiter, opts ...RatelimiterComposeOption) *Ratelimiter
Compose returns a new Ratelimiter which has functional fields composed both from t and x. Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type RatelimiterComposeOption ¶ added in v3.17.0
type RatelimiterComposeOption func(o *ratelimiterComposeOptions)
RatelimiterOption specified Ratelimiter compose option Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func WithRatelimiterPanicCallback ¶ added in v3.17.0
func WithRatelimiterPanicCallback(cb func(e interface{})) RatelimiterComposeOption
    WithRatelimiterPanicCallback specified behavior on panic Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type Retry ¶
type Retry struct {
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnRetry func(RetryLoopStartInfo) func(RetryLoopDoneInfo)
}
    Retry specified trace of retry call activity. gtrace:gen Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func (*Retry) Compose ¶
func (t *Retry) Compose(x *Retry, opts ...RetryComposeOption) *Retry
Compose returns a new Retry which has functional fields composed both from t and x. Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type RetryComposeOption ¶ added in v3.17.0
type RetryComposeOption func(o *retryComposeOptions)
RetryOption specified Retry compose option Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func WithRetryPanicCallback ¶ added in v3.17.0
func WithRetryPanicCallback(cb func(e interface{})) RetryComposeOption
    WithRetryPanicCallback specified behavior on panic Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type RetryLoopDoneInfo ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type RetryLoopStartInfo ¶
type RetryLoopStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call       call
	Label      string
	Idempotent bool
	NestedCall bool // a sign for detect Retry calls inside head Retry
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type Scheme ¶ added in v3.10.0
type Scheme struct {
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnListDirectory func(SchemeListDirectoryStartInfo) func(SchemeListDirectoryDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnDescribePath func(SchemeDescribePathStartInfo) func(SchemeDescribePathDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnMakeDirectory func(SchemeMakeDirectoryStartInfo) func(SchemeMakeDirectoryDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnRemoveDirectory func(SchemeRemoveDirectoryStartInfo) func(SchemeRemoveDirectoryDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnModifyPermissions func(SchemeModifyPermissionsStartInfo) func(SchemeModifyPermissionsDoneInfo)
}
    Scheme specified trace of scheme client activity. gtrace:gen Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func (*Scheme) Compose ¶ added in v3.10.0
func (t *Scheme) Compose(x *Scheme, opts ...SchemeComposeOption) *Scheme
Compose returns a new Scheme which has functional fields composed both from t and x. Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type SchemeComposeOption ¶ added in v3.17.0
type SchemeComposeOption func(o *schemeComposeOptions)
SchemeOption specified Scheme compose option Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func WithSchemePanicCallback ¶ added in v3.17.0
func WithSchemePanicCallback(cb func(e interface{})) SchemeComposeOption
    WithSchemePanicCallback specified behavior on panic Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type SchemeDescribePathDoneInfo ¶ added in v3.54.2
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type SchemeDescribePathStartInfo ¶ added in v3.54.2
type SchemeDescribePathStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Path    string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type SchemeListDirectoryDoneInfo ¶ added in v3.54.2
type SchemeListDirectoryDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type SchemeListDirectoryStartInfo ¶ added in v3.54.2
type SchemeListDirectoryStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type SchemeMakeDirectoryDoneInfo ¶ added in v3.54.2
type SchemeMakeDirectoryDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type SchemeMakeDirectoryStartInfo ¶ added in v3.54.2
type SchemeMakeDirectoryStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Path    string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type SchemeModifyPermissionsDoneInfo ¶ added in v3.54.2
type SchemeModifyPermissionsDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type SchemeModifyPermissionsStartInfo ¶ added in v3.54.2
type SchemeModifyPermissionsStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Path    string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type SchemeRemoveDirectoryDoneInfo ¶ added in v3.54.2
type SchemeRemoveDirectoryDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type SchemeRemoveDirectoryStartInfo ¶ added in v3.54.2
type SchemeRemoveDirectoryStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Path    string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type Scripting ¶ added in v3.10.0
type Scripting struct {
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnExecute func(ScriptingExecuteStartInfo) func(ScriptingExecuteDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnStreamExecute func(
		ScriptingStreamExecuteStartInfo,
	) func(
		ScriptingStreamExecuteIntermediateInfo,
	) func(
		ScriptingStreamExecuteDoneInfo,
	)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnExplain func(ScriptingExplainStartInfo) func(ScriptingExplainDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnClose func(ScriptingCloseStartInfo) func(ScriptingCloseDoneInfo)
}
    Scripting specified trace of scripting client activity. gtrace:gen Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func (*Scripting) Compose ¶ added in v3.10.0
func (t *Scripting) Compose(x *Scripting, opts ...ScriptingComposeOption) *Scripting
Compose returns a new Scripting which has functional fields composed both from t and x. Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type ScriptingCloseDoneInfo ¶ added in v3.13.1
type ScriptingCloseDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type ScriptingCloseStartInfo ¶ added in v3.13.1
type ScriptingCloseStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type ScriptingComposeOption ¶ added in v3.17.0
type ScriptingComposeOption func(o *scriptingComposeOptions)
ScriptingOption specified Scripting compose option Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func WithScriptingPanicCallback ¶ added in v3.17.0
func WithScriptingPanicCallback(cb func(e interface{})) ScriptingComposeOption
    WithScriptingPanicCallback specified behavior on panic Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type ScriptingExecuteDoneInfo ¶ added in v3.13.1
type ScriptingExecuteDoneInfo struct {
	Result scriptingResult
	Error  error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type ScriptingExecuteStartInfo ¶ added in v3.13.1
type ScriptingExecuteStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context    *context.Context
	Call       call
	Query      string
	Parameters scriptingQueryParameters
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type ScriptingExplainDoneInfo ¶ added in v3.13.1
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type ScriptingExplainStartInfo ¶ added in v3.13.1
type ScriptingExplainStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Query   string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type ScriptingStreamExecuteDoneInfo ¶ added in v3.13.1
type ScriptingStreamExecuteDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type ScriptingStreamExecuteIntermediateInfo ¶ added in v3.13.1
type ScriptingStreamExecuteIntermediateInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type ScriptingStreamExecuteStartInfo ¶ added in v3.13.1
type ScriptingStreamExecuteStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context    *context.Context
	Call       call
	Query      string
	Parameters scriptingQueryParameters
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type Table ¶
type Table struct {
	// Client events
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnInit func(TableInitStartInfo) func(TableInitDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnClose func(TableCloseStartInfo) func(TableCloseDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnDo func(TableDoStartInfo) func(TableDoDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnDoTx func(TableDoTxStartInfo) func(TableDoTxDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnCreateSession func(TableCreateSessionStartInfo) func(TableCreateSessionDoneInfo)
	// Session events
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnSessionNew func(TableSessionNewStartInfo) func(TableSessionNewDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnSessionDelete func(TableSessionDeleteStartInfo) func(TableSessionDeleteDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnSessionKeepAlive func(TableKeepAliveStartInfo) func(TableKeepAliveDoneInfo)
	// Query events
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnSessionBulkUpsert func(TableBulkUpsertStartInfo) func(TableBulkUpsertDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnSessionQueryPrepare func(TablePrepareDataQueryStartInfo) func(TablePrepareDataQueryDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnSessionQueryExecute func(TableExecuteDataQueryStartInfo) func(TableExecuteDataQueryDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnSessionQueryExplain func(TableExplainQueryStartInfo) func(TableExplainQueryDoneInfo)
	// Stream events
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnSessionQueryStreamExecute func(TableSessionQueryStreamExecuteStartInfo) func(TableSessionQueryStreamExecuteDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnSessionQueryStreamRead func(TableSessionQueryStreamReadStartInfo) func(TableSessionQueryStreamReadDoneInfo)
	// Transaction events
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnTxBegin func(TableTxBeginStartInfo) func(
		TableTxBeginDoneInfo,
	)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnTxExecute func(TableTransactionExecuteStartInfo) func(
		TableTransactionExecuteDoneInfo,
	)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnTxExecuteStatement func(TableTransactionExecuteStatementStartInfo) func(
		TableTransactionExecuteStatementDoneInfo,
	)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnTxCommit func(TableTxCommitStartInfo) func(
		TableTxCommitDoneInfo,
	)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnTxRollback func(TableTxRollbackStartInfo) func(TableTxRollbackDoneInfo)
	// Pool state event
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnPoolStateChange func(TablePoolStateChangeInfo)
	// Pool session lifecycle events
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnPoolSessionAdd func(info TablePoolSessionAddInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnPoolSessionRemove func(info TablePoolSessionRemoveInfo)
	// Pool common API events
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnPoolPut func(TablePoolPutStartInfo) func(TablePoolPutDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnPoolGet func(TablePoolGetStartInfo) func(TablePoolGetDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnPoolWait func(TablePoolWaitStartInfo) func(TablePoolWaitDoneInfo)
}
    Table specified trace of table client activity. gtrace:gen Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func (*Table) Compose ¶
func (t *Table) Compose(x *Table, opts ...TableComposeOption) *Table
Compose returns a new Table which has functional fields composed both from t and x. Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableBulkUpsertDoneInfo ¶ added in v3.54.2
type TableBulkUpsertDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableBulkUpsertStartInfo ¶ added in v3.54.2
type TableBulkUpsertStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Session tableSessionInfo
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableCloseDoneInfo ¶ added in v3.13.1
type TableCloseDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableCloseStartInfo ¶ added in v3.13.1
type TableCloseStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableComposeOption ¶ added in v3.17.0
type TableComposeOption func(o *tableComposeOptions)
TableOption specified Table compose option Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func WithTablePanicCallback ¶ added in v3.17.0
func WithTablePanicCallback(cb func(e interface{})) TableComposeOption
    WithTablePanicCallback specified behavior on panic Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableCreateSessionDoneInfo ¶ added in v3.15.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableCreateSessionStartInfo ¶ added in v3.15.0
type TableCreateSessionStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableDoDoneInfo ¶ added in v3.15.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableDoStartInfo ¶ added in v3.15.0
type TableDoStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Label      string
	Idempotent bool
	NestedCall bool // flag when Retry called inside head Retry
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableDoTxDoneInfo ¶ added in v3.15.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableDoTxStartInfo ¶ added in v3.15.0
type TableDoTxStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Label      string
	Idempotent bool
	NestedCall bool // flag when Retry called inside head Retry
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableExecuteDataQueryDoneInfo ¶ added in v3.15.0
type TableExecuteDataQueryDoneInfo struct {
	Tx       tableTransactionInfo
	Prepared bool
	Result   tableResult
	Error    error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableExecuteDataQueryStartInfo ¶ added in v3.15.0
type TableExecuteDataQueryStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context     *context.Context
	Call        call
	Session     tableSessionInfo
	Query       tableDataQuery
	Parameters  tableQueryParameters
	KeepInCache bool
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableExplainQueryDoneInfo ¶ added in v3.15.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableExplainQueryStartInfo ¶ added in v3.15.0
type TableExplainQueryStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Session tableSessionInfo
	Query   string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableInitDoneInfo ¶ added in v3.13.1
type TableInitDoneInfo struct {
	Limit int
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableInitStartInfo ¶ added in v3.13.1
type TableInitStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableKeepAliveDoneInfo ¶ added in v3.15.0
type TableKeepAliveDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableKeepAliveStartInfo ¶ added in v3.15.0
type TableKeepAliveStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Session tableSessionInfo
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TablePoolGetDoneInfo ¶ added in v3.15.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TablePoolGetStartInfo ¶ added in v3.15.0
type TablePoolGetStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TablePoolPutDoneInfo ¶ added in v3.15.0
type TablePoolPutDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TablePoolPutStartInfo ¶ added in v3.15.0
type TablePoolPutStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Session tableSessionInfo
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TablePoolSessionAddInfo ¶ added in v3.33.0
type TablePoolSessionAddInfo struct {
	Session tableSessionInfo
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TablePoolSessionCloseDoneInfo ¶ added in v3.15.0
type TablePoolSessionCloseDoneInfo struct{}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TablePoolSessionCloseStartInfo ¶ added in v3.15.0
type TablePoolSessionCloseStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Session tableSessionInfo
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TablePoolSessionNewDoneInfo ¶ added in v3.15.0
type TablePoolSessionNewDoneInfo struct {
	Session tableSessionInfo
	Error   error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TablePoolSessionNewStartInfo ¶ added in v3.15.0
type TablePoolSessionNewStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TablePoolSessionRemoveInfo ¶ added in v3.33.0
type TablePoolSessionRemoveInfo struct {
	Session tableSessionInfo
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TablePoolStateChangeInfo ¶ added in v3.26.10
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TablePoolWaitDoneInfo ¶ added in v3.15.0
type TablePoolWaitDoneInfo struct {
	Session tableSessionInfo
	Error   error
}
    TablePoolWaitDoneInfo means a wait iteration inside Get call is done Warning: Session and Error may be nil at the same time. This means that a wait iteration donned without any significant tableResultErr Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TablePoolWaitStartInfo ¶ added in v3.15.0
type TablePoolWaitStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TablePrepareDataQueryDoneInfo ¶ added in v3.15.0
type TablePrepareDataQueryDoneInfo struct {
	Result tableDataQuery
	Error  error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TablePrepareDataQueryStartInfo ¶ added in v3.15.0
type TablePrepareDataQueryStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Session tableSessionInfo
	Query   string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableSessionDeleteDoneInfo ¶ added in v3.15.0
type TableSessionDeleteDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableSessionDeleteStartInfo ¶ added in v3.15.0
type TableSessionDeleteStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Session tableSessionInfo
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableSessionNewDoneInfo ¶ added in v3.15.0
type TableSessionNewDoneInfo struct {
	Session tableSessionInfo
	Error   error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableSessionNewStartInfo ¶ added in v3.15.0
type TableSessionNewStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableSessionQueryStreamExecuteDoneInfo ¶ added in v3.15.0
type TableSessionQueryStreamExecuteDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableSessionQueryStreamExecuteStartInfo ¶ added in v3.15.0
type TableSessionQueryStreamExecuteStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context    *context.Context
	Call       call
	Session    tableSessionInfo
	Query      tableDataQuery
	Parameters tableQueryParameters
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableSessionQueryStreamReadDoneInfo ¶ added in v3.15.0
type TableSessionQueryStreamReadDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableSessionQueryStreamReadStartInfo ¶ added in v3.15.0
type TableSessionQueryStreamReadStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Session tableSessionInfo
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableTransactionExecuteDoneInfo ¶ added in v3.34.2
type TableTransactionExecuteDoneInfo struct {
	Result tableResult
	Error  error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableTransactionExecuteStartInfo ¶ added in v3.34.2
type TableTransactionExecuteStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context    *context.Context
	Call       call
	Session    tableSessionInfo
	Tx         tableTransactionInfo
	Query      tableDataQuery
	Parameters tableQueryParameters
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableTransactionExecuteStatementDoneInfo ¶ added in v3.34.2
type TableTransactionExecuteStatementDoneInfo struct {
	Result tableResult
	Error  error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableTransactionExecuteStatementStartInfo ¶ added in v3.34.2
type TableTransactionExecuteStatementStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context        *context.Context
	Call           call
	Session        tableSessionInfo
	Tx             tableTransactionInfo
	StatementQuery tableDataQuery
	Parameters     tableQueryParameters
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableTxBeginDoneInfo ¶ added in v3.59.0
type TableTxBeginDoneInfo struct {
	Tx    tableTransactionInfo
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableTxBeginStartInfo ¶ added in v3.59.0
type TableTxBeginStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Session tableSessionInfo
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableTxCommitDoneInfo ¶ added in v3.59.0
type TableTxCommitDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableTxCommitStartInfo ¶ added in v3.59.0
type TableTxCommitStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Session tableSessionInfo
	Tx      tableTransactionInfo
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableTxRollbackDoneInfo ¶ added in v3.59.0
type TableTxRollbackDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableTxRollbackStartInfo ¶ added in v3.59.0
type TableTxRollbackStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Call    call
	Session tableSessionInfo
	Tx      tableTransactionInfo
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type Topic ¶ added in v3.31.0
type Topic struct {
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnReaderStart func(info TopicReaderStartInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnReaderReconnect func(TopicReaderReconnectStartInfo) func(TopicReaderReconnectDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnReaderReconnectRequest func(TopicReaderReconnectRequestInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnReaderPartitionReadStartResponse func(
		TopicReaderPartitionReadStartResponseStartInfo,
	) func(
		TopicReaderPartitionReadStartResponseDoneInfo,
	)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnReaderPartitionReadStopResponse func(
		TopicReaderPartitionReadStopResponseStartInfo,
	) func(
		TopicReaderPartitionReadStopResponseDoneInfo,
	)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnReaderCommit func(TopicReaderCommitStartInfo) func(TopicReaderCommitDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnReaderSendCommitMessage func(TopicReaderSendCommitMessageStartInfo) func(TopicReaderSendCommitMessageDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnReaderCommittedNotify func(TopicReaderCommittedNotifyInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnReaderClose func(TopicReaderCloseStartInfo) func(TopicReaderCloseDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnReaderInit func(TopicReaderInitStartInfo) func(TopicReaderInitDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnReaderError func(TopicReaderErrorInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnReaderUpdateToken func(
		OnReadUpdateTokenStartInfo,
	) func(
		OnReadUpdateTokenMiddleTokenReceivedInfo,
	) func(
		OnReadStreamUpdateTokenDoneInfo,
	)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnReaderSentDataRequest func(TopicReaderSentDataRequestInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnReaderReceiveDataResponse func(TopicReaderReceiveDataResponseStartInfo) func(TopicReaderReceiveDataResponseDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnReaderReadMessages func(TopicReaderReadMessagesStartInfo) func(TopicReaderReadMessagesDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnReaderUnknownGrpcMessage func(OnReadUnknownGrpcMessageInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnWriterReconnect func(TopicWriterReconnectStartInfo) func(TopicWriterReconnectDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnWriterInitStream func(TopicWriterInitStreamStartInfo) func(TopicWriterInitStreamDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnWriterClose func(TopicWriterCloseStartInfo) func(TopicWriterCloseDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnWriterCompressMessages func(TopicWriterCompressMessagesStartInfo) func(TopicWriterCompressMessagesDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnWriterSendMessages func(TopicWriterSendMessagesStartInfo) func(TopicWriterSendMessagesDoneInfo)
	// Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
	OnWriterReadUnknownGrpcMessage func(TopicOnWriterReadUnknownGrpcMessageInfo)
}
    Topic specified trace of topic reader client activity. gtrace:gen Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func (*Topic) Compose ¶ added in v3.31.0
func (t *Topic) Compose(x *Topic, opts ...TopicComposeOption) *Topic
Compose returns a new Topic which has functional fields composed both from t and x. Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicComposeOption ¶ added in v3.31.0
type TopicComposeOption func(o *topicComposeOptions)
TopicOption specified Topic compose option Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func WithTopicPanicCallback ¶ added in v3.31.0
func WithTopicPanicCallback(cb func(e interface{})) TopicComposeOption
    WithTopicPanicCallback specified behavior on panic Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicOnWriterReadUnknownGrpcMessageInfo ¶ added in v3.38.0
type TopicOnWriterReadUnknownGrpcMessageInfo struct {
	WriterInstanceID string
	SessionID        string
	Error            error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReadStreamInitRequestInfo ¶ added in v3.32.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderCloseDoneInfo ¶ added in v3.32.0
type TopicReaderCloseDoneInfo struct {
	CloseError error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderCloseStartInfo ¶ added in v3.32.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderCommitDoneInfo ¶ added in v3.32.0
type TopicReaderCommitDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderCommitStartInfo ¶ added in v3.32.0
type TopicReaderCommitStartInfo struct {
	RequestContext     *context.Context
	Topic              string
	PartitionID        int64
	PartitionSessionID int64
	StartOffset        int64
	EndOffset          int64
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderCommittedNotifyInfo ¶ added in v3.32.0
type TopicReaderCommittedNotifyInfo struct {
	ReaderConnectionID string
	Topic              string
	PartitionID        int64
	PartitionSessionID int64
	CommittedOffset    int64
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderDataResponseInfo ¶ added in v3.32.0
type TopicReaderDataResponseInfo interface {
	GetBytesSize() int
	GetPartitionBatchMessagesCounts() (partitionCount, batchCount, messagesCount int)
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderErrorInfo ¶ added in v3.32.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderInitDoneInfo ¶ added in v3.32.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderInitStartInfo ¶ added in v3.32.0
type TopicReaderInitStartInfo struct {
	PreInitReaderConnectionID string
	InitRequestInfo           TopicReadStreamInitRequestInfo
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderPartitionReadStartResponseDoneInfo ¶ added in v3.32.0
type TopicReaderPartitionReadStartResponseDoneInfo struct {
	ReadOffset   *int64
	CommitOffset *int64
	Error        error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderPartitionReadStartResponseStartInfo ¶ added in v3.32.0
type TopicReaderPartitionReadStartResponseStartInfo struct {
	ReaderConnectionID string
	PartitionContext   *context.Context
	Topic              string
	PartitionID        int64
	PartitionSessionID int64
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderPartitionReadStopResponseDoneInfo ¶ added in v3.32.0
type TopicReaderPartitionReadStopResponseDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderPartitionReadStopResponseStartInfo ¶ added in v3.32.0
type TopicReaderPartitionReadStopResponseStartInfo struct {
	ReaderConnectionID string
	PartitionContext   *context.Context
	Topic              string
	PartitionID        int64
	PartitionSessionID int64
	CommittedOffset    int64
	Graceful           bool
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderReadMessagesDoneInfo ¶ added in v3.32.0
type TopicReaderReadMessagesDoneInfo struct {
	MessagesCount      int
	Topic              string
	PartitionID        int64
	PartitionSessionID int64
	OffsetStart        int64
	OffsetEnd          int64
	FreeBufferCapacity int
	Error              error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderReadMessagesStartInfo ¶ added in v3.32.0
type TopicReaderReadMessagesStartInfo struct {
	RequestContext     *context.Context
	MinCount           int
	MaxCount           int
	FreeBufferCapacity int
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderReceiveDataResponseDoneInfo ¶ added in v3.32.0
type TopicReaderReceiveDataResponseDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderReceiveDataResponseStartInfo ¶ added in v3.32.0
type TopicReaderReceiveDataResponseStartInfo struct {
	ReaderConnectionID          string
	LocalBufferSizeAfterReceive int
	DataResponse                TopicReaderDataResponseInfo
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderReconnectDoneInfo ¶ added in v3.32.0
type TopicReaderReconnectDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderReconnectRequestInfo ¶ added in v3.32.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderReconnectStartInfo ¶ added in v3.32.0
type TopicReaderReconnectStartInfo struct {
	Reason error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderSendCommitMessageDoneInfo ¶ added in v3.32.0
type TopicReaderSendCommitMessageDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderSendCommitMessageStartInfo ¶ added in v3.32.0
type TopicReaderSendCommitMessageStartInfo struct {
	CommitsInfo TopicReaderStreamSendCommitMessageStartMessageInfo
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderSentDataRequestInfo ¶ added in v3.32.0
type TopicReaderSentDataRequestInfo struct {
	ReaderConnectionID       string
	RequestBytes             int
	LocalBufferSizeAfterSent int
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderStartInfo ¶ added in v3.52.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderStreamCommitInfo ¶ added in v3.52.0
type TopicReaderStreamCommitInfo struct {
	Topic              string
	PartitionID        int64
	PartitionSessionID int64
	StartOffset        int64
	EndOffset          int64
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderStreamSendCommitMessageStartMessageInfo ¶ added in v3.32.0
type TopicReaderStreamSendCommitMessageStartMessageInfo interface {
	GetCommitsInfo() []TopicReaderStreamCommitInfo
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicWriterCloseDoneInfo ¶ added in v3.38.0
type TopicWriterCloseDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicWriterCloseStartInfo ¶ added in v3.38.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicWriterCompressMessagesDoneInfo ¶ added in v3.38.0
type TopicWriterCompressMessagesDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicWriterCompressMessagesReason ¶ added in v3.38.0
type TopicWriterCompressMessagesReason string
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func (TopicWriterCompressMessagesReason) String ¶ added in v3.38.0
func (r TopicWriterCompressMessagesReason) String() string
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicWriterCompressMessagesStartInfo ¶ added in v3.38.0
type TopicWriterCompressMessagesStartInfo struct {
	WriterInstanceID string
	SessionID        string
	Codec            int32
	FirstSeqNo       int64
	MessagesCount    int
	Reason           TopicWriterCompressMessagesReason
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicWriterInitStreamDoneInfo ¶ added in v3.38.0
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicWriterInitStreamStartInfo ¶ added in v3.38.0
type TopicWriterInitStreamStartInfo struct {
	WriterInstanceID string
	Topic            string
	ProducerID       string
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicWriterReconnectDoneInfo ¶ added in v3.38.0
type TopicWriterReconnectDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicWriterReconnectStartInfo ¶ added in v3.38.0
type TopicWriterReconnectStartInfo struct {
	WriterInstanceID string
	Topic            string
	ProducerID       string
	Attempt          int
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicWriterSendMessagesDoneInfo ¶ added in v3.38.0
type TopicWriterSendMessagesDoneInfo struct {
	Error error
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicWriterSendMessagesStartInfo ¶ added in v3.38.0
type TopicWriterSendMessagesStartInfo struct {
	WriterInstanceID string
	SessionID        string
	Codec            int32
	FirstSeqNo       int64
	MessagesCount    int
}
    Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
       Source Files
      ¶
      Source Files
      ¶
    
- call.go
- coordination.go
- coordination_gtrace.go
- details.go
- discovery.go
- discovery_gtrace.go
- driver.go
- driver_gtrace.go
- query.go
- query_gtrace.go
- ratelimiter.go
- ratelimiter_gtrace.go
- retry.go
- retry_gtrace.go
- scheme.go
- scheme_gtrace.go
- scripting.go
- scripting_gtrace.go
- sql.go
- sql_gtrace.go
- table.go
- table_gtrace.go
- topic.go
- topic_gtrace.go