package trace

import "github.com/ydb-platform/ydb-go-sdk/v3/trace"

Index

Constants

const (
	TopicWriterCompressMessagesReasonCompressData                = TopicWriterCompressMessagesReason("compress-on-send")
	TopicWriterCompressMessagesReasonCompressDataOnWriteReadData = TopicWriterCompressMessagesReason("compress-on-call-write")
	TopicWriterCompressMessagesReasonCodecsMeasure               = TopicWriterCompressMessagesReason("compress-on-codecs-measure")
)

Functions

func ClearContext

func ClearContext(x interface{}) interface{}

func DatabaseSQLOnConnBegin

func DatabaseSQLOnConnBegin(t DatabaseSQL, c *context.Context) func(tx tableTransactionInfo, _ error)

func DatabaseSQLOnConnClose

func DatabaseSQLOnConnClose(t DatabaseSQL) func(error)

func DatabaseSQLOnConnExec

func DatabaseSQLOnConnExec(t DatabaseSQL, c *context.Context, query string, mode string, idempotent bool) func(error)

func DatabaseSQLOnConnPing

func DatabaseSQLOnConnPing(t DatabaseSQL, c *context.Context) func(error)

func DatabaseSQLOnConnPrepare

func DatabaseSQLOnConnPrepare(t DatabaseSQL, c *context.Context, query string) func(error)

func DatabaseSQLOnConnQuery

func DatabaseSQLOnConnQuery(t DatabaseSQL, c *context.Context, query string, mode string, idempotent bool) func(error)

func DatabaseSQLOnConnectorConnect

func DatabaseSQLOnConnectorConnect(t DatabaseSQL, c *context.Context) func(error)

func DatabaseSQLOnDoTx

func DatabaseSQLOnDoTx(t DatabaseSQL, c *context.Context, iD string, idempotent bool) func(error) func(attempts int, _ error)

func DatabaseSQLOnStmtClose

func DatabaseSQLOnStmtClose(t DatabaseSQL) func(error)

func DatabaseSQLOnStmtExec

func DatabaseSQLOnStmtExec(t DatabaseSQL, c *context.Context, query string) func(error)

func DatabaseSQLOnStmtQuery

func DatabaseSQLOnStmtQuery(t DatabaseSQL, c *context.Context, query string) func(error)

func DatabaseSQLOnTxCommit

func DatabaseSQLOnTxCommit(t DatabaseSQL, c *context.Context, tx tableTransactionInfo) func(error)

func DatabaseSQLOnTxExec

func DatabaseSQLOnTxExec(t DatabaseSQL, c *context.Context, txContext context.Context, tx tableTransactionInfo, query string, idempotent bool) func(error)

func DatabaseSQLOnTxQuery

func DatabaseSQLOnTxQuery(t DatabaseSQL, c *context.Context, txContext context.Context, tx tableTransactionInfo, query string, idempotent bool) func(error)

func DatabaseSQLOnTxRollback

func DatabaseSQLOnTxRollback(t DatabaseSQL, c *context.Context, tx tableTransactionInfo) func(error)

func DiscoveryOnDiscover

func DiscoveryOnDiscover(t Discovery, c *context.Context, address string, database string) func(location string, endpoints []EndpointInfo, _ error)

func DiscoveryOnWhoAmI

func DiscoveryOnWhoAmI(t Discovery, c *context.Context) func(user string, groups []string, _ error)

func DriverOnBalancerChooseEndpoint

func DriverOnBalancerChooseEndpoint(t Driver, c *context.Context) func(endpoint EndpointInfo, _ error)

func DriverOnBalancerClose

func DriverOnBalancerClose(t Driver, c *context.Context) func(error)

func DriverOnBalancerInit

func DriverOnBalancerInit(t Driver, c *context.Context) func(error)

func DriverOnBalancerUpdate

func DriverOnBalancerUpdate(t Driver, c *context.Context, needLocalDC bool) func(endpoints []EndpointInfo, localDC string, _ error)

func DriverOnClose

func DriverOnClose(t Driver, c *context.Context) func(error)

func DriverOnConnAllow

func DriverOnConnAllow(t Driver, c *context.Context, endpoint EndpointInfo, state ConnState) func(state ConnState)

func DriverOnConnBan

func DriverOnConnBan(t Driver, c *context.Context, endpoint EndpointInfo, state ConnState, cause error) func(state ConnState)

func DriverOnConnClose

func DriverOnConnClose(t Driver, c *context.Context, endpoint EndpointInfo) func(error)

func DriverOnConnInvoke

func DriverOnConnInvoke(t Driver, c *context.Context, 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, endpoint EndpointInfo, m Method) func(error) func(_ error, state ConnState, metadata map[string][]string)

func DriverOnConnPark

func DriverOnConnPark(t Driver, c *context.Context, endpoint EndpointInfo) func(error)

func DriverOnConnStateChange

func DriverOnConnStateChange(t Driver, endpoint EndpointInfo, state ConnState) func(state ConnState)

