Documentation ¶
Index ¶
- Constants
- Variables
- func BenchmarkBatchDelete(b *testing.B, db Database, name string, keys, values [][]byte)
- func BenchmarkBatchPut(b *testing.B, db Database, name string, keys, values [][]byte)
- func BenchmarkBatchWrite(b *testing.B, db Database, name string, keys, values [][]byte)
- func BenchmarkDelete(b *testing.B, db Database, name string, keys, values [][]byte)
- func BenchmarkGet(b *testing.B, db Database, name string, keys, values [][]byte)
- func BenchmarkParallelDelete(b *testing.B, db Database, name string, keys, values [][]byte)
- func BenchmarkParallelGet(b *testing.B, db Database, name string, keys, values [][]byte)
- func BenchmarkParallelPut(b *testing.B, db Database, name string, keys, values [][]byte)
- func BenchmarkPut(b *testing.B, db Database, name string, keys, values [][]byte)
- func GetID(db KeyValueReader, key []byte) (ids.ID, error)
- func GetTimestamp(db KeyValueReader, key []byte) (time.Time, error)
- func GetUInt32(db KeyValueReader, key []byte) (uint32, error)
- func GetUInt64(db KeyValueReader, key []byte) (uint64, error)
- func PackUInt32(val uint32) []byte
- func PackUInt64(val uint64) []byte
- func ParseID(b []byte) (ids.ID, error)
- func ParseTimestamp(b []byte) (time.Time, error)
- func ParseUInt32(b []byte) (uint32, error)
- func ParseUInt64(b []byte) (uint64, error)
- func PutID(db KeyValueWriter, key []byte, val ids.ID) error
- func PutTimestamp(db KeyValueWriter, key []byte, val time.Time) error
- func PutUInt32(db KeyValueWriter, key []byte, val uint32) error
- func PutUInt64(db KeyValueWriter, key []byte, val uint64) error
- func SetupBenchmark(b *testing.B, count int, keySize, valueSize int) ([][]byte, [][]byte)
- func Size(db Iteratee) (int, error)
- func TestBatchDelete(t *testing.T, db Database)
- func TestBatchInner(t *testing.T, db Database)
- func TestBatchLargeSize(t *testing.T, db Database)
- func TestBatchPut(t *testing.T, db Database)
- func TestBatchReplay(t *testing.T, db Database)
- func TestBatchReset(t *testing.T, db Database)
- func TestBatchReuse(t *testing.T, db Database)
- func TestBatchRewrite(t *testing.T, db Database)
- func TestCompactNoPanic(t *testing.T, db Database)
- func TestIterator(t *testing.T, db Database)
- func TestIteratorClosed(t *testing.T, db Database)
- func TestIteratorError(t *testing.T, db Database)
- func TestIteratorErrorAfterRelease(t *testing.T, db Database)
- func TestIteratorMemorySafety(t *testing.T, db Database)
- func TestIteratorPrefix(t *testing.T, db Database)
- func TestIteratorSnapshot(t *testing.T, db Database)
- func TestIteratorStart(t *testing.T, db Database)
- func TestIteratorStartPrefix(t *testing.T, db Database)
- func TestKeyEmptyValue(t *testing.T, db Database)
- func TestMemorySafetyBatch(t *testing.T, db Database)
- func TestMemorySafetyDatabase(t *testing.T, db Database)
- func TestSimpleKeyValue(t *testing.T, db Database)
- func TestSimpleKeyValueClosed(t *testing.T, db Database)
- func TestStatNoPanic(t *testing.T, db Database)
- type Batch
- type Batcher
- type Compacter
- type Database
- type Iteratee
- type Iterator
- type KeyValueReader
- type KeyValueWriter
- type Stater
Constants ¶
const ( // If, when a batch is reset, the cap(batch)/len(batch) > MaxExcessCapacityFactor, // the underlying array's capacity will be reduced by a factor of capacityReductionFactor. // Higher value for MaxExcessCapacityFactor --> less aggressive array downsizing --> less memory allocations // but more unnecessary data in the underlying array that can't be garbage collected. // Higher value for CapacityReductionFactor --> more aggressive array downsizing --> more memory allocations // but less unnecessary data in the underlying array that can't be garbage collected. MaxExcessCapacityFactor = 4 CapacityReductionFactor = 2 )
Variables ¶
var ( // Benchmarks is a list of all database benchmarks Benchmarks = []func(b *testing.B, db Database, name string, keys, values [][]byte){ BenchmarkGet, BenchmarkPut, BenchmarkDelete, BenchmarkBatchPut, BenchmarkBatchDelete, BenchmarkBatchWrite, BenchmarkParallelGet, BenchmarkParallelPut, BenchmarkParallelDelete, } // BenchmarkSizes to use with each benchmark BenchmarkSizes = [][]int{ {1024, 32, 32}, {1024, 256, 256}, {1024, 2 * units.KiB, 2 * units.KiB}, } )
var ( ErrClosed = errors.New("closed") ErrNotFound = errors.New("not found") ErrAvoidCorruption = errors.New("closed to avoid possible corruption") )
common errors
var Tests = []func(t *testing.T, db Database){ TestSimpleKeyValue, TestKeyEmptyValue, TestSimpleKeyValueClosed, TestBatchPut, TestBatchDelete, TestBatchReset, TestBatchReuse, TestBatchRewrite, TestBatchReplay, TestBatchInner, TestBatchLargeSize, TestIteratorSnapshot, TestIterator, TestIteratorStart, TestIteratorPrefix, TestIteratorStartPrefix, TestIteratorMemorySafety, TestIteratorClosed, TestIteratorError, TestIteratorErrorAfterRelease, TestStatNoPanic, TestCompactNoPanic, TestMemorySafetyDatabase, TestMemorySafetyBatch, }
Tests is a list of all database tests
Functions ¶
func BenchmarkBatchDelete ¶ added in v1.4.11
BenchmarkBatchDelete measures the time it takes to batch delete.
func BenchmarkBatchPut ¶ added in v1.4.7
BenchmarkBatchPut measures the time it takes to batch put.
func BenchmarkBatchWrite ¶ added in v1.4.11
BenchmarkBatchWrite measures the time it takes to batch write.
func BenchmarkDelete ¶ added in v1.4.7
BenchmarkDelete measures the time it takes to delete a (k, v) from a database.
func BenchmarkGet ¶ added in v1.4.7
BenchmarkGet measures the time it takes to get an operation from a database.
func BenchmarkParallelDelete ¶ added in v1.4.7
BenchmarkParallelDelete measures the time it takes to delete a (k, v) from the db.
func BenchmarkParallelGet ¶ added in v1.4.7
BenchmarkParallelGet measures the time it takes to read in parallel.
func BenchmarkParallelPut ¶ added in v1.4.7
BenchmarkParallelPut measures the time it takes to write to the db in parallel.
func BenchmarkPut ¶ added in v1.4.7
BenchmarkPut measures the time it takes to write an operation to a database.
func GetTimestamp ¶ added in v1.4.5
func GetTimestamp(db KeyValueReader, key []byte) (time.Time, error)
func PackUInt32 ¶ added in v1.4.5
func PackUInt64 ¶ added in v1.4.5
func ParseUInt32 ¶ added in v1.4.5
func ParseUInt64 ¶ added in v1.4.5
func PutTimestamp ¶ added in v1.4.5
func PutTimestamp(db KeyValueWriter, key []byte, val time.Time) error
func SetupBenchmark ¶ added in v1.4.7
Writes size data into the db in order to setup reads in subsequent tests.
func TestBatchDelete ¶
TestBatchDelete tests to make sure that batched deletes work as expected.
func TestBatchInner ¶
TestBatchInner tests to make sure that inner can be used to write to the database.
func TestBatchLargeSize ¶ added in v1.4.0
TestBatchLargeSize tests to make sure that the batch can support a large amount of entries.
func TestBatchPut ¶
TestBatchPut tests to make sure that batched writes work as expected.
func TestBatchReplay ¶
TestBatchReplay tests to make sure that batches will correctly replay their contents.
func TestBatchReset ¶
TestBatchReset tests to make sure that a batch drops un-written operations when it is reset.
func TestBatchReuse ¶
TestBatchReuse tests to make sure that a batch can be reused once it is reset.
func TestBatchRewrite ¶
TestBatchRewrite tests to make sure that write can be called multiple times on a batch and the values will be updated correctly.
func TestCompactNoPanic ¶
TestCompactNoPanic tests to make sure compact never panics.
func TestIterator ¶
TestIterator tests to make sure the database iterates over the database contents lexicographically.
func TestIteratorClosed ¶
TestIteratorClosed tests to make sure that an iterator that was created with a closed database will report a closed error correctly.
func TestIteratorError ¶ added in v1.3.2
TestIteratorError tests to make sure that an iterator still works after the database is closed.
func TestIteratorErrorAfterRelease ¶ added in v1.3.2
TestIteratorErrorAfterRelease tests to make sure that an iterator that was released still reports the error correctly.
func TestIteratorMemorySafety ¶ added in v0.8.0
TestIteratorMemorySafety tests to make sure that keys can values are able to be modified from the returned iterator.
func TestIteratorPrefix ¶
TestIteratorPrefix tests to make sure the iterator can be configured to skip keys missing the provided prefix.
func TestIteratorSnapshot ¶ added in v1.4.11
TestIteratorSnapshot tests to make sure the database iterates over a snapshot of the database at the time of the iterator creation.
func TestIteratorStart ¶
TestIteratorStart tests to make sure the the iterator can be configured to start mid way through the database.
func TestIteratorStartPrefix ¶
TestIteratorStartPrefix tests to make sure that the iterator can start mid way through the database while skipping a prefix.
func TestKeyEmptyValue ¶ added in v1.4.10
func TestMemorySafetyBatch ¶ added in v1.0.5
TestMemorySafetyDatabase ensures it is safe to modify a key after passing it to Batch.Put.
func TestMemorySafetyDatabase ¶ added in v1.0.5
TestMemorySafetyDatabase ensures it is safe to modify a key after passing it to Database.Put and Database.Get.
func TestSimpleKeyValue ¶
TestSimpleKeyValue tests to make sure that simple Put + Get + Delete + Has calls return the expected values.
func TestSimpleKeyValueClosed ¶
TestSimpleKeyValueClosed tests to make sure that Put + Get + Delete + Has calls return the correct error when the database has been closed.
func TestStatNoPanic ¶
TestStatNoPanic tests to make sure that Stat never panics.
Types ¶
type Batch ¶
type Batch interface { KeyValueWriter // Size retrieves the amount of data queued up for writing, this includes // the keys, values, and deleted keys. Size() int // Write flushes any accumulated data to disk. Write() error // Reset resets the batch for reuse. Reset() // Replay replays the batch contents in the same order they were written // to the batch. Replay(w KeyValueWriter) error // Inner returns a Batch writing to the inner database, if one exists. If // this batch is already writing to the base DB, then itself should be // returned. Inner() Batch }
Batch is a write-only database that commits changes to its host database when Write is called. A batch cannot be used concurrently.
type Batcher ¶
type Batcher interface { // NewBatch creates a write-only database that buffers changes to its host db // until a final write is called. NewBatch() Batch }
Batcher wraps the NewBatch method of a backing data store.
type Compacter ¶
type Compacter interface { // Compact the underlying DB for the given key range. // Specifically, deleted and overwritten versions are discarded, // and the data is rearranged to reduce the cost of operations // needed to access the data. This operation should typically only // be invoked by users who understand the underlying implementation. // // A nil start is treated as a key before all keys in the DB. // And a nil limit is treated as a key after all keys in the DB. // Therefore if both are nil then it will compact entire DB. Compact(start []byte, limit []byte) error }
Compacter wraps the Compact method of a backing data store.
type Database ¶
type Database interface { KeyValueReader KeyValueWriter Batcher Iteratee Stater Compacter io.Closer }
Database contains all the methods required to allow handling different key-value data stores backing the database.
type Iteratee ¶
type Iteratee interface { // NewIterator creates an iterator over the entire keyspace contained within // the key-value database. NewIterator() Iterator // NewIteratorWithStart creates an iterator over a subset of database // content starting at a particular initial key. NewIteratorWithStart(start []byte) Iterator // NewIteratorWithPrefix creates an iterator over a subset of database // content with a particular key prefix. NewIteratorWithPrefix(prefix []byte) Iterator // NewIteratorWithStartAndPrefix creates an iterator over a subset of // database content with a particular key prefix starting at a specified // key. NewIteratorWithStartAndPrefix(start, prefix []byte) Iterator }
Iteratee wraps the NewIterator methods of a backing data store.
type Iterator ¶
type Iterator interface { // Next moves the iterator to the next key/value pair. It returns whether // the iterator successfully moved to a new key/value pair. Next() bool // Error returns any accumulated error. Exhausting all the key/value pairs // is not considered to be an error. Error() error // Key returns the key of the current key/value pair, or nil if done. Key() []byte // Value returns the value of the current key/value pair, or nil if done. Value() []byte // Release releases associated resources. Release should always succeed and // can be called multiple times without causing error. Release() }
Iterator iterates over a database's key/value pairs.
When it encounters an error any seek will return false and will yield no key/ value pairs. The error can be queried by calling the Error method. Calling Release is still necessary.
An iterator must be released after use, but it is not necessary to read an iterator until exhaustion. An iterator is not safe for concurrent use, but it is safe to use multiple iterators concurrently.
type KeyValueReader ¶
type KeyValueReader interface { // Has retrieves if a key is present in the key-value data store. Has(key []byte) (bool, error) // Get retrieves the given key if it's present in the key-value data store. Get(key []byte) ([]byte, error) }
KeyValueReader wraps the Has and Get method of a backing data store.
Source Files ¶
Directories ¶
Path | Synopsis |
---|---|
^ Only build this file if this computer is not Linux OR it's not AMD64 OR rocksdb is not allowed (c) 2019-2020, Ava Labs, Inc.
|
^ Only build this file if this computer is not Linux OR it's not AMD64 OR rocksdb is not allowed (c) 2019-2020, Ava Labs, Inc. |