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