func DriverOnConnTake

func DriverOnConnTake(t Driver, c *context.Context, endpoint EndpointInfo) func(error)

func DriverOnGetCredentials

func DriverOnGetCredentials(t Driver, c *context.Context) func(token string, _ error)

func DriverOnInit

func DriverOnInit(t Driver, c *context.Context, endpoint string, database string, secure bool) func(error)

func DriverOnNetClose

func DriverOnNetClose(t Driver, address string) func(error)

func DriverOnNetDial

func DriverOnNetDial(t Driver, c *context.Context, address string) func(error)

func DriverOnNetRead

func DriverOnNetRead(t Driver, address string, buffer int) func(received int, _ error)

func DriverOnNetWrite

func DriverOnNetWrite(t Driver, address string, bytes int) func(sent int, _ error)

func DriverOnRepeaterWakeUp

func DriverOnRepeaterWakeUp(t Driver, c *context.Context, name string, event string) func(error)

func DriverOnResolve

func DriverOnResolve(t Driver, target string, resolved []string) func(error)

func RetryOnRetry

func RetryOnRetry(t Retry, c *context.Context, iD string, idempotent bool) func(error) func(attempts int, _ error)

func ScriptingOnClose

func ScriptingOnClose(t Scripting, c *context.Context) func(error)

func ScriptingOnExecute

func ScriptingOnExecute(t Scripting, c *context.Context, query string, parameters scriptingQueryParameters) func(result scriptingResult, _ error)

func ScriptingOnExplain

func ScriptingOnExplain(t Scripting, c *context.Context, query string) func(plan string, _ error)

func ScriptingOnStreamExecute

func ScriptingOnStreamExecute(t Scripting, c *context.Context, 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 TableOnClose(t Table, c *context.Context) func(error)

func TableOnCreateSession

func TableOnCreateSession(t Table, c *context.Context) func(error) func(session tableSessionInfo, attempts int, _ error)

func TableOnDo

func TableOnDo(t Table, c *context.Context, idempotent bool) func(error) func(attempts int, _ error)

func TableOnDoTx

func TableOnDoTx(t Table, c *context.Context, idempotent bool) func(error) func(attempts int, _ error)

func TableOnInit

func TableOnInit(t Table, c *context.Context) func(limit int)

func TableOnPoolGet

func TableOnPoolGet(t Table, c *context.Context) func(session tableSessionInfo, attempts int, _ error)

func TableOnPoolPut

func TableOnPoolPut(t Table, c *context.Context, session tableSessionInfo) func(error)

func TableOnPoolSessionAdd

func TableOnPoolSessionAdd(t Table, session tableSessionInfo)

func TableOnPoolSessionClose

func TableOnPoolSessionClose(t Table, c *context.Context, session tableSessionInfo) func()

func TableOnPoolSessionNew

func TableOnPoolSessionNew(t Table, c *context.Context) func(session tableSessionInfo, _ error)

func TableOnPoolSessionRemove

func TableOnPoolSessionRemove(t Table, session tableSessionInfo)

func TableOnPoolStateChange

func TableOnPoolStateChange(t Table, size int, event string)

func TableOnPoolWait

func TableOnPoolWait(t Table, c *context.Context) func(session tableSessionInfo, _ error)

func TableOnSessionDelete

func TableOnSessionDelete(t Table, c *context.Context, session tableSessionInfo) func(error)

func TableOnSessionKeepAlive

func TableOnSessionKeepAlive(t Table, c *context.Context, session tableSessionInfo) func(error)

func TableOnSessionNew

func TableOnSessionNew(t Table, c *context.Context) func(session tableSessionInfo, _ error)

func TableOnSessionQueryExecute

func TableOnSessionQueryExecute(t Table, c *context.Context, 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, session tableSessionInfo, query string) func(aST string, plan string, _ error)

func TableOnSessionQueryPrepare

func TableOnSessionQueryPrepare(t Table, c *context.Context, session tableSessionInfo, query string) func(result tableDataQuery, _ error)

func TableOnSessionQueryStreamExecute

func TableOnSessionQueryStreamExecute(t Table, c *context.Context, session tableSessionInfo, query tableDataQuery, parameters tableQueryParameters) func(error) func(error)

func TableOnSessionQueryStreamRead

func TableOnSessionQueryStreamRead(t Table, c *context.Context, session tableSessionInfo) func(error) func(error)

func TableOnSessionTransactionBegin

func TableOnSessionTransactionBegin(t Table, c *context.Context, session tableSessionInfo) func(tx tableTransactionInfo, _ error)

func TableOnSessionTransactionCommit

func TableOnSessionTransactionCommit(t Table, c *context.Context, session tableSessionInfo, tx tableTransactionInfo) func(error)

func TableOnSessionTransactionExecute

func TableOnSessionTransactionExecute(t Table, c *context.Context, session tableSessionInfo, tx tableTransactionInfo, query tableDataQuery, parameters tableQueryParameters, keepInCache bool) func(result tableResult, _ error)

func TableOnSessionTransactionExecuteStatement

func TableOnSessionTransactionExecuteStatement(t Table, c *context.Context, session tableSessionInfo, tx tableTransactionInfo, parameters tableQueryParameters) func(result tableResult, _ error)

func TableOnSessionTransactionRollback

func TableOnSessionTransactionRollback(t Table, c *context.Context, 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 TopicOnReaderError(t Topic, readerConnectionID string, e error)

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 TopicOnReaderReconnect(t Topic) func(error)

func TopicOnReaderReconnectRequest

func TopicOnReaderReconnectRequest(t Topic, reason error, wasSent bool)

func TopicOnReaderSendCommitMessage

func TopicOnReaderSendCommitMessage(t Topic, commitsInfo TopicReaderStreamSendCommitMessageStartMessageInfo) func(error)

func TopicOnReaderSentDataRequest

func TopicOnReaderSentDataRequest(t Topic, readerConnectionID string, requestBytes int, localBufferSizeAfterSent int)

func TopicOnReaderUnknownGrpcMessage

func TopicOnReaderUnknownGrpcMessage(t Topic, readerConnectionID string, e error)

func TopicOnReaderUpdateToken

func TopicOnReaderUpdateToken(t Topic, readerConnectionID string) func(tokenLen int, _ error) func(error)

func TopicOnWriterClose

func TopicOnWriterClose(t Topic, writerInstanceID string, reason error) func(error)

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 ConnState interface {
	fmt.Stringer

	IsValid() bool
	Code() int
}

type Coordination

type Coordination struct{}

Coordination specified trace of coordination client activity. gtrace:gen

func (Coordination) Compose

Compose returns a new Coordination which has functional fields composed both from t and x.

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 DatabaseSQL

DatabaseSQL specified trace of `database/sql` call activity. gtrace:gen

func (DatabaseSQL) Compose

func (t DatabaseSQL) Compose(x DatabaseSQL, opts ...DatabaseSQLComposeOption) (ret 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
}

type DatabaseSQLConnCloseDoneInfo

type DatabaseSQLConnCloseDoneInfo struct {
	Error error
}

type DatabaseSQLConnCloseStartInfo

type DatabaseSQLConnCloseStartInfo struct{}

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
	Query      string
	Mode       string
	Idempotent bool
}

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
}

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
	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
	Query      string
	Mode       string
	Idempotent bool
}

