Documentation
      ¶
    
    
  
    
  
    Index ¶
- Constants
 - Variables
 - func BootstrapSession(store kv.Storage) (*domain.Domain, error)
 - func Compile(ctx context.Context, stmtNode ast.StmtNode) (ast.Statement, error)
 - func DialPumpClientWithRetry(binlogSocket string, maxRetries int, dialerOpt grpc.DialOption) (*grpc.ClientConn, error)
 - func GetRows(rs ast.RecordSet) ([][]types.Datum, error)
 - func IsQuery(sql string) bool
 - func NewStore(path string) (kv.Storage, error)
 - func Parse(ctx context.Context, src string) ([]ast.StmtNode, error)
 - func RegisterLocalStore(name string, driver engine.Driver) error
 - func RegisterStore(name string, driver kv.Driver) error
 - func SetCommitRetryLimit(limit int)
 - func SetSchemaLease(lease time.Duration)
 - func SetStatsLease(lease time.Duration)
 - type Session
 - type StmtHistory
 
Constants ¶
const ( // CreateUserTable is the SQL statement creates User table in system db. CreateUserTable = `` /* 1365-byte string literal not displayed */ // CreateDBPrivTable is the SQL statement creates DB scope privilege table in system db. CreateDBPrivTable = `` /* 1127-byte string literal not displayed */ // CreateTablePrivTable is the SQL statement creates table scope privilege table in system db. CreateTablePrivTable = `` /* 380-byte string literal not displayed */ // CreateColumnPrivTable is the SQL statement creates column scope privilege table in system db. CreateColumnPrivTable = `` /* 300-byte string literal not displayed */ // CreateGloablVariablesTable is the SQL statement creates global variable table in system db. // TODO: MySQL puts GLOBAL_VARIABLES table in INFORMATION_SCHEMA db. // INFORMATION_SCHEMA is a virtual db in TiDB. So we put this table in system db. // Maybe we will put it back to INFORMATION_SCHEMA. CreateGloablVariablesTable = `` /* 147-byte string literal not displayed */ // CreateTiDBTable is the SQL statement creates a table in system db. // This table is a key-value struct contains some information used by TiDB. // Currently we only put bootstrapped in it which indicates if the system is already bootstrapped. CreateTiDBTable = `` /* 160-byte string literal not displayed */ // CreateHelpTopic is the SQL statement creates help_topic table in system db. // See: https://dev.mysql.com/doc/refman/5.5/en/system-database.html#system-database-help-tables CreateHelpTopic = `` /* 392-byte string literal not displayed */ // CreateStatsMetaTable stores the meta of table statistics. CreateStatsMetaTable = `` /* 270-byte string literal not displayed */ // CreateStatsColsTable stores the statistics of table columns. CreateStatsColsTable = `` /* 376-byte string literal not displayed */ // CreateStatsBucketsTable stores the histogram info for every table columns. CreateStatsBucketsTable = `` /* 349-byte string literal not displayed */ // CreateGCDeleteRangeTable stores schemas which can be deleted by DeleteRange. CreateGCDeleteRangeTable = `` /* 390-byte string literal not displayed */ )
const (
	EngineGoLevelDBMemory = "memory://"
)
    Engine prefix name
Variables ¶
var ( // SchemaOutOfDateRetryInterval is the sleeping time when we fail to try. SchemaOutOfDateRetryInterval = int64(500 * time.Millisecond) // SchemaOutOfDateRetryTimes is upper bound of retry times when the schema is out of date. SchemaOutOfDateRetryTimes = int32(10) )
var SchemaChangedWithoutRetry bool
    SchemaChangedWithoutRetry is used for testing.
Functions ¶
func BootstrapSession ¶
BootstrapSession runs the first time when the TiDB server start.
func Compile ¶
Compile is safe for concurrent use by multiple goroutines.
func DialPumpClientWithRetry ¶
func DialPumpClientWithRetry(binlogSocket string, maxRetries int, dialerOpt grpc.DialOption) (*grpc.ClientConn, error)
DialPumpClientWithRetry tries to dial to binlogSocket, if any error happens, it will try to re-dial, or return this error when timeout.
func GetRows ¶
GetRows gets all the rows from a RecordSet.
func IsQuery ¶
IsQuery checks if a sql statement is a query statement.
func NewStore ¶
NewStore creates a kv Storage with path.
The path must be a URL format 'engine://path?params' like the one for tidb.Open() but with the dbname cut off. Examples:
goleveldb://relative/path boltdb:///absolute/path
The engine should be registered before creating storage.
func Parse ¶
Parse parses a query string to raw ast.StmtNode.
func RegisterLocalStore ¶
RegisterLocalStore registers a local kv storage with unique name and its associated engine Driver.
func RegisterStore ¶
RegisterStore registers a kv storage with unique name and its associated Driver.
func SetCommitRetryLimit ¶
func SetCommitRetryLimit(limit int)
SetCommitRetryLimit setups the maximum number of retries when trying to recover from retryable errors. Retryable errors are generally refer to temporary errors that are expected to be reinstated by retry, including network interruption, transaction conflicts, and so on.
func SetSchemaLease ¶
SetSchemaLease changes the default schema lease time for DDL. This function is very dangerous, don't use it if you really know what you do. SetSchemaLease only affects not local storage after bootstrapped.
Types ¶
type Session ¶
type Session interface {
	context.Context
	Status() uint16                              // Flag of current status, such as autocommit.
	LastInsertID() uint64                        // LastInsertID is the last inserted auto_increment ID.
	AffectedRows() uint64                        // Affected rows by latest executed stmt.
	Execute(sql string) ([]ast.RecordSet, error) // Execute a sql statement.
	String() string                              // String is used to debug.
	CommitTxn() error
	RollbackTxn() error
	// PrepareStmt executes prepare statement in binary protocol.
	PrepareStmt(sql string) (stmtID uint32, paramCount int, fields []*ast.ResultField, err error)
	// ExecutePreparedStmt executes a prepared statement.
	ExecutePreparedStmt(stmtID uint32, param ...interface{}) (ast.RecordSet, error)
	DropPreparedStmt(stmtID uint32) error
	SetClientCapability(uint32) // Set client capability flags.
	SetConnectionID(uint64)
	SetTLSState(*tls.ConnectionState)
	SetCollation(coID int) error
	SetSessionManager(util.SessionManager)
	Close()
	Auth(user *auth.UserIdentity, auth []byte, salt []byte) bool
	// Cancel the execution of current transaction.
	Cancel()
	ShowProcess() util.ProcessInfo
	// PrePareTxnCtx is exported for test.
	PrepareTxnCtx()
}
    Session context
type StmtHistory ¶
type StmtHistory struct {
	// contains filtered or unexported fields
}
    StmtHistory holds all histories of statements in a txn.
func GetHistory ¶
func GetHistory(ctx context.Context) *StmtHistory
GetHistory get all stmtHistory in current txn. Exported only for test.
func (*StmtHistory) Add ¶
func (h *StmtHistory) Add(stmtID uint32, st ast.Statement, stmtCtx *variable.StatementContext, params ...interface{})
Add appends a stmt to history list.
      
      Source Files
      ¶
    
- bootstrap.go
 - metrics.go
 - session.go
 - tidb.go
 
      
      Directories
      ¶
    
    | Path | Synopsis | 
|---|---|
| 
       _vendor
        | 
      |
| 
         
          
            src/github.com/BurntSushi/toml
            
            
          
           
      Package toml provides facilities for decoding and encoding TOML configuration files via reflection. 
         | 
      Package toml provides facilities for decoding and encoding TOML configuration files via reflection. | 
| 
         
          
            src/github.com/Sirupsen/logrus
            
            
          
           
      Package logrus is a structured logger for Go, completely API compatible with the standard library logger. 
         | 
      Package logrus is a structured logger for Go, completely API compatible with the standard library logger. | 
| 
         
          
            src/github.com/beorn7/perks/quantile
            
            
          
           
      Package quantile computes approximate quantiles over an unbounded data stream within low memory and CPU bounds. 
         | 
      Package quantile computes approximate quantiles over an unbounded data stream within low memory and CPU bounds. | 
| 
         
          
            src/github.com/boltdb/bolt
            
            
          
           
      Package bolt implements a low-level key/value store in pure Go. 
         | 
      Package bolt implements a low-level key/value store in pure Go. | 
| 
         
          
            src/github.com/codahale/hdrhistogram
            
            
          
           
      Package hdrhistogram provides an implementation of Gil Tene's HDR Histogram data structure. 
         | 
      Package hdrhistogram provides an implementation of Gil Tene's HDR Histogram data structure. | 
| 
         
          
            src/github.com/coreos/etcd/auth/authpb
            
            
          
           
      Package authpb is a generated protocol buffer package. 
         | 
      Package authpb is a generated protocol buffer package. | 
| 
         
          
            src/github.com/coreos/etcd/clientv3
            
            
          
           
      Package clientv3 implements the official Go etcd client for v3. 
         | 
      Package clientv3 implements the official Go etcd client for v3. | 
| 
         
          
            src/github.com/coreos/etcd/clientv3/concurrency
            
            
          
           
      Package concurrency implements concurrency operations on top of etcd such as distributed locks, barriers, and elections. 
         | 
      Package concurrency implements concurrency operations on top of etcd such as distributed locks, barriers, and elections. | 
| 
         
          
            src/github.com/coreos/etcd/etcdserver/api/v3rpc/rpctypes
            
            
          
           
      Package rpctypes has types and values shared by the etcd server and client for v3 RPC interaction. 
         | 
      Package rpctypes has types and values shared by the etcd server and client for v3 RPC interaction. | 
| 
         
          
            src/github.com/coreos/etcd/etcdserver/etcdserverpb
            
            
          
           
      Package etcdserverpb is a generated protocol buffer package. 
         | 
      Package etcdserverpb is a generated protocol buffer package. | 
| 
         
          
            src/github.com/coreos/etcd/mvcc/mvccpb
            
            
          
           
      Package mvccpb is a generated protocol buffer package. 
         | 
      Package mvccpb is a generated protocol buffer package. | 
| 
         
          
            src/github.com/cznic/golex/lex
            
            
          
           
      Package lex is a Unicode-friendly run time library for golex[0] generated lexical analyzers[1]. 
         | 
      Package lex is a Unicode-friendly run time library for golex[0] generated lexical analyzers[1]. | 
| 
         
          
            src/github.com/cznic/mathutil
            
            
          
           
      Package mathutil provides utilities supplementing the standard 'math' and 'math/rand' packages. 
         | 
      Package mathutil provides utilities supplementing the standard 'math' and 'math/rand' packages. | 
| 
         
          
            src/github.com/cznic/parser/yacc
            
            
          
           
      Package parser implements a parser for yacc source files. 
         | 
      Package parser implements a parser for yacc source files. | 
| 
         
          
            src/github.com/cznic/sortutil
            
            
          
           
      Package sortutil provides utilities supplementing the standard 'sort' package. 
         | 
      Package sortutil provides utilities supplementing the standard 'sort' package. | 
| 
         
          
            src/github.com/cznic/strutil
            
            
          
           
      Package strutil collects utils supplemental to the standard strings package. 
         | 
      Package strutil collects utils supplemental to the standard strings package. | 
| 
         
          
            src/github.com/cznic/y
            
            
          
           
      Package y converts .y (yacc[2]) source files to data suitable for a parser generator. 
         | 
      Package y converts .y (yacc[2]) source files to data suitable for a parser generator. | 
| 
         
          
            src/github.com/go-sql-driver/mysql
            
            
          
           
      Package mysql provides a MySQL driver for Go's database/sql package. 
         | 
      Package mysql provides a MySQL driver for Go's database/sql package. | 
| 
         
          
            src/github.com/golang/protobuf/proto
            
            
          
           
      Package proto converts data structures to and from the wire format of protocol buffers. 
         | 
      Package proto converts data structures to and from the wire format of protocol buffers. | 
| 
         
          
            src/github.com/golang/protobuf/ptypes/any
            
            
          
           
      Package any is a generated protocol buffer package. 
         | 
      Package any is a generated protocol buffer package. | 
| 
         
          
            src/github.com/golang/snappy
            
            
          
           
      Package snappy implements the snappy block-based compression format. 
         | 
      Package snappy implements the snappy block-based compression format. | 
| 
         
          
            src/github.com/gorilla/context
            
            
          
           
      Package context stores values shared during a request lifetime. 
         | 
      Package context stores values shared during a request lifetime. | 
| 
         
          
            src/github.com/gorilla/mux
            
            
          
           
      Package mux implements a request router and dispatcher. 
         | 
      Package mux implements a request router and dispatcher. | 
| 
         
          
            src/github.com/grpc-ecosystem/go-grpc-middleware
            
            
          
           
      `grpc_middleware` is a collection of gRPC middleware packages: interceptors, helpers and tools. 
         | 
      `grpc_middleware` is a collection of gRPC middleware packages: interceptors, helpers and tools. | 
| 
         
          
            src/github.com/grpc-ecosystem/go-grpc-middleware/tags
            
            
          
           
      `grpc_ctxtags` adds a Tag object to the context that can be used by other middleware to add context about a request. 
         | 
      `grpc_ctxtags` adds a Tag object to the context that can be used by other middleware to add context about a request. | 
| 
         
          
            src/github.com/grpc-ecosystem/go-grpc-middleware/tracing/opentracing
            
            
          
           
      `grpc_opentracing` adds OpenTracing 
         | 
      `grpc_opentracing` adds OpenTracing | 
| 
         
          
            src/github.com/juju/errors
            
            
          
           
      [godoc-link-here] 
         | 
      [godoc-link-here] | 
| 
         
          
            src/github.com/matttproud/golang_protobuf_extensions/pbutil
            
            
          
           
      Package pbutil provides record length-delimited Protocol Buffer streaming. 
         | 
      Package pbutil provides record length-delimited Protocol Buffer streaming. | 
| 
         
          
            src/github.com/ngaut/pools
            
            
          
           
      Package pools provides functionality to manage and reuse resources like connections. 
         | 
      Package pools provides functionality to manage and reuse resources like connections. | 
| 
         
          
            src/github.com/petar/GoLLRB/llrb
            
            
          
           
      A Left-Leaning Red-Black (LLRB) implementation of 2-3 balanced binary search trees, based on the following work: 
         | 
      A Left-Leaning Red-Black (LLRB) implementation of 2-3 balanced binary search trees, based on the following work: | 
| 
         
          
            src/github.com/pingcap/check
            
            
          
           
      Package check is a rich testing extension for Go's testing package. 
         | 
      Package check is a rich testing extension for Go's testing package. | 
| 
         
          
            src/github.com/pingcap/goleveldb/leveldb
            
            
          
           
      Package leveldb provides implementation of LevelDB key/value database. 
         | 
      Package leveldb provides implementation of LevelDB key/value database. | 
| 
         
          
            src/github.com/pingcap/goleveldb/leveldb/cache
            
            
          
           
      Package cache provides interface and implementation of a cache algorithms. 
         | 
      Package cache provides interface and implementation of a cache algorithms. | 
| 
         
          
            src/github.com/pingcap/goleveldb/leveldb/comparer
            
            
          
           
      Package comparer provides interface and implementation for ordering sets of data. 
         | 
      Package comparer provides interface and implementation for ordering sets of data. | 
| 
         
          
            src/github.com/pingcap/goleveldb/leveldb/errors
            
            
          
           
      Package errors provides common error types used throughout leveldb. 
         | 
      Package errors provides common error types used throughout leveldb. | 
| 
         
          
            src/github.com/pingcap/goleveldb/leveldb/filter
            
            
          
           
      Package filter provides interface and implementation of probabilistic data structure. 
         | 
      Package filter provides interface and implementation of probabilistic data structure. | 
| 
         
          
            src/github.com/pingcap/goleveldb/leveldb/iterator
            
            
          
           
      Package iterator provides interface and implementation to traverse over contents of a database. 
         | 
      Package iterator provides interface and implementation to traverse over contents of a database. | 
| 
         
          
            src/github.com/pingcap/goleveldb/leveldb/journal
            
            
          
           
      Package journal reads and writes sequences of journals. 
         | 
      Package journal reads and writes sequences of journals. | 
| 
         
          
            src/github.com/pingcap/goleveldb/leveldb/memdb
            
            
          
           
      Package memdb provides in-memory key/value database implementation. 
         | 
      Package memdb provides in-memory key/value database implementation. | 
| 
         
          
            src/github.com/pingcap/goleveldb/leveldb/opt
            
            
          
           
      Package opt provides sets of options used by LevelDB. 
         | 
      Package opt provides sets of options used by LevelDB. | 
| 
         
          
            src/github.com/pingcap/goleveldb/leveldb/storage
            
            
          
           
      Package storage provides storage abstraction for LevelDB. 
         | 
      Package storage provides storage abstraction for LevelDB. | 
| 
         
          
            src/github.com/pingcap/goleveldb/leveldb/table
            
            
          
           
      Package table allows read and write sorted key/value. 
         | 
      Package table allows read and write sorted key/value. | 
| 
         
          
            src/github.com/pingcap/goleveldb/leveldb/util
            
            
          
           
      Package util provides utilities used throughout leveldb. 
         | 
      Package util provides utilities used throughout leveldb. | 
| 
         
          
            src/github.com/pingcap/kvproto/pkg/coprocessor
            
            
          
           
      Package coprocessor is a generated protocol buffer package. 
         | 
      Package coprocessor is a generated protocol buffer package. | 
| 
         
          
            src/github.com/pingcap/kvproto/pkg/eraftpb
            
            
          
           
      Package eraftpb is a generated protocol buffer package. 
         | 
      Package eraftpb is a generated protocol buffer package. | 
| 
         
          
            src/github.com/pingcap/kvproto/pkg/errorpb
            
            
          
           
      Package errorpb is a generated protocol buffer package. 
         | 
      Package errorpb is a generated protocol buffer package. | 
| 
         
          
            src/github.com/pingcap/kvproto/pkg/kvrpcpb
            
            
          
           
      Package kvrpcpb is a generated protocol buffer package. 
         | 
      Package kvrpcpb is a generated protocol buffer package. | 
| 
         
          
            src/github.com/pingcap/kvproto/pkg/metapb
            
            
          
           
      Package metapb is a generated protocol buffer package. 
         | 
      Package metapb is a generated protocol buffer package. | 
| 
         
          
            src/github.com/pingcap/kvproto/pkg/pdpb
            
            
          
           
      Package pdpb is a generated protocol buffer package. 
         | 
      Package pdpb is a generated protocol buffer package. | 
| 
         
          
            src/github.com/pingcap/kvproto/pkg/raft_serverpb
            
            
          
           
      Package raft_serverpb is a generated protocol buffer package. 
         | 
      Package raft_serverpb is a generated protocol buffer package. | 
| 
         
          
            src/github.com/pingcap/kvproto/pkg/tikvpb
            
            
          
           
      Package tikvpb is a generated protocol buffer package. 
         | 
      Package tikvpb is a generated protocol buffer package. | 
| 
         
          
            src/github.com/pingcap/tipb/go-binlog
            
            
          
           
      Package binlog is a generated protocol buffer package. 
         | 
      Package binlog is a generated protocol buffer package. | 
| 
         
          
            src/github.com/pingcap/tipb/go-mysqlx
            
            
          
           
      Package Mysqlx is a generated protocol buffer package. 
         | 
      Package Mysqlx is a generated protocol buffer package. | 
| 
         
          
            src/github.com/pingcap/tipb/go-mysqlx/Connection
            
            
          
           
      Package Mysqlx_Connection is a generated protocol buffer package. 
         | 
      Package Mysqlx_Connection is a generated protocol buffer package. | 
| 
         
          
            src/github.com/pingcap/tipb/go-mysqlx/Crud
            
            
          
           
      Package Mysqlx_Crud is a generated protocol buffer package. 
         | 
      Package Mysqlx_Crud is a generated protocol buffer package. | 
| 
         
          
            src/github.com/pingcap/tipb/go-mysqlx/Datatypes
            
            
          
           
      Package Mysqlx_Datatypes is a generated protocol buffer package. 
         | 
      Package Mysqlx_Datatypes is a generated protocol buffer package. | 
| 
         
          
            src/github.com/pingcap/tipb/go-mysqlx/Expect
            
            
          
           
      Package Mysqlx_Expect is a generated protocol buffer package. 
         | 
      Package Mysqlx_Expect is a generated protocol buffer package. | 
| 
         
          
            src/github.com/pingcap/tipb/go-mysqlx/Expr
            
            
          
           
      Package Mysqlx_Expr is a generated protocol buffer package. 
         | 
      Package Mysqlx_Expr is a generated protocol buffer package. | 
| 
         
          
            src/github.com/pingcap/tipb/go-mysqlx/Notice
            
            
          
           
      Package Mysqlx_Notice is a generated protocol buffer package. 
         | 
      Package Mysqlx_Notice is a generated protocol buffer package. | 
| 
         
          
            src/github.com/pingcap/tipb/go-mysqlx/Resultset
            
            
          
           
      Package Mysqlx_Resultset is a generated protocol buffer package. 
         | 
      Package Mysqlx_Resultset is a generated protocol buffer package. | 
| 
         
          
            src/github.com/pingcap/tipb/go-mysqlx/Session
            
            
          
           
      Package Mysqlx_Session is a generated protocol buffer package. 
         | 
      Package Mysqlx_Session is a generated protocol buffer package. | 
| 
         
          
            src/github.com/pingcap/tipb/go-mysqlx/Sql
            
            
          
           
      Package Mysqlx_Sql is a generated protocol buffer package. 
         | 
      Package Mysqlx_Sql is a generated protocol buffer package. | 
| 
         
          
            src/github.com/pingcap/tipb/go-tipb
            
            
          
           
      Package tipb is a generated protocol buffer package. 
         | 
      Package tipb is a generated protocol buffer package. | 
| 
         
          
            src/github.com/prometheus/client_golang/prometheus
            
            
          
           
      Package prometheus provides metrics primitives to instrument code for monitoring. 
         | 
      Package prometheus provides metrics primitives to instrument code for monitoring. | 
| 
         
          
            src/github.com/prometheus/client_golang/prometheus/push
            
            
          
           
      Package push provides functions to push metrics to a Pushgateway. 
         | 
      Package push provides functions to push metrics to a Pushgateway. | 
| 
         
          
            src/github.com/prometheus/client_model/go
            
            
          
           
      Package io_prometheus_client is a generated protocol buffer package. 
         | 
      Package io_prometheus_client is a generated protocol buffer package. | 
| 
         
          
            src/github.com/prometheus/common/expfmt
            
            
          
           
      A package for reading and writing Prometheus metrics. 
         | 
      A package for reading and writing Prometheus metrics. | 
| 
         
          
            src/github.com/prometheus/common/internal/bitbucket.org/ww/goautoneg
            
            
          
           
      HTTP Content-Type Autonegotiation. 
         | 
      HTTP Content-Type Autonegotiation. | 
| 
         
          
            src/github.com/prometheus/common/model
            
            
          
           
      Package model contains common data structures that are shared across Prometheus components and libraries. 
         | 
      Package model contains common data structures that are shared across Prometheus components and libraries. | 
| 
         
          
            src/github.com/prometheus/procfs
            
            
          
           
      Package procfs provides functions to retrieve system, kernel and process metrics from the pseudo-filesystem proc. 
         | 
      Package procfs provides functions to retrieve system, kernel and process metrics from the pseudo-filesystem proc. | 
| 
         
          
            src/github.com/spaolacci/murmur3
            
            
          
           
      Native (and fast) implementation of Austin Appleby's MurmurHash3. 
         | 
      Native (and fast) implementation of Austin Appleby's MurmurHash3. | 
| 
         
          
            src/github.com/twinj/uuid
            
            
          
           
      This package provides RFC4122 UUIDs. 
         | 
      This package provides RFC4122 UUIDs. | 
| 
         
          
            src/github.com/uber/jaeger-client-go
            
            
          
           
      Package jaeger implements an OpenTracing (http://opentracing.io) Tracer. 
         | 
      Package jaeger implements an OpenTracing (http://opentracing.io) Tracer. | 
| 
         
          
            src/github.com/uber/jaeger-client-go/rpcmetrics
            
            
          
           
      Package rpcmetrics implements an Observer that can be used to emit RPC metrics. 
         | 
      Package rpcmetrics implements an Observer that can be used to emit RPC metrics. | 
| 
         
          
            src/golang.org/x/net/context
            
            
          
           
      Package context defines the Context type, which carries deadlines, cancelation signals, and other request-scoped values across API boundaries and between processes. 
         | 
      Package context defines the Context type, which carries deadlines, cancelation signals, and other request-scoped values across API boundaries and between processes. | 
| 
         
          
            src/golang.org/x/net/http2
            
            
          
           
      Package http2 implements the HTTP/2 protocol. 
         | 
      Package http2 implements the HTTP/2 protocol. | 
| 
         
          
            src/golang.org/x/net/http2/hpack
            
            
          
           
      Package hpack implements HPACK, a compression format for efficiently representing HTTP header fields in the context of HTTP/2. 
         | 
      Package hpack implements HPACK, a compression format for efficiently representing HTTP header fields in the context of HTTP/2. | 
| 
         
          
            src/golang.org/x/net/idna
            
            
          
           
      Package idna implements IDNA2008 using the compatibility processing defined by UTS (Unicode Technical Standard) #46, which defines a standard to deal with the transition from IDNA2003. 
         | 
      Package idna implements IDNA2008 using the compatibility processing defined by UTS (Unicode Technical Standard) #46, which defines a standard to deal with the transition from IDNA2003. | 
| 
         
          
            src/golang.org/x/net/internal/timeseries
            
            
          
           
      Package timeseries implements a time series structure for stats collection. 
         | 
      Package timeseries implements a time series structure for stats collection. | 
| 
         
          
            src/golang.org/x/net/lex/httplex
            
            
          
           
      Package httplex contains rules around lexical matters of various HTTP-related specifications. 
         | 
      Package httplex contains rules around lexical matters of various HTTP-related specifications. | 
| 
         
          
            src/golang.org/x/net/trace
            
            
          
           
      Package trace implements tracing of requests and long-lived objects. 
         | 
      Package trace implements tracing of requests and long-lived objects. | 
| 
         
          
            src/golang.org/x/sys/unix
            
            
          
           
      Package unix contains an interface to the low-level operating system primitives. 
         | 
      Package unix contains an interface to the low-level operating system primitives. | 
| 
         
          
            src/golang.org/x/text/encoding
            
            
          
           
      Package encoding defines an interface for character encodings, such as Shift JIS and Windows 1252, that can convert to and from UTF-8. 
         | 
      Package encoding defines an interface for character encodings, such as Shift JIS and Windows 1252, that can convert to and from UTF-8. | 
| 
         
          
            src/golang.org/x/text/encoding/charmap
            
            
          
           
      Package charmap provides simple character encodings such as IBM Code Page 437 and Windows 1252. 
         | 
      Package charmap provides simple character encodings such as IBM Code Page 437 and Windows 1252. | 
| 
         
          
            src/golang.org/x/text/encoding/internal
            
            
          
           
      Package internal contains code that is shared among encoding implementations. 
         | 
      Package internal contains code that is shared among encoding implementations. | 
| 
         
          
            src/golang.org/x/text/encoding/internal/identifier
            
            
          
           
      Package identifier defines the contract between implementations of Encoding and Index by defining identifiers that uniquely identify standardized coded character sets (CCS) and character encoding schemes (CES), which we will together refer to as encodings, for which Encoding implementations provide converters to and from UTF-8. 
         | 
      Package identifier defines the contract between implementations of Encoding and Index by defining identifiers that uniquely identify standardized coded character sets (CCS) and character encoding schemes (CES), which we will together refer to as encodings, for which Encoding implementations provide converters to and from UTF-8. | 
| 
         
          
            src/golang.org/x/text/encoding/japanese
            
            
          
           
      Package japanese provides Japanese encodings such as EUC-JP and Shift JIS. 
         | 
      Package japanese provides Japanese encodings such as EUC-JP and Shift JIS. | 
| 
         
          
            src/golang.org/x/text/encoding/korean
            
            
          
           
      Package korean provides Korean encodings such as EUC-KR. 
         | 
      Package korean provides Korean encodings such as EUC-KR. | 
| 
         
          
            src/golang.org/x/text/encoding/simplifiedchinese
            
            
          
           
      Package simplifiedchinese provides Simplified Chinese encodings such as GBK. 
         | 
      Package simplifiedchinese provides Simplified Chinese encodings such as GBK. | 
| 
         
          
            src/golang.org/x/text/encoding/traditionalchinese
            
            
          
           
      Package traditionalchinese provides Traditional Chinese encodings such as Big5. 
         | 
      Package traditionalchinese provides Traditional Chinese encodings such as Big5. | 
| 
         
          
            src/golang.org/x/text/encoding/unicode
            
            
          
           
      Package unicode provides Unicode encodings such as UTF-16. 
         | 
      Package unicode provides Unicode encodings such as UTF-16. | 
| 
         
          
            src/golang.org/x/text/internal/utf8internal
            
            
          
           
      Package utf8internal contains low-level utf8-related constants, tables, etc. 
         | 
      Package utf8internal contains low-level utf8-related constants, tables, etc. | 
| 
         
          
            src/golang.org/x/text/runes
            
            
          
           
      Package runes provide transforms for UTF-8 encoded text. 
         | 
      Package runes provide transforms for UTF-8 encoded text. | 
| 
         
          
            src/golang.org/x/text/secure/bidirule
            
            
          
           
      Package bidirule implements the Bidi Rule defined by RFC 5893. 
         | 
      Package bidirule implements the Bidi Rule defined by RFC 5893. | 
| 
         
          
            src/golang.org/x/text/transform
            
            
          
           
      Package transform provides reader and writer wrappers that transform the bytes passing through as well as various transformations. 
         | 
      Package transform provides reader and writer wrappers that transform the bytes passing through as well as various transformations. | 
| 
         
          
            src/golang.org/x/text/unicode/bidi
            
            
          
           
      Package bidi contains functionality for bidirectional text support. 
         | 
      Package bidi contains functionality for bidirectional text support. | 
| 
         
          
            src/golang.org/x/text/unicode/norm
            
            
          
           
      Package norm contains types and functions for normalizing Unicode strings. 
         | 
      Package norm contains types and functions for normalizing Unicode strings. | 
| 
         
          
            src/google.golang.org/genproto/googleapis/rpc/status
            
            
          
           
      Package status is a generated protocol buffer package. 
         | 
      Package status is a generated protocol buffer package. | 
| 
         
          
            src/google.golang.org/grpc
            
            
          
           
      Package grpc implements an RPC system called gRPC. 
         | 
      Package grpc implements an RPC system called gRPC. | 
| 
         
          
            src/google.golang.org/grpc/codes
            
            
          
           
      Package codes defines the canonical error codes used by gRPC. 
         | 
      Package codes defines the canonical error codes used by gRPC. | 
| 
         
          
            src/google.golang.org/grpc/credentials
            
            
          
           
      Package credentials implements various credentials supported by gRPC library, which encapsulate all the state needed by a client to authenticate with a server and make various assertions, e.g., about the client's identity, role, or whether it is authorized to make a particular call. 
         | 
      Package credentials implements various credentials supported by gRPC library, which encapsulate all the state needed by a client to authenticate with a server and make various assertions, e.g., about the client's identity, role, or whether it is authorized to make a particular call. | 
| 
         
          
            src/google.golang.org/grpc/grpclb/grpc_lb_v1
            
            
          
           
      Package grpc_lb_v1 is a generated protocol buffer package. 
         | 
      Package grpc_lb_v1 is a generated protocol buffer package. | 
| 
         
          
            src/google.golang.org/grpc/grpclog
            
            
          
           
      Package grpclog defines logging for grpc. 
         | 
      Package grpclog defines logging for grpc. | 
| 
         
          
            src/google.golang.org/grpc/internal
            
            
          
           
      Package internal contains gRPC-internal code for testing, to avoid polluting the godoc of the top-level grpc package. 
         | 
      Package internal contains gRPC-internal code for testing, to avoid polluting the godoc of the top-level grpc package. | 
| 
         
          
            src/google.golang.org/grpc/keepalive
            
            
          
           
      Package keepalive defines configurable parameters for point-to-point healthcheck. 
         | 
      Package keepalive defines configurable parameters for point-to-point healthcheck. | 
| 
         
          
            src/google.golang.org/grpc/metadata
            
            
          
           
      Package metadata define the structure of the metadata supported by gRPC library. 
         | 
      Package metadata define the structure of the metadata supported by gRPC library. | 
| 
         
          
            src/google.golang.org/grpc/naming
            
            
          
           
      Package naming defines the naming API and related data structures for gRPC. 
         | 
      Package naming defines the naming API and related data structures for gRPC. | 
| 
         
          
            src/google.golang.org/grpc/peer
            
            
          
           
      Package peer defines various peer information associated with RPCs and corresponding utils. 
         | 
      Package peer defines various peer information associated with RPCs and corresponding utils. | 
| 
         
          
            src/google.golang.org/grpc/stats
            
            
          
           
      Package stats is for collecting and reporting various network and RPC stats. 
         | 
      Package stats is for collecting and reporting various network and RPC stats. | 
| 
         
          
            src/google.golang.org/grpc/status
            
            
          
           
      Package status implements errors returned by gRPC. 
         | 
      Package status implements errors returned by gRPC. | 
| 
         
          
            src/google.golang.org/grpc/tap
            
            
          
           
      Package tap defines the function handles which are executed on the transport layer of gRPC-Go and related information. 
         | 
      Package tap defines the function handles which are executed on the transport layer of gRPC-Go and related information. | 
| 
         
          
            src/google.golang.org/grpc/transport
            
            
          
           
      Package transport defines and implements message oriented communication channel to complete various transactions (e.g., an RPC). 
         | 
      Package transport defines and implements message oriented communication channel to complete various transactions (e.g., an RPC). | 
| 
         
          
            src/gopkg.in/natefinch/lumberjack.v2
            
            
          
           
      Package lumberjack provides a rolling logger. 
         | 
      Package lumberjack provides a rolling logger. | 
| 
       Package ast is the abstract syntax tree parsed from a SQL statement by parser. 
         | 
      Package ast is the abstract syntax tree parsed from a SQL statement by parser. | 
| 
       cmd
        | 
      |
| 
         
          
            benchdb
            
            command
          
          
         
       | 
      |
| 
         
          
            benchfilesort
            
            command
          
          
         
       | 
      |
| 
         
          
            benchkv
            
            command
          
          
         
       | 
      |
| 
         
          
            benchraw
            
            command
          
          
         
       | 
      |
| 
         
          
            goyacc
            
            command
          
           
      Goyacc is a version of yacc generating Go parsers. 
         | 
      Goyacc is a version of yacc generating Go parsers. | 
| 
       store
        | 
      |
| 
         
          
            tikv
            
            
          
           
      Package tikv provides tcp connection to kvserver. 
         | 
      Package tikv provides tcp connection to kvserver. | 
| 
         
          
            mock
            
            
          
           
      Package mock is just for test only. 
         | 
      Package mock is just for test only. | 

