Path | Synopsis |
---|---|
pkg/acceptance | |
pkg/acceptance/cluster | |
pkg/acceptance/localcluster | |
pkg/acceptance/localcluster/tc | Package tc contains utility methods for using the Linux tc (traffic control) command to mess with the network links between cockroach nodes running on the local machine. |
pkg/base | |
pkg/bench | |
pkg/bench/ddl_analysis | |
pkg/blobs | Package blobs contains a gRPC service to be used for remote file access. |
pkg/blobs/blobspb | |
pkg/build | |
pkg/ccl | |
pkg/ccl/backupccl | |
pkg/ccl/baseccl | |
pkg/ccl/buildccl | |
pkg/ccl/changefeedccl | |
pkg/ccl/changefeedccl/cdctest | |
pkg/ccl/changefeedccl/changefeedbase | |
pkg/ccl/changefeedccl/kvfeed | Package kvfeed provides an abstraction to stream kvs to a buffer. |
pkg/ccl/changefeedccl/schemafeed | |
pkg/ccl/changefeedccl/schemafeed/schematestutils | Package schematestutils is a utility package for constructing schema objects in the context of cdc. |
pkg/ccl/cliccl | |
pkg/ccl/cliccl/cliflagsccl | |
pkg/ccl/cmdccl/enc_utils | |
pkg/ccl/gssapiccl | |
pkg/ccl/importccl | |
pkg/ccl/kvccl | |
pkg/ccl/kvccl/kvfollowerreadsccl | Package kvfollowerreadsccl implements and injects the functionality needed to expose follower reads to clients. |
pkg/ccl/kvccl/kvtenantccl | Package kvtenantccl provides utilities required by SQL-only tenant processes in order to interact with the key-value layer. |
pkg/ccl/logictestccl | Package logictestccl houses the SQL logic tests that test CCL features. |
pkg/ccl/oidcccl | |
pkg/ccl/partitionccl | |
pkg/ccl/serverccl | Package serverccl houses tests that verify CCL behavior of a running CockroachDB server. |
pkg/ccl/sqlproxyccl | |
pkg/ccl/storageccl | |
pkg/ccl/storageccl/engineccl | |
pkg/ccl/storageccl/engineccl/enginepbccl | |
pkg/ccl/streamingccl | |
pkg/ccl/streamingccl/streamclient | |
pkg/ccl/utilccl | |
pkg/ccl/utilccl/licenseccl | |
pkg/ccl/utilccl/sampledataccl | |
pkg/ccl/workloadccl | |
pkg/ccl/workloadccl/allccl | |
pkg/ccl/workloadccl/cliccl | |
pkg/ccl/workloadccl/format | |
pkg/ccl/workloadccl/roachmartccl | |
pkg/cli | |
pkg/cli/cliflags | |
pkg/cli/exit | Package exit encapsulates calls to os.Exit to control the production of process exit status codes. |
pkg/cli/syncbench | |
pkg/cli/systembench | |
pkg/cli/systembench/systembenchpb | |
pkg/clusterversion | Package clusterversion defines the interfaces to interact with cluster/binary versions in order accommodate backward incompatible behaviors. |
pkg/cmd/allocsim | |
pkg/cmd/cmdutil | |
pkg/cmd/cmpconn | Package cmpconn assists in comparing results from DB connections. |
pkg/cmd/cmp-protocol | cmp-protocol connects to postgres and cockroach servers and compares the binary and text pgwire encodings of SQL statements. |
pkg/cmd/cmp-protocol/pgconnect | Package pgconnect provides a way to get byte encodings from a simple query. |
pkg/cmd/cmp-sql | cmp-sql connects to postgres and cockroach servers and compares the results of SQL statements. |
pkg/cmd/cockroach | This is the default entry point for a CockroachDB binary. |
pkg/cmd/cockroach-oss | cockroach-oss is an entry point for a CockroachDB binary that excludes all CCL-licensed code. |
pkg/cmd/cockroach-short | cockroach-short is an entry point for a CockroachDB binary that excludes certain components that are slow to build or have heavyweight dependencies. |
pkg/cmd/compile-build | |
pkg/cmd/cr2pg | cr2pg is a program that reads CockroachDB-formatted SQL files on stdin, modifies them to be Postgres compatible, and outputs them to stdout. |
pkg/cmd/cr2pg/sqlstream | Package sqlstream streams an io.Reader into SQL statements. |
pkg/cmd/docgen | |
pkg/cmd/docgen/extract | |
pkg/cmd/fuzz | fuzz builds and executes fuzz tests. |
pkg/cmd/generate-binary | This connects to a postgres server and crafts postgres-protocol message to encode its arguments into postgres' text and binary encodings. |
pkg/cmd/generate-spatial-ref-sys | |
pkg/cmd/geoviz | |
pkg/cmd/github-post | Command github-post parses the JSON-formatted output from a Go test session, as generated by either 'go test -json' or './pkg.test | go tool test2json -t', and posts issues for any failed tests to GitHub. |
pkg/cmd/github-pull-request-make | This utility detects new tests added in a given pull request, and runs them under stress in our CI infrastructure. |
pkg/cmd/gossipsim | Package simulation provides tools meant to visualize or test aspects of a Cockroach cluster on a single host. |
pkg/cmd/internal/issues | |
pkg/cmd/prereqs | prereqs generates Make prerequisites for Go binaries. |
pkg/cmd/protoc-gen-gogoroach | |
pkg/cmd/publish-artifacts | |
pkg/cmd/publish-provisional-artifacts | |
pkg/cmd/reduce | reduce reduces SQL passed over stdin using cockroach demo. |
pkg/cmd/returncheck | |
pkg/cmd/roachprod | |
pkg/cmd/roachprod/cloud | |
pkg/cmd/roachprod/config | |
pkg/cmd/roachprod/errors | |
pkg/cmd/roachprod/install | |
pkg/cmd/roachprod/ssh | |
pkg/cmd/roachprod-stress | |
pkg/cmd/roachprod/ui | |
pkg/cmd/roachprod/vm | |
pkg/cmd/roachprod/vm/aws | |
pkg/cmd/roachprod/vm/aws/terraformgen | Command terraformgen generate the terraform file used to configure AWS for multiregion support. |
pkg/cmd/roachprod/vm/azure | Package azure allows roachprod to create instances within the Microsoft Azure cloud. |
pkg/cmd/roachprod/vm/flagstub | |
pkg/cmd/roachprod/vm/gce | |
pkg/cmd/roachprod/vm/local | |
pkg/cmd/roachtest | |
pkg/cmd/roachvet | Command roachvet is a vettool which includes all of the standard analysis passes included in go vet as well as the `shadow` pass and some first-party passes. |
pkg/cmd/skiperrs | skiperrs connects to a postgres-compatible server with its URL specified as the first argument. |
pkg/cmd/skipped-tests | |
pkg/cmd/skip-test | |
pkg/cmd/smithcmp | smithcmp is a tool to execute random queries on a database. |
pkg/cmd/smithtest | smithtest is a tool to execute sqlsmith tests on cockroach demo instances. |
pkg/cmd/teamcity-trigger | teamcity-trigger launches a variety of nightly build jobs on TeamCity using its REST API. |
pkg/cmd/testfilter | testfilter is a utility to manipulate JSON streams in [test2json] format. |
pkg/cmd/uptodate | uptodate efficiently computes whether an output file is up-to-date with regard to its input files. |
pkg/cmd/urlcheck | |
pkg/cmd/urlcheck/lib/urlcheck | |
pkg/cmd/whoownsit | whoownsit looks for OWNERS in the directory and parenting directories until it finds an owner for a given file. |
pkg/cmd/workload | |
pkg/cmd/wraprules | |
pkg/cmd/zerosum | |
pkg/col/coldata | |
pkg/col/coldataext | |
pkg/col/coldatatestutils | |
pkg/col/colserde | |
pkg/col/colserde/arrowserde | Package arrowserde contains the flatbuffer generated code used for Apache Arrow serialization (and some small helpers associated with the generated code). |
pkg/col/typeconv | |
pkg/compose | |
pkg/config | |
pkg/config/zonepb | |
pkg/docs | |
pkg/featureflag | |
pkg/geo | Package geo contains the base types for spatial data type operations. |
pkg/geo/geodist | Package geodist finds distances between two geospatial shapes. |
pkg/geo/geogen | Package geogen provides utilities for generating various geospatial types. |
pkg/geo/geogfn | |
pkg/geo/geographiclib | Package geographiclib is a wrapper around the GeographicLib library. |
pkg/geo/geoindex | |
pkg/geo/geomfn | Package geomfn contains functions that are used for geometry-based builtins. |
pkg/geo/geopb | |
pkg/geo/geoproj | Package geoproj contains functions that interface with the PROJ library. |
pkg/geo/geoprojbase | Package geoprojbase is a minimal dependency package that contains basic metadata and data structures for SRIDs and their CRS transformations. |
pkg/geo/geos | Package geos is a wrapper around the spatial data types between the geo package and the GEOS C library. |
pkg/geo/geosegmentize | |
pkg/geo/geotransform | |
pkg/gossip | Package gossip implements a protocol for sharing information between Cockroach nodes using an ad-hoc, peer-to-peer network. |
pkg/gossip/resolver | |
pkg/gossip/simulation | |
pkg/internal/client/requestbatcher | Package requestbatcher is a library to enable easy batching of roachpb requests. |
pkg/internal/codeowners | |
pkg/internal/gopath | Package gopath contains utilities to get the current GOPATH. |
pkg/internal/rsg | |
pkg/internal/rsg/yacc | Package yacc parses .y files. |
pkg/internal/sqlsmith | |
pkg/internal/team | Package team involves processing team information based on a yaml file containing team metadata. |
pkg/jobs | |
pkg/jobs/jobspb | |
pkg/jobs/jobsprotectedts | |
pkg/jobs/jobstest | |
pkg/keys | Package keys manages the construction of keys for CockroachDB's key-value layer. |
pkg/kv | Package kv and its KV API have been deprecated for external usage. |
pkg/kv/bulk | |
pkg/kv/kvbase | |
pkg/kv/kvclient | Package kvclient houses the implementation of the KV client. |
pkg/kv/kvclient/kvcoord | Package kvcoord provides a key-value API to an underlying cockroach datastore. |
pkg/kv/kvclient/kvtenant | Package kvtenant provides utilities required by SQL-only tenant processes in order to interact with the key-value layer. |
pkg/kv/kvclient/rangecache | |
pkg/kv/kvnemesis | Package kvnemesis exercises the KV api with random traffic and then validates that the observed behaviors are consistent with our guarantees. |
pkg/kv/kvserver | Package kvserver provides access to the Store and Range abstractions. |
pkg/kv/kvserver/abortspan | |
pkg/kv/kvserver/apply | Package apply provides abstractions and routines associated with the application of committed raft entries to a replicated state machine. |
pkg/kv/kvserver/batcheval | |
pkg/kv/kvserver/batcheval/result | |
pkg/kv/kvserver/closedts | Package closedts houses the interfaces and basic definitions used by the various components of the closed timestamp subsystems. |
pkg/kv/kvserver/closedts/container | |
pkg/kv/kvserver/closedts/ctpb | |
pkg/kv/kvserver/closedts/minprop | Package minprop exports a main data structure, Tracker, which checkpoints closed timestamps and associated Raft Lease Applied indexes positions for which (under additional conditions) it is legal to serve follower reads. |
pkg/kv/kvserver/closedts/provider | |
pkg/kv/kvserver/closedts/provider/testutils | |
pkg/kv/kvserver/closedts/storage | |
pkg/kv/kvserver/closedts/transport | |
pkg/kv/kvserver/closedts/transport/testutils | |
pkg/kv/kvserver/concurrency | Package concurrency provides a concurrency manager structure that encapsulates the details of concurrency control and contention handling for serializable key-value transactions. |
pkg/kv/kvserver/concurrency/lock | Package lock provides type definitions for locking-related concepts used by concurrency control in the key-value layer. |
pkg/kv/kvserver/constraint | |
pkg/kv/kvserver/diskmap | |
pkg/kv/kvserver/gc | Package gc contains the logic to run scan a range for garbage and issue GC requests to remove that garbage. |
pkg/kv/kvserver/idalloc | |
pkg/kv/kvserver/intentresolver | |
pkg/kv/kvserver/kvserverbase | |
pkg/kv/kvserver/kvserverpb | |
pkg/kv/kvserver/liveness | |
pkg/kv/kvserver/liveness/livenesspb | |
pkg/kv/kvserver/observedts | Package observedts contains logic and documentation related to the observed timestamp system, which allows transactions to track causality between themselves and other, possibly-concurrent, transactions in order to avoid uncertainty related restarts. |
pkg/kv/kvserver/protectedts | Package protectedts exports the interface to the protected timestamp subsystem which allows clients to prevent GC of expired data. |
pkg/kv/kvserver/protectedts/ptcache | |
pkg/kv/kvserver/protectedts/ptpb | |
pkg/kv/kvserver/protectedts/ptprovider | Package ptprovider encapsulates the concrete implementation of the protectedts.Provider. |
pkg/kv/kvserver/protectedts/ptreconcile | Package ptreconcile provides logic to reconcile protected timestamp records with state associated with their metadata. |
pkg/kv/kvserver/protectedts/ptstorage | Package ptstorage implements protectedts.Storage. |
pkg/kv/kvserver/protectedts/ptverifier | |
pkg/kv/kvserver/raftentry | Package raftentry provides a cache for entries to avoid extra deserializations. |
pkg/kv/kvserver/rangefeed | |
pkg/kv/kvserver/rditer | |
pkg/kv/kvserver/reports | |
pkg/kv/kvserver/spanlatch | Package spanlatch provides a latch management structure for serializing access to keys and key ranges. |
pkg/kv/kvserver/spanset | |
pkg/kv/kvserver/split | |
pkg/kv/kvserver/stateloader | |
pkg/kv/kvserver/tenantrate | Package tenantrate contains logic for rate limiting client requests on a per-tenant basis. |
pkg/kv/kvserver/tscache | Package tscache provides a timestamp cache structure that records the maximum timestamp that key ranges were read from and written to. |
pkg/kv/kvserver/txnrecovery | |
pkg/kv/kvserver/txnwait | |
pkg/migration | Package migration captures the facilities needed to define and execute migrations for a crdb cluster. |
pkg/release | Package release contains utilities for assisting with the release process. |
pkg/roachpb | |
pkg/rpc | |
pkg/rpc/nodedialer | |
pkg/scheduledjobs | |
pkg/security | |
pkg/security/securitytest | Package securitytest embeds the TLS test certificates. |
pkg/server | Package server implements the Cockroach storage node. |
pkg/server/debug | |
pkg/server/debug/goroutineui | |
pkg/server/debug/pprofui | |
pkg/server/diagnostics | |
pkg/server/dumpstore | |
pkg/server/goroutinedumper | |
pkg/server/heapprofiler | |
pkg/server/serverpb | Package serverpb is a reverse proxy. |
pkg/server/status | |
pkg/server/status/statuspb | |
pkg/server/telemetry | Package telemetry contains helpers for capturing diagnostics information. |
pkg/settings | Package settings provides a central registry of runtime editable settings and accompanying helper functions for retrieving their current values. |
pkg/settings/cluster | |
pkg/sql | Package sql provides the user-facing API for access to a Cockroach datastore. |
pkg/sql/backfill | |
pkg/sql/catalog | |
pkg/sql/catalog/accessors | |
pkg/sql/catalog/bootstrap | Package bootstrap contains the metadata required to bootstrap the sql schema for a fresh cockroach cluster. |
pkg/sql/catalog/catalogkeys | |
pkg/sql/catalog/catalogkv | Package catalogkv provides functions for interacting with the system catalog tables using the kv client. |
pkg/sql/catalog/catconstants | |
pkg/sql/catalog/catformat | |
pkg/sql/catalog/colinfo | Package colinfo contains type information and related structures for dealing with columns returned from sql operations. |
pkg/sql/catalog/database | Package database primarily provides the incoherent database cache and related interfaces. |
pkg/sql/catalog/dbdesc | Package dbdesc contains the concrete implementations of catalog.DatabaseDescriptor. |
pkg/sql/catalog/descpb | |
pkg/sql/catalog/descs | Package descs provides abstractions for dealing with sets of descriptors. |
pkg/sql/catalog/hydratedtables | Package hydratedtables contains logic to cache table descriptors with user defined types hydrated. |
pkg/sql/catalog/lease | Package lease provides functionality to create and manage sql schema leases. |
pkg/sql/catalog/resolver | |
pkg/sql/catalog/schemadesc | |
pkg/sql/catalog/schemaexpr | Package schemaexpr provides utilities for dealing with expressions with table schemas, such as check constraints, computed columns, and partial index predicates. |
pkg/sql/catalog/systemschema | |
pkg/sql/catalog/tabledesc | Package tabledesc provides concrete implementations of catalog.TableDesc. |
pkg/sql/catalog/typedesc | Package typedesc contains the concrete implementations of catalog.TypeDescriptor. |
pkg/sql/colcontainer | |
pkg/sql/colconv | |
pkg/sql/colencoding | |
pkg/sql/colexec | |
pkg/sql/colexecbase | |
pkg/sql/colexecbase/colexecerror | |
pkg/sql/colexec/colbuilder | |
pkg/sql/colexec/colexecagg | |
pkg/sql/colexec/execgen | |
pkg/sql/colfetcher | |
pkg/sql/colflow | |
pkg/sql/colflow/colrpc | |
pkg/sql/colmem | |
pkg/sql/contention | |
pkg/sql/covering | |
pkg/sql/delegate | |
pkg/sql/distsql | |
pkg/sql/doctor | Package doctor provides utilities for checking the consistency of cockroach internal persisted metadata. |
pkg/sql/enum | |
pkg/sql/execinfra | |
pkg/sql/execinfrapb | |
pkg/sql/execstats | |
pkg/sql/faketreeeval | Package faketreeeval provides fake implementations of tree eval interfaces. |
pkg/sql/flowinfra | |
pkg/sql/gcjob | |
pkg/sql/gcjob/gcjobnotifier | Package gcjobnotifier provides a mechanism to share a SystemConfigDeltaFilter among all gc jobs. |
pkg/sql/lex | |
pkg/sql/lexbase | |
pkg/sql/logictest | |
pkg/sqlmigrations | |
pkg/sqlmigrations/leasemanager | Package leasemanager provides functionality for acquiring and managing leases via the kv api for use during sqlmigrations. |
pkg/sql/mutations | |
pkg/sql/oidext | Package oidext contains oids that are not in `github.com/lib/pq/oid` as they are not shipped by default with postgres. |
pkg/sql/opt | Package opt contains the Cockroach SQL optimizer. |
pkg/sql/opt/bench | Package bench houses benchmarks for the SQL optimizer. |
pkg/sql/opt/cat | Package cat contains interfaces that are used by the query optimizer to avoid including specifics of sqlbase structures in the opt code. |
pkg/sql/opt/constraint | |
pkg/sql/opt/exec | |
pkg/sql/opt/exec/execbuilder | |
pkg/sql/opt/exec/explain | |
pkg/sql/opt/idxconstraint | |
pkg/sql/opt/invertedexpr | |
pkg/sql/opt/invertedidx | |
pkg/sql/optionalnodeliveness | |
pkg/sql/opt/memo | |
pkg/sql/opt/norm | |
pkg/sql/opt/opbench | |
pkg/sql/opt/optbuilder | |
pkg/sql/opt/optgen/exprgen | |
pkg/sql/opt/optgen/lang | Package lang implements a language called Optgen, short for "optimizer generator". |
pkg/sql/opt/ordering | Package ordering contains operator-specific logic related to orderings - whether ops can provide Required orderings, what orderings do they need to require from their children, etc. |
pkg/sql/opt/partialidx | |
pkg/sql/opt/props | |
pkg/sql/opt/props/physical | |
pkg/sql/opt/testutils | |
pkg/sql/opt/testutils/opttester | |
pkg/sql/opt/testutils/testcat | |
pkg/sql/opt/testutils/testexpr | |
pkg/sql/opt/xform | |
pkg/sql/paramparse | Package paramparse parses parameters that are set in param lists or session vars. |
pkg/sql/parser | |
pkg/sql/parser/fuzz | |
pkg/sql/pgwire | |
pkg/sql/pgwire/hba | Package hba implements an hba.conf parser. |
pkg/sql/pgwire/pgcode | Package pgcode defines the PostgreSQL 5-character support codes used throughout the CockroachDB source tree. |
pkg/sql/pgwire/pgerror | |
pkg/sql/pgwire/pgnotice | |
pkg/sql/pgwire/pgwirebase | Package pgwirebase contains type definitions and very basic protocol structures to be used by both the pgwire package and by others (particularly by the sql package). |
pkg/sql/physicalplan | |
pkg/sql/physicalplan/replicaoracle | Package replicaoracle provides functionality for physicalplan to choose a replica for a range. |
pkg/sql/privilege | |
pkg/sql/protoreflect | |
pkg/sql/querycache | |
pkg/sql/roleoption | |
pkg/sql/row | |
pkg/sql/rowcontainer | |
pkg/sql/rowenc | |
pkg/sql/rowexec | |
pkg/sql/rowflow | |
pkg/sql/schemachange | |
pkg/sql/scrub | |
pkg/sql/sem/builtins | |
pkg/sql/sem/transform | |
pkg/sql/sem/tree | |
pkg/sql/sessiondata | |
pkg/sql/sessiondatapb | |
pkg/sql/span | |
pkg/sql/sqlerrors | Package sqlerrors exports errors which can occur in the sql package. |
pkg/sql/sqlliveness | Package sqlliveness provides interfaces to associate resources at the SQL level with tenant SQL processes. |
pkg/sql/sqlliveness/slinstance | Package slinstance provides functionality for acquiring sqlliveness leases via sessions that have a unique id and expiration. |
pkg/sql/sqlliveness/slprovider | Package slprovider exposes an implementation of the sqlliveness.Provider interface. |
pkg/sql/sqlliveness/slstorage | |
pkg/sql/sqltelemetry | Package sqltelemetry contains telemetry counter definitions for various SQL features. |
pkg/sql/sqltestutils | Package sqltestutils provides helper methods for testing sql packages. |
pkg/sql/sqlutil | |
pkg/sql/stats | |
pkg/sql/stmtdiagnostics | |
pkg/sql/tests | |
pkg/sql/types | |
pkg/sql/vtable | |
pkg/storage | Package storage provides low-level storage. |
pkg/storage/cloud | |
pkg/storage/cloudimpl | |
pkg/storage/cloudimpl/filetable | |
pkg/storage/enginepb | |
pkg/storage/fs | |
pkg/storage/metamorphic | |
pkg/testutils | |
pkg/testutils/buildutil | |
pkg/testutils/colcontainerutils | |
pkg/testutils/diagutils | |
pkg/testutils/distsqlutils | |
pkg/testutils/gossiputil | |
pkg/testutils/jobutils | |
pkg/testutils/keysutils | |
pkg/testutils/kvclientutils | |
pkg/testutils/lint | Package lint tests Go code for policy and style violations, as well as detecting suspicious constructs that are typically bugs. |
pkg/testutils/lint/passes/descriptormarshal | Package descriptormarshal defines an suite of Analyzers that detects correct setting of timestamps when unmarshaling table descriptors. |
pkg/testutils/lint/passes/errcmp | Package errcmp defines an Analyzer which checks for usage of errors.Is instead of direct ==/!= comparisons. |
pkg/testutils/lint/passes/fmtsafe | |
pkg/testutils/lint/passes/hash | Package hash defines an Analyzer that detects correct use of hash.Hash. |
pkg/testutils/lint/passes/nocopy | Package nocopy defines an Analyzer that detects invalid uses of util.NoCopy. |
pkg/testutils/lint/passes/passesutil | Package passesutil provides useful functionality for implementing passes. |
pkg/testutils/lint/passes/returnerrcheck | Package returnerrcheck defines an suite of Analyzers that detects conditionals which check for a non-nil error and then proceed to return a nil error. |
pkg/testutils/lint/passes/timer | Package timer defines an Analyzer that detects correct use of timeutil.Timer. |
pkg/testutils/lint/passes/unconvert | Package unconvert defines an Analyzer that detects unnecessary type conversions. |
pkg/testutils/localtestcluster | |
pkg/testutils/pgtest | |
pkg/testutils/physicalplanutils | |
pkg/testutils/reduce | Package reduce implements a reducer core for reducing the size of test failure cases. |
pkg/testutils/reduce/reducesql | |
pkg/testutils/serverutils | |
pkg/testutils/skip | |
pkg/testutils/sqlutils | |
pkg/testutils/storageutils | |
pkg/testutils/testcluster | |
pkg/testutils/zerofields | |
pkg/ts | Package ts provides a basic time series database on top of the underlying CockroachDB key/value datastore. |
pkg/ts/catalog | |
pkg/ts/testmodel | |
pkg/ts/tspb | Package tspb is a reverse proxy. |
pkg/ui | Package ui embeds the assets for the web UI into the Cockroach binary. |
pkg/ui/distccl | Package distccl embeds the assets for the CCL version of the web UI into the Cockroach binary. |
pkg/ui/distoss | Package distoss embeds the assets for the OSS version of the web UI into the Cockroach binary. |
pkg/util | |
pkg/util/arith | |
pkg/util/binfetcher | |
pkg/util/bitarray | |
pkg/util/bufalloc | |
pkg/util/cache | |
pkg/util/caller | |
pkg/util/cancelchecker | |
pkg/util/cgroups | |
pkg/util/cloudinfo | |
pkg/util/contextutil | |
pkg/util/ctxgroup | Package ctxgroup wraps golang.org/x/sync/errgroup with a context func. |
pkg/util/duration | |
pkg/util/encoding | |
pkg/util/encoding/csv | Package csv reads and writes comma-separated values (CSV) files. |
pkg/util/encoding/encodingtype | |
pkg/util/envutil | |
pkg/util/errorutil | |
pkg/util/errorutil/unimplemented | |
pkg/util/fileutil | |
pkg/util/flagutil | Package flagutil facilitates creation of rich flag types. |
pkg/util/fsm | Package fsm provides an interface for defining and working with finite-state machines. |
pkg/util/fuzzystrmatch | |
pkg/util/growstack | |
pkg/util/grpcutil | |
pkg/util/hlc | Package hlc implements the Hybrid Logical Clock outlined in "Logical Physical Clocks and Consistent Snapshots in Globally Distributed Databases", available online at http://www.cse.buffalo.edu/tech-reports/2014-04.pdf. |
pkg/util/httputil | |
pkg/util/humanizeutil | |
pkg/util/interval | Package interval provides two implementations for an interval tree. |
pkg/util/interval/generic | Package generic provides an implementation of a generic immutable interval B-Tree. |
pkg/util/interval/generic/internal | |
pkg/util/ipaddr | |
pkg/util/iterutil | |
pkg/util/json | |
pkg/util/jsonbytes | |
pkg/util/keysutil | |
pkg/util/leaktest | Package leaktest provides tools to detect leaked goroutines in tests. |
pkg/util/limit | |
pkg/util/log | Package log implements logging. |
pkg/util/log/channel | |
pkg/util/log/eventpb | Package eventpb defines standardized payloads for cluster-level and SQL-level event reporting. |
pkg/util/log/logconfig | Package logconfig manages the configuration of the logging channels and their logging sinks. |
pkg/util/log/logcrash | |
pkg/util/log/logflags | |
pkg/util/log/logpb | |
pkg/util/log/severity | |
pkg/util/metric | Package metric provides server metrics (a.k.a. |
pkg/util/metric/aggmetric | Package aggmetric provides functionality to create metrics which expose aggregate metrics for internal collection and additionally per-child reporting to prometheus. |
pkg/util/mon | |
pkg/util/netutil | |
pkg/util/optional | |
pkg/util/pretty | Package pretty prints documents based on a target line width. |
pkg/util/protoutil | |
pkg/util/quotapool | Package quotapool provides an abstract implementation of a pool of resources to be distributed among concurrent clients. |
pkg/util/randutil | |
pkg/util/retry | |
pkg/util/ring | |
pkg/util/sdnotify | Package sdnotify implements both sides of the systemd readiness protocol. |
pkg/util/search | |
pkg/util/sequence | |
pkg/util/shuffle | |
pkg/util/sort | |
pkg/util/span | |
pkg/util/stop | |
pkg/util/stringarena | |
pkg/util/stringencoding | |
pkg/util/syncutil | |
pkg/util/syncutil/singleflight | Package singleflight provides a duplicate function call suppression mechanism. |
pkg/util/sysutil | Package sysutil is a cross-platform compatibility layer on top of package syscall. |
pkg/util/timeofday | |
pkg/util/timetz | |
pkg/util/timeutil | |
pkg/util/timeutil/pgdate | Package pgdate contains parsing functions and types for dates and times in a manner that is compatible with PostgreSQL. |
pkg/util/tracing | Package tracing encapsulates all tracing facilities used in CockroachDB. |
pkg/util/tracing/tracingpb | |
pkg/util/treeprinter | |
pkg/util/uint128 | |
pkg/util/unaccent | |
pkg/util/unique | |
pkg/util/uuid | |
pkg/util/version | |
pkg/workload | Package workload provides an abstraction for generators of sql query loads (and requisite initial data) as well as tools for working with these generators. |
pkg/workload/bank | |
pkg/workload/bulkingest | Package bulkingest defines a workload that is intended to stress some edge cases in our bulk-ingestion infrastructure. |
pkg/workload/cli | |
pkg/workload/debug | Package debug provides a workload subcommand under which useful workload utilities live. |
pkg/workload/examples | |
pkg/workload/faker | |
pkg/workload/geospatial | |
pkg/workload/histogram | |
pkg/workload/indexes | |
pkg/workload/interleavebench | |
pkg/workload/interleavedpartitioned | |
pkg/workload/jsonload | |
pkg/workload/kv | |
pkg/workload/ledger | |
pkg/workload/movr | |
pkg/workload/querybench | |
pkg/workload/querylog | |
pkg/workload/queue | |
pkg/workload/rand | |
pkg/workload/schemachange | |
pkg/workload/sqlsmith | |
pkg/workload/tpcc | |
pkg/workload/tpccchecks | |
pkg/workload/tpcds | |
pkg/workload/tpch | |
pkg/workload/workloadimpl | Package workloadimpl provides dependency-light helpers for implementing workload.Generators. |
pkg/workload/workloadsql | |
pkg/workload/ycsb | Package ycsb is the workload specified by the Yahoo! Cloud Serving Benchmark. |
Updated 2021-01-24. Refresh now. Tools for package owners.