type DatabaseSQLConnectorConnectDoneInfo

type DatabaseSQLConnectorConnectDoneInfo struct {
	Error error
}

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
}

type DatabaseSQLDoTxDoneInfo

type DatabaseSQLDoTxDoneInfo struct {
	Attempts int
	Error    error
}

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
	ID         string
	Idempotent bool
}

type DatabaseSQLStmtCloseDoneInfo

type DatabaseSQLStmtCloseDoneInfo struct {
	Error error
}

type DatabaseSQLStmtCloseStartInfo

type DatabaseSQLStmtCloseStartInfo struct{}

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
	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
	Query   string
}

type DatabaseSQLTxCommitDoneInfo

type DatabaseSQLTxCommitDoneInfo struct {
	Error error
}

type DatabaseSQLTxCommitStartInfo

type DatabaseSQLTxCommitStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	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
	TxContext  context.Context
	Tx         tableTransactionInfo
	Query      string
	Idempotent bool
}

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
	TxContext  context.Context
	Tx         tableTransactionInfo
	Query      string
	Idempotent bool
}

type DatabaseSQLTxRollbackDoneInfo

type DatabaseSQLTxRollbackDoneInfo struct {
	Error error
}

type DatabaseSQLTxRollbackStartInfo

type DatabaseSQLTxRollbackStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Tx      tableTransactionInfo
}

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

	TopicControlPlaneEvents

	TopicReaderStreamLifeCycleEvents
	TopicReaderStreamEvents
	TopicReaderMessageEvents
	TopicReaderPartitionEvents

	TopicWriterStreamLifeCycleEvents
	TopicWriterStreamEvents

	DatabaseSQLConnectorEvents
	DatabaseSQLConnEvents
	DatabaseSQLTxEvents
	DatabaseSQLStmtEvents

	RetryEvents

	DiscoveryEvents

	SchemeEvents

	ScriptingEvents

	RatelimiterEvents

	CoordinationEvents

	// Deprecated: has no effect now
	DriverClusterEvents

	DriverEvents = DriverNetEvents |
		DriverConnEvents |
		DriverBalancerEvents |
		DriverResolverEvents |
		DriverRepeaterEvents |
		DriverCredentialsEvents

	TableEvents = TableSessionLifeCycleEvents |
		TableSessionQueryInvokeEvents |
		TableSessionQueryStreamEvents |
		TableSessionTransactionEvents |
		TablePoolLifeCycleEvents |
		TablePoolSessionLifeCycleEvents |
		TablePoolAPIEvents

	TablePoolEvents = TablePoolLifeCycleEvents |
		TablePoolSessionLifeCycleEvents |
		TablePoolAPIEvents

	TableSessionQueryEvents = TableSessionQueryInvokeEvents |
		TableSessionQueryStreamEvents
	TableSessionEvents = TableSessionLifeCycleEvents |
		TableSessionQueryEvents |
		TableSessionTransactionEvents

	TopicReaderEvents = TopicReaderStreamEvents | TopicReaderMessageEvents |
		TopicReaderPartitionEvents |
		TopicReaderStreamLifeCycleEvents

	TopicEvents = TopicControlPlaneEvents | TopicReaderEvents

	DatabaseSQLEvents = DatabaseSQLConnectorEvents |
		DatabaseSQLConnEvents |
		DatabaseSQLTxEvents |
		DatabaseSQLStmtEvents

	DetailsAll = ^Details(0) // All bits enabled
)

