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 txInfo, _ 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 sessionInfo)
- 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 txInfo) 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 txInfo) 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 DriverOnConnStreamFinish(t *Driver, c context.Context, call call, e 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 QueryOnExec(t *Query, c *context.Context, call call, query string) func(error)
- func QueryOnNew(t *Query, c *context.Context, call call) func()
- func QueryOnPoolChange(t *Query, limit int, index int, idle int, wait int, createInProgress int)
- func QueryOnPoolClose(t *Query, c *context.Context, call call) func(error)
- func QueryOnPoolGet(t *Query, c *context.Context, call call) func(session sessionInfo, attempts int, _ error)
- func QueryOnPoolNew(t *Query, c *context.Context, call call) func(limit int)
- func QueryOnPoolPut(t *Query, c *context.Context, call call, session sessionInfo) func(error)
- func QueryOnPoolTry(t *Query, c *context.Context, call call) func(error)
- func QueryOnPoolWith(t *Query, c *context.Context, call call) func(attempts int, _ error)
- func QueryOnQuery(t *Query, c *context.Context, call call, query string) func(error)
- func QueryOnQueryResultSet(t *Query, c *context.Context, call call, query string) func(error)
- func QueryOnQueryRow(t *Query, c *context.Context, call call, query string) func(error)
- 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(stats *Ydb_TableStats.QueryStats, _ error)
- func QueryOnResultNextResultSet(t *Query, c *context.Context, call call) func(error)
- func QueryOnSessionAttach(t *Query, c *context.Context, call call, session sessionInfo) func(error)
- func QueryOnSessionBegin(t *Query, c *context.Context, call call, session sessionInfo) func(_ error, tx txInfo)
- func QueryOnSessionCreate(t *Query, c *context.Context, call call) func(session sessionInfo, _ error)
- func QueryOnSessionDelete(t *Query, c *context.Context, call call, session sessionInfo) func(error)
- func QueryOnSessionExec(t *Query, c *context.Context, call call, session sessionInfo, query string) func(error)
- func QueryOnSessionQuery(t *Query, c *context.Context, call call, session sessionInfo, query string) func(error)
- func QueryOnSessionQueryResultSet(t *Query, c *context.Context, call call, session sessionInfo, query string) func(error)
- func QueryOnSessionQueryRow(t *Query, c *context.Context, call call, session sessionInfo, query string) func(error)
- func QueryOnTxExec(t *Query, c *context.Context, call call, session sessionInfo, tx txInfo, ...) func(error)
- func QueryOnTxQuery(t *Query, c *context.Context, call call, session sessionInfo, tx txInfo, ...) func(error)
- func QueryOnTxQueryResultSet(t *Query, c *context.Context, call call, tx txInfo, query string) func(error)
- func QueryOnTxQueryRow(t *Query, c *context.Context, call call, tx txInfo, query string) 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 sessionInfo, 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 sessionInfo, attempts int, _ error)
- func TableOnPoolPut(t *Table, c *context.Context, call call, session sessionInfo) func(error)
- func TableOnPoolSessionAdd(t *Table, session sessionInfo)
- func TableOnPoolSessionRemove(t *Table, session sessionInfo)
- func TableOnPoolStateChange(t *Table, limit int, index int, idle int, wait int, createInProgress int, ...)
- func TableOnPoolWait(t *Table, c *context.Context, call call) func(session sessionInfo, _ error)
- func TableOnPoolWith(t *Table, c *context.Context, call call) func(attempts int, _ error)
- func TableOnSessionBulkUpsert(t *Table, c *context.Context, call call, session sessionInfo) func(error)
- func TableOnSessionDelete(t *Table, c *context.Context, call call, session sessionInfo) func(error)
- func TableOnSessionKeepAlive(t *Table, c *context.Context, call call, session sessionInfo) func(error)
- func TableOnSessionNew(t *Table, c *context.Context, call call) func(session sessionInfo, _ error)
- func TableOnSessionQueryExecute(t *Table, c *context.Context, call call, session sessionInfo, ...) func(tx txInfo, prepared bool, result tableResult, _ error)
- func TableOnSessionQueryExplain(t *Table, c *context.Context, call call, session sessionInfo, query string) func(aST string, plan string, _ error)
- func TableOnSessionQueryPrepare(t *Table, c *context.Context, call call, session sessionInfo, query string) func(result tableDataQuery, _ error)
- func TableOnSessionQueryStreamExecute(t *Table, c *context.Context, call call, session sessionInfo, ...) func(error)
- func TableOnSessionQueryStreamRead(t *Table, c *context.Context, call call, session sessionInfo) func(error)
- func TableOnTxBegin(t *Table, c *context.Context, call call, session sessionInfo) func(tx txInfo, _ error)
- func TableOnTxCommit(t *Table, c *context.Context, call call, session sessionInfo, tx txInfo) func(error)
- func TableOnTxExecute(t *Table, c *context.Context, call call, session sessionInfo, tx txInfo, ...) func(result tableResult, _ error)
- func TableOnTxExecuteStatement(t *Table, c *context.Context, call call, session sessionInfo, tx txInfo, ...) func(result tableResult, _ error)
- func TableOnTxRollback(t *Table, c *context.Context, call call, session sessionInfo, tx txInfo) 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 TopicOnReaderPopBatchTx(t *Topic, c *context.Context, readerID int64, transactionSessionID string, ...) func(startOffset int64, endOffset int64, messagesCount int, _ 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, e error)
- func TopicOnReaderStreamPopBatchTx(t *Topic, c *context.Context, readerID int64, readerConnectionID string, ...) func(error)
- func TopicOnReaderTransactionCompleted(t *Topic, c *context.Context, readerID int64, readerConnectionID string, ...) func()
- func TopicOnReaderTransactionRollback(t *Topic, c *context.Context, readerID int64, readerConnectionID string, ...) func(rollbackError error)
- func TopicOnReaderUnknownGrpcMessage(t *Topic, readerConnectionID string, e error)
- func TopicOnReaderUpdateOffsetsInTransaction(t *Topic, c *context.Context, readerID int64, readerConnectionID string, ...) func(error)
- func TopicOnReaderUpdateToken(t *Topic, readerConnectionID string) func(tokenLen int, _ error) func(error)
- func TopicOnWriterAfterFinishTransaction(t *Topic, e error, sessionID string, transactionID string) func(closeError error)
- func TopicOnWriterBeforeCommitTransaction(t *Topic, ctx *context.Context, kqpSessionID string, topicSessionID string, ...) func(_ error, topicSessionID string)
- 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 TopicOnWriterReceiveResult(t *Topic, writerInstanceID string, sessionID string, partitionID int64, ...)
- 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 DriverConnStreamFinishInfo
- 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 QueryExecDoneInfo
- type QueryExecStartInfo
- 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 QueryQueryDoneInfo
- type QueryQueryResultSetDoneInfo
- type QueryQueryResultSetStartInfo
- type QueryQueryRowDoneInfo
- type QueryQueryRowStartInfo
- type QueryQueryStartInfo
- type QueryReadResultSetDoneInfo
- type QueryReadResultSetStartInfo
- type QueryReadRowDoneInfo
- type QueryReadRowStartInfo
- type QueryResultCloseDoneInfo
- type QueryResultCloseStartInfo
- type QueryResultNewDoneInfo
- type QueryResultNewStartInfo
- type QueryResultNextPartDoneInfo
- type QueryResultNextPartStartInfo
- type QueryResultNextResultSetDoneInfo
- type QueryResultNextResultSetStartInfo
- type QuerySessionAttachDoneInfo
- type QuerySessionAttachStartInfo
- type QuerySessionBeginDoneInfo
- type QuerySessionBeginStartInfo
- type QuerySessionCreateDoneInfo
- type QuerySessionCreateStartInfo
- type QuerySessionDeleteDoneInfo
- type QuerySessionDeleteStartInfo
- type QuerySessionExecDoneInfo
- type QuerySessionExecStartInfo
- type QuerySessionQueryDoneInfo
- type QuerySessionQueryResultSetDoneInfo
- type QuerySessionQueryResultSetStartInfo
- type QuerySessionQueryRowDoneInfo
- type QuerySessionQueryRowStartInfo
- type QuerySessionQueryStartInfo
- type QueryTxExecDoneInfo
- type QueryTxExecStartInfo
- type QueryTxQueryDoneInfo
- type QueryTxQueryResultSetDoneInfo
- type QueryTxQueryResultSetStartInfo
- type QueryTxQueryRowDoneInfo
- type QueryTxQueryRowStartInfo
- type QueryTxQueryStartInfo
- 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 TablePoolWithDoneInfo
- type TablePoolWithStartInfo
- 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 TopicOnWriterAfterFinishTransactionDoneInfo
- type TopicOnWriterAfterFinishTransactionStartInfo
- type TopicOnWriterBeforeCommitTransactionDoneInfo
- type TopicOnWriterBeforeCommitTransactionStartInfo
- type TopicOnWriterReadUnknownGrpcMessageInfo
- type TopicReadStreamInitRequestInfo
- type TopicReaderCloseDoneInfo
- type TopicReaderCloseStartInfo
- type TopicReaderCommitDoneInfo
- type TopicReaderCommitStartInfo
- type TopicReaderCommittedNotifyInfo
- type TopicReaderDataResponseInfo
- type TopicReaderErrorInfo
- type TopicReaderInitDoneInfo
- type TopicReaderInitStartInfo
- type TopicReaderOnUpdateOffsetsInTransactionDoneInfo
- type TopicReaderOnUpdateOffsetsInTransactionStartInfo
- type TopicReaderPartitionReadStartResponseDoneInfo
- type TopicReaderPartitionReadStartResponseStartInfo
- type TopicReaderPartitionReadStopResponseDoneInfo
- type TopicReaderPartitionReadStopResponseStartInfo
- type TopicReaderPopBatchTxDoneInfo
- type TopicReaderPopBatchTxStartInfo
- 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 TopicReaderStreamPopBatchTxDoneInfo
- type TopicReaderStreamPopBatchTxStartInfo
- type TopicReaderStreamSendCommitMessageStartMessageInfo
- type TopicReaderTransactionCompletedDoneInfo
- type TopicReaderTransactionCompletedStartInfo
- type TopicReaderTransactionRollbackDoneInfo
- type TopicReaderTransactionRollbackStartInfo
- type TopicWriterCloseDoneInfo
- type TopicWriterCloseStartInfo
- type TopicWriterCompressMessagesDoneInfo
- type TopicWriterCompressMessagesReason
- type TopicWriterCompressMessagesStartInfo
- type TopicWriterInitStreamDoneInfo
- type TopicWriterInitStreamStartInfo
- type TopicWriterReconnectDoneInfo
- type TopicWriterReconnectStartInfo
- type TopicWriterResultMessagesInfo
- type TopicWriterResultMessagesInfoAcks
- 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 ¶
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 ¶
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 ¶
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 ¶
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 ¶
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 ¶
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 ¶
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 ¶
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 ¶
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 ¶
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 ¶
func CoordinationOnSessionReceiveUnexpected(t *Coordination, response *Ydb_Coordination.SessionResponse)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func CoordinationOnSessionSend ¶
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 ¶
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 ¶
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 ¶
func CoordinationOnSessionStart(t *Coordination) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func CoordinationOnSessionStartTimeout ¶
func CoordinationOnSessionStartTimeout(t *Coordination, timeout time.Duration)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func CoordinationOnSessionStarted ¶
func CoordinationOnSessionStarted(t *Coordination, sessionID uint64, expectedSessionID uint64)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func CoordinationOnSessionStop ¶
func CoordinationOnSessionStop(t *Coordination, sessionID uint64)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func CoordinationOnSessionStopTimeout ¶
func CoordinationOnSessionStopTimeout(t *Coordination, timeout time.Duration)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func CoordinationOnSessionStopped ¶
func CoordinationOnSessionStopped(t *Coordination, sessionID uint64, expectedSessionID uint64)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func CoordinationOnStreamNew ¶
func CoordinationOnStreamNew(t *Coordination) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DatabaseSQLOnConnBegin ¶
func DatabaseSQLOnConnBegin(t *DatabaseSQL, c *context.Context, call call) func(tx txInfo, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DatabaseSQLOnConnClose ¶
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 ¶
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 ¶
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 ¶
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 ¶
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 ¶
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 ¶
func DatabaseSQLOnConnectorConnect(t *DatabaseSQL, c *context.Context, call call) func(_ error, session sessionInfo)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DatabaseSQLOnDoTx ¶
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 ¶
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 ¶
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 ¶
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 ¶
func DatabaseSQLOnTxCommit(t *DatabaseSQL, c *context.Context, call call, tx txInfo) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DatabaseSQLOnTxExec ¶
func DatabaseSQLOnTxExec(t *DatabaseSQL, c *context.Context, call call, txContext context.Context, tx txInfo, query string) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DatabaseSQLOnTxPrepare ¶
func DatabaseSQLOnTxPrepare(t *DatabaseSQL, c *context.Context, call call, txContext context.Context, tx txInfo, query string) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DatabaseSQLOnTxQuery ¶
func DatabaseSQLOnTxQuery(t *DatabaseSQL, c *context.Context, call call, txContext context.Context, tx txInfo, query string) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DatabaseSQLOnTxRollback ¶
func DatabaseSQLOnTxRollback(t *DatabaseSQL, c *context.Context, call call, tx txInfo) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DiscoveryOnDiscover ¶
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 ¶
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 ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnBalancerClusterDiscoveryAttempt ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnBalancerUpdate ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnConnAllow ¶
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 ¶
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 ¶
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 ¶
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 ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnConnStreamFinish ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnConnStreamRecvMsg ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnConnStreamSendMsg ¶
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 ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnPoolRelease ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnRepeaterWakeUp ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func DriverOnWith ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnDo ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnDoTx ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnExec ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnNew ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnPoolChange ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnPoolClose ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnPoolGet ¶
func QueryOnPoolGet(t *Query, c *context.Context, call call) func(session sessionInfo, attempts int, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnPoolNew ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnPoolPut ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnPoolTry ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnPoolWith ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnQuery ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnQueryResultSet ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnQueryRow ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnResultClose ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnResultNew ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnResultNextPart ¶
func QueryOnResultNextPart(t *Query, c *context.Context, call call) func(stats *Ydb_TableStats.QueryStats, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnResultNextResultSet ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnSessionAttach ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnSessionBegin ¶
func QueryOnSessionBegin(t *Query, c *context.Context, call call, session sessionInfo) func(_ error, tx txInfo)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnSessionCreate ¶
func QueryOnSessionCreate(t *Query, c *context.Context, call call) func(session sessionInfo, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnSessionDelete ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnSessionExec ¶
func QueryOnSessionExec(t *Query, c *context.Context, call call, session sessionInfo, query string) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnSessionQuery ¶
func QueryOnSessionQuery(t *Query, c *context.Context, call call, session sessionInfo, query string) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnSessionQueryResultSet ¶
func QueryOnSessionQueryResultSet(t *Query, c *context.Context, call call, session sessionInfo, query string) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnSessionQueryRow ¶
func QueryOnSessionQueryRow(t *Query, c *context.Context, call call, session sessionInfo, query string) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnTxExec ¶
func QueryOnTxExec(t *Query, c *context.Context, call call, session sessionInfo, tx txInfo, query string) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnTxQuery ¶
func QueryOnTxQuery(t *Query, c *context.Context, call call, session sessionInfo, tx txInfo, query string) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnTxQueryResultSet ¶
func QueryOnTxQueryResultSet(t *Query, c *context.Context, call call, tx txInfo, query string) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func QueryOnTxQueryRow ¶
func QueryOnTxQueryRow(t *Query, c *context.Context, call call, tx txInfo, 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 ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func SchemeOnMakeDirectory ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func SchemeOnModifyPermissions ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func SchemeOnRemoveDirectory ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func ScriptingOnClose ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func ScriptingOnExecute ¶
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 ¶
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 ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnCreateSession ¶
func TableOnCreateSession(t *Table, c *context.Context, call call) func(session sessionInfo, attempts int, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnDo ¶
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 ¶
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 ¶
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 sessionInfo, 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 ¶
func TableOnPoolSessionAdd(t *Table, session sessionInfo)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnPoolSessionRemove ¶
func TableOnPoolSessionRemove(t *Table, session sessionInfo)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnPoolStateChange ¶
func TableOnPoolStateChange(t *Table, limit int, index int, idle int, wait int, createInProgress int, size int)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnPoolWait ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnPoolWith ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnSessionBulkUpsert ¶
func TableOnSessionBulkUpsert(t *Table, c *context.Context, call call, session sessionInfo) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnSessionDelete ¶
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 sessionInfo) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnSessionNew ¶
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 sessionInfo, query tableDataQuery, parameters tableQueryParameters, keepInCache bool) func(tx txInfo, prepared bool, result tableResult, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnSessionQueryExplain ¶
func TableOnSessionQueryExplain(t *Table, c *context.Context, call call, session sessionInfo, 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 sessionInfo, 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 sessionInfo, 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 sessionInfo) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnTxBegin ¶
func TableOnTxBegin(t *Table, c *context.Context, call call, session sessionInfo) func(tx txInfo, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnTxCommit ¶
func TableOnTxCommit(t *Table, c *context.Context, call call, session sessionInfo, tx txInfo) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnTxExecute ¶
func TableOnTxExecute(t *Table, c *context.Context, call call, session sessionInfo, tx txInfo, query tableDataQuery, parameters tableQueryParameters) func(result tableResult, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnTxExecuteStatement ¶
func TableOnTxExecuteStatement(t *Table, c *context.Context, call call, session sessionInfo, tx txInfo, statementQuery tableDataQuery, parameters tableQueryParameters) func(result tableResult, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TableOnTxRollback ¶
func TableOnTxRollback(t *Table, c *context.Context, call call, session sessionInfo, tx txInfo) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnReaderClose ¶
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 ¶
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 ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnReaderInit ¶
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 ¶
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 ¶
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 TopicOnReaderPopBatchTx ¶
func TopicOnReaderPopBatchTx(t *Topic, c *context.Context, readerID int64, transactionSessionID string, tx txInfo) func(startOffset int64, endOffset int64, messagesCount int, _ error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnReaderReadMessages ¶
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 ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnReaderReconnectRequest ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnReaderSendCommitMessage ¶
func TopicOnReaderSendCommitMessage(t *Topic, commitsInfo TopicReaderStreamSendCommitMessageStartMessageInfo) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnReaderSentDataRequest ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnReaderStreamPopBatchTx ¶
func TopicOnReaderStreamPopBatchTx(t *Topic, c *context.Context, readerID int64, readerConnectionID string, transactionSessionID string, tx txInfo) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnReaderTransactionCompleted ¶
func TopicOnReaderTransactionCompleted(t *Topic, c *context.Context, readerID int64, readerConnectionID string, transactionSessionID string, tx txInfo, transactionResult error) func()
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnReaderTransactionRollback ¶
func TopicOnReaderTransactionRollback(t *Topic, c *context.Context, readerID int64, readerConnectionID string, transactionSessionID string, tx txInfo) func(rollbackError error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnReaderUnknownGrpcMessage ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnReaderUpdateOffsetsInTransaction ¶
func TopicOnReaderUpdateOffsetsInTransaction(t *Topic, c *context.Context, readerID int64, readerConnectionID string, transactionSessionID string, tx txInfo) func(error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnReaderUpdateToken ¶
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 TopicOnWriterAfterFinishTransaction ¶
func TopicOnWriterAfterFinishTransaction(t *Topic, e error, sessionID string, transactionID string) func(closeError error)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnWriterBeforeCommitTransaction ¶
func TopicOnWriterBeforeCommitTransaction(t *Topic, ctx *context.Context, kqpSessionID string, topicSessionID string, transactionID string) func(_ error, topicSessionID string)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnWriterClose ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnWriterCompressMessages ¶
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 ¶
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 ¶
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 TopicOnWriterReceiveResult ¶
func TopicOnWriterReceiveResult(t *Topic, writerInstanceID string, sessionID string, partitionID int64, acks TopicWriterResultMessagesInfoAcks)
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func TopicOnWriterReconnect ¶
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 ¶
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 ¶
func WithDefaultDetails(defaultDetails Details) matchDetailsOption
func WithPOSIXMatch ¶
func WithPOSIXMatch() matchDetailsOption
Types ¶
type ConnState ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type Coordination ¶
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 ¶
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 ¶
type CoordinationAlterNodeDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationAlterNodeStartInfo ¶
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 ¶
type CoordinationCloseDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationCloseStartInfo ¶
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 ¶
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 ¶
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 ¶
type CoordinationCreateNodeDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationCreateNodeStartInfo ¶
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 ¶
type CoordinationDescribeNodeDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationDescribeNodeStartInfo ¶
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 ¶
type CoordinationDropNodeDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationDropNodeStartInfo ¶
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 ¶
type CoordinationNewDoneInfo struct{}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationNewStartInfo ¶
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 ¶
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 ¶
type CoordinationSessionDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionKeepAliveTimeoutInfo ¶
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 ¶
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 ¶
type CoordinationSessionReceiveStartInfo struct{}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionReceiveUnexpectedInfo ¶
type CoordinationSessionReceiveUnexpectedInfo struct {
Response *Ydb_Coordination.SessionResponse
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionSendDoneInfo ¶
type CoordinationSessionSendDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionSendStartInfo ¶
type CoordinationSessionSendStartInfo struct {
Request *Ydb_Coordination.SessionRequest
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionServerErrorInfo ¶
type CoordinationSessionServerErrorInfo struct {
Failure *Ydb_Coordination.SessionResponse_Failure
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionServerExpireInfo ¶
type CoordinationSessionServerExpireInfo struct {
Failure *Ydb_Coordination.SessionResponse_Failure
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionStartDoneInfo ¶
type CoordinationSessionStartDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionStartInfo ¶
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 ¶
type CoordinationSessionStartStartInfo struct{}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionStartTimeoutInfo ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionStartedInfo ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionStopInfo ¶
type CoordinationSessionStopInfo struct {
SessionID uint64
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionStopTimeoutInfo ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationSessionStoppedInfo ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationStreamNewDoneInfo ¶
type CoordinationStreamNewDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type CoordinationStreamNewStartInfo ¶
type CoordinationStreamNewStartInfo struct{}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQL ¶
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 ¶
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 ¶
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 ¶
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 ¶
type DatabaseSQLConnBeginDoneInfo struct { Tx txInfo Error error }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLConnBeginStartInfo ¶
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 ¶
type DatabaseSQLConnCloseDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLConnCloseStartInfo ¶
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 ¶
type DatabaseSQLConnExecDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLConnExecStartInfo ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLConnIsTableExistsStartInfo ¶
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 ¶
type DatabaseSQLConnPingDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLConnPingStartInfo ¶
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 ¶
type DatabaseSQLConnPrepareDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLConnPrepareStartInfo ¶
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 ¶
type DatabaseSQLConnQueryDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLConnQueryStartInfo ¶
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 ¶
type DatabaseSQLConnectorConnectDoneInfo struct { Error error Session sessionInfo }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLConnectorConnectStartInfo ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLDoTxIntermediateInfo ¶
type DatabaseSQLDoTxIntermediateInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLDoTxStartInfo ¶
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 ¶
type DatabaseSQLStmtCloseDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLStmtCloseStartInfo ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLStmtExecDoneInfo ¶
type DatabaseSQLStmtExecDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLStmtExecStartInfo ¶
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 ¶
type DatabaseSQLStmtQueryDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLStmtQueryStartInfo ¶
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 ¶
type DatabaseSQLTxCommitDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLTxCommitStartInfo ¶
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 txInfo }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLTxExecDoneInfo ¶
type DatabaseSQLTxExecDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLTxExecStartInfo ¶
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 txInfo Query string }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLTxPrepareDoneInfo ¶
type DatabaseSQLTxPrepareDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLTxPrepareStartInfo ¶
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 txInfo Query string }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLTxQueryDoneInfo ¶
type DatabaseSQLTxQueryDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLTxQueryStartInfo ¶
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 txInfo Query string }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLTxRollbackDoneInfo ¶
type DatabaseSQLTxRollbackDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DatabaseSQLTxRollbackStartInfo ¶
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 txInfo }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type Details ¶
type Details uint64
const ( DriverNetEvents Details = 1 << iota // for bitmask: 1, 2, 4, 8, 16, 32, ... DriverConnEvents DriverConnStreamEvents DriverBalancerEvents DriverResolverEvents DriverRepeaterEvents DriverCredentialsEvents TableSessionLifeCycleEvents TableSessionQueryInvokeEvents TableSessionQueryStreamEvents TableSessionTransactionEvents TablePoolLifeCycleEvents TablePoolSessionLifeCycleEvents TablePoolAPIEvents QuerySessionEvents QueryResultEvents QueryTransactionEvents QueryPoolEvents TopicControlPlaneEvents TopicReaderCustomerEvents TopicReaderStreamLifeCycleEvents TopicReaderStreamEvents TopicReaderTransactionEvents TopicReaderMessageEvents TopicReaderPartitionEvents TopicWriterStreamLifeCycleEvents TopicWriterStreamEvents DatabaseSQLConnectorEvents DatabaseSQLConnEvents DatabaseSQLTxEvents DatabaseSQLStmtEvents RetryEvents DiscoveryEvents SchemeEvents ScriptingEvents RatelimiterEvents CoordinationEvents DriverEvents = DriverConnEvents | DriverConnStreamEvents | 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 ¶
type Discovery ¶
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 ¶
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 ¶
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 ¶
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 ¶
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 ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DiscoveryWhoAmIStartInfo ¶
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 OnConnStreamFinish func(info DriverConnStreamFinishInfo) // 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 ¶
type DriverBalancerChooseEndpointDoneInfo struct { Endpoint EndpointInfo Error error }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverBalancerChooseEndpointStartInfo ¶
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 ¶
type DriverBalancerCloseDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverBalancerCloseStartInfo ¶
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 ¶
type DriverBalancerClusterDiscoveryAttemptDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverBalancerClusterDiscoveryAttemptStartInfo ¶
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 ¶
type DriverBalancerDialEntrypointDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverBalancerDialEntrypointStartInfo ¶
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 ¶
type DriverBalancerInitDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverBalancerInitStartInfo ¶
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 ¶
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 ¶
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 ¶
type DriverCloseDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverCloseStartInfo ¶
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 ¶
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 ¶
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 ¶
type DriverConnAllowDoneInfo struct {
State ConnState
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnAllowStartInfo ¶
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 ¶
type DriverConnBanDoneInfo struct {
State ConnState
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnBanStartInfo ¶
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 ¶
type DriverConnCloseDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnCloseStartInfo ¶
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 ¶
type DriverConnDialDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnDialStartInfo ¶
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 ¶
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 ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnNewStreamStartInfo ¶
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 ¶
type DriverConnParkDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnParkStartInfo ¶
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 ¶
type DriverConnPoolNewDoneInfo struct{}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnPoolNewStartInfo ¶
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 ¶
type DriverConnPoolReleaseDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnPoolReleaseStartInfo ¶
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 ¶
type DriverConnStateChangeDoneInfo struct {
State ConnState
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnStateChangeStartInfo ¶
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 ¶
type DriverConnStreamCloseSendDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnStreamCloseSendStartInfo ¶
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 DriverConnStreamFinishInfo ¶
type DriverConnStreamFinishInfo 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 //nolint:containedctx Call call Error error }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnStreamRecvMsgDoneInfo ¶
type DriverConnStreamRecvMsgDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnStreamRecvMsgStartInfo ¶
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 ¶
type DriverConnStreamSendMsgDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnStreamSendMsgStartInfo ¶
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 ¶
type DriverConnTakeDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverConnTakeStartInfo ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverGetCredentialsStartInfo ¶
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 ¶
type DriverInitDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverInitStartInfo ¶
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 ¶
type DriverNetCloseDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverNetCloseStartInfo ¶
type DriverNetCloseStartInfo struct { Call call Address string }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverNetDialDoneInfo ¶
type DriverNetDialDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverNetDialStartInfo ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverNetReadStartInfo ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverNetWriteDoneInfo ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverNetWriteStartInfo ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverRepeaterWakeUpDoneInfo ¶
type DriverRepeaterWakeUpDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverRepeaterWakeUpStartInfo ¶
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 ¶
type DriverResolveDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverResolveStartInfo ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverWithDoneInfo ¶
type DriverWithDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type DriverWithStartInfo ¶
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 ¶
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 ¶
type OnReadStreamUpdateTokenDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type OnReadUnknownGrpcMessageInfo ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type OnReadUpdateTokenMiddleTokenReceivedInfo ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type OnReadUpdateTokenStartInfo ¶
type OnReadUpdateTokenStartInfo struct {
ReaderConnectionID string
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type Query ¶
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 OnExec func(QueryExecStartInfo) func(QueryExecDoneInfo) // Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals OnQuery func(QueryQueryStartInfo) func(QueryQueryDoneInfo) // Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals OnQueryResultSet func(QueryQueryResultSetStartInfo) func(QueryQueryResultSetDoneInfo) // Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals OnQueryRow func(QueryQueryRowStartInfo) func(QueryQueryRowDoneInfo) // 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 OnSessionExec func(QuerySessionExecStartInfo) func(info QuerySessionExecDoneInfo) // Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals OnSessionQuery func(QuerySessionQueryStartInfo) func(info QuerySessionQueryDoneInfo) // Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals OnSessionQueryResultSet func(QuerySessionQueryResultSetStartInfo) func(QuerySessionQueryResultSetDoneInfo) // Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals OnSessionQueryRow func(QuerySessionQueryRowStartInfo) func(QuerySessionQueryRowDoneInfo) // Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals OnSessionBegin func(QuerySessionBeginStartInfo) func(info QuerySessionBeginDoneInfo) // Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals OnTxExec func(QueryTxExecStartInfo) func(info QueryTxExecDoneInfo) // Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals OnTxQuery func(QueryTxQueryStartInfo) func(info QueryTxQueryDoneInfo) // Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals OnTxQueryResultSet func(QueryTxQueryResultSetStartInfo) func(QueryTxQueryResultSetDoneInfo) // Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals OnTxQueryRow func(QueryTxQueryRowStartInfo) func(QueryTxQueryRowDoneInfo) // Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals OnResultNew func(QueryResultNewStartInfo) func(info QueryResultNewDoneInfo) // Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals OnResultNextPart func(QueryResultNextPartStartInfo) func(info QueryResultNextPartDoneInfo) // Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals OnResultNextResultSet func(QueryResultNextResultSetStartInfo) func(info QueryResultNextResultSetDoneInfo) // Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals OnResultClose func(QueryResultCloseStartInfo) func(info QueryResultCloseDoneInfo) }
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 ¶
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 ¶
type QueryCloseDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryCloseStartInfo ¶
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 ¶
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 ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryDoStartInfo ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryDoTxStartInfo ¶
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 QueryExecDoneInfo ¶
type QueryExecDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryExecStartInfo ¶
type QueryExecStartInfo 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 QueryNewDoneInfo ¶
type QueryNewDoneInfo struct{}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryNewStartInfo ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryPoolCloseDoneInfo ¶
type QueryPoolCloseDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryPoolCloseStartInfo ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryPoolGetStartInfo ¶
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 ¶
type QueryPoolNewDoneInfo struct {
Limit int
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryPoolNewStartInfo ¶
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 ¶
type QueryPoolPutDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryPoolPutStartInfo ¶
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 Session sessionInfo }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryPoolTryDoneInfo ¶
type QueryPoolTryDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryPoolTryStartInfo ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryPoolWithStartInfo ¶
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 QueryQueryDoneInfo ¶
type QueryQueryDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryQueryResultSetDoneInfo ¶
type QueryQueryResultSetDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryQueryResultSetStartInfo ¶
type QueryQueryResultSetStartInfo 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 QueryQueryRowDoneInfo ¶
type QueryQueryRowDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryQueryRowStartInfo ¶
type QueryQueryRowStartInfo 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 QueryQueryStartInfo ¶
type QueryQueryStartInfo 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 QueryReadResultSetDoneInfo ¶
type QueryReadResultSetDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryReadResultSetStartInfo ¶
type QueryReadResultSetStartInfo 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 QueryReadRowDoneInfo ¶
type QueryReadRowDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryReadRowStartInfo ¶
type QueryReadRowStartInfo 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 QueryResultCloseDoneInfo ¶
type QueryResultCloseDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryResultCloseStartInfo ¶
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 ¶
type QueryResultNewDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryResultNewStartInfo ¶
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 ¶
type QueryResultNextPartDoneInfo struct { Stats *Ydb_TableStats.QueryStats Error error }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryResultNextPartStartInfo ¶
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 ¶
type QueryResultNextResultSetDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryResultNextResultSetStartInfo ¶
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 QuerySessionAttachDoneInfo ¶
type QuerySessionAttachDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QuerySessionAttachStartInfo ¶
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 sessionInfo }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QuerySessionBeginDoneInfo ¶
type QuerySessionBeginDoneInfo struct { Error error Tx txInfo }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QuerySessionBeginStartInfo ¶
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 sessionInfo }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QuerySessionCreateDoneInfo ¶
type QuerySessionCreateDoneInfo struct { Session sessionInfo Error error }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QuerySessionCreateStartInfo ¶
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 ¶
type QuerySessionDeleteDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QuerySessionDeleteStartInfo ¶
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 sessionInfo }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QuerySessionExecDoneInfo ¶
type QuerySessionExecDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QuerySessionExecStartInfo ¶
type QuerySessionExecStartInfo 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 sessionInfo Query string }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QuerySessionQueryDoneInfo ¶
type QuerySessionQueryDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QuerySessionQueryResultSetDoneInfo ¶
type QuerySessionQueryResultSetDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QuerySessionQueryResultSetStartInfo ¶
type QuerySessionQueryResultSetStartInfo 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 sessionInfo Query string }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QuerySessionQueryRowDoneInfo ¶
type QuerySessionQueryRowDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QuerySessionQueryRowStartInfo ¶
type QuerySessionQueryRowStartInfo 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 sessionInfo Query string }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QuerySessionQueryStartInfo ¶
type QuerySessionQueryStartInfo 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 sessionInfo Query string }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryTxExecDoneInfo ¶
type QueryTxExecDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryTxExecStartInfo ¶
type QueryTxExecStartInfo 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 sessionInfo Tx txInfo Query string }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryTxQueryDoneInfo ¶
type QueryTxQueryDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryTxQueryResultSetDoneInfo ¶
type QueryTxQueryResultSetDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryTxQueryResultSetStartInfo ¶
type QueryTxQueryResultSetStartInfo 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 Tx txInfo Query string }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryTxQueryRowDoneInfo ¶
type QueryTxQueryRowDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryTxQueryRowStartInfo ¶
type QueryTxQueryRowStartInfo 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 Tx txInfo Query string }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type QueryTxQueryStartInfo ¶
type QueryTxQueryStartInfo 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 sessionInfo Tx txInfo Query string }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type Ratelimiter ¶
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 ¶
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 ¶
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 ¶
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 ¶
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 ¶
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 ¶
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 ¶
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 ¶
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 ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type SchemeDescribePathStartInfo ¶
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 ¶
type SchemeListDirectoryDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type SchemeListDirectoryStartInfo ¶
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 ¶
type SchemeMakeDirectoryDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type SchemeMakeDirectoryStartInfo ¶
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 ¶
type SchemeModifyPermissionsDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type SchemeModifyPermissionsStartInfo ¶
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 ¶
type SchemeRemoveDirectoryDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type SchemeRemoveDirectoryStartInfo ¶
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 ¶
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 ¶
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 ¶
type ScriptingCloseDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type ScriptingCloseStartInfo ¶
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 ¶
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 ¶
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 ¶
type ScriptingExecuteDoneInfo struct { Result scriptingResult Error error }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type ScriptingExecuteStartInfo ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type ScriptingExplainStartInfo ¶
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 ¶
type ScriptingStreamExecuteDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type ScriptingStreamExecuteIntermediateInfo ¶
type ScriptingStreamExecuteIntermediateInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type ScriptingStreamExecuteStartInfo ¶
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 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 OnPoolWith func(TablePoolWithStartInfo) func(TablePoolWithDoneInfo) // Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals OnPoolStateChange func(TablePoolStateChangeInfo) // Deprecated // Will be removed after March 2025. // Read about versioning policy: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#deprecated OnPoolSessionAdd func(info TablePoolSessionAddInfo) // Deprecated // Will be removed after March 2025. // Read about versioning policy: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#deprecated OnPoolSessionRemove func(info TablePoolSessionRemoveInfo) // Deprecated // Will be removed after March 2025. // Read about versioning policy: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#deprecated 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 ¶
type TableBulkUpsertDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableBulkUpsertStartInfo ¶
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 sessionInfo }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableCloseDoneInfo ¶
type TableCloseDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableCloseStartInfo ¶
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 ¶
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 ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableCreateSessionStartInfo ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableDoStartInfo ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableDoTxStartInfo ¶
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 ¶
type TableExecuteDataQueryDoneInfo struct { Tx txInfo Prepared bool Result tableResult Error error }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableExecuteDataQueryStartInfo ¶
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 sessionInfo Query tableDataQuery Parameters tableQueryParameters KeepInCache bool }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableExplainQueryDoneInfo ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableExplainQueryStartInfo ¶
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 sessionInfo Query string }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableInitDoneInfo ¶
type TableInitDoneInfo struct {
Limit int
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableInitStartInfo ¶
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 ¶
type TableKeepAliveDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableKeepAliveStartInfo ¶
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 sessionInfo }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TablePoolGetDoneInfo ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TablePoolGetStartInfo ¶
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 ¶
type TablePoolPutDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TablePoolPutStartInfo ¶
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 sessionInfo }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TablePoolSessionAddInfo ¶
type TablePoolSessionAddInfo struct {
Session sessionInfo
}
Deprecated Will be removed after March 2025. Read about versioning policy: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#deprecated
type TablePoolSessionCloseDoneInfo ¶
type TablePoolSessionCloseDoneInfo struct{}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TablePoolSessionCloseStartInfo ¶
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 sessionInfo }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TablePoolSessionNewDoneInfo ¶
type TablePoolSessionNewDoneInfo struct { Session sessionInfo Error error }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TablePoolSessionNewStartInfo ¶
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 ¶
type TablePoolSessionRemoveInfo struct {
Session sessionInfo
}
Deprecated Will be removed after March 2025. Read about versioning policy: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#deprecated
type TablePoolStateChangeInfo ¶
type TablePoolStateChangeInfo struct { Limit int Index int Idle int Wait int CreateInProgress int // Deprecated: use Index field instead. // Will be removed after March 2025. // Read about versioning policy: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#deprecated Size int }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TablePoolWaitDoneInfo ¶
type TablePoolWaitDoneInfo struct { Session sessionInfo Error error }
Deprecated Will be removed after March 2025. Read about versioning policy: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#deprecated
type TablePoolWaitStartInfo ¶
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 }
Deprecated Will be removed after March 2025. Read about versioning policy: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#deprecated
type TablePoolWithDoneInfo ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TablePoolWithStartInfo ¶
type TablePoolWithStartInfo 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 ¶
type TablePrepareDataQueryDoneInfo struct { Result tableDataQuery Error error }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TablePrepareDataQueryStartInfo ¶
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 sessionInfo Query string }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableSessionDeleteDoneInfo ¶
type TableSessionDeleteDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableSessionDeleteStartInfo ¶
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 sessionInfo }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableSessionNewDoneInfo ¶
type TableSessionNewDoneInfo struct { Session sessionInfo Error error }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableSessionNewStartInfo ¶
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 ¶
type TableSessionQueryStreamExecuteDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableSessionQueryStreamExecuteStartInfo ¶
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 sessionInfo Query tableDataQuery Parameters tableQueryParameters }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableSessionQueryStreamReadDoneInfo ¶
type TableSessionQueryStreamReadDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableSessionQueryStreamReadStartInfo ¶
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 sessionInfo }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableTransactionExecuteDoneInfo ¶
type TableTransactionExecuteDoneInfo struct { Result tableResult Error error }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableTransactionExecuteStartInfo ¶
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 sessionInfo Tx txInfo Query tableDataQuery Parameters tableQueryParameters }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableTransactionExecuteStatementDoneInfo ¶
type TableTransactionExecuteStatementDoneInfo struct { Result tableResult Error error }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableTransactionExecuteStatementStartInfo ¶
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 sessionInfo Tx txInfo StatementQuery tableDataQuery Parameters tableQueryParameters }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableTxBeginDoneInfo ¶
type TableTxBeginDoneInfo struct { Tx txInfo Error error }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableTxBeginStartInfo ¶
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 sessionInfo }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableTxCommitDoneInfo ¶
type TableTxCommitDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableTxCommitStartInfo ¶
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 sessionInfo Tx txInfo }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableTxRollbackDoneInfo ¶
type TableTxRollbackDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TableTxRollbackStartInfo ¶
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 sessionInfo Tx txInfo }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type Topic ¶
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 OnReaderPopBatchTx func(TopicReaderPopBatchTxStartInfo) func(TopicReaderPopBatchTxDoneInfo) // Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals OnReaderStreamPopBatchTx func( TopicReaderStreamPopBatchTxStartInfo, ) func( TopicReaderStreamPopBatchTxDoneInfo, ) // Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals OnReaderUpdateOffsetsInTransaction func( TopicReaderOnUpdateOffsetsInTransactionStartInfo, ) func( TopicReaderOnUpdateOffsetsInTransactionDoneInfo, ) // Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals OnReaderTransactionCompleted func( TopicReaderTransactionCompletedStartInfo, ) func( TopicReaderTransactionCompletedDoneInfo, ) // Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals OnReaderTransactionRollback func( TopicReaderTransactionRollbackStartInfo, ) func( TopicReaderTransactionRollbackDoneInfo, ) // 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 OnWriterBeforeCommitTransaction func( TopicOnWriterBeforeCommitTransactionStartInfo, ) func(TopicOnWriterBeforeCommitTransactionDoneInfo) // Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals OnWriterAfterFinishTransaction func( TopicOnWriterAfterFinishTransactionStartInfo, ) func(TopicOnWriterAfterFinishTransactionDoneInfo) // 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 OnWriterReceiveResult func(TopicWriterResultMessagesInfo) // 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 ¶
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 ¶
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 ¶
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 TopicOnWriterAfterFinishTransactionDoneInfo ¶
type TopicOnWriterAfterFinishTransactionDoneInfo struct {
CloseError error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicOnWriterAfterFinishTransactionStartInfo ¶
type TopicOnWriterAfterFinishTransactionStartInfo struct { Error error SessionID string TransactionID string }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicOnWriterBeforeCommitTransactionDoneInfo ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicOnWriterBeforeCommitTransactionStartInfo ¶
type TopicOnWriterBeforeCommitTransactionStartInfo struct { Ctx *context.Context KqpSessionID string TopicSessionID string TransactionID string }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicOnWriterReadUnknownGrpcMessageInfo ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderCloseDoneInfo ¶
type TopicReaderCloseDoneInfo struct {
CloseError error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderCloseStartInfo ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderCommitDoneInfo ¶
type TopicReaderCommitDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderCommitStartInfo ¶
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 ¶
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 ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderInitDoneInfo ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderInitStartInfo ¶
type TopicReaderInitStartInfo struct { PreInitReaderConnectionID string InitRequestInfo TopicReadStreamInitRequestInfo }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderOnUpdateOffsetsInTransactionDoneInfo ¶
type TopicReaderOnUpdateOffsetsInTransactionDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderOnUpdateOffsetsInTransactionStartInfo ¶
type TopicReaderOnUpdateOffsetsInTransactionStartInfo struct { Context *context.Context ReaderID int64 ReaderConnectionID string TransactionSessionID string Tx txInfo }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderPartitionReadStartResponseDoneInfo ¶
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 ¶
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 ¶
type TopicReaderPartitionReadStopResponseDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderPartitionReadStopResponseStartInfo ¶
type TopicReaderPartitionReadStopResponseStartInfo struct { ReaderConnectionID string PartitionContext context.Context //nolint:containedctx 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 TopicReaderPopBatchTxDoneInfo ¶
type TopicReaderPopBatchTxDoneInfo struct { StartOffset int64 EndOffset int64 MessagesCount int Error error }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderPopBatchTxStartInfo ¶
type TopicReaderPopBatchTxStartInfo struct { Context *context.Context ReaderID int64 TransactionSessionID string Tx txInfo }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderReadMessagesDoneInfo ¶
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 ¶
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 ¶
type TopicReaderReceiveDataResponseDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderReceiveDataResponseStartInfo ¶
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 ¶
type TopicReaderReconnectDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderReconnectRequestInfo ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderReconnectStartInfo ¶
type TopicReaderReconnectStartInfo struct {
Reason error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderSendCommitMessageDoneInfo ¶
type TopicReaderSendCommitMessageDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderSendCommitMessageStartInfo ¶
type TopicReaderSendCommitMessageStartInfo struct {
CommitsInfo TopicReaderStreamSendCommitMessageStartMessageInfo
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderSentDataRequestInfo ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderStreamCommitInfo ¶
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 TopicReaderStreamPopBatchTxDoneInfo ¶
type TopicReaderStreamPopBatchTxDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderStreamPopBatchTxStartInfo ¶
type TopicReaderStreamPopBatchTxStartInfo struct { Context *context.Context ReaderID int64 ReaderConnectionID string TransactionSessionID string Tx txInfo }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderStreamSendCommitMessageStartMessageInfo ¶
type TopicReaderStreamSendCommitMessageStartMessageInfo interface {
GetCommitsInfo() []TopicReaderStreamCommitInfo
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderTransactionCompletedDoneInfo ¶
type TopicReaderTransactionCompletedDoneInfo struct{}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderTransactionCompletedStartInfo ¶
type TopicReaderTransactionCompletedStartInfo struct { Context *context.Context ReaderID int64 ReaderConnectionID string TransactionSessionID string Tx txInfo TransactionResult error }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderTransactionRollbackDoneInfo ¶
type TopicReaderTransactionRollbackDoneInfo struct {
RollbackError error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicReaderTransactionRollbackStartInfo ¶
type TopicReaderTransactionRollbackStartInfo struct { Context *context.Context ReaderID int64 ReaderConnectionID string TransactionSessionID string Tx txInfo }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicWriterCloseDoneInfo ¶
type TopicWriterCloseDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicWriterCloseStartInfo ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicWriterCompressMessagesDoneInfo ¶
type TopicWriterCompressMessagesDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicWriterCompressMessagesReason ¶
type TopicWriterCompressMessagesReason string
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
func (TopicWriterCompressMessagesReason) String ¶
func (r TopicWriterCompressMessagesReason) String() string
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicWriterCompressMessagesStartInfo ¶
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 ¶
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicWriterInitStreamStartInfo ¶
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 ¶
type TopicWriterReconnectDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicWriterReconnectStartInfo ¶
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 TopicWriterResultMessagesInfo ¶
type TopicWriterResultMessagesInfo struct { WriterInstanceID string SessionID string PartitionID int64 Acks TopicWriterResultMessagesInfoAcks }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicWriterResultMessagesInfoAcks ¶
type TopicWriterResultMessagesInfoAcks interface { GetAcks() struct { AcksCount int SeqNoMin int64 SeqNoMax int64 WrittenOffsetMin int64 WrittenOffsetMax int64 WrittenCount int WrittenInTxCount int SkipCount int } }
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicWriterSendMessagesDoneInfo ¶
type TopicWriterSendMessagesDoneInfo struct {
Error error
}
Internals: https://github.com/ydb-platform/ydb-go-sdk/blob/master/VERSIONING.md#internals
type TopicWriterSendMessagesStartInfo ¶
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
¶
- 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
- session_info.go
- sql.go
- sql_gtrace.go
- table.go
- table_gtrace.go
- topic.go
- topic_gtrace.go
- tx_info.go