package trace
import "github.com/ydb-platform/ydb-go-sdk/v3/trace"
Index ¶
- Constants
- func ClearContext(x interface{}) interface{}
- func CoordinationOnAlterNode(t *Coordination, c *context.Context, call call, path string) func(error)
- func CoordinationOnClose(t *Coordination, c *context.Context, call call) func(error)
- func CoordinationOnCreateNode(t *Coordination, c *context.Context, call call, path string) func(error)
- func CoordinationOnDescribeNode(t *Coordination, c *context.Context, call call, path string) func(error)
- func CoordinationOnDropNode(t *Coordination, c *context.Context, call call, path string) func(error)
- func CoordinationOnNew(t *Coordination, c *context.Context, call call) func()
- func CoordinationOnSession(t *Coordination, c *context.Context, call call, path string) func(error)
- func CoordinationOnSessionClientTimeout(t *Coordination, lastGoodResponseTime time.Time, timeout time.Duration)
- func CoordinationOnSessionKeepAliveTimeout(t *Coordination, lastGoodResponseTime time.Time, timeout time.Duration)
- func CoordinationOnSessionReceive(t *Coordination) func(response *Ydb_Coordination.SessionResponse, _ error)
- func CoordinationOnSessionReceiveUnexpected(t *Coordination, response *Ydb_Coordination.SessionResponse)
- func CoordinationOnSessionSend(t *Coordination, request *Ydb_Coordination.SessionRequest) func(error)
- func CoordinationOnSessionServerError(t *Coordination, failure *Ydb_Coordination.SessionResponse_Failure)
- func CoordinationOnSessionServerExpire(t *Coordination, failure *Ydb_Coordination.SessionResponse_Failure)
- func CoordinationOnSessionStart(t *Coordination) func(error)
- func CoordinationOnSessionStartTimeout(t *Coordination, timeout time.Duration)
- func CoordinationOnSessionStarted(t *Coordination, sessionID uint64, expectedSessionID uint64)
- func CoordinationOnSessionStop(t *Coordination, sessionID uint64)
- func CoordinationOnSessionStopTimeout(t *Coordination, timeout time.Duration)
- func CoordinationOnSessionStopped(t *Coordination, sessionID uint64, expectedSessionID uint64)
- func CoordinationOnStreamNew(t *Coordination) func(error)
- func DatabaseSQLOnConnBegin(t *DatabaseSQL, c *context.Context, call call) func(tx tableTransactionInfo, _ error)
- func DatabaseSQLOnConnClose(t *DatabaseSQL, c *context.Context, call call) func(error)
- func DatabaseSQLOnConnExec(t *DatabaseSQL, c *context.Context, call call, query string, mode string, idempotent bool, idleTime time.Duration) 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, idempotent bool, idleTime time.Duration) 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, query string) func(error)
- func DatabaseSQLOnStmtQuery(t *DatabaseSQL, c *context.Context, call call, stmtContext context.Context, query string) 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, tx tableTransactionInfo, query string) func(error)
- func DatabaseSQLOnTxPrepare(t *DatabaseSQL, c *context.Context, call call, txContext *context.Context, tx tableTransactionInfo, query string) func(error)
- func DatabaseSQLOnTxQuery(t *DatabaseSQL, c *context.Context, call call, txContext context.Context, tx tableTransactionInfo, query string) 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(endpoints []EndpointInfo, added []EndpointInfo, dropped []EndpointInfo, localDC string)
- func DriverOnClose(t *Driver, c *context.Context, call call) func(error)
- func DriverOnConnAllow(t *Driver, c *context.Context, call call, endpoint EndpointInfo, state ConnState) func(state ConnState)
- func DriverOnConnBan(t *Driver, c *context.Context, call call, endpoint EndpointInfo, state ConnState, cause error) 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, metadata map[string][]string)
- 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, state ConnState) 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, secure bool) 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, secure bool) 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, query string) func(error)
- func QueryOnTxExecute(t *Query, c *context.Context, call call, session querySessionInfo, tx queryTransactionInfo, query string) func(error)
- func RetryOnRetry(t *Retry, c *context.Context, call call, label string, idempotent bool, nestedCall 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, parameters scriptingQueryParameters) 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, parameters scriptingQueryParameters) 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, nestedCall bool) func(attempts int, _ error)
- func TableOnDoTx(t *Table, c *context.Context, call call, label string, idempotent bool, nestedCall 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, query tableDataQuery, parameters tableQueryParameters, keepInCache bool) func(tx tableTransactionInfo, prepared bool, result tableResult, _ error)
- func TableOnSessionQueryExplain(t *Table, c *context.Context, call call, session tableSessionInfo, query string) func(aST string, plan string, _ error)
- func TableOnSessionQueryPrepare(t *Table, c *context.Context, call call, session tableSessionInfo, query string) func(result tableDataQuery, _ error)
- func TableOnSessionQueryStreamExecute(t *Table, c *context.Context, call call, session tableSessionInfo, query tableDataQuery, parameters tableQueryParameters) 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, tx tableTransactionInfo) func(error)
- func TableOnTxExecute(t *Table, c *context.Context, call call, session tableSessionInfo, tx tableTransactionInfo, query tableDataQuery, parameters tableQueryParameters) func(result tableResult, _ error)
- func TableOnTxExecuteStatement(t *Table, c *context.Context, call call, session tableSessionInfo, tx tableTransactionInfo, statementQuery tableDataQuery, parameters tableQueryParameters) func(result tableResult, _ error)
- func TableOnTxRollback(t *Table, c *context.Context, call call, session tableSessionInfo, tx tableTransactionInfo) func(error)
- func TopicOnReaderClose(t *Topic, readerConnectionID string, closeReason error) func(closeError error)
- func TopicOnReaderCommit(t *Topic, requestContext context.Context, topic string, partitionID int64, partitionSessionID int64, startOffset int64, endOffset int64) func(error)
- func TopicOnReaderCommittedNotify(t *Topic, readerConnectionID string, topic string, partitionID int64, partitionSessionID int64, committedOffset int64)
- func TopicOnReaderError(t *Topic, readerConnectionID string, e error)
- func TopicOnReaderInit(t *Topic, preInitReaderConnectionID string, initRequestInfo TopicReadStreamInitRequestInfo) func(readerConnectionID string, _ error)
- func TopicOnReaderPartitionReadStartResponse(t *Topic, readerConnectionID string, partitionContext context.Context, topic string, partitionID int64, partitionSessionID int64) func(readOffset *int64, commitOffset *int64, _ error)
- func TopicOnReaderPartitionReadStopResponse(t *Topic, readerConnectionID string, partitionContext context.Context, topic string, partitionID int64, partitionSessionID int64, committedOffset int64, graceful bool) func(error)
- func TopicOnReaderReadMessages(t *Topic, requestContext context.Context, minCount int, maxCount int, freeBufferCapacity int) func(messagesCount int, topic string, partitionID int64, partitionSessionID int64, offsetStart int64, offsetEnd int64, freeBufferCapacity int, _ error)
- func TopicOnReaderReceiveDataResponse(t *Topic, readerConnectionID string, localBufferSizeAfterReceive int, dataResponse TopicReaderDataResponseInfo) 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, localBufferSizeAfterSent 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, firstSeqNo int64, messagesCount int, reason TopicWriterCompressMessagesReason) 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, attempt int) func(error)
- func TopicOnWriterSendMessages(t *Topic, writerInstanceID string, sessionID string, codec int32, firstSeqNo int64, messagesCount int) func(error)
- func WithDefaultDetails(defaultDetails Details) matchDetailsOption
- func WithPOSIXMatch() matchDetailsOption
- type ConnState
- type Coordination
- type CoordinationAlterNodeDoneInfo
- type CoordinationAlterNodeStartInfo
- type CoordinationCloseDoneInfo
- type CoordinationCloseStartInfo
- type CoordinationComposeOption
- type CoordinationCreateNodeDoneInfo
- type CoordinationCreateNodeStartInfo
- type CoordinationDescribeNodeDoneInfo
- type CoordinationDescribeNodeStartInfo
- type CoordinationDropNodeDoneInfo
- type CoordinationDropNodeStartInfo
- type CoordinationNewDoneInfo
- type CoordinationNewStartInfo
- type CoordinationSessionClientTimeoutInfo
- type CoordinationSessionDoneInfo
- type CoordinationSessionKeepAliveTimeoutInfo
- type CoordinationSessionReceiveDoneInfo
- type CoordinationSessionReceiveStartInfo
- type CoordinationSessionReceiveUnexpectedInfo
- type CoordinationSessionSendDoneInfo
- type CoordinationSessionSendStartInfo
- type CoordinationSessionServerErrorInfo
- type CoordinationSessionServerExpireInfo
- type CoordinationSessionStartDoneInfo
- type CoordinationSessionStartInfo
- type CoordinationSessionStartStartInfo
- type CoordinationSessionStartTimeoutInfo
- type CoordinationSessionStartedInfo
- type CoordinationSessionStopInfo
- type CoordinationSessionStopTimeoutInfo
- type CoordinationSessionStoppedInfo
- type CoordinationStreamNewDoneInfo
- type CoordinationStreamNewStartInfo
- type DatabaseSQL
- type DatabaseSQLComposeOption
- type DatabaseSQLConnBeginDoneInfo
- type DatabaseSQLConnBeginStartInfo
- type DatabaseSQLConnCloseDoneInfo
- type DatabaseSQLConnCloseStartInfo
- type DatabaseSQLConnExecDoneInfo
- type DatabaseSQLConnExecStartInfo
- type DatabaseSQLConnIsTableExistsDoneInfo
- type DatabaseSQLConnIsTableExistsStartInfo
- type DatabaseSQLConnPingDoneInfo
- type DatabaseSQLConnPingStartInfo
- type DatabaseSQLConnPrepareDoneInfo
- type DatabaseSQLConnPrepareStartInfo
- type DatabaseSQLConnQueryDoneInfo
- type DatabaseSQLConnQueryStartInfo
- type DatabaseSQLConnectorConnectDoneInfo
- type DatabaseSQLConnectorConnectStartInfo
- type DatabaseSQLDoTxDoneInfo
- type DatabaseSQLDoTxIntermediateInfo
- type DatabaseSQLDoTxStartInfo
- type DatabaseSQLStmtCloseDoneInfo
- type DatabaseSQLStmtCloseStartInfo
- type DatabaseSQLStmtExecDoneInfo
- type DatabaseSQLStmtExecStartInfo
- type DatabaseSQLStmtQueryDoneInfo
- type DatabaseSQLStmtQueryStartInfo
- type DatabaseSQLTxCommitDoneInfo
- type DatabaseSQLTxCommitStartInfo
- type DatabaseSQLTxExecDoneInfo
- type DatabaseSQLTxExecStartInfo
- type DatabaseSQLTxPrepareDoneInfo
- type DatabaseSQLTxPrepareStartInfo
- type DatabaseSQLTxQueryDoneInfo
- type DatabaseSQLTxQueryStartInfo
- type DatabaseSQLTxRollbackDoneInfo
- type DatabaseSQLTxRollbackStartInfo
- type Detailer
- type Details
- func MatchDetails(pattern string, opts ...matchDetailsOption) (d Details)
- func (d Details) Details() Details
- func (d Details) String() string
- 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
- func (m Method) Name() (s string)
- func (m Method) Service() (s string)
- func (m Method) Split() (service, method string)
- 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 )
Functions ¶
func ClearContext ¶
func ClearContext(x interface{}) interface{}
func CoordinationOnAlterNode ¶
func CoordinationOnAlterNode(t *Coordination, c *context.Context, call call, path string) func(error)
func CoordinationOnClose ¶
func CoordinationOnClose(t *Coordination, c *context.Context, call call) func(error)
func CoordinationOnCreateNode ¶
func CoordinationOnCreateNode(t *Coordination, c *context.Context, call call, path string) func(error)
func CoordinationOnDescribeNode ¶
func CoordinationOnDescribeNode(t *Coordination, c *context.Context, call call, path string) func(error)
func CoordinationOnDropNode ¶
func CoordinationOnDropNode(t *Coordination, c *context.Context, call call, path string) func(error)
func CoordinationOnNew ¶
func CoordinationOnNew(t *Coordination, c *context.Context, call call) func()
func CoordinationOnSession ¶
func CoordinationOnSession(t *Coordination, c *context.Context, call call, path string) func(error)
func CoordinationOnSessionClientTimeout ¶
func CoordinationOnSessionClientTimeout(t *Coordination, lastGoodResponseTime time.Time, timeout time.Duration)
func CoordinationOnSessionKeepAliveTimeout ¶
func CoordinationOnSessionKeepAliveTimeout(t *Coordination, lastGoodResponseTime time.Time, timeout time.Duration)
func CoordinationOnSessionReceive ¶
func CoordinationOnSessionReceive(t *Coordination) func(response *Ydb_Coordination.SessionResponse, _ error)
func CoordinationOnSessionReceiveUnexpected ¶
func CoordinationOnSessionReceiveUnexpected(t *Coordination, response *Ydb_Coordination.SessionResponse)
func CoordinationOnSessionSend ¶
func CoordinationOnSessionSend(t *Coordination, request *Ydb_Coordination.SessionRequest) func(error)
func CoordinationOnSessionServerError ¶
func CoordinationOnSessionServerError(t *Coordination, failure *Ydb_Coordination.SessionResponse_Failure)
func CoordinationOnSessionServerExpire ¶
func CoordinationOnSessionServerExpire(t *Coordination, failure *Ydb_Coordination.SessionResponse_Failure)
func CoordinationOnSessionStart ¶
func CoordinationOnSessionStart(t *Coordination) func(error)
func CoordinationOnSessionStartTimeout ¶
func CoordinationOnSessionStartTimeout(t *Coordination, timeout time.Duration)
func CoordinationOnSessionStarted ¶
func CoordinationOnSessionStarted(t *Coordination, sessionID uint64, expectedSessionID uint64)
func CoordinationOnSessionStop ¶
func CoordinationOnSessionStop(t *Coordination, sessionID uint64)
func CoordinationOnSessionStopTimeout ¶
func CoordinationOnSessionStopTimeout(t *Coordination, timeout time.Duration)
func CoordinationOnSessionStopped ¶
func CoordinationOnSessionStopped(t *Coordination, sessionID uint64, expectedSessionID uint64)
func CoordinationOnStreamNew ¶
func CoordinationOnStreamNew(t *Coordination) func(error)
func DatabaseSQLOnConnBegin ¶
func DatabaseSQLOnConnBegin(t *DatabaseSQL, c *context.Context, call call) func(tx tableTransactionInfo, _ error)
func DatabaseSQLOnConnClose ¶
func DatabaseSQLOnConnClose(t *DatabaseSQL, c *context.Context, call call) func(error)
func DatabaseSQLOnConnExec ¶
func DatabaseSQLOnConnExec(t *DatabaseSQL, c *context.Context, call call, query string, mode string, idempotent bool, idleTime time.Duration) func(error)
func DatabaseSQLOnConnIsTableExists ¶
func DatabaseSQLOnConnIsTableExists(t *DatabaseSQL, c *context.Context, call call, tableName string) func(exists bool, _ error)
func DatabaseSQLOnConnPing ¶
func DatabaseSQLOnConnPing(t *DatabaseSQL, c *context.Context, call call) func(error)
func DatabaseSQLOnConnPrepare ¶
func DatabaseSQLOnConnPrepare(t *DatabaseSQL, c *context.Context, call call, query string) func(error)
func DatabaseSQLOnConnQuery ¶
func DatabaseSQLOnConnQuery(t *DatabaseSQL, c *context.Context, call call, query string, mode string, idempotent bool, idleTime time.Duration) func(error)
func DatabaseSQLOnConnectorConnect ¶
func DatabaseSQLOnConnectorConnect(t *DatabaseSQL, c *context.Context, call call) func(_ error, session tableSessionInfo)
func DatabaseSQLOnDoTx ¶
func DatabaseSQLOnDoTx(t *DatabaseSQL, c *context.Context, call call, iD string, idempotent bool) func(error) func(attempts int, _ error)
func DatabaseSQLOnStmtClose ¶
func DatabaseSQLOnStmtClose(t *DatabaseSQL, stmtContext *context.Context, call call) func(error)
func DatabaseSQLOnStmtExec ¶
func DatabaseSQLOnStmtExec(t *DatabaseSQL, c *context.Context, call call, stmtContext context.Context, query string) func(error)
func DatabaseSQLOnStmtQuery ¶
func DatabaseSQLOnStmtQuery(t *DatabaseSQL, c *context.Context, call call, stmtContext context.Context, query string) func(error)
func DatabaseSQLOnTxCommit ¶
func DatabaseSQLOnTxCommit(t *DatabaseSQL, c *context.Context, call call, tx tableTransactionInfo) func(error)
func DatabaseSQLOnTxExec ¶
func DatabaseSQLOnTxExec(t *DatabaseSQL, c *context.Context, call call, txContext context.Context, tx tableTransactionInfo, query string) func(error)
func DatabaseSQLOnTxPrepare ¶
func DatabaseSQLOnTxPrepare(t *DatabaseSQL, c *context.Context, call call, txContext *context.Context, tx tableTransactionInfo, query string) func(error)
func DatabaseSQLOnTxQuery ¶
func DatabaseSQLOnTxQuery(t *DatabaseSQL, c *context.Context, call call, txContext context.Context, tx tableTransactionInfo, query string) func(error)
func DatabaseSQLOnTxRollback ¶
func DatabaseSQLOnTxRollback(t *DatabaseSQL, c *context.Context, call call, tx tableTransactionInfo) func(error)
func DiscoveryOnDiscover ¶
func DiscoveryOnDiscover(t *Discovery, c *context.Context, call call, address string, database string) func(location string, endpoints []EndpointInfo, _ error)
func DiscoveryOnWhoAmI ¶
func DiscoveryOnWhoAmI(t *Discovery, c *context.Context, call call) func(user string, groups []string, _ error)
func DriverOnBalancerChooseEndpoint ¶
func DriverOnBalancerChooseEndpoint(t *Driver, c *context.Context, call call) func(endpoint EndpointInfo, _ error)
func DriverOnBalancerClose ¶
func DriverOnBalancerClusterDiscoveryAttempt ¶
func DriverOnBalancerClusterDiscoveryAttempt(t *Driver, c *context.Context, call call, address string) func(error)
func DriverOnBalancerInit ¶
func DriverOnBalancerUpdate ¶
func DriverOnBalancerUpdate(t *Driver, c *context.Context, call call, needLocalDC bool) func(endpoints []EndpointInfo, added []EndpointInfo, dropped []EndpointInfo, localDC string)
func DriverOnClose ¶
func DriverOnConnAllow ¶
func DriverOnConnAllow(t *Driver, c *context.Context, call call, endpoint EndpointInfo, state ConnState) func(state ConnState)
func DriverOnConnBan ¶
func DriverOnConnBan(t *Driver, c *context.Context, call call, endpoint EndpointInfo, state ConnState, cause error) func(state ConnState)
func DriverOnConnClose ¶
func DriverOnConnClose(t *Driver, c *context.Context, call call, endpoint EndpointInfo) func(error)
func DriverOnConnDial ¶
func DriverOnConnDial(t *Driver, c *context.Context, call call, endpoint EndpointInfo) func(error)
func DriverOnConnInvoke ¶
func DriverOnConnInvoke(t *Driver, c *context.Context, call call, endpoint EndpointInfo, m Method) func(_ error, issues []Issue, opID string, state ConnState, metadata map[string][]string)
func DriverOnConnNewStream ¶
func DriverOnConnNewStream(t *Driver, c *context.Context, call call, endpoint EndpointInfo, m Method) func(_ error, state ConnState)
func DriverOnConnPark ¶
func DriverOnConnPark(t *Driver, c *context.Context, call call, endpoint EndpointInfo) func(error)
func DriverOnConnStateChange ¶
func DriverOnConnStateChange(t *Driver, c *context.Context, call call, endpoint EndpointInfo, state ConnState) func(state ConnState)
func DriverOnConnStreamCloseSend ¶
func DriverOnConnStreamRecvMsg ¶
func DriverOnConnStreamSendMsg ¶
func DriverOnGetCredentials ¶
func DriverOnInit ¶
func DriverOnInit(t *Driver, c *context.Context, call call, endpoint string, database string, secure bool) func(error)
func DriverOnPoolNew ¶
func DriverOnPoolRelease ¶
func DriverOnRepeaterWakeUp ¶
func DriverOnRepeaterWakeUp(t *Driver, c *context.Context, call call, name string, event string) func(error)
func DriverOnResolve ¶
func DriverOnWith ¶
func DriverOnWith(t *Driver, c *context.Context, call call, endpoint string, database string, secure bool) func(error)
func QueryOnClose ¶
func QueryOnDo ¶
func QueryOnDoTx ¶
func QueryOnNew ¶
func QueryOnPoolChange ¶
func QueryOnPoolClose ¶
func QueryOnPoolGet ¶
func QueryOnPoolNew ¶
func QueryOnPoolPut ¶
func QueryOnPoolTry ¶
func QueryOnPoolWith ¶
func QueryOnResultClose ¶
func QueryOnResultNew ¶
func QueryOnResultNextPart ¶
func QueryOnResultNextResultSet ¶
func QueryOnResultSetNextRow ¶
func QueryOnRowScan ¶
func QueryOnRowScanNamed ¶
func QueryOnRowScanStruct ¶
func QueryOnSessionAttach ¶
func QueryOnSessionAttach(t *Query, c *context.Context, call call, session querySessionInfo) func(error)
func QueryOnSessionBegin ¶
func QueryOnSessionBegin(t *Query, c *context.Context, call call, session querySessionInfo) func(_ error, tx queryTransactionInfo)
func QueryOnSessionCreate ¶
func QueryOnSessionCreate(t *Query, c *context.Context, call call) func(session querySessionInfo, _ error)
func QueryOnSessionDelete ¶
func QueryOnSessionDelete(t *Query, c *context.Context, call call, session querySessionInfo) func(error)
func QueryOnSessionExecute ¶
func QueryOnSessionExecute(t *Query, c *context.Context, call call, session querySessionInfo, query string) func(error)
func QueryOnTxExecute ¶
func QueryOnTxExecute(t *Query, c *context.Context, call call, session querySessionInfo, tx queryTransactionInfo, query string) func(error)
func RetryOnRetry ¶
func RetryOnRetry(t *Retry, c *context.Context, call call, label string, idempotent bool, nestedCall bool) func(attempts int, _ error)
func SchemeOnDescribePath ¶
func SchemeOnDescribePath(t *Scheme, c *context.Context, call call, path string) func(entryType string, _ error)
func SchemeOnListDirectory ¶
func SchemeOnMakeDirectory ¶
func SchemeOnModifyPermissions ¶
func SchemeOnRemoveDirectory ¶
func ScriptingOnClose ¶
func ScriptingOnExecute ¶
func ScriptingOnExecute(t *Scripting, c *context.Context, call call, query string, parameters scriptingQueryParameters) func(result scriptingResult, _ error)
func ScriptingOnExplain ¶
func ScriptingOnExplain(t *Scripting, c *context.Context, call call, query string) func(plan string, _ error)
func ScriptingOnStreamExecute ¶
func ScriptingOnStreamExecute(t *Scripting, c *context.Context, call call, query string, parameters scriptingQueryParameters) func(error) func(error)
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 ¶
func TableOnCreateSession ¶
func TableOnCreateSession(t *Table, c *context.Context, call call) func(session tableSessionInfo, attempts int, _ error)
func TableOnDo ¶
func TableOnDo(t *Table, c *context.Context, call call, label string, idempotent bool, nestedCall bool) func(attempts int, _ error)
func TableOnDoTx ¶
func TableOnDoTx(t *Table, c *context.Context, call call, label string, idempotent bool, nestedCall bool) func(attempts int, _ error)
func TableOnInit ¶
func TableOnPoolGet ¶
func TableOnPoolGet(t *Table, c *context.Context, call call) func(session tableSessionInfo, attempts int, _ error)
func TableOnPoolPut ¶
func TableOnPoolSessionAdd ¶
func TableOnPoolSessionAdd(t *Table, session tableSessionInfo)
func TableOnPoolSessionRemove ¶
func TableOnPoolSessionRemove(t *Table, session tableSessionInfo)
func TableOnPoolStateChange ¶
func TableOnPoolWait ¶
func TableOnPoolWait(t *Table, c *context.Context, call call) func(session tableSessionInfo, _ error)
func TableOnSessionBulkUpsert ¶
func TableOnSessionBulkUpsert(t *Table, c *context.Context, call call, session tableSessionInfo) func(error)
func TableOnSessionDelete ¶
func TableOnSessionDelete(t *Table, c *context.Context, call call, session tableSessionInfo) func(error)
func TableOnSessionKeepAlive ¶
func TableOnSessionKeepAlive(t *Table, c *context.Context, call call, session tableSessionInfo) func(error)
func TableOnSessionNew ¶
func TableOnSessionNew(t *Table, c *context.Context, call call) func(session tableSessionInfo, _ error)
func TableOnSessionQueryExecute ¶
func TableOnSessionQueryExecute(t *Table, c *context.Context, call call, session tableSessionInfo, query tableDataQuery, parameters tableQueryParameters, keepInCache bool) func(tx tableTransactionInfo, prepared bool, result tableResult, _ error)
func TableOnSessionQueryExplain ¶
func TableOnSessionQueryExplain(t *Table, c *context.Context, call call, session tableSessionInfo, query string) func(aST string, plan string, _ error)
func TableOnSessionQueryPrepare ¶
func TableOnSessionQueryPrepare(t *Table, c *context.Context, call call, session tableSessionInfo, query string) func(result tableDataQuery, _ error)
func TableOnSessionQueryStreamExecute ¶
func TableOnSessionQueryStreamExecute(t *Table, c *context.Context, call call, session tableSessionInfo, query tableDataQuery, parameters tableQueryParameters) func(error)
func TableOnSessionQueryStreamRead ¶
func TableOnSessionQueryStreamRead(t *Table, c *context.Context, call call, session tableSessionInfo) func(error)
func TableOnTxBegin ¶
func TableOnTxBegin(t *Table, c *context.Context, call call, session tableSessionInfo) func(tx tableTransactionInfo, _ error)
func TableOnTxCommit ¶
func TableOnTxCommit(t *Table, c *context.Context, call call, session tableSessionInfo, tx tableTransactionInfo) func(error)
func TableOnTxExecute ¶
func TableOnTxExecute(t *Table, c *context.Context, call call, session tableSessionInfo, tx tableTransactionInfo, query tableDataQuery, parameters tableQueryParameters) func(result tableResult, _ error)
func TableOnTxExecuteStatement ¶
func TableOnTxExecuteStatement(t *Table, c *context.Context, call call, session tableSessionInfo, tx tableTransactionInfo, statementQuery tableDataQuery, parameters tableQueryParameters) func(result tableResult, _ error)
func TableOnTxRollback ¶
func TableOnTxRollback(t *Table, c *context.Context, call call, session tableSessionInfo, tx tableTransactionInfo) func(error)
func TopicOnReaderClose ¶
func TopicOnReaderClose(t *Topic, readerConnectionID string, closeReason error) func(closeError error)
func TopicOnReaderCommit ¶
func TopicOnReaderCommit(t *Topic, requestContext context.Context, topic string, partitionID int64, partitionSessionID int64, startOffset int64, endOffset int64) func(error)
func TopicOnReaderCommittedNotify ¶
func TopicOnReaderCommittedNotify(t *Topic, readerConnectionID string, topic string, partitionID int64, partitionSessionID int64, committedOffset int64)
func TopicOnReaderError ¶
func TopicOnReaderInit ¶
func TopicOnReaderInit(t *Topic, preInitReaderConnectionID string, initRequestInfo TopicReadStreamInitRequestInfo) func(readerConnectionID string, _ error)
func TopicOnReaderPartitionReadStartResponse ¶
func TopicOnReaderPartitionReadStartResponse(t *Topic, readerConnectionID string, partitionContext context.Context, topic string, partitionID int64, partitionSessionID int64) func(readOffset *int64, commitOffset *int64, _ error)
func TopicOnReaderPartitionReadStopResponse ¶
func TopicOnReaderPartitionReadStopResponse(t *Topic, readerConnectionID string, partitionContext context.Context, topic string, partitionID int64, partitionSessionID int64, committedOffset int64, graceful bool) func(error)
func TopicOnReaderReadMessages ¶
func TopicOnReaderReadMessages(t *Topic, requestContext context.Context, minCount int, maxCount int, freeBufferCapacity int) func(messagesCount int, topic string, partitionID int64, partitionSessionID int64, offsetStart int64, offsetEnd int64, freeBufferCapacity int, _ error)
func TopicOnReaderReceiveDataResponse ¶
func TopicOnReaderReceiveDataResponse(t *Topic, readerConnectionID string, localBufferSizeAfterReceive int, dataResponse TopicReaderDataResponseInfo) func(error)
func TopicOnReaderReconnect ¶
func TopicOnReaderReconnectRequest ¶
func TopicOnReaderSendCommitMessage ¶
func TopicOnReaderSendCommitMessage(t *Topic, commitsInfo TopicReaderStreamSendCommitMessageStartMessageInfo) func(error)
func TopicOnReaderSentDataRequest ¶
func TopicOnReaderSentDataRequest(t *Topic, readerConnectionID string, requestBytes int, localBufferSizeAfterSent int)
func TopicOnReaderStart ¶
func TopicOnReaderUnknownGrpcMessage ¶
func TopicOnReaderUpdateToken ¶
func TopicOnReaderUpdateToken(t *Topic, readerConnectionID string) func(tokenLen int, _ error) func(error)
func TopicOnWriterClose ¶
func TopicOnWriterCompressMessages ¶
func TopicOnWriterCompressMessages(t *Topic, writerInstanceID string, sessionID string, codec int32, firstSeqNo int64, messagesCount int, reason TopicWriterCompressMessagesReason) func(error)
func TopicOnWriterInitStream ¶
func TopicOnWriterInitStream(t *Topic, writerInstanceID string, topic string, producerID string) func(sessionID string, _ error)
func TopicOnWriterReadUnknownGrpcMessage ¶
func TopicOnWriterReadUnknownGrpcMessage(t *Topic, writerInstanceID string, sessionID string, e error)
func TopicOnWriterReconnect ¶
func TopicOnWriterReconnect(t *Topic, writerInstanceID string, topic string, producerID string, attempt int) func(error)
func TopicOnWriterSendMessages ¶
func TopicOnWriterSendMessages(t *Topic, writerInstanceID string, sessionID string, codec int32, firstSeqNo int64, messagesCount int) func(error)
func WithDefaultDetails ¶
func WithDefaultDetails(defaultDetails Details) matchDetailsOption
func WithPOSIXMatch ¶
func WithPOSIXMatch() matchDetailsOption
Types ¶
type ConnState ¶
type Coordination ¶
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) OnSession func(CoordinationSessionStartInfo) func(CoordinationSessionDoneInfo) OnClose func(CoordinationCloseStartInfo) func(CoordinationCloseDoneInfo) 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 ¶
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 ¶
type CoordinationAlterNodeDoneInfo struct { Error error }
type CoordinationAlterNodeStartInfo ¶
type CoordinationAlterNodeStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Path string }
type CoordinationCloseDoneInfo ¶
type CoordinationCloseDoneInfo struct { Error error }
type CoordinationCloseStartInfo ¶
type CoordinationCloseStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type CoordinationComposeOption ¶
type CoordinationComposeOption func(o *coordinationComposeOptions)
CoordinationOption specified Coordination compose option
func WithCoordinationPanicCallback ¶
func WithCoordinationPanicCallback(cb func(e interface{})) CoordinationComposeOption
WithCoordinationPanicCallback specified behavior on panic
type CoordinationCreateNodeDoneInfo ¶
type CoordinationCreateNodeDoneInfo struct { Error error }
type CoordinationCreateNodeStartInfo ¶
type CoordinationCreateNodeStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Path string }
type CoordinationDescribeNodeDoneInfo ¶
type CoordinationDescribeNodeDoneInfo struct { Error error }
type CoordinationDescribeNodeStartInfo ¶
type CoordinationDescribeNodeStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Path string }
type CoordinationDropNodeDoneInfo ¶
type CoordinationDropNodeDoneInfo struct { Error error }
type CoordinationDropNodeStartInfo ¶
type CoordinationDropNodeStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Path string }
type CoordinationNewDoneInfo ¶
type CoordinationNewDoneInfo struct{}
type CoordinationNewStartInfo ¶
type CoordinationNewStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type CoordinationSessionClientTimeoutInfo ¶
type CoordinationSessionClientTimeoutInfo struct { LastGoodResponseTime time.Time Timeout time.Duration }
type CoordinationSessionDoneInfo ¶
type CoordinationSessionDoneInfo struct { Error error }
type CoordinationSessionKeepAliveTimeoutInfo ¶
type CoordinationSessionKeepAliveTimeoutInfo struct { LastGoodResponseTime time.Time Timeout time.Duration }
type CoordinationSessionReceiveDoneInfo ¶
type CoordinationSessionReceiveDoneInfo struct { Response *Ydb_Coordination.SessionResponse Error error }
type CoordinationSessionReceiveStartInfo ¶
type CoordinationSessionReceiveStartInfo struct{}
type CoordinationSessionReceiveUnexpectedInfo ¶
type CoordinationSessionReceiveUnexpectedInfo struct { Response *Ydb_Coordination.SessionResponse }
type CoordinationSessionSendDoneInfo ¶
type CoordinationSessionSendDoneInfo struct { Error error }
type CoordinationSessionSendStartInfo ¶
type CoordinationSessionSendStartInfo struct { Request *Ydb_Coordination.SessionRequest }
type CoordinationSessionServerErrorInfo ¶
type CoordinationSessionServerErrorInfo struct { Failure *Ydb_Coordination.SessionResponse_Failure }
type CoordinationSessionServerExpireInfo ¶
type CoordinationSessionServerExpireInfo struct { Failure *Ydb_Coordination.SessionResponse_Failure }
type CoordinationSessionStartDoneInfo ¶
type CoordinationSessionStartDoneInfo struct { Error error }
type CoordinationSessionStartInfo ¶
type CoordinationSessionStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Path string }
type CoordinationSessionStartStartInfo ¶
type CoordinationSessionStartStartInfo struct{}
type CoordinationSessionStartTimeoutInfo ¶
type CoordinationSessionStartedInfo ¶
type CoordinationSessionStopInfo ¶
type CoordinationSessionStopInfo struct { SessionID uint64 }
type CoordinationSessionStopTimeoutInfo ¶
type CoordinationSessionStoppedInfo ¶
type CoordinationStreamNewDoneInfo ¶
type CoordinationStreamNewDoneInfo struct { Error error }
type CoordinationStreamNewStartInfo ¶
type CoordinationStreamNewStartInfo struct{}
type DatabaseSQL ¶
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 ¶
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 ¶
type DatabaseSQLComposeOption func(o *databaseSQLComposeOptions)
DatabaseSQLOption specified DatabaseSQL compose option
func WithDatabaseSQLPanicCallback ¶
func WithDatabaseSQLPanicCallback(cb func(e interface{})) DatabaseSQLComposeOption
WithDatabaseSQLPanicCallback specified behavior on panic
type DatabaseSQLConnBeginDoneInfo ¶
type DatabaseSQLConnBeginDoneInfo struct { Tx tableTransactionInfo Error error }
type DatabaseSQLConnBeginStartInfo ¶
type DatabaseSQLConnBeginStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type DatabaseSQLConnCloseDoneInfo ¶
type DatabaseSQLConnCloseDoneInfo struct { Error error }
type DatabaseSQLConnCloseStartInfo ¶
type DatabaseSQLConnCloseStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type DatabaseSQLConnExecDoneInfo ¶
type DatabaseSQLConnExecDoneInfo struct { Error error }
type DatabaseSQLConnExecStartInfo ¶
type DatabaseSQLConnExecStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Query string Mode string Idempotent bool IdleTime time.Duration }
type DatabaseSQLConnIsTableExistsDoneInfo ¶
type DatabaseSQLConnIsTableExistsStartInfo ¶
type DatabaseSQLConnIsTableExistsStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call TableName string }
type DatabaseSQLConnPingDoneInfo ¶
type DatabaseSQLConnPingDoneInfo struct { Error error }
type DatabaseSQLConnPingStartInfo ¶
type DatabaseSQLConnPingStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type DatabaseSQLConnPrepareDoneInfo ¶
type DatabaseSQLConnPrepareDoneInfo struct { Error error }
type DatabaseSQLConnPrepareStartInfo ¶
type DatabaseSQLConnPrepareStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Query string }
type DatabaseSQLConnQueryDoneInfo ¶
type DatabaseSQLConnQueryDoneInfo struct { Error error }
type DatabaseSQLConnQueryStartInfo ¶
type DatabaseSQLConnQueryStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Query string Mode string Idempotent bool IdleTime time.Duration }
type DatabaseSQLConnectorConnectDoneInfo ¶
type DatabaseSQLConnectorConnectDoneInfo struct { Error error Session tableSessionInfo }
type DatabaseSQLConnectorConnectStartInfo ¶
type DatabaseSQLConnectorConnectStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type DatabaseSQLDoTxDoneInfo ¶
type DatabaseSQLDoTxIntermediateInfo ¶
type DatabaseSQLDoTxIntermediateInfo struct { Error error }
type DatabaseSQLDoTxStartInfo ¶
type DatabaseSQLDoTxStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call ID string Idempotent bool }
type DatabaseSQLStmtCloseDoneInfo ¶
type DatabaseSQLStmtCloseDoneInfo struct { Error error }
type DatabaseSQLStmtCloseStartInfo ¶
type DatabaseSQLStmtExecDoneInfo ¶
type DatabaseSQLStmtExecDoneInfo struct { Error error }
type DatabaseSQLStmtExecStartInfo ¶
type DatabaseSQLStmtExecStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call StmtContext context.Context Query string }
type DatabaseSQLStmtQueryDoneInfo ¶
type DatabaseSQLStmtQueryDoneInfo struct { Error error }
type DatabaseSQLStmtQueryStartInfo ¶
type DatabaseSQLStmtQueryStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call StmtContext context.Context Query string }
type DatabaseSQLTxCommitDoneInfo ¶
type DatabaseSQLTxCommitDoneInfo struct { Error error }
type DatabaseSQLTxCommitStartInfo ¶
type DatabaseSQLTxCommitStartInfo struct { // TxContext make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Tx tableTransactionInfo }
type DatabaseSQLTxExecDoneInfo ¶
type DatabaseSQLTxExecDoneInfo struct { Error error }
type DatabaseSQLTxExecStartInfo ¶
type DatabaseSQLTxExecStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call TxContext context.Context Tx tableTransactionInfo Query string }
type DatabaseSQLTxPrepareDoneInfo ¶
type DatabaseSQLTxPrepareDoneInfo struct { Error error }
type DatabaseSQLTxPrepareStartInfo ¶
type DatabaseSQLTxPrepareStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call TxContext *context.Context Tx tableTransactionInfo Query string }
type DatabaseSQLTxQueryDoneInfo ¶
type DatabaseSQLTxQueryDoneInfo struct { Error error }
type DatabaseSQLTxQueryStartInfo ¶
type DatabaseSQLTxQueryStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call TxContext context.Context Tx tableTransactionInfo Query string }
type DatabaseSQLTxRollbackDoneInfo ¶
type DatabaseSQLTxRollbackDoneInfo struct { Error error }
type DatabaseSQLTxRollbackStartInfo ¶
type DatabaseSQLTxRollbackStartInfo struct { // TxContext make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Tx tableTransactionInfo }
type Detailer ¶
type Detailer interface { Details() Details }
type Details ¶
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 ¶
func (Details) Details ¶
func (Details) String ¶
type Discovery ¶
type Discovery struct { OnDiscover func(DiscoveryDiscoverStartInfo) func(DiscoveryDiscoverDoneInfo) OnWhoAmI func(DiscoveryWhoAmIStartInfo) func(DiscoveryWhoAmIDoneInfo) }
Discovery specified trace of discovery client activity. gtrace:gen
func (*Discovery) Compose ¶
func (t *Discovery) Compose(x *Discovery, opts ...DiscoveryComposeOption) *Discovery
Compose returns a new Discovery which has functional fields composed both from t and x.
type DiscoveryComposeOption ¶
type DiscoveryComposeOption func(o *discoveryComposeOptions)
DiscoveryOption specified Discovery compose option
func WithDiscoveryPanicCallback ¶
func WithDiscoveryPanicCallback(cb func(e interface{})) DiscoveryComposeOption
WithDiscoveryPanicCallback specified behavior on panic
type DiscoveryDiscoverDoneInfo ¶
type DiscoveryDiscoverDoneInfo struct { Location string Endpoints []EndpointInfo Error error }
type DiscoveryDiscoverStartInfo ¶
type DiscoveryDiscoverStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Address string Database string }
type DiscoveryWhoAmIDoneInfo ¶
type DiscoveryWhoAmIStartInfo ¶
type DiscoveryWhoAmIStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
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
func (*Driver) Compose ¶
func (t *Driver) Compose(x *Driver, opts ...DriverComposeOption) *Driver
Compose returns a new Driver which has functional fields composed both from t and x.
type DriverBalancerChooseEndpointDoneInfo ¶
type DriverBalancerChooseEndpointDoneInfo struct { Endpoint EndpointInfo Error error }
type DriverBalancerChooseEndpointStartInfo ¶
type DriverBalancerChooseEndpointStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type DriverBalancerCloseDoneInfo ¶
type DriverBalancerCloseDoneInfo struct { Error error }
type DriverBalancerCloseStartInfo ¶
type DriverBalancerCloseStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type DriverBalancerClusterDiscoveryAttemptDoneInfo ¶
type DriverBalancerClusterDiscoveryAttemptDoneInfo struct { Error error }
type DriverBalancerClusterDiscoveryAttemptStartInfo ¶
type DriverBalancerClusterDiscoveryAttemptStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Address string }
type DriverBalancerDialEntrypointDoneInfo ¶
type DriverBalancerDialEntrypointDoneInfo struct { Error error }
type DriverBalancerDialEntrypointStartInfo ¶
type DriverBalancerDialEntrypointStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Address string }
type DriverBalancerInitDoneInfo ¶
type DriverBalancerInitDoneInfo struct { Error error }
type DriverBalancerInitStartInfo ¶
type DriverBalancerInitStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Name string }
type DriverBalancerUpdateDoneInfo ¶
type DriverBalancerUpdateDoneInfo struct { Endpoints []EndpointInfo Added []EndpointInfo Dropped []EndpointInfo LocalDC string }
type DriverBalancerUpdateStartInfo ¶
type DriverBalancerUpdateStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call NeedLocalDC bool }
type DriverCloseDoneInfo ¶
type DriverCloseDoneInfo struct { Error error }
type DriverCloseStartInfo ¶
type DriverCloseStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type DriverComposeOption ¶
type DriverComposeOption func(o *driverComposeOptions)
DriverOption specified Driver compose option
func WithDriverPanicCallback ¶
func WithDriverPanicCallback(cb func(e interface{})) DriverComposeOption
WithDriverPanicCallback specified behavior on panic
type DriverConnAllowDoneInfo ¶
type DriverConnAllowDoneInfo struct { State ConnState }
type DriverConnAllowStartInfo ¶
type DriverConnAllowStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Endpoint EndpointInfo State ConnState }
type DriverConnBanDoneInfo ¶
type DriverConnBanDoneInfo struct { State ConnState }
type DriverConnBanStartInfo ¶
type DriverConnBanStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Endpoint EndpointInfo State ConnState Cause error }
type DriverConnCloseDoneInfo ¶
type DriverConnCloseDoneInfo struct { Error error }
type DriverConnCloseStartInfo ¶
type DriverConnCloseStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Endpoint EndpointInfo }
type DriverConnDialDoneInfo ¶
type DriverConnDialDoneInfo struct { Error error }
type DriverConnDialStartInfo ¶
type DriverConnDialStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Endpoint EndpointInfo }
type DriverConnInvokeDoneInfo ¶
type DriverConnInvokeDoneInfo struct { Error error Issues []Issue OpID string State ConnState Metadata map[string][]string }
type DriverConnInvokeStartInfo ¶
type DriverConnInvokeStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Endpoint EndpointInfo Method Method }
type DriverConnNewStreamDoneInfo ¶
type DriverConnNewStreamStartInfo ¶
type DriverConnNewStreamStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Endpoint EndpointInfo Method Method }
type DriverConnParkDoneInfo ¶
type DriverConnParkDoneInfo struct { Error error }
type DriverConnParkStartInfo ¶
type DriverConnParkStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Endpoint EndpointInfo }
type DriverConnPoolNewDoneInfo ¶
type DriverConnPoolNewDoneInfo struct{}
type DriverConnPoolNewStartInfo ¶
type DriverConnPoolNewStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type DriverConnPoolReleaseDoneInfo ¶
type DriverConnPoolReleaseDoneInfo struct { Error error }
type DriverConnPoolReleaseStartInfo ¶
type DriverConnPoolReleaseStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type DriverConnStateChangeDoneInfo ¶
type DriverConnStateChangeDoneInfo struct { State ConnState }
type DriverConnStateChangeStartInfo ¶
type DriverConnStateChangeStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Endpoint EndpointInfo State ConnState }
type DriverConnStreamCloseSendDoneInfo ¶
type DriverConnStreamCloseSendDoneInfo struct { Error error }
type DriverConnStreamCloseSendStartInfo ¶
type DriverConnStreamCloseSendStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type DriverConnStreamRecvMsgDoneInfo ¶
type DriverConnStreamRecvMsgDoneInfo struct { Error error }
type DriverConnStreamRecvMsgStartInfo ¶
type DriverConnStreamRecvMsgStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type DriverConnStreamSendMsgDoneInfo ¶
type DriverConnStreamSendMsgDoneInfo struct { Error error }
type DriverConnStreamSendMsgStartInfo ¶
type DriverConnStreamSendMsgStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type DriverConnTakeDoneInfo ¶
type DriverConnTakeDoneInfo struct { Error error }
type DriverConnTakeStartInfo ¶
type DriverConnTakeStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Endpoint EndpointInfo }
type DriverGetCredentialsDoneInfo ¶
type DriverGetCredentialsStartInfo ¶
type DriverGetCredentialsStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type DriverInitDoneInfo ¶
type DriverInitDoneInfo struct { Error error }
type DriverInitStartInfo ¶
type DriverInitStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Endpoint string Database string Secure bool }
type DriverNetCloseDoneInfo ¶
type DriverNetCloseDoneInfo struct { Error error }
type DriverNetCloseStartInfo ¶
type DriverNetCloseStartInfo struct { Call call Address string }
type DriverNetDialDoneInfo ¶
type DriverNetDialDoneInfo struct { Error error }
type DriverNetDialStartInfo ¶
type DriverNetDialStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Address string }
type DriverNetReadDoneInfo ¶
type DriverNetReadStartInfo ¶
type DriverNetWriteDoneInfo ¶
type DriverNetWriteStartInfo ¶
type DriverRepeaterWakeUpDoneInfo ¶
type DriverRepeaterWakeUpDoneInfo struct { Error error }
type DriverRepeaterWakeUpStartInfo ¶
type DriverRepeaterWakeUpStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Name string Event string }
type DriverResolveDoneInfo ¶
type DriverResolveDoneInfo struct { Error error }
type DriverResolveStartInfo ¶
type DriverWithDoneInfo ¶
type DriverWithDoneInfo struct { Error error }
type DriverWithStartInfo ¶
type DriverWithStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Endpoint string Database string Secure bool }
type EndpointInfo ¶
type EndpointInfo interface { fmt.Stringer NodeID() uint32 Address() string LocalDC() bool Location() string LoadFactor() float32 LastUpdated() time.Time }
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 Issue ¶
Issue declare interface of operation error issues
type Method ¶
type Method string
Method represents rpc method.
func (Method) Name ¶
Name returns the rpc method name.
func (Method) Service ¶
Service returns the rpc service name.
func (Method) Split ¶
Split returns service name and method.
type OnReadStreamUpdateTokenDoneInfo ¶
type OnReadStreamUpdateTokenDoneInfo struct { Error error }
type OnReadUnknownGrpcMessageInfo ¶
type OnReadUpdateTokenMiddleTokenReceivedInfo ¶
type OnReadUpdateTokenStartInfo ¶
type OnReadUpdateTokenStartInfo struct { ReaderConnectionID string }
type Query ¶
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
func (*Query) Compose ¶
func (t *Query) Compose(x *Query, opts ...QueryComposeOption) *Query
Compose returns a new Query which has functional fields composed both from t and x.
type QueryCloseDoneInfo ¶
type QueryCloseDoneInfo struct { Error error }
type QueryCloseStartInfo ¶
type QueryCloseStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type QueryComposeOption ¶
type QueryComposeOption func(o *queryComposeOptions)
QueryOption specified Query compose option
func WithQueryPanicCallback ¶
func WithQueryPanicCallback(cb func(e interface{})) QueryComposeOption
WithQueryPanicCallback specified behavior on panic
type QueryDoDoneInfo ¶
type QueryDoStartInfo ¶
type QueryDoStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type QueryDoTxDoneInfo ¶
type QueryDoTxStartInfo ¶
type QueryDoTxStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type QueryNewDoneInfo ¶
type QueryNewDoneInfo struct{}
type QueryNewStartInfo ¶
type QueryNewStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type QueryPoolChange ¶
type QueryPoolCloseDoneInfo ¶
type QueryPoolCloseDoneInfo struct { Error error }
type QueryPoolCloseStartInfo ¶
type QueryPoolCloseStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type QueryPoolGetDoneInfo ¶
type QueryPoolGetDoneInfo struct { Error error }
type QueryPoolGetStartInfo ¶
type QueryPoolGetStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type QueryPoolNewDoneInfo ¶
type QueryPoolNewDoneInfo struct { Limit int }
type QueryPoolNewStartInfo ¶
type QueryPoolNewStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type QueryPoolPutDoneInfo ¶
type QueryPoolPutDoneInfo struct { Error error }
type QueryPoolPutStartInfo ¶
type QueryPoolPutStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type QueryPoolTryDoneInfo ¶
type QueryPoolTryDoneInfo struct { Error error }
type QueryPoolTryStartInfo ¶
type QueryPoolTryStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type QueryPoolWithDoneInfo ¶
type QueryPoolWithStartInfo ¶
type QueryPoolWithStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type QueryResultCloseDoneInfo ¶
type QueryResultCloseDoneInfo struct { Error error }
type QueryResultCloseStartInfo ¶
type QueryResultCloseStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type QueryResultNewDoneInfo ¶
type QueryResultNewDoneInfo struct { Error error }
type QueryResultNewStartInfo ¶
type QueryResultNewStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type QueryResultNextPartDoneInfo ¶
type QueryResultNextPartDoneInfo struct { Error error }
type QueryResultNextPartStartInfo ¶
type QueryResultNextPartStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type QueryResultNextResultSetDoneInfo ¶
type QueryResultNextResultSetDoneInfo struct { Error error }
type QueryResultNextResultSetStartInfo ¶
type QueryResultNextResultSetStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type QueryResultSetNextRowDoneInfo ¶
type QueryResultSetNextRowDoneInfo struct { Error error }
type QueryResultSetNextRowStartInfo ¶
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 ¶
type QueryRowScanDoneInfo struct { Error error }
type QueryRowScanNamedDoneInfo ¶
type QueryRowScanNamedDoneInfo struct { Error error }
type QueryRowScanNamedStartInfo ¶
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 ¶
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 ¶
type QueryRowScanStructDoneInfo struct { Error error }
type QueryRowScanStructStartInfo ¶
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 ¶
type QuerySessionAttachDoneInfo struct { Error error }
type QuerySessionAttachStartInfo ¶
type QuerySessionAttachStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Session querySessionInfo }
type QuerySessionBeginDoneInfo ¶
type QuerySessionBeginDoneInfo struct { Error error Tx queryTransactionInfo }
type QuerySessionBeginStartInfo ¶
type QuerySessionBeginStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Session querySessionInfo }
type QuerySessionCreateDoneInfo ¶
type QuerySessionCreateDoneInfo struct { Session querySessionInfo Error error }
type QuerySessionCreateStartInfo ¶
type QuerySessionCreateStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type QuerySessionDeleteDoneInfo ¶
type QuerySessionDeleteDoneInfo struct { Error error }
type QuerySessionDeleteStartInfo ¶
type QuerySessionDeleteStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Session querySessionInfo }
type QuerySessionExecuteDoneInfo ¶
type QuerySessionExecuteDoneInfo struct { Error error }
type QuerySessionExecuteStartInfo ¶
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 ¶
type QueryTxExecuteDoneInfo struct { Error error }
type QueryTxExecuteStartInfo ¶
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 ¶
type Ratelimiter struct{}
Ratelimiter specified trace of ratelimiter client activity. gtrace:gen
func (*Ratelimiter) Compose ¶
func (t *Ratelimiter) Compose(x *Ratelimiter, opts ...RatelimiterComposeOption) *Ratelimiter
Compose returns a new Ratelimiter which has functional fields composed both from t and x.
type RatelimiterComposeOption ¶
type RatelimiterComposeOption func(o *ratelimiterComposeOptions)
RatelimiterOption specified Ratelimiter compose option
func WithRatelimiterPanicCallback ¶
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
func (*Retry) Compose ¶
func (t *Retry) Compose(x *Retry, opts ...RetryComposeOption) *Retry
Compose returns a new Retry which has functional fields composed both from t and x.
type RetryComposeOption ¶
type RetryComposeOption func(o *retryComposeOptions)
RetryOption specified Retry compose option
func WithRetryPanicCallback ¶
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 ¶
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
func (*Scheme) Compose ¶
func (t *Scheme) Compose(x *Scheme, opts ...SchemeComposeOption) *Scheme
Compose returns a new Scheme which has functional fields composed both from t and x.
type SchemeComposeOption ¶
type SchemeComposeOption func(o *schemeComposeOptions)
SchemeOption specified Scheme compose option
func WithSchemePanicCallback ¶
func WithSchemePanicCallback(cb func(e interface{})) SchemeComposeOption
WithSchemePanicCallback specified behavior on panic
type SchemeDescribePathDoneInfo ¶
type SchemeDescribePathStartInfo ¶
type SchemeDescribePathStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Path string }
type SchemeListDirectoryDoneInfo ¶
type SchemeListDirectoryDoneInfo struct { Error error }
type SchemeListDirectoryStartInfo ¶
type SchemeListDirectoryStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type SchemeMakeDirectoryDoneInfo ¶
type SchemeMakeDirectoryDoneInfo struct { Error error }
type SchemeMakeDirectoryStartInfo ¶
type SchemeMakeDirectoryStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Path string }
type SchemeModifyPermissionsDoneInfo ¶
type SchemeModifyPermissionsDoneInfo struct { Error error }
type SchemeModifyPermissionsStartInfo ¶
type SchemeModifyPermissionsStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Path string }
type SchemeRemoveDirectoryDoneInfo ¶
type SchemeRemoveDirectoryDoneInfo struct { Error error }
type SchemeRemoveDirectoryStartInfo ¶
type SchemeRemoveDirectoryStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Path string }
type Scripting ¶
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
func (*Scripting) Compose ¶
func (t *Scripting) Compose(x *Scripting, opts ...ScriptingComposeOption) *Scripting
Compose returns a new Scripting which has functional fields composed both from t and x.
type ScriptingCloseDoneInfo ¶
type ScriptingCloseDoneInfo struct { Error error }
type ScriptingCloseStartInfo ¶
type ScriptingCloseStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type ScriptingComposeOption ¶
type ScriptingComposeOption func(o *scriptingComposeOptions)
ScriptingOption specified Scripting compose option
func WithScriptingPanicCallback ¶
func WithScriptingPanicCallback(cb func(e interface{})) ScriptingComposeOption
WithScriptingPanicCallback specified behavior on panic
type ScriptingExecuteDoneInfo ¶
type ScriptingExecuteDoneInfo struct { Result scriptingResult Error error }
type ScriptingExecuteStartInfo ¶
type ScriptingExecuteStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Query string Parameters scriptingQueryParameters }
type ScriptingExplainDoneInfo ¶
type ScriptingExplainStartInfo ¶
type ScriptingExplainStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Query string }
type ScriptingStreamExecuteDoneInfo ¶
type ScriptingStreamExecuteDoneInfo struct { Error error }
type ScriptingStreamExecuteIntermediateInfo ¶
type ScriptingStreamExecuteIntermediateInfo struct { Error error }
type ScriptingStreamExecuteStartInfo ¶
type ScriptingStreamExecuteStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Query string Parameters scriptingQueryParameters }
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
func (*Table) Compose ¶
func (t *Table) Compose(x *Table, opts ...TableComposeOption) *Table
Compose returns a new Table which has functional fields composed both from t and x.
type TableBulkUpsertDoneInfo ¶
type TableBulkUpsertDoneInfo struct { Error error }
type TableBulkUpsertStartInfo ¶
type TableBulkUpsertStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Session tableSessionInfo }
type TableCloseDoneInfo ¶
type TableCloseDoneInfo struct { Error error }
type TableCloseStartInfo ¶
type TableCloseStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type TableComposeOption ¶
type TableComposeOption func(o *tableComposeOptions)
TableOption specified Table compose option
func WithTablePanicCallback ¶
func WithTablePanicCallback(cb func(e interface{})) TableComposeOption
WithTablePanicCallback specified behavior on panic
type TableCreateSessionDoneInfo ¶
type TableCreateSessionStartInfo ¶
type TableCreateSessionStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type TableDoDoneInfo ¶
type TableDoStartInfo ¶
type TableDoStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Label string Idempotent bool NestedCall bool // flag when Retry called inside head Retry }
type TableDoTxDoneInfo ¶
type TableDoTxStartInfo ¶
type TableDoTxStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Label string Idempotent bool NestedCall bool // flag when Retry called inside head Retry }
type TableExecuteDataQueryDoneInfo ¶
type TableExecuteDataQueryDoneInfo struct { Tx tableTransactionInfo Prepared bool Result tableResult Error error }
type TableExecuteDataQueryStartInfo ¶
type TableExecuteDataQueryStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Session tableSessionInfo Query tableDataQuery Parameters tableQueryParameters KeepInCache bool }
type TableExplainQueryDoneInfo ¶
type TableExplainQueryStartInfo ¶
type TableExplainQueryStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Session tableSessionInfo Query string }
type TableInitDoneInfo ¶
type TableInitDoneInfo struct { Limit int }
type TableInitStartInfo ¶
type TableInitStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type TableKeepAliveDoneInfo ¶
type TableKeepAliveDoneInfo struct { Error error }
type TableKeepAliveStartInfo ¶
type TableKeepAliveStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Session tableSessionInfo }
type TablePoolGetDoneInfo ¶
type TablePoolGetStartInfo ¶
type TablePoolGetStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type TablePoolPutDoneInfo ¶
type TablePoolPutDoneInfo struct { Error error }
type TablePoolPutStartInfo ¶
type TablePoolPutStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Session tableSessionInfo }
type TablePoolSessionAddInfo ¶
type TablePoolSessionAddInfo struct {
Session tableSessionInfo
}
type TablePoolSessionCloseDoneInfo ¶
type TablePoolSessionCloseDoneInfo struct{}
type TablePoolSessionCloseStartInfo ¶
type TablePoolSessionCloseStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Session tableSessionInfo }
type TablePoolSessionNewDoneInfo ¶
type TablePoolSessionNewDoneInfo struct { Session tableSessionInfo Error error }
type TablePoolSessionNewStartInfo ¶
type TablePoolSessionNewStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type TablePoolSessionRemoveInfo ¶
type TablePoolSessionRemoveInfo struct {
Session tableSessionInfo
}
type TablePoolStateChangeInfo ¶
type TablePoolWaitDoneInfo ¶
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 ¶
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 ¶
type TablePrepareDataQueryDoneInfo struct { Result tableDataQuery Error error }
type TablePrepareDataQueryStartInfo ¶
type TablePrepareDataQueryStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Session tableSessionInfo Query string }
type TableSessionDeleteDoneInfo ¶
type TableSessionDeleteDoneInfo struct { Error error }
type TableSessionDeleteStartInfo ¶
type TableSessionDeleteStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Session tableSessionInfo }
type TableSessionNewDoneInfo ¶
type TableSessionNewDoneInfo struct { Session tableSessionInfo Error error }
type TableSessionNewStartInfo ¶
type TableSessionNewStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call }
type TableSessionQueryStreamExecuteDoneInfo ¶
type TableSessionQueryStreamExecuteDoneInfo struct { Error error }
type TableSessionQueryStreamExecuteStartInfo ¶
type TableSessionQueryStreamExecuteStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Session tableSessionInfo Query tableDataQuery Parameters tableQueryParameters }
type TableSessionQueryStreamReadDoneInfo ¶
type TableSessionQueryStreamReadDoneInfo struct { Error error }
type TableSessionQueryStreamReadStartInfo ¶
type TableSessionQueryStreamReadStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Session tableSessionInfo }
type TableTransactionExecuteDoneInfo ¶
type TableTransactionExecuteDoneInfo struct { Result tableResult Error error }
type TableTransactionExecuteStartInfo ¶
type TableTransactionExecuteStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Session tableSessionInfo Tx tableTransactionInfo Query tableDataQuery Parameters tableQueryParameters }
type TableTransactionExecuteStatementDoneInfo ¶
type TableTransactionExecuteStatementDoneInfo struct { Result tableResult Error error }
type TableTransactionExecuteStatementStartInfo ¶
type TableTransactionExecuteStatementStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Session tableSessionInfo Tx tableTransactionInfo StatementQuery tableDataQuery Parameters tableQueryParameters }
type TableTxBeginDoneInfo ¶
type TableTxBeginDoneInfo struct { Tx tableTransactionInfo Error error }
type TableTxBeginStartInfo ¶
type TableTxBeginStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Session tableSessionInfo }
type TableTxCommitDoneInfo ¶
type TableTxCommitDoneInfo struct { Error error }
type TableTxCommitStartInfo ¶
type TableTxCommitStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Session tableSessionInfo Tx tableTransactionInfo }
type TableTxRollbackDoneInfo ¶
type TableTxRollbackDoneInfo struct { Error error }
type TableTxRollbackStartInfo ¶
type TableTxRollbackStartInfo struct { // Context make available context in trace callback function. // Pointer to context provide replacement of context in trace callback function. // Warning: concurrent access to pointer on client side must be excluded. // Safe replacement of context are provided only inside callback function Context *context.Context Call call Session tableSessionInfo Tx tableTransactionInfo }
type Topic ¶
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
func (*Topic) Compose ¶
func (t *Topic) Compose(x *Topic, opts ...TopicComposeOption) *Topic
Compose returns a new Topic which has functional fields composed both from t and x.
type TopicComposeOption ¶
type TopicComposeOption func(o *topicComposeOptions)
TopicOption specified Topic compose option
func WithTopicPanicCallback ¶
func WithTopicPanicCallback(cb func(e interface{})) TopicComposeOption
WithTopicPanicCallback specified behavior on panic
type TopicOnWriterReadUnknownGrpcMessageInfo ¶
type TopicOnWriterReadUnknownGrpcMessageInfo struct { WriterInstanceID string SessionID string Error error }
type TopicReadStreamInitRequestInfo ¶
type TopicReaderCloseDoneInfo ¶
type TopicReaderCloseDoneInfo struct { CloseError error }
type TopicReaderCloseStartInfo ¶
type TopicReaderCommitDoneInfo ¶
type TopicReaderCommitDoneInfo struct { Error error }
type TopicReaderCommitStartInfo ¶
type TopicReaderCommitStartInfo struct { RequestContext context.Context Topic string PartitionID int64 PartitionSessionID int64 StartOffset int64 EndOffset int64 }
type TopicReaderCommittedNotifyInfo ¶
type TopicReaderCommittedNotifyInfo struct { ReaderConnectionID string Topic string PartitionID int64 PartitionSessionID int64 CommittedOffset int64 }
type TopicReaderDataResponseInfo ¶
type TopicReaderDataResponseInfo interface { GetBytesSize() int GetPartitionBatchMessagesCounts() (partitionCount, batchCount, messagesCount int) }
type TopicReaderErrorInfo ¶
type TopicReaderInitDoneInfo ¶
type TopicReaderInitStartInfo ¶
type TopicReaderInitStartInfo struct { PreInitReaderConnectionID string InitRequestInfo TopicReadStreamInitRequestInfo }
type TopicReaderPartitionReadStartResponseDoneInfo ¶
type TopicReaderPartitionReadStartResponseDoneInfo struct { ReadOffset *int64 CommitOffset *int64 Error error }
type TopicReaderPartitionReadStartResponseStartInfo ¶
type TopicReaderPartitionReadStartResponseStartInfo struct { ReaderConnectionID string PartitionContext context.Context Topic string PartitionID int64 PartitionSessionID int64 }
type TopicReaderPartitionReadStopResponseDoneInfo ¶
type TopicReaderPartitionReadStopResponseDoneInfo struct { Error error }
type TopicReaderPartitionReadStopResponseStartInfo ¶
type TopicReaderPartitionReadStopResponseStartInfo struct { ReaderConnectionID string PartitionContext context.Context Topic string PartitionID int64 PartitionSessionID int64 CommittedOffset int64 Graceful bool }
type TopicReaderReadMessagesDoneInfo ¶
type TopicReaderReadMessagesDoneInfo struct { MessagesCount int Topic string PartitionID int64 PartitionSessionID int64 OffsetStart int64 OffsetEnd int64 FreeBufferCapacity int Error error }
type TopicReaderReadMessagesStartInfo ¶
type TopicReaderReadMessagesStartInfo struct { RequestContext context.Context MinCount int MaxCount int FreeBufferCapacity int }
type TopicReaderReceiveDataResponseDoneInfo ¶
type TopicReaderReceiveDataResponseDoneInfo struct { Error error }
type TopicReaderReceiveDataResponseStartInfo ¶
type TopicReaderReceiveDataResponseStartInfo struct { ReaderConnectionID string LocalBufferSizeAfterReceive int DataResponse TopicReaderDataResponseInfo }
type TopicReaderReconnectDoneInfo ¶
type TopicReaderReconnectDoneInfo struct { Error error }
type TopicReaderReconnectRequestInfo ¶
type TopicReaderReconnectStartInfo ¶
type TopicReaderReconnectStartInfo struct { Reason error }
type TopicReaderSendCommitMessageDoneInfo ¶
type TopicReaderSendCommitMessageDoneInfo struct { Error error }
type TopicReaderSendCommitMessageStartInfo ¶
type TopicReaderSendCommitMessageStartInfo struct { CommitsInfo TopicReaderStreamSendCommitMessageStartMessageInfo }
type TopicReaderSentDataRequestInfo ¶
type TopicReaderSentDataRequestInfo struct { ReaderConnectionID string RequestBytes int LocalBufferSizeAfterSent int }
type TopicReaderStartInfo ¶
type TopicReaderStreamCommitInfo ¶
type TopicReaderStreamCommitInfo struct { Topic string PartitionID int64 PartitionSessionID int64 StartOffset int64 EndOffset int64 }
type TopicReaderStreamSendCommitMessageStartMessageInfo ¶
type TopicReaderStreamSendCommitMessageStartMessageInfo interface { GetCommitsInfo() []TopicReaderStreamCommitInfo }
type TopicWriterCloseDoneInfo ¶
type TopicWriterCloseDoneInfo struct { Error error }
type TopicWriterCloseStartInfo ¶
type TopicWriterCompressMessagesDoneInfo ¶
type TopicWriterCompressMessagesDoneInfo struct { Error error }
type TopicWriterCompressMessagesReason ¶
type TopicWriterCompressMessagesReason string
func (TopicWriterCompressMessagesReason) String ¶
func (r TopicWriterCompressMessagesReason) String() string
type TopicWriterCompressMessagesStartInfo ¶
type TopicWriterCompressMessagesStartInfo struct { WriterInstanceID string SessionID string Codec int32 FirstSeqNo int64 MessagesCount int Reason TopicWriterCompressMessagesReason }
type TopicWriterInitStreamDoneInfo ¶
type TopicWriterInitStreamStartInfo ¶
type TopicWriterInitStreamStartInfo struct { WriterInstanceID string Topic string ProducerID string }
type TopicWriterReconnectDoneInfo ¶
type TopicWriterReconnectDoneInfo struct { Error error }
type TopicWriterReconnectStartInfo ¶
type TopicWriterReconnectStartInfo struct { WriterInstanceID string Topic string ProducerID string Attempt int }
type TopicWriterSendMessagesDoneInfo ¶
type TopicWriterSendMessagesDoneInfo struct { Error error }
type TopicWriterSendMessagesStartInfo ¶
type TopicWriterSendMessagesStartInfo struct { WriterInstanceID string SessionID string Codec int32 FirstSeqNo int64 MessagesCount int }
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
- Version
- v3.62.0
- Published
- Apr 4, 2024
- Platform
- darwin/amd64
- Imports
- 8 packages
- Last checked
- 6 seconds ago –
Tools for package owners.