func MatchDetails

func MatchDetails(pattern string, opts ...matchDetailsOption) (d Details)

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) (ret 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
	Address  string
	Database string
}

type DiscoveryWhoAmIDoneInfo

type DiscoveryWhoAmIDoneInfo struct {
	User   string
	Groups []string
	Error  error
}

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
}

type Driver

type Driver struct {
	// Driver runtime events
	OnInit  func(DriverInitStartInfo) func(DriverInitDoneInfo)
	OnClose func(DriverCloseStartInfo) func(DriverCloseDoneInfo)

	// Network events
	OnNetRead  func(DriverNetReadStartInfo) func(DriverNetReadDoneInfo)
	OnNetWrite func(DriverNetWriteStartInfo) func(DriverNetWriteDoneInfo)
	OnNetDial  func(DriverNetDialStartInfo) func(DriverNetDialDoneInfo)
	OnNetClose func(DriverNetCloseStartInfo) func(DriverNetCloseDoneInfo)

	// Resolver events
	OnResolve func(DriverResolveStartInfo) func(DriverResolveDoneInfo)

	// Conn events
	OnConnStateChange func(DriverConnStateChangeStartInfo) func(DriverConnStateChangeDoneInfo)
	OnConnInvoke      func(DriverConnInvokeStartInfo) func(DriverConnInvokeDoneInfo)
	OnConnNewStream   func(
		DriverConnNewStreamStartInfo,
	) func(
		DriverConnNewStreamRecvInfo,
	) func(
		DriverConnNewStreamDoneInfo,
	)
	OnConnTake  func(DriverConnTakeStartInfo) func(DriverConnTakeDoneInfo)
	OnConnPark  func(DriverConnParkStartInfo) func(DriverConnParkDoneInfo)
	OnConnBan   func(DriverConnBanStartInfo) func(DriverConnBanDoneInfo)
	OnConnAllow func(DriverConnAllowStartInfo) func(DriverConnAllowDoneInfo)
	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)
	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) (ret 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
}

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
}

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
}

type DriverBalancerUpdateDoneInfo

type DriverBalancerUpdateDoneInfo struct {
	Endpoints []EndpointInfo
	LocalDC   string
	Error     error
}

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
	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
}

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
	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
	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
	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
	Endpoint EndpointInfo
	Method   Method
}

type DriverConnNewStreamDoneInfo

type DriverConnNewStreamDoneInfo struct {
	Error    error
	State    ConnState
	Metadata map[string][]string
}

type DriverConnNewStreamRecvInfo

type DriverConnNewStreamRecvInfo struct {
	Error error
}

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
	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
	Endpoint EndpointInfo
}

type DriverConnStateChangeDoneInfo

type DriverConnStateChangeDoneInfo struct {
	State ConnState
}

type DriverConnStateChangeStartInfo

type DriverConnStateChangeStartInfo struct {
	Endpoint EndpointInfo
	State    ConnState
}

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
	Endpoint EndpointInfo
}

type DriverGetCredentialsDoneInfo

type DriverGetCredentialsDoneInfo struct {
	Token string
	Error error
}

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
}

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
	Endpoint string
	Database string
	Secure   bool
}

type DriverNetCloseDoneInfo

type DriverNetCloseDoneInfo struct {
	Error error
}

type DriverNetCloseStartInfo

type DriverNetCloseStartInfo struct {
	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
	Address string
}

type DriverNetReadDoneInfo

type DriverNetReadDoneInfo struct {
	Received int
	Error    error
}

type DriverNetReadStartInfo

type DriverNetReadStartInfo struct {
	Address string
	Buffer  int
}

type DriverNetWriteDoneInfo

type DriverNetWriteDoneInfo struct {
	Sent  int
	Error error
}

type DriverNetWriteStartInfo

type DriverNetWriteStartInfo struct {
	Address string
	Bytes   int
}

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
	Name    string
	Event   string
}

type DriverResolveDoneInfo

type DriverResolveDoneInfo struct {
	Error error
}

type DriverResolveStartInfo

type DriverResolveStartInfo struct {
	Target   string
	Resolved []string
}

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

