Versions in this module Expand all Collapse all v2 v2.4.0 Jul 11, 2025 Changes in this version + var ErrConcurrentSchemaUpdate = errors.New("concurrent schema update") type BeginRequest + func (req *BeginRequest) IsSync(isSync bool) *BeginRequest type CommitRequest + func (req *CommitRequest) IsSync(isSync bool) *CommitRequest v2.3.2 Apr 14, 2025 v2.3.1 Apr 3, 2025 v2.3.0 Mar 11, 2025 v2.2.1 Dec 27, 2024 v2.2.0 Dec 16, 2024 Changes in this version + func EncodeSpace(res SchemaResolver, enc *msgpack.Encoder, space interface{}) error type Response + func DecodeBaseResponse(header Header, body io.Reader) (Response, error) v2.1.0 Mar 6, 2024 v2.0.0 Feb 12, 2024 Changes in this version + const Closed + const Connected + const Disconnected + const ErrConnectionClosed + const ErrConnectionNotReady + const ErrConnectionShutdown + const ErrIoError + const ErrProtocolError + const ErrRateLimited + const ErrTimeouted + const ErrorNo + const LogAppendPushFailed + const LogLastReconnectFailed + const LogReconnectFailed + const LogUnexpectedResultId + const LogWatchEventReadFailed + const ReconnectFailed + const Shutdown + type Auth int + const AutoAuth + const ChapSha1Auth + const PapSha256Auth + func (a Auth) String() string + type AuthDialer struct + Auth Auth + Dialer Dialer + Password string + Username string + func (d AuthDialer) Dial(ctx context.Context, opts DialOpts) (Conn, error) + type BeginRequest struct + func NewBeginRequest() *BeginRequest + func (req *BeginRequest) Async() bool + func (req *BeginRequest) Body(res SchemaResolver, enc *msgpack.Encoder) error + func (req *BeginRequest) Context(ctx context.Context) *BeginRequest + func (req *BeginRequest) Ctx() context.Context + func (req *BeginRequest) Response(header Header, body io.Reader) (Response, error) + func (req *BeginRequest) Timeout(timeout time.Duration) *BeginRequest + func (req *BeginRequest) TxnIsolation(txnIsolation TxnIsolationLevel) *BeginRequest + func (req *BeginRequest) Type() iproto.Type + type BoxError struct + Code uint64 + Errno uint64 + Fields map[string]interface{} + File string + Line uint64 + Msg string + Prev *BoxError + Type string + func (e *BoxError) Depth() int + func (e *BoxError) Error() string + func (e *BoxError) MarshalMsgpack() ([]byte, error) + func (e *BoxError) UnmarshalMsgpack(b []byte) error + type BroadcastRequest struct + func NewBroadcastRequest(key string) *BroadcastRequest + func (req *BroadcastRequest) Async() bool + func (req *BroadcastRequest) Body(res SchemaResolver, enc *msgpack.Encoder) error + func (req *BroadcastRequest) Context(ctx context.Context) *BroadcastRequest + func (req *BroadcastRequest) Ctx() context.Context + func (req *BroadcastRequest) Response(header Header, body io.Reader) (Response, error) + func (req *BroadcastRequest) Type() iproto.Type + func (req *BroadcastRequest) Value(value interface{}) *BroadcastRequest + type CallRequest struct + func NewCall16Request(function string) *CallRequest + func NewCall17Request(function string) *CallRequest + func NewCallRequest(function string) *CallRequest + func (req *CallRequest) Args(args interface{}) *CallRequest + func (req *CallRequest) Async() bool + func (req *CallRequest) Body(res SchemaResolver, enc *msgpack.Encoder) error + func (req *CallRequest) Context(ctx context.Context) *CallRequest + func (req *CallRequest) Ctx() context.Context + func (req *CallRequest) Response(header Header, body io.Reader) (Response, error) + func (req *CallRequest) Type() iproto.Type + type ClientError struct + Code uint32 + Msg string + func (clierr ClientError) Error() string + func (clierr ClientError) Temporary() bool + type ColumnMetaData struct + FieldCollation string + FieldIsAutoincrement bool + FieldIsNullable bool + FieldName string + FieldSpan string + FieldType string + func (meta *ColumnMetaData) DecodeMsgpack(d *msgpack.Decoder) error + type CommitRequest struct + func NewCommitRequest() *CommitRequest + func (req *CommitRequest) Async() bool + func (req *CommitRequest) Body(res SchemaResolver, enc *msgpack.Encoder) error + func (req *CommitRequest) Context(ctx context.Context) *CommitRequest + func (req *CommitRequest) Ctx() context.Context + func (req *CommitRequest) Response(header Header, body io.Reader) (Response, error) + func (req *CommitRequest) Type() iproto.Type + type Conn interface + Addr func() net.Addr + Close func() error + Flush func() error + Greeting func() Greeting + ProtocolInfo func() ProtocolInfo + Read func(b []byte) (int, error) + Write func(b []byte) (int, error) + type ConnEvent struct + Conn *Connection + Kind ConnEventKind + When time.Time + type ConnEventKind int + type ConnLogKind int + type ConnectedRequest interface + Conn func() *Connection + type Connection struct + Greeting *Greeting + func Connect(ctx context.Context, dialer Dialer, opts Opts) (conn *Connection, err error) + func (conn *Connection) Addr() net.Addr + func (conn *Connection) Call(functionName string, args interface{}) ([]interface{}, error) + func (conn *Connection) Call16(functionName string, args interface{}) ([]interface{}, error) + func (conn *Connection) Call16Async(functionName string, args interface{}) *Future + func (conn *Connection) Call16Typed(functionName string, args interface{}, result interface{}) error + func (conn *Connection) Call17(functionName string, args interface{}) ([]interface{}, error) + func (conn *Connection) Call17Async(functionName string, args interface{}) *Future + func (conn *Connection) Call17Typed(functionName string, args interface{}, result interface{}) error + func (conn *Connection) CallAsync(functionName string, args interface{}) *Future + func (conn *Connection) CallTyped(functionName string, args interface{}, result interface{}) error + func (conn *Connection) Close() error + func (conn *Connection) CloseGraceful() error + func (conn *Connection) ClosedNow() bool + func (conn *Connection) ConfiguredTimeout() time.Duration + func (conn *Connection) ConnectedNow() bool + func (conn *Connection) Delete(space, index interface{}, key interface{}) ([]interface{}, error) + func (conn *Connection) DeleteAsync(space, index interface{}, key interface{}) *Future + func (conn *Connection) DeleteTyped(space, index interface{}, key interface{}, result interface{}) error + func (conn *Connection) Do(req Request) *Future + func (conn *Connection) Eval(expr string, args interface{}) ([]interface{}, error) + func (conn *Connection) EvalAsync(expr string, args interface{}) *Future + func (conn *Connection) EvalTyped(expr string, args interface{}, result interface{}) error + func (conn *Connection) Execute(expr string, args interface{}) ([]interface{}, error) + func (conn *Connection) ExecuteAsync(expr string, args interface{}) *Future + func (conn *Connection) ExecuteTyped(expr string, args interface{}, result interface{}) (SQLInfo, []ColumnMetaData, error) + func (conn *Connection) GetTyped(space, index interface{}, key interface{}, result interface{}) error + func (conn *Connection) Handle() interface{} + func (conn *Connection) Insert(space interface{}, tuple interface{}) ([]interface{}, error) + func (conn *Connection) InsertAsync(space interface{}, tuple interface{}) *Future + func (conn *Connection) InsertTyped(space interface{}, tuple interface{}, result interface{}) error + func (conn *Connection) NewPrepared(expr string) (*Prepared, error) + func (conn *Connection) NewStream() (*Stream, error) + func (conn *Connection) NewWatcher(key string, callback WatchCallback) (Watcher, error) + func (conn *Connection) Ping() ([]interface{}, error) + func (conn *Connection) ProtocolInfo() ProtocolInfo + func (conn *Connection) Replace(space interface{}, tuple interface{}) ([]interface{}, error) + func (conn *Connection) ReplaceAsync(space interface{}, tuple interface{}) *Future + func (conn *Connection) ReplaceTyped(space interface{}, tuple interface{}, result interface{}) error + func (conn *Connection) Select(space, index interface{}, offset, limit uint32, iterator Iter, key interface{}) ([]interface{}, error) + func (conn *Connection) SelectAsync(space, index interface{}, offset, limit uint32, iterator Iter, key interface{}) *Future + func (conn *Connection) SelectTyped(space, index interface{}, offset, limit uint32, iterator Iter, key interface{}, ...) error + func (conn *Connection) SetSchema(s Schema) + func (conn *Connection) Update(space, index, key interface{}, ops *Operations) ([]interface{}, error) + func (conn *Connection) UpdateAsync(space, index interface{}, key interface{}, ops *Operations) *Future + func (conn *Connection) UpdateTyped(space, index interface{}, key interface{}, ops *Operations, result interface{}) error + func (conn *Connection) Upsert(space, tuple interface{}, ops *Operations) ([]interface{}, error) + func (conn *Connection) UpsertAsync(space, tuple interface{}, ops *Operations) *Future + type Connector interface + Call func(functionName string, args interface{}) ([]interface{}, error) + Call16 func(functionName string, args interface{}) ([]interface{}, error) + Call16Async func(functionName string, args interface{}) *Future + Call16Typed func(functionName string, args interface{}, result interface{}) error + Call17 func(functionName string, args interface{}) ([]interface{}, error) + Call17Async func(functionName string, args interface{}) *Future + Call17Typed func(functionName string, args interface{}, result interface{}) error + CallAsync func(functionName string, args interface{}) *Future + CallTyped func(functionName string, args interface{}, result interface{}) error + Close func() error + ConfiguredTimeout func() time.Duration + ConnectedNow func() bool + Delete func(space, index interface{}, key interface{}) ([]interface{}, error) + DeleteAsync func(space, index interface{}, key interface{}) *Future + DeleteTyped func(space, index interface{}, key interface{}, result interface{}) error + Eval func(expr string, args interface{}) ([]interface{}, error) + EvalAsync func(expr string, args interface{}) *Future + EvalTyped func(expr string, args interface{}, result interface{}) error + Execute func(expr string, args interface{}) ([]interface{}, error) + ExecuteAsync func(expr string, args interface{}) *Future + ExecuteTyped func(expr string, args interface{}, result interface{}) (SQLInfo, []ColumnMetaData, error) + GetTyped func(space, index interface{}, key interface{}, result interface{}) error + Insert func(space interface{}, tuple interface{}) ([]interface{}, error) + InsertAsync func(space interface{}, tuple interface{}) *Future + InsertTyped func(space interface{}, tuple interface{}, result interface{}) error + NewPrepared func(expr string) (*Prepared, error) + NewStream func() (*Stream, error) + NewWatcher func(key string, callback WatchCallback) (Watcher, error) + Ping func() ([]interface{}, error) + Replace func(space interface{}, tuple interface{}) ([]interface{}, error) + ReplaceAsync func(space interface{}, tuple interface{}) *Future + ReplaceTyped func(space interface{}, tuple interface{}, result interface{}) error + Select func(space, index interface{}, offset, limit uint32, iterator Iter, key interface{}) ([]interface{}, error) + SelectAsync func(space, index interface{}, offset, limit uint32, iterator Iter, key interface{}) *Future + SelectTyped func(space, index interface{}, offset, limit uint32, iterator Iter, key interface{}, ...) error + Update func(space, index interface{}, key interface{}, ops *Operations) ([]interface{}, error) + UpdateAsync func(space, index interface{}, key interface{}, ops *Operations) *Future + UpdateTyped func(space, index interface{}, key interface{}, ops *Operations, result interface{}) error + Upsert func(space interface{}, tuple interface{}, ops *Operations) ([]interface{}, error) + UpsertAsync func(space interface{}, tuple interface{}, ops *Operations) *Future + type DeleteRequest struct + func NewDeleteRequest(space interface{}) *DeleteRequest + func (req *DeleteRequest) Body(res SchemaResolver, enc *msgpack.Encoder) error + func (req *DeleteRequest) Context(ctx context.Context) *DeleteRequest + func (req *DeleteRequest) Index(index interface{}) *DeleteRequest + func (req *DeleteRequest) Key(key interface{}) *DeleteRequest + type DialOpts struct + IoTimeout time.Duration + type Dialer interface + Dial func(ctx context.Context, opts DialOpts) (Conn, error) + type Doer interface + Do func(req Request) (fut *Future) + type Error struct + Code iproto.Error + ExtendedInfo *BoxError + Msg string + func (tnterr Error) Error() string + type EvalRequest struct + func NewEvalRequest(expr string) *EvalRequest + func (req *EvalRequest) Args(args interface{}) *EvalRequest + func (req *EvalRequest) Async() bool + func (req *EvalRequest) Body(res SchemaResolver, enc *msgpack.Encoder) error + func (req *EvalRequest) Context(ctx context.Context) *EvalRequest + func (req *EvalRequest) Ctx() context.Context + func (req *EvalRequest) Response(header Header, body io.Reader) (Response, error) + func (req *EvalRequest) Type() iproto.Type + type ExecutePreparedRequest struct + func NewExecutePreparedRequest(stmt *Prepared) *ExecutePreparedRequest + func (req *ExecutePreparedRequest) Args(args interface{}) *ExecutePreparedRequest + func (req *ExecutePreparedRequest) Async() bool + func (req *ExecutePreparedRequest) Body(res SchemaResolver, enc *msgpack.Encoder) error + func (req *ExecutePreparedRequest) Conn() *Connection + func (req *ExecutePreparedRequest) Context(ctx context.Context) *ExecutePreparedRequest + func (req *ExecutePreparedRequest) Ctx() context.Context + func (req *ExecutePreparedRequest) Response(header Header, body io.Reader) (Response, error) + func (req *ExecutePreparedRequest) Type() iproto.Type + type ExecuteRequest struct + func NewExecuteRequest(expr string) *ExecuteRequest + func (req *ExecuteRequest) Args(args interface{}) *ExecuteRequest + func (req *ExecuteRequest) Async() bool + func (req *ExecuteRequest) Body(res SchemaResolver, enc *msgpack.Encoder) error + func (req *ExecuteRequest) Context(ctx context.Context) *ExecuteRequest + func (req *ExecuteRequest) Ctx() context.Context + func (req *ExecuteRequest) Response(header Header, body io.Reader) (Response, error) + func (req *ExecuteRequest) Type() iproto.Type + type ExecuteResponse struct + func (resp *ExecuteResponse) Decode() ([]interface{}, error) + func (resp *ExecuteResponse) DecodeTyped(res interface{}) error + func (resp *ExecuteResponse) Header() Header + func (resp *ExecuteResponse) MetaData() ([]ColumnMetaData, error) + func (resp *ExecuteResponse) SQLInfo() (SQLInfo, error) + func (resp *ExecuteResponse) String() (str string) + type FdDialer struct + Fd uintptr + RequiredProtocolInfo ProtocolInfo + func (d FdDialer) Dial(ctx context.Context, opts DialOpts) (Conn, error) + type Field struct + Id uint32 + IsNullable bool + Name string + Type string + func (field *Field) DecodeMsgpack(d *msgpack.Decoder) error + type Future struct + func NewFuture(req Request) (fut *Future) + func (fut *Future) AppendPush(header Header, body io.Reader) error + func (fut *Future) Get() ([]interface{}, error) + func (fut *Future) GetIterator() (it TimeoutResponseIterator) + func (fut *Future) GetResponse() (Response, error) + func (fut *Future) GetTyped(result interface{}) error + func (fut *Future) SetError(err error) + func (fut *Future) SetResponse(header Header, body io.Reader) error + func (fut *Future) WaitChan() <-chan struct{} + type Greeting struct + Salt string + Version string + type GreetingDialer struct + Dialer Dialer + func (d GreetingDialer) Dial(ctx context.Context, opts DialOpts) (Conn, error) + type Header struct + Error iproto.Error + RequestId uint32 + type IdRequest struct + func NewIdRequest(protocolInfo ProtocolInfo) *IdRequest + func (req *IdRequest) Async() bool + func (req *IdRequest) Body(res SchemaResolver, enc *msgpack.Encoder) error + func (req *IdRequest) Context(ctx context.Context) *IdRequest + func (req *IdRequest) Ctx() context.Context + func (req *IdRequest) Response(header Header, body io.Reader) (Response, error) + func (req *IdRequest) Type() iproto.Type + type Index struct + Fields []IndexField + Id uint32 + Name string + SpaceId uint32 + Type string + Unique bool + func (index *Index) DecodeMsgpack(d *msgpack.Decoder) error + type IndexField struct + Id uint32 + Type string + func (indexField *IndexField) DecodeMsgpack(d *msgpack.Decoder) error + type InsertRequest struct + func NewInsertRequest(space interface{}) *InsertRequest + func (req *InsertRequest) Body(res SchemaResolver, enc *msgpack.Encoder) error + func (req *InsertRequest) Context(ctx context.Context) *InsertRequest + func (req *InsertRequest) Tuple(tuple interface{}) *InsertRequest + type IntIntKey struct + I1 int + I2 int + func (k IntIntKey) EncodeMsgpack(enc *msgpack.Encoder) error + type IntKey struct + I int + func (k IntKey) EncodeMsgpack(enc *msgpack.Encoder) error + type Iter uint32 + const IterAll + const IterBitsAllNotSet + const IterBitsAllSet + const IterBitsAnySet + const IterEq + const IterGe + const IterGt + const IterLe + const IterLt + const IterNeighbor + const IterOverlaps + const IterReq + type KeyValueBind struct + Key string + Value interface{} + type Logger interface + Report func(event ConnLogKind, conn *Connection, v ...interface{}) + type NetDialer struct + Address string + Password string + RequiredProtocolInfo ProtocolInfo + User string + func (d NetDialer) Dial(ctx context.Context, opts DialOpts) (Conn, error) + type Operations struct + func NewOperations() *Operations + func (ops *Operations) Add(field int, arg interface{}) *Operations + func (ops *Operations) Assign(field int, arg interface{}) *Operations + func (ops *Operations) BitwiseAnd(field int, arg interface{}) *Operations + func (ops *Operations) BitwiseOr(field int, arg interface{}) *Operations + func (ops *Operations) BitwiseXor(field int, arg interface{}) *Operations + func (ops *Operations) Delete(field int, arg interface{}) *Operations + func (ops *Operations) EncodeMsgpack(enc *msgpack.Encoder) error + func (ops *Operations) Insert(field int, arg interface{}) *Operations + func (ops *Operations) Splice(field, pos, len int, replace string) *Operations + func (ops *Operations) Subtract(field int, arg interface{}) *Operations + type Opts struct + Concurrency uint32 + Handle interface{} + Logger Logger + MaxReconnects uint + Notify chan<- ConnEvent + RLimitAction RLimitAction + RateLimit uint + Reconnect time.Duration + SkipSchema bool + Timeout time.Duration + type PingRequest struct + func NewPingRequest() *PingRequest + func (req *PingRequest) Async() bool + func (req *PingRequest) Body(res SchemaResolver, enc *msgpack.Encoder) error + func (req *PingRequest) Context(ctx context.Context) *PingRequest + func (req *PingRequest) Ctx() context.Context + func (req *PingRequest) Response(header Header, body io.Reader) (Response, error) + func (req *PingRequest) Type() iproto.Type + type PrepareRequest struct + func NewPrepareRequest(expr string) *PrepareRequest + func (req *PrepareRequest) Async() bool + func (req *PrepareRequest) Body(res SchemaResolver, enc *msgpack.Encoder) error + func (req *PrepareRequest) Context(ctx context.Context) *PrepareRequest + func (req *PrepareRequest) Ctx() context.Context + func (req *PrepareRequest) Response(header Header, body io.Reader) (Response, error) + func (req *PrepareRequest) Type() iproto.Type + type PrepareResponse ExecuteResponse + type Prepared struct + Conn *Connection + MetaData []ColumnMetaData + ParamCount uint64 + StatementID PreparedID + func NewPreparedFromResponse(conn *Connection, resp Response) (*Prepared, error) + type PreparedID uint64 + type ProtocolDialer struct + Dialer Dialer + RequiredProtocolInfo ProtocolInfo + func (d ProtocolDialer) Dial(ctx context.Context, opts DialOpts) (Conn, error) + type ProtocolInfo struct + Auth Auth + Features []iproto.Feature + Version ProtocolVersion + func (info ProtocolInfo) Clone() ProtocolInfo + type ProtocolVersion uint64 + type PushResponse struct + func (resp *PushResponse) Decode() ([]interface{}, error) + func (resp *PushResponse) DecodeTyped(res interface{}) error + func (resp *PushResponse) Header() Header + func (resp *PushResponse) String() (str string) + type RLimitAction int + const RLimitDrop + const RLimitWait + type ReplaceRequest struct + func NewReplaceRequest(space interface{}) *ReplaceRequest + func (req *ReplaceRequest) Body(res SchemaResolver, enc *msgpack.Encoder) error + func (req *ReplaceRequest) Context(ctx context.Context) *ReplaceRequest + func (req *ReplaceRequest) Tuple(tuple interface{}) *ReplaceRequest + type Request interface + Async func() bool + Body func(resolver SchemaResolver, enc *msgpack.Encoder) error + Ctx func() context.Context + Response func(header Header, body io.Reader) (Response, error) + Type func() iproto.Type + type Response interface + Decode func() ([]interface{}, error) + DecodeTyped func(res interface{}) error + Header func() Header + type ResponseIterator interface + Err func() error + IsPush func() bool + Next func() bool + Value func() Response + type RollbackRequest struct + func NewRollbackRequest() *RollbackRequest + func (req *RollbackRequest) Async() bool + func (req *RollbackRequest) Body(res SchemaResolver, enc *msgpack.Encoder) error + func (req *RollbackRequest) Context(ctx context.Context) *RollbackRequest + func (req *RollbackRequest) Ctx() context.Context + func (req *RollbackRequest) Response(header Header, body io.Reader) (Response, error) + func (req *RollbackRequest) Type() iproto.Type + type SQLInfo struct + AffectedCount uint64 + InfoAutoincrementIds []uint64 + func (info *SQLInfo) DecodeMsgpack(d *msgpack.Decoder) error + type Schema struct + Spaces map[string]Space + SpacesById map[uint32]Space + Version uint + func GetSchema(doer Doer) (Schema, error) + type SchemaResolver interface + NamesUseSupported func() bool + ResolveIndex func(i interface{}, spaceNo uint32) (indexNo uint32, err error) + ResolveSpace func(s interface{}) (spaceNo uint32, err error) + type SelectRequest struct + func NewSelectRequest(space interface{}) *SelectRequest + func (req *SelectRequest) After(after interface{}) *SelectRequest + func (req *SelectRequest) Body(res SchemaResolver, enc *msgpack.Encoder) error + func (req *SelectRequest) Context(ctx context.Context) *SelectRequest + func (req *SelectRequest) FetchPos(fetch bool) *SelectRequest + func (req *SelectRequest) Index(index interface{}) *SelectRequest + func (req *SelectRequest) Iterator(iterator Iter) *SelectRequest + func (req *SelectRequest) Key(key interface{}) *SelectRequest + func (req *SelectRequest) Limit(limit uint32) *SelectRequest + func (req *SelectRequest) Offset(offset uint32) *SelectRequest + func (req *SelectRequest) Response(header Header, body io.Reader) (Response, error) + type SelectResponse struct + func (resp *SelectResponse) Decode() ([]interface{}, error) + func (resp *SelectResponse) DecodeTyped(res interface{}) error + func (resp *SelectResponse) Header() Header + func (resp *SelectResponse) Pos() ([]byte, error) + func (resp *SelectResponse) String() (str string) + type Space struct + Engine string + Fields map[string]Field + FieldsById map[uint32]Field + FieldsCount uint32 + Id uint32 + Indexes map[string]Index + IndexesById map[uint32]Index + Name string + Temporary bool + func (space *Space) DecodeMsgpack(d *msgpack.Decoder) error + type Stream struct + Conn *Connection + Id uint64 + func (s *Stream) Do(req Request) *Future + type StringKey struct + S string + func (k StringKey) EncodeMsgpack(enc *msgpack.Encoder) error + type TimeoutResponseIterator interface + WithTimeout func(timeout time.Duration) TimeoutResponseIterator + type TxnIsolationLevel uint + const BestEffortLevel + const DefaultIsolationLevel + const ReadCommittedLevel + const ReadConfirmedLevel + type UintKey struct + I uint + func (k UintKey) EncodeMsgpack(enc *msgpack.Encoder) error + type UnprepareRequest struct + func NewUnprepareRequest(stmt *Prepared) *UnprepareRequest + func (req *UnprepareRequest) Async() bool + func (req *UnprepareRequest) Body(res SchemaResolver, enc *msgpack.Encoder) error + func (req *UnprepareRequest) Conn() *Connection + func (req *UnprepareRequest) Context(ctx context.Context) *UnprepareRequest + func (req *UnprepareRequest) Ctx() context.Context + func (req *UnprepareRequest) Response(header Header, body io.Reader) (Response, error) + func (req *UnprepareRequest) Type() iproto.Type + type UpdateRequest struct + func NewUpdateRequest(space interface{}) *UpdateRequest + func (req *UpdateRequest) Body(res SchemaResolver, enc *msgpack.Encoder) error + func (req *UpdateRequest) Context(ctx context.Context) *UpdateRequest + func (req *UpdateRequest) Index(index interface{}) *UpdateRequest + func (req *UpdateRequest) Key(key interface{}) *UpdateRequest + func (req *UpdateRequest) Operations(ops *Operations) *UpdateRequest + type UpsertRequest struct + func NewUpsertRequest(space interface{}) *UpsertRequest + func (req *UpsertRequest) Body(res SchemaResolver, enc *msgpack.Encoder) error + func (req *UpsertRequest) Context(ctx context.Context) *UpsertRequest + func (req *UpsertRequest) Operations(ops *Operations) *UpsertRequest + func (req *UpsertRequest) Tuple(tuple interface{}) *UpsertRequest + type WatchCallback func(event WatchEvent) + type WatchEvent struct + Conn *Connection + Key string + Value interface{} + type WatchOnceRequest struct + func NewWatchOnceRequest(key string) *WatchOnceRequest + func (req *WatchOnceRequest) Async() bool + func (req *WatchOnceRequest) Body(res SchemaResolver, enc *msgpack.Encoder) error + func (req *WatchOnceRequest) Context(ctx context.Context) *WatchOnceRequest + func (req *WatchOnceRequest) Ctx() context.Context + func (req *WatchOnceRequest) Response(header Header, body io.Reader) (Response, error) + func (req *WatchOnceRequest) Type() iproto.Type + type Watcher interface + Unregister func() Other modules containing this package github.com/tarantool/go-tarantool