type Issue interface {
	GetMessage() string
	GetIssueCode() uint32
	GetSeverity() uint32
}

Issue declare interface of operation error issues

type Method

type Method string

Method represents rpc method.

func (Method) Name

func (m Method) Name() (s string)

Name returns the rpc method name.

func (Method) Service

func (m Method) Service() (s string)

Service returns the rpc service name.

func (Method) Split

func (m Method) Split() (service, method string)

Split returns service name and method.

type OnReadStreamUpdateTokenDoneInfo

type OnReadStreamUpdateTokenDoneInfo struct {
	Error error
}

OnReadStreamUpdateTokenDoneInfo

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type OnReadUnknownGrpcMessageInfo

type OnReadUnknownGrpcMessageInfo struct {
	ReaderConnectionID string
	Error              error
}

OnReadUnknownGrpcMessageInfo

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type OnReadUpdateTokenMiddleTokenReceivedInfo

type OnReadUpdateTokenMiddleTokenReceivedInfo struct {
	TokenLen int
	Error    error
}

OnReadUpdateTokenMiddleTokenReceivedInfo

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type OnReadUpdateTokenStartInfo

type OnReadUpdateTokenStartInfo struct {
	ReaderConnectionID string
}

OnReadUpdateTokenStartInfo

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

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) (ret 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(RetryLoopIntermediateInfo) func(RetryLoopDoneInfo)
}

Retry specified trace of retry call activity. gtrace:gen

func (Retry) Compose

func (t Retry) Compose(x Retry, opts ...RetryComposeOption) (ret 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 RetryLoopDoneInfo struct {
	Attempts int
	Error    error
}

type RetryLoopIntermediateInfo

type RetryLoopIntermediateInfo struct {
	Error error
}

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
	ID         string
	Idempotent bool
}

type Scheme

type Scheme struct{}

Scheme specified trace of scheme client activity. gtrace:gen

func (Scheme) Compose

func (t Scheme) Compose(x Scheme, opts ...SchemeComposeOption) (ret 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 Scripting

Scripting specified trace of scripting client activity. gtrace:gen

func (Scripting) Compose

func (t Scripting) Compose(x Scripting, opts ...ScriptingComposeOption) (ret 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
}

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
	Query      string
	Parameters scriptingQueryParameters
}

type ScriptingExplainDoneInfo

type ScriptingExplainDoneInfo struct {
	Plan  string
	Error error
}

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
	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
	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(info TableDoIntermediateInfo) func(TableDoDoneInfo)
	OnDoTx          func(TableDoTxStartInfo) func(info TableDoTxIntermediateInfo) func(TableDoTxDoneInfo)
	OnCreateSession func(
		TableCreateSessionStartInfo,
	) func(
		info TableCreateSessionIntermediateInfo,
	) func(
		TableCreateSessionDoneInfo,
	)
	// Session events
	OnSessionNew       func(TableSessionNewStartInfo) func(TableSessionNewDoneInfo)
	OnSessionDelete    func(TableSessionDeleteStartInfo) func(TableSessionDeleteDoneInfo)
	OnSessionKeepAlive func(TableKeepAliveStartInfo) func(TableKeepAliveDoneInfo)
	// Query events
	OnSessionQueryPrepare func(TablePrepareDataQueryStartInfo) func(TablePrepareDataQueryDoneInfo)
	OnSessionQueryExecute func(TableExecuteDataQueryStartInfo) func(TableExecuteDataQueryDoneInfo)
	OnSessionQueryExplain func(TableExplainQueryStartInfo) func(TableExplainQueryDoneInfo)
	// Stream events
	OnSessionQueryStreamExecute func(
		TableSessionQueryStreamExecuteStartInfo,
	) func(
		TableSessionQueryStreamExecuteIntermediateInfo,
	) func(
		TableSessionQueryStreamExecuteDoneInfo,
	)
	OnSessionQueryStreamRead func(
		TableSessionQueryStreamReadStartInfo,
	) func(
		TableSessionQueryStreamReadIntermediateInfo,
	) func(
		TableSessionQueryStreamReadDoneInfo,
	)
	// Transaction events
	OnSessionTransactionBegin func(TableSessionTransactionBeginStartInfo) func(
		TableSessionTransactionBeginDoneInfo,
	)
	OnSessionTransactionExecute func(TableTransactionExecuteStartInfo) func(
		TableTransactionExecuteDoneInfo,
	)
	OnSessionTransactionExecuteStatement func(TableTransactionExecuteStatementStartInfo) func(
		TableTransactionExecuteStatementDoneInfo,
	)
	OnSessionTransactionCommit func(TableSessionTransactionCommitStartInfo) func(
		TableSessionTransactionCommitDoneInfo,
	)
	OnSessionTransactionRollback func(TableSessionTransactionRollbackStartInfo) func(
		TableSessionTransactionRollbackDoneInfo,
	)
	// Pool state event
	OnPoolStateChange func(TablePoolStateChangeInfo)

	// Pool session lifecycle events
	OnPoolSessionAdd    func(info TablePoolSessionAddInfo)
	OnPoolSessionRemove func(info TablePoolSessionRemoveInfo)

	// OnPoolSessionNew is user-defined callback for listening events about creating sessions with
	// internal session pool calls
	//
	// Deprecated: use OnPoolSessionAdd callback
	OnPoolSessionNew func(TablePoolSessionNewStartInfo) func(TablePoolSessionNewDoneInfo)

	// OnPoolSessionClose is user-defined callback for listening sessionClose calls
	//
	// Deprecated: use OnPoolSessionRemove callback
	OnPoolSessionClose func(TablePoolSessionCloseStartInfo) func(TablePoolSessionCloseDoneInfo)
	// 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) (ret Table)

Compose returns a new Table which has functional fields composed both from t and x.

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
}

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 TableCreateSessionDoneInfo struct {
	Session  tableSessionInfo
	Attempts int
	Error    error
}

type TableCreateSessionIntermediateInfo

type TableCreateSessionIntermediateInfo struct {
	Error error
}

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
}

type TableDoDoneInfo

type TableDoDoneInfo struct {
	Attempts int
	Error    error
}

type TableDoIntermediateInfo

type TableDoIntermediateInfo struct {
	Error error
}

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
	Idempotent bool
}

type TableDoTxDoneInfo

type TableDoTxDoneInfo struct {
	Attempts int
	Error    error
}

type TableDoTxIntermediateInfo

type TableDoTxIntermediateInfo struct {
	Error error
}

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
	Idempotent bool
}

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
	Session     tableSessionInfo
	Query       tableDataQuery
	Parameters  tableQueryParameters
	KeepInCache bool
}

type TableExplainQueryDoneInfo

type TableExplainQueryDoneInfo struct {
	AST   string
	Plan  string
	Error error
}

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
	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
}

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
	Session tableSessionInfo
}

type TablePoolGetDoneInfo

type TablePoolGetDoneInfo struct {
	Session  tableSessionInfo
	Attempts int
	Error    error
}

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
}

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
	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
	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
}

type TablePoolSessionRemoveInfo

type TablePoolSessionRemoveInfo struct {
	Session tableSessionInfo
}

type TablePoolStateChangeInfo

type TablePoolStateChangeInfo struct {
	Size  int
	Event string
}

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
}

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
	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
	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
}

type TableSessionQueryStreamExecuteDoneInfo

type TableSessionQueryStreamExecuteDoneInfo struct {
	Error error
}

type TableSessionQueryStreamExecuteIntermediateInfo

type TableSessionQueryStreamExecuteIntermediateInfo 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
	Session    tableSessionInfo
	Query      tableDataQuery
	Parameters tableQueryParameters
}

type TableSessionQueryStreamReadDoneInfo

type TableSessionQueryStreamReadDoneInfo struct {
	Error error
}

type TableSessionQueryStreamReadIntermediateInfo

type TableSessionQueryStreamReadIntermediateInfo 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
	Session tableSessionInfo
}

type TableSessionTransactionBeginDoneInfo

type TableSessionTransactionBeginDoneInfo struct {
	Tx    tableTransactionInfo
	Error error
}

type TableSessionTransactionBeginStartInfo

type TableSessionTransactionBeginStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Session tableSessionInfo
}

type TableSessionTransactionCommitDoneInfo

type TableSessionTransactionCommitDoneInfo struct {
	Error error
}

type TableSessionTransactionCommitStartInfo

type TableSessionTransactionCommitStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Session tableSessionInfo
	Tx      tableTransactionInfo
}

type TableSessionTransactionRollbackDoneInfo

type TableSessionTransactionRollbackDoneInfo struct {
	Error error
}

type TableSessionTransactionRollbackStartInfo

type TableSessionTransactionRollbackStartInfo struct {
	// Context make available context in trace callback function.
	// Pointer to context provide replacement of context in trace callback function.
	// Warning: concurrent access to pointer on client side must be excluded.
	// Safe replacement of context are provided only inside callback function
	Context *context.Context
	Session tableSessionInfo
	Tx      tableTransactionInfo
}

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
	Session     tableSessionInfo
	Tx          tableTransactionInfo
	Query       tableDataQuery
	Parameters  tableQueryParameters
	KeepInCache bool
}

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
	Session    tableSessionInfo
	Tx         tableTransactionInfo
	Parameters tableQueryParameters
}

type Topic

type Topic struct {
	// TopicReaderStreamLifeCycleEvents
	OnReaderReconnect        func(startInfo TopicReaderReconnectStartInfo) func(doneInfo TopicReaderReconnectDoneInfo)
	OnReaderReconnectRequest func(info TopicReaderReconnectRequestInfo)

	// TopicReaderPartitionEvents
	OnReaderPartitionReadStartResponse func(startInfo TopicReaderPartitionReadStartResponseStartInfo) func(doneInfo TopicReaderPartitionReadStartResponseDoneInfo)
	OnReaderPartitionReadStopResponse  func(startInfo TopicReaderPartitionReadStopResponseStartInfo) func(doneInfo TopicReaderPartitionReadStopResponseDoneInfo)

	// TopicReaderStreamEvents
	OnReaderCommit            func(startInfo TopicReaderCommitStartInfo) func(doneInfo TopicReaderCommitDoneInfo)
	OnReaderSendCommitMessage func(startInfo TopicReaderSendCommitMessageStartInfo) func(doneInfo TopicReaderSendCommitMessageDoneInfo)
	OnReaderCommittedNotify   func(info TopicReaderCommittedNotifyInfo)
	OnReaderClose             func(startInfo TopicReaderCloseStartInfo) func(doneInfo TopicReaderCloseDoneInfo)
	OnReaderInit              func(startInfo TopicReaderInitStartInfo) func(doneInfo TopicReaderInitDoneInfo)
	OnReaderError             func(info TopicReaderErrorInfo)
	OnReaderUpdateToken       func(startInfo OnReadUpdateTokenStartInfo) func(updateTokenInfo OnReadUpdateTokenMiddleTokenReceivedInfo) func(doneInfo OnReadStreamUpdateTokenDoneInfo)

	// TopicReaderMessageEvents
	OnReaderSentDataRequest     func(startInfo TopicReaderSentDataRequestInfo)
	OnReaderReceiveDataResponse func(startInfo TopicReaderReceiveDataResponseStartInfo) func(doneInfo TopicReaderReceiveDataResponseDoneInfo)
	OnReaderReadMessages        func(startInfo TopicReaderReadMessagesStartInfo) func(doneInfo TopicReaderReadMessagesDoneInfo)
	OnReaderUnknownGrpcMessage  func(info OnReadUnknownGrpcMessageInfo)

	// TopicWriterStreamLifeCycleEvents
	OnWriterReconnect  func(startInfo TopicWriterReconnectStartInfo) func(doneInfo TopicWriterReconnectDoneInfo)
	OnWriterInitStream func(startInfo TopicWriterInitStreamStartInfo) func(doneInfo TopicWriterInitStreamDoneInfo)
	OnWriterClose      func(startInfo TopicWriterCloseStartInfo) func(doneInfo TopicWriterCloseDoneInfo)

	// TopicWriterStreamEvents
	OnWriterCompressMessages       func(startInfo TopicWriterCompressMessagesStartInfo) func(doneInfo TopicWriterCompressMessagesDoneInfo)
	OnWriterSendMessages           func(startInfo TopicWriterSendMessagesStartInfo) func(doneInfo TopicWriterSendMessagesDoneInfo)
	OnWriterReadUnknownGrpcMessage func(info TopicOnWriterReadUnknownGrpcMessageInfo)
}

Topic specified trace of topic reader client activity. gtrace:gen Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

func (Topic) Compose

func (t Topic) Compose(x Topic, opts ...TopicComposeOption) (ret 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 TopicReadStreamInitRequestInfo interface {
	GetConsumer() string
	GetTopics() []string
}

TopicReadStreamInitRequestInfo

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type TopicReaderCloseDoneInfo

type TopicReaderCloseDoneInfo struct {
	CloseError error
}

TopicReaderCloseDoneInfo

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type TopicReaderCloseStartInfo

type TopicReaderCloseStartInfo struct {
	ReaderConnectionID string
	CloseReason        error
}

TopicReaderCloseStartInfo

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type TopicReaderCommitDoneInfo

type TopicReaderCommitDoneInfo struct {
	Error error
}

TopicReaderCommitDoneInfo

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type TopicReaderCommitStartInfo

type TopicReaderCommitStartInfo struct {
	RequestContext     context.Context
	Topic              string
	PartitionID        int64
	PartitionSessionID int64
	StartOffset        int64
	EndOffset          int64
}

TopicReaderCommitStartInfo

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type TopicReaderCommittedNotifyInfo

type TopicReaderCommittedNotifyInfo struct {
	ReaderConnectionID string
	Topic              string
	PartitionID        int64
	PartitionSessionID int64
	CommittedOffset    int64
}

TopicReaderCommittedNotifyInfo

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type TopicReaderDataResponseInfo

type TopicReaderDataResponseInfo interface {
	GetBytesSize() int
	GetPartitionBatchMessagesCounts() (partitionCount, batchCount, messagesCount int)
}

type TopicReaderErrorInfo

type TopicReaderErrorInfo struct {
	ReaderConnectionID string
	Error              error
}

TopicReaderErrorInfo

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type TopicReaderInitDoneInfo

type TopicReaderInitDoneInfo struct {
	ReaderConnectionID string
	Error              error
}

TopicReaderInitDoneInfo

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type TopicReaderInitStartInfo

type TopicReaderInitStartInfo struct {
	PreInitReaderConnectionID string
	InitRequestInfo           TopicReadStreamInitRequestInfo
}

TopicReaderInitStartInfo

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type TopicReaderPartitionReadStartResponseDoneInfo

type TopicReaderPartitionReadStartResponseDoneInfo struct {
	ReadOffset   *int64
	CommitOffset *int64
	Error        error
}

TopicReaderPartitionReadStartResponseDoneInfo Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type TopicReaderPartitionReadStartResponseStartInfo

type TopicReaderPartitionReadStartResponseStartInfo struct {
	ReaderConnectionID string
	PartitionContext   context.Context
	Topic              string
	PartitionID        int64
	PartitionSessionID int64
}

TopicReaderPartitionReadStartResponseStartInfo Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type TopicReaderPartitionReadStopResponseDoneInfo

type TopicReaderPartitionReadStopResponseDoneInfo struct {
	Error error
}

TopicReaderPartitionReadStopResponseDoneInfo

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type TopicReaderPartitionReadStopResponseStartInfo

type TopicReaderPartitionReadStopResponseStartInfo struct {
	ReaderConnectionID string
	PartitionContext   context.Context
	Topic              string
	PartitionID        int64
	PartitionSessionID int64
	CommittedOffset    int64
	Graceful           bool
}

TopicReaderPartitionReadStopResponseStartInfo

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type TopicReaderReadMessagesDoneInfo

type TopicReaderReadMessagesDoneInfo struct {
	MessagesCount      int
	Topic              string
	PartitionID        int64
	PartitionSessionID int64
	OffsetStart        int64
	OffsetEnd          int64
	FreeBufferCapacity int
	Error              error
}

TopicReaderReadMessagesDoneInfo

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type TopicReaderReadMessagesStartInfo

type TopicReaderReadMessagesStartInfo struct {
	RequestContext     context.Context
	MinCount           int
	MaxCount           int
	FreeBufferCapacity int
}

TopicReaderReadMessagesStartInfo

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type TopicReaderReceiveDataResponseDoneInfo

type TopicReaderReceiveDataResponseDoneInfo struct {
	Error error
}

TopicReaderReceiveDataResponseDoneInfo

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type TopicReaderReceiveDataResponseStartInfo

type TopicReaderReceiveDataResponseStartInfo struct {
	ReaderConnectionID          string
	LocalBufferSizeAfterReceive int
	DataResponse                TopicReaderDataResponseInfo
}

TopicReaderReceiveDataResponseStartInfo

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type TopicReaderReconnectDoneInfo

type TopicReaderReconnectDoneInfo struct {
	Error error
}

TopicReaderReconnectDoneInfo

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type TopicReaderReconnectRequestInfo

type TopicReaderReconnectRequestInfo struct {
	Reason  error
	WasSent bool
}

TopicReaderReconnectRequestInfo

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type TopicReaderReconnectStartInfo

type TopicReaderReconnectStartInfo struct{}

TopicReaderReconnectStartInfo

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type TopicReaderSendCommitMessageDoneInfo

type TopicReaderSendCommitMessageDoneInfo struct {
	Error error
}

TopicReaderSendCommitMessageDoneInfo

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type TopicReaderSendCommitMessageStartInfo

type TopicReaderSendCommitMessageStartInfo struct {
	// ReaderConnectionID string unimplemented yet - need some internal changes
	CommitsInfo TopicReaderStreamSendCommitMessageStartMessageInfo
}

TopicReaderSendCommitMessageStartInfo

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type TopicReaderSentDataRequestInfo

type TopicReaderSentDataRequestInfo struct {
	ReaderConnectionID       string
	RequestBytes             int
	LocalBufferSizeAfterSent int
}

TopicReaderSentDataRequestInfo

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type TopicReaderStreamSendCommitMessageStartMessageInfo

type TopicReaderStreamSendCommitMessageStartMessageInfo interface {
	PartitionIDs() []int64
	PartitionSessionIDs() []int64
}

TopicReaderStreamSendCommitMessageStartMessageInfo

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type TopicWriterCloseDoneInfo

type TopicWriterCloseDoneInfo struct {
	Error error
}

type TopicWriterCloseStartInfo

type TopicWriterCloseStartInfo struct {
	WriterInstanceID string
	Reason           error
}

type TopicWriterCompressMessagesDoneInfo

type TopicWriterCompressMessagesDoneInfo struct {
	Error error
}

type TopicWriterCompressMessagesReason

type TopicWriterCompressMessagesReason string

func (TopicWriterCompressMessagesReason) String

type TopicWriterCompressMessagesStartInfo

type TopicWriterCompressMessagesStartInfo struct {
	WriterInstanceID string
	SessionID        string
	Codec            int32
	FirstSeqNo       int64
	MessagesCount    int
	Reason           TopicWriterCompressMessagesReason
}

type TopicWriterInitStreamDoneInfo

type TopicWriterInitStreamDoneInfo struct {
	SessionID string
	Error     error
}

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

coordination.go coordination_gtrace.go details.go discovery.go discovery_gtrace.go driver.go driver_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.38.0
Published
Sep 19, 2022
Platform
js/wasm
Imports
6 packages
Last checked
1 second ago

Tools for package owners.