Documentation
¶
Overview ¶
Package nutsdb implements a simple, fast, embeddable and persistent key/value store written in pure Go. It supports fully serializable transactions. And it also supports data structure such as list、set、sorted set etc.
NutsDB currently works on Mac OS, Linux and Windows.
Usage ¶
NutsDB has the following main types: DB, BPTree, Entry, DataFile And Tx. and NutsDB supports bucket, A bucket is a collection of unique keys that are associated with values.
All operations happen inside a Tx. Tx represents a transaction, which can be read-only or read-write. Read-only transactions can read values for a given key , or iterate over a set of key-value pairs (prefix scanning or range scanning). read-write transactions can also update and delete keys from the DB.
See the examples for more usage details.
Index ¶
- Constants
- Variables
- func ErrBucketAndKey(bucket string, key []byte) error
- func ErrNotFoundKeyInBucket(bucket string, key []byte) error
- func ErrSeparatorForZSetKey() error
- func ErrWhenBuildListIdx(err error) error
- func IsBucketEmpty(err error) bool
- func IsBucketNotFound(err error) bool
- func IsDBClosed(err error) bool
- func IsExpired(ttl uint32, timestamp uint64) bool
- func IsKeyEmpty(err error) bool
- func IsKeyNotFound(err error) bool
- func IsPrefixScan(err error) bool
- func IsPrefixSearchScan(err error) bool
- func MarshalInts(ints []int) ([]byte, error)
- func MatchForRange(pattern, key string, f func(key string) bool) (end bool, err error)
- func SortFID(BPTreeRootIdxGroup []*BPTreeRootIdx, by sortBy)
- func SortedEntryKeys(m map[string]*Entry) (keys []string, es map[string]*Entry)
- func Truncate(path string, capacity int64, f *os.File) error
- func UnmarshalInts(data []byte) ([]int, error)
- type BPTree
- func (t *BPTree) All() (records Records, err error)
- func (t *BPTree) Find(key []byte) (*Record, error)
- func (t *BPTree) FindLeaf(key []byte) *Node
- func (t *BPTree) FindRange(start, end []byte, f func(key []byte, pointer interface{}) bool) (numFound int, keys [][]byte, pointers []interface{})
- func (t *BPTree) Insert(key []byte, e *Entry, h *Hint, countFlag bool) error
- func (t *BPTree) PrefixScan(prefix []byte, offsetNum int, limitNum int) (records Records, off int, err error)
- func (t *BPTree) PrefixSearchScan(prefix []byte, reg string, offsetNum int, limitNum int) (records Records, off int, err error)
- func (t *BPTree) Range(start, end []byte) (records Records, err error)
- func (t *BPTree) SetKeyPosMap(keyPosMap map[string]int64)
- func (t *BPTree) ToBinary(n *Node) (result []byte, err error)
- func (t *BPTree) WriteNode(n *Node, off int64, syncEnable bool, fd *os.File) (number int, err error)
- func (t *BPTree) WriteNodes(rwMode RWMode, syncEnable bool, flag int) error
- type BPTreeIdx
- type BPTreeRootIdx
- type BPTreeRootIdxWrapper
- type BinaryNode
- type BucketMeta
- type BucketMetasIdx
- type DB
- type DataFile
- type Entries
- type Entry
- type EntryIdxMode
- type FdInfo
- type FileIORWManager
- type Hint
- type Iterator
- type IteratorOptions
- type ListIdx
- type MMapRWManager
- type MetaData
- type Node
- type Option
- func WithCleanFdsCacheThreshold(threshold float64) Option
- func WithDir(dir string) Option
- func WithEntryIdxMode(entryIdxMode EntryIdxMode) Option
- func WithMaxFdNumsInCache(num int) Option
- func WithNodeNum(num int64) Option
- func WithRWMode(rwMode RWMode) Option
- func WithSegmentSize(size int64) Option
- func WithSyncEnable(enable bool) Option
- type Options
- type RWManager
- type RWMode
- type Record
- type Records
- type SetIdx
- type SortedSetIdx
- type Tx
- func (tx *Tx) Commit() error
- func (tx *Tx) Delete(bucket string, key []byte) error
- func (tx *Tx) DeleteBucket(ds uint16, bucket string) error
- func (tx *Tx) FindLeafOnDisk(fID int64, rootOff int64, key, newKey []byte) (bn *BinaryNode, err error)
- func (tx *Tx) FindOnDisk(fID uint64, rootOff uint64, key, newKey []byte) (entry *Entry, err error)
- func (tx *Tx) FindTxIDOnDisk(fID, txID uint64) (ok bool, err error)
- func (tx *Tx) Get(bucket string, key []byte) (e *Entry, err error)
- func (tx *Tx) GetAll(bucket string) (entries Entries, err error)
- func (tx *Tx) IterateBuckets(ds uint16, pattern string, f func(key string) bool) error
- func (tx *Tx) LKeys(bucket, pattern string, f func(key string) bool) error
- func (tx *Tx) LPeek(bucket string, key []byte) (item []byte, err error)
- func (tx *Tx) LPop(bucket string, key []byte) (item []byte, err error)
- func (tx *Tx) LPush(bucket string, key []byte, values ...[]byte) error
- func (tx *Tx) LRange(bucket string, key []byte, start, end int) (list [][]byte, err error)
- func (tx *Tx) LRem(bucket string, key []byte, count int, value []byte) (removedNum int, err error)
- func (tx *Tx) LRemByIndex(bucket string, key []byte, indexes ...int) (removedNum int, err error)
- func (tx *Tx) LSet(bucket string, key []byte, index int, value []byte) error
- func (tx *Tx) LSize(bucket string, key []byte) (int, error)
- func (tx *Tx) LTrim(bucket string, key []byte, start, end int) error
- func (tx *Tx) PrefixScan(bucket string, prefix []byte, offsetNum int, limitNum int) (es Entries, off int, err error)
- func (tx *Tx) PrefixSearchScan(bucket string, prefix []byte, reg string, offsetNum int, limitNum int) (es Entries, off int, err error)
- func (tx *Tx) Put(bucket string, key, value []byte, ttl uint32) error
- func (tx *Tx) PutWithTimestamp(bucket string, key, value []byte, ttl uint32, timestamp uint64) error
- func (tx *Tx) RPeek(bucket string, key []byte) (item []byte, err error)
- func (tx *Tx) RPop(bucket string, key []byte) (item []byte, err error)
- func (tx *Tx) RPush(bucket string, key []byte, values ...[]byte) error
- func (tx *Tx) RangeScan(bucket string, start, end []byte) (es Entries, err error)
- func (tx *Tx) Rollback() error
- func (tx *Tx) SAdd(bucket string, key []byte, items ...[]byte) error
- func (tx *Tx) SAreMembers(bucket string, key []byte, items ...[]byte) (bool, error)
- func (tx *Tx) SCard(bucket string, key []byte) (int, error)
- func (tx *Tx) SDiffByOneBucket(bucket string, key1, key2 []byte) (list [][]byte, err error)
- func (tx *Tx) SDiffByTwoBuckets(bucket1 string, key1 []byte, bucket2 string, key2 []byte) (list [][]byte, err error)
- func (tx *Tx) SHasKey(bucket string, key []byte) (bool, error)
- func (tx *Tx) SIsMember(bucket string, key, item []byte) (bool, error)
- func (tx *Tx) SKeys(bucket, pattern string, f func(key string) bool) error
- func (tx *Tx) SMembers(bucket string, key []byte) (list [][]byte, err error)
- func (tx *Tx) SMoveByOneBucket(bucket string, key1, key2, item []byte) (bool, error)
- func (tx *Tx) SMoveByTwoBuckets(bucket1 string, key1 []byte, bucket2 string, key2, item []byte) (bool, error)
- func (tx *Tx) SPop(bucket string, key []byte) ([]byte, error)
- func (tx *Tx) SRem(bucket string, key []byte, items ...[]byte) error
- func (tx *Tx) SUnionByOneBucket(bucket string, key1, key2 []byte) (list [][]byte, err error)
- func (tx *Tx) SUnionByTwoBuckets(bucket1 string, key1 []byte, bucket2 string, key2 []byte) (list [][]byte, err error)
- func (tx *Tx) ZAdd(bucket string, key []byte, score float64, val []byte) error
- func (tx *Tx) ZCard(bucket string) (int, error)
- func (tx *Tx) ZCount(bucket string, start, end float64, opts *zset.GetByScoreRangeOptions) (int, error)
- func (tx *Tx) ZGetByKey(bucket string, key []byte) (*zset.SortedSetNode, error)
- func (tx *Tx) ZKeys(bucket, pattern string, f func(key string) bool) error
- func (tx *Tx) ZMembers(bucket string) (map[string]*zset.SortedSetNode, error)
- func (tx *Tx) ZPeekMax(bucket string) (*zset.SortedSetNode, error)
- func (tx *Tx) ZPeekMin(bucket string) (*zset.SortedSetNode, error)
- func (tx *Tx) ZPopMax(bucket string) (*zset.SortedSetNode, error)
- func (tx *Tx) ZPopMin(bucket string) (*zset.SortedSetNode, error)
- func (tx *Tx) ZRangeByRank(bucket string, start, end int) ([]*zset.SortedSetNode, error)
- func (tx *Tx) ZRangeByScore(bucket string, start, end float64, opts *zset.GetByScoreRangeOptions) ([]*zset.SortedSetNode, error)
- func (tx *Tx) ZRank(bucket string, key []byte) (int, error)
- func (tx *Tx) ZRem(bucket, key string) error
- func (tx *Tx) ZRemRangeByRank(bucket string, start, end int) error
- func (tx *Tx) ZRevRank(bucket string, key []byte) (int, error)
- func (tx *Tx) ZScore(bucket string, key []byte) (float64, error)
Constants ¶
const ( // DefaultInvalidAddress returns default invalid node address. DefaultInvalidAddress = -1 // RangeScan returns range scanMode flag. RangeScan = "RangeScan" // PrefixScan returns prefix scanMode flag. PrefixScan = "PrefixScan" // PrefixSearchScan returns prefix and search scanMode flag. PrefixSearchScan = "PrefixSearchScan" // CountFlagEnabled returns enabled CountFlag. CountFlagEnabled = true // CountFlagDisabled returns disabled CountFlag. CountFlagDisabled = false // BPTIndexSuffix returns b+ tree index suffix. BPTIndexSuffix = ".bptidx" // BPTRootIndexSuffix returns b+ tree root index suffix. BPTRootIndexSuffix = ".bptridx" // BPTTxIDIndexSuffix returns b+ tree tx ID index suffix. BPTTxIDIndexSuffix = ".bpttxid" // BPTRootTxIDIndexSuffix returns b+ tree root tx ID index suffix. BPTRootTxIDIndexSuffix = ".bptrtxid" )
const ( // BucketMetaHeaderSize returns the header size of the BucketMeta. BucketMetaHeaderSize = 12 // BucketMetaSuffix returns b+ tree index suffix. BucketMetaSuffix = ".meta" )
const ( // DataSuffix returns the data suffix DataSuffix = ".dat" // DataEntryHeaderSize returns the entry header size DataEntryHeaderSize = 42 )
const ( // DataDeleteFlag represents the data delete flag DataDeleteFlag uint16 = iota // DataSetFlag represents the data set flag DataSetFlag // DataLPushFlag represents the data LPush flag DataLPushFlag // DataRPushFlag represents the data RPush flag DataRPushFlag // DataLRemFlag represents the data LRem flag DataLRemFlag // DataLPopFlag represents the data LPop flag DataLPopFlag // DataRPopFlag represents the data RPop flag DataRPopFlag // DataLSetFlag represents the data LSet flag DataLSetFlag // DataLTrimFlag represents the data LTrim flag DataLTrimFlag // DataZAddFlag represents the data ZAdd flag DataZAddFlag // DataZRemFlag represents the data ZRem flag DataZRemFlag // DataZRemRangeByRankFlag represents the data ZRemRangeByRank flag DataZRemRangeByRankFlag // DataZPopMaxFlag represents the data ZPopMax flag DataZPopMaxFlag // DataZPopMinFlag represents the data aZPopMin flag DataZPopMinFlag // DataSetBucketDeleteFlag represents the delete Set bucket flag DataSetBucketDeleteFlag // DataSortedSetBucketDeleteFlag represents the delete Sorted Set bucket flag DataSortedSetBucketDeleteFlag // DataBPTreeBucketDeleteFlag represents the delete BPTree bucket flag DataBPTreeBucketDeleteFlag // DataListBucketDeleteFlag represents the delete List bucket flag DataListBucketDeleteFlag // LRemByIndex represents the data LRemByIndex flag DataLRemByIndex )
const ( // UnCommitted represents the tx unCommitted status UnCommitted uint16 = 0 // Committed represents the tx committed status Committed uint16 = 1 // Persistent represents the data persistent flag Persistent uint32 = 0 // ScanNoLimit represents the data scan no limit flag ScanNoLimit int = -1 )
const ( // DataStructureSet represents the data structure set flag DataStructureSet uint16 = iota // DataStructureSortedSet represents the data structure sorted set flag DataStructureSortedSet // DataStructureBPTree represents the data structure b+ tree flag DataStructureBPTree // DataStructureList represents the data structure list flag DataStructureList // DataStructureNone represents not the data structure DataStructureNone )
const ( B = 1 KB = 1024 * B MB = 1024 * KB GB = 1024 * MB )
const BPTreeRootIdxHeaderSize = 28
BPTreeRootIdxHeaderSize returns the header size of the root index.
const (
DefaultMaxFileNums = 256
)
const SeparatorForListKey = "|"
SeparatorForListKey represents separator for listKey
const SeparatorForZSetKey = "|"
SeparatorForZSetKey represents separator for zSet key.
const (
TooManyFileOpenErrSuffix = "too many open files"
)
Variables ¶
var ( // ErrStartKey is returned when Range is called by a error start key. ErrStartKey = errors.New("err start key") // ErrScansNoResult is returned when Range or prefixScan or prefixSearchScan are called no result to found. ErrScansNoResult = errors.New("range scans or prefix or prefix and search scans no result") // ErrPrefixSearchScansNoResult is returned when prefixSearchScan is called no result to found. ErrPrefixSearchScansNoResult = errors.New("prefix and search scans no result") // ErrKeyNotFound is returned when the key is not in the b+ tree. ErrKeyNotFound = errors.New("key not found") // ErrBadRegexp is returned when bad regular expression given. ErrBadRegexp = errors.New("bad regular expression") )
var ( // ErrCrcZero is returned when crc is 0 ErrCrcZero = errors.New("error crc is 0") // ErrCrc is returned when crc is error ErrCrc = errors.New("crc error") // ErrCapacity is returned when capacity is error. ErrCapacity = errors.New("capacity error") )
var ( // ErrDBClosed is returned when db is closed. ErrDBClosed = errors.New("db is closed") // ErrBucket is returned when bucket is not in the HintIdx. ErrBucket = errors.New("err bucket") // ErrEntryIdxModeOpt is returned when set db EntryIdxMode option is wrong. ErrEntryIdxModeOpt = errors.New("err EntryIdxMode option set") // ErrFn is returned when fn is nil. ErrFn = errors.New("err fn") // ErrBucketNotFound is returned when looking for bucket that does not exist ErrBucketNotFound = errors.New("bucket not found") // ErrNotSupportHintBPTSparseIdxMode is returned not support mode `HintBPTSparseIdxMode` ErrNotSupportHintBPTSparseIdxMode = errors.New("not support mode `HintBPTSparseIdxMode`") )
var ( // ErrUnmappedMemory is returned when a function is called on unmapped memory ErrUnmappedMemory = errors.New("unmapped memory") // ErrIndexOutOfBound is returned when given offset out of mapped region ErrIndexOutOfBound = errors.New("offset out of mapped region") )
var ( // ErrKeyAndValSize is returned when given key and value size is too big. ErrKeyAndValSize = errors.New("key and value size too big") // ErrTxClosed is returned when committing or rolling back a transaction // that has already been committed or rolled back. ErrTxClosed = errors.New("tx is closed") // ErrTxNotWritable is returned when performing a write operation on // a read-only transaction. ErrTxNotWritable = errors.New("tx not writable") // ErrKeyEmpty is returned if an empty key is passed on an update function. ErrKeyEmpty = errors.New("key cannot be empty") // ErrBucketEmpty is returned if bucket is empty. ErrBucketEmpty = errors.New("bucket is empty") // ErrRangeScan is returned when range scanning not found the result ErrRangeScan = errors.New("range scans not found") // ErrPrefixScan is returned when prefix scanning not found the result ErrPrefixScan = errors.New("prefix scans not found") // ErrPrefixSearchScan is returned when prefix and search scanning not found the result ErrPrefixSearchScan = errors.New("prefix and search scans not found") // ErrNotFoundKey is returned when key not found int the bucket on an view function. ErrNotFoundKey = errors.New("key not found in the bucket") )
var DefaultOptions = func() Options { return Options{ EntryIdxMode: HintKeyValAndRAMIdxMode, SegmentSize: defaultSegmentSize, NodeNum: 1, RWMode: FileIO, SyncEnable: true, } }()
DefaultOptions represents the default options.
var ( // ErrSeparatorForListKey returns when list key contains the SeparatorForListKey. ErrSeparatorForListKey = errors.Errorf("contain separator (%s) for List key", SeparatorForListKey) )
Functions ¶
func ErrBucketAndKey ¶ added in v0.2.0
ErrBucketAndKey returns when bucket or key not found.
func ErrNotFoundKeyInBucket ¶ added in v0.2.0
ErrNotFoundKeyInBucket returns when key not in the bucket.
func ErrSeparatorForZSetKey ¶ added in v0.2.0
func ErrSeparatorForZSetKey() error
ErrSeparatorForZSetKey returns when zSet key contains the SeparatorForZSetKey flag.
func ErrWhenBuildListIdx ¶ added in v0.2.0
ErrWhenBuildListIdx returns err when build listIdx
func IsBucketEmpty ¶ added in v0.9.0
IsBucketEmpty is true if the bucket is empty.
func IsBucketNotFound ¶ added in v0.9.0
IsBucketNotFound is true if the error indicates the bucket is not exists.
func IsDBClosed ¶ added in v0.9.0
IsDBClosed is true if the error indicates the db was closed.
func IsKeyEmpty ¶ added in v0.9.0
IsKeyEmpty is true if the key is empty.
func IsKeyNotFound ¶ added in v0.9.0
IsKeyNotFound is true if the error indicates the key is not found.
func IsPrefixScan ¶ added in v0.9.0
IsPrefixScan is true if prefix scanning not found the result.
func IsPrefixSearchScan ¶ added in v0.9.0
IsPrefixSearchScan is true if prefix and search scanning not found the result.
func MarshalInts ¶ added in v0.10.0
func MatchForRange ¶ added in v0.11.0
func SortFID ¶ added in v0.5.0
func SortFID(BPTreeRootIdxGroup []*BPTreeRootIdx, by sortBy)
SortFID sorts BPTreeRootIdx data.
func SortedEntryKeys ¶
SortedEntryKeys returns sorted entries.
func UnmarshalInts ¶ added in v0.10.0
Types ¶
type BPTree ¶
type BPTree struct { ValidKeyCount int // the number of the key that not expired or deleted FirstKey []byte LastKey []byte LastAddress int64 Filepath string // contains filtered or unexported fields }
BPTree records root node and valid key number.
func NewTree ¶
func NewTree() *BPTree
NewTree returns a newly initialized BPTree Object that implements the BPTree.
func (*BPTree) FindRange ¶ added in v0.7.0
func (t *BPTree) FindRange(start, end []byte, f func(key []byte, pointer interface{}) bool) (numFound int, keys [][]byte, pointers []interface{})
FindRange returns numFound,keys and pointers at the given start key and end key.
func (*BPTree) Insert ¶
Insert inserts record to the b+ tree, and if the key exists, update the record and the counter(if countFlag set true,it will start count).
func (*BPTree) PrefixScan ¶
func (t *BPTree) PrefixScan(prefix []byte, offsetNum int, limitNum int) (records Records, off int, err error)
PrefixScan returns records at the given prefix and limitNum. limitNum: limit the number of the scanned records return.
func (*BPTree) PrefixSearchScan ¶ added in v0.6.0
func (t *BPTree) PrefixSearchScan(prefix []byte, reg string, offsetNum int, limitNum int) (records Records, off int, err error)
PrefixSearchScan returns records at the given prefix, match regular expression and limitNum limitNum: limit the number of the scanned records return.
func (*BPTree) SetKeyPosMap ¶ added in v0.5.0
SetKeyPosMap sets the key offset of all entries in the b+ tree.
func (*BPTree) WriteNode ¶ added in v0.5.0
func (t *BPTree) WriteNode(n *Node, off int64, syncEnable bool, fd *os.File) (number int, err error)
WriteNode writes a binary node to the File starting at byte offset off. It returns the number of bytes written and an error, if any. WriteAt returns a non-nil error when n != len(b).
type BPTreeRootIdx ¶ added in v0.5.0
type BPTreeRootIdx struct {
// contains filtered or unexported fields
}
BPTreeRootIdx represents the b+ tree root index.
func ReadBPTreeRootIdxAt ¶ added in v0.5.0
func ReadBPTreeRootIdxAt(fd *os.File, off int64) (*BPTreeRootIdx, error)
ReadBPTreeRootIdxAt reads BPTreeRootIdx entry from the File starting at byte offset off.
func (*BPTreeRootIdx) Encode ¶ added in v0.5.0
func (bri *BPTreeRootIdx) Encode() []byte
Encode returns the slice after the BPTreeRootIdx be encoded.
func (*BPTreeRootIdx) GetCrc ¶ added in v0.5.0
func (bri *BPTreeRootIdx) GetCrc(buf []byte) uint32
GetCrc returns the crc at given buf slice.
func (*BPTreeRootIdx) IsZero ¶ added in v0.5.0
func (bri *BPTreeRootIdx) IsZero() bool
IsZero checks if the BPTreeRootIdx entry is zero or not.
func (*BPTreeRootIdx) Persistence ¶ added in v0.5.0
func (bri *BPTreeRootIdx) Persistence(path string, offset int64, syncEnable bool) (number int, err error)
Persistence writes BPTreeRootIdx entry to the File starting at byte offset off.
func (*BPTreeRootIdx) Size ¶ added in v0.5.0
func (bri *BPTreeRootIdx) Size() int64
Size returns the size of the BPTreeRootIdx entry.
type BPTreeRootIdxWrapper ¶ added in v0.5.0
type BPTreeRootIdxWrapper struct { BSGroup []*BPTreeRootIdx // contains filtered or unexported fields }
BPTreeRootIdxWrapper records BSGroup and by, in order to sort.
func (BPTreeRootIdxWrapper) Len ¶ added in v0.5.0
func (bsw BPTreeRootIdxWrapper) Len() int
Len is the number of elements in the collection bsw.BSGroup.
func (BPTreeRootIdxWrapper) Less ¶ added in v0.5.0
func (bsw BPTreeRootIdxWrapper) Less(i, j int) bool
Less reports whether the element with index i should sort before the element with index j.
func (BPTreeRootIdxWrapper) Swap ¶ added in v0.5.0
func (bsw BPTreeRootIdxWrapper) Swap(i, j int)
Swap swaps the elements with indexes i and j.
type BinaryNode ¶ added in v0.5.0
type BinaryNode struct { // hint offset Keys [order - 1]int64 // the last pointer would point to the previous node // the next to last one pointer would point to the next node Pointers [order + 1]int64 IsLeaf uint16 KeysNum uint16 Address int64 NextAddress int64 }
BinaryNode represents binary node.
type BucketMeta ¶ added in v0.5.0
type BucketMeta struct {
// contains filtered or unexported fields
}
BucketMeta represents the bucket's meta-information.
func ReadBucketMeta ¶ added in v0.5.0
func ReadBucketMeta(name string) (bucketMeta *BucketMeta, err error)
ReadBucketMeta returns bucketMeta at given file path name.
func (*BucketMeta) Encode ¶ added in v0.5.0
func (bm *BucketMeta) Encode() []byte
Encode returns the slice after the BucketMeta be encoded.
func (*BucketMeta) GetCrc ¶ added in v0.5.0
func (bm *BucketMeta) GetCrc(buf []byte) uint32
GetCrc returns the crc at given buf slice.
func (*BucketMeta) Size ¶ added in v0.5.0
func (bm *BucketMeta) Size() int64
Size returns the size of the BucketMeta.
type BucketMetasIdx ¶ added in v0.5.0
type BucketMetasIdx map[string]*BucketMeta
BucketMetasIdx represents the index of the bucket's meta-information
type DB ¶
type DB struct { BPTreeIdx BPTreeIdx // Hint Index BPTreeRootIdxes []*BPTreeRootIdx BPTreeKeyEntryPosMap map[string]int64 // key = bucket+key val = EntryPos SetIdx SetIdx SortedSetIdx SortedSetIdx ListIdx ListIdx ActiveFile *DataFile ActiveBPTreeIdx *BPTree ActiveCommittedTxIdsIdx *BPTree MaxFileID int64 KeyCount int // total key number ,include expired, deleted, repeated. // contains filtered or unexported fields }
DB represents a collection of buckets that persist on disk.
func (*DB) BackupTarGZ ¶ added in v0.7.0
BackupTarGZ Backup copy the database to writer.
func (*DB) Begin ¶
Begin opens a new transaction. Multiple read-only transactions can be opened at the same time but there can only be one read/write transaction at a time. Attempting to open a read/write transactions while another one is in progress will result in blocking until the current read/write transaction is completed. All transactions must be closed by calling Commit() or Rollback() when done.
func (*DB) Merge ¶
Merge removes dirty data and reduce data redundancy,following these steps:
1. Filter delete or expired entry.
2. Write entry to activeFile if the key not exist,if exist miss this write operation.
3. Filter the entry which is committed.
4. At last remove the merged files.
Caveat: Merge is Called means starting multiple write transactions, and it will affect the other write request. so execute it at the appropriate time.
type DataFile ¶
type DataFile struct { ActualSize int64 // contains filtered or unexported fields }
DataFile records about data file information.
func NewDataFile ¶
NewDataFile will return a new DataFile Object.
func (*DataFile) Close ¶ added in v0.4.0
Close closes the RWManager. If RWManager is FileRWManager represents closes the File, rendering it unusable for I/O. If RWManager is a MMapRWManager represents Unmap deletes the memory mapped region, flushes any remaining changes.
type Entry ¶
type Entry struct { Key []byte Value []byte Meta *MetaData // contains filtered or unexported fields }
Entry represents the data item.
func (*Entry) Encode ¶
Encode returns the slice after the entry be encoded.
the entry stored format: |----------------------------------------------------------------------------------------------------------------| | crc | timestamp | ksz | valueSize | flag | TTL |bucketSize| status | ds | txId | bucket | key | value | |----------------------------------------------------------------------------------------------------------------| | uint32| uint64 |uint32 | uint32 | uint16 | uint32| uint32 | uint16 | uint16 |uint64 |[]byte|[]byte | []byte | |----------------------------------------------------------------------------------------------------------------|
func (*Entry) ParsePayload ¶ added in v0.11.0
ParsePayload means this function will parse a byte array to bucket, key, size of an entry
type EntryIdxMode ¶
type EntryIdxMode int
EntryIdxMode represents entry index mode.
const ( // HintKeyValAndRAMIdxMode represents ram index (key and value) mode. HintKeyValAndRAMIdxMode EntryIdxMode = iota // HintKeyAndRAMIdxMode represents ram index (only key) mode. HintKeyAndRAMIdxMode // HintBPTSparseIdxMode represents b+ tree sparse index mode. HintBPTSparseIdxMode )
type FdInfo ¶ added in v0.9.0
type FdInfo struct {
// contains filtered or unexported fields
}
FdInfo holds base fd info
type FileIORWManager ¶ added in v0.4.0
type FileIORWManager struct {
// contains filtered or unexported fields
}
FileIORWManager represents the RWManager which using standard I/O.
func (*FileIORWManager) Close ¶ added in v0.4.0
func (fm *FileIORWManager) Close() (err error)
Close will remove the cache in the fdm of the specified path, and call the close method of the os of the file
func (*FileIORWManager) ReadAt ¶ added in v0.4.0
func (fm *FileIORWManager) ReadAt(b []byte, off int64) (n int, err error)
ReadAt reads len(b) bytes from the File starting at byte offset off. `ReadAt` is a wrapper of the *File.ReadAt.
func (*FileIORWManager) Release ¶ added in v0.9.0
func (fm *FileIORWManager) Release() (err error)
Release is a wrapper around the reduceUsing method
func (*FileIORWManager) Sync ¶ added in v0.4.0
func (fm *FileIORWManager) Sync() (err error)
Sync commits the current contents of the file to stable storage. Typically, this means flushing the file system's in-memory copy of recently written data to disk. `Sync` is a wrapper of the *File.Sync.
type Iterator ¶ added in v0.10.0
type Iterator struct {
// contains filtered or unexported fields
}
func NewIterator ¶ added in v0.10.0
func NewIterator(tx *Tx, bucket string, options IteratorOptions) *Iterator
func (*Iterator) Entry ¶ added in v0.10.0
Entry would return the current Entry item after calling SetNext
func (*Iterator) Seek ¶ added in v0.10.0
Seek would seek to the key, If the key is not available it would seek to the first smallest greater key than the input key.
type IteratorOptions ¶ added in v0.11.0
type IteratorOptions struct {
Reverse bool
}
type MMapRWManager ¶ added in v0.4.0
type MMapRWManager struct {
// contains filtered or unexported fields
}
MMapRWManager represents the RWManager which using mmap.
func (*MMapRWManager) Close ¶ added in v0.4.0
func (mm *MMapRWManager) Close() (err error)
Close will remove the cache in the fdm of the specified path, and call the close method of the os of the file
func (*MMapRWManager) ReadAt ¶ added in v0.4.0
func (mm *MMapRWManager) ReadAt(b []byte, off int64) (n int, err error)
ReadAt copies data to b slice from mapped region starting at given off and returns number of bytes copied to the b slice.
func (*MMapRWManager) Release ¶ added in v0.9.0
func (mm *MMapRWManager) Release() (err error)
Release deletes the memory mapped region, flushes any remaining changes
func (*MMapRWManager) Sync ¶ added in v0.4.0
func (mm *MMapRWManager) Sync() (err error)
Sync synchronizes the mapping's contents to the file's contents on disk.
type MetaData ¶
type MetaData struct { KeySize uint32 ValueSize uint32 Timestamp uint64 TTL uint32 Flag uint16 // delete / set Bucket []byte BucketSize uint32 TxID uint64 Status uint16 // committed / uncommitted Ds uint16 // data structure }
MetaData represents the meta information of the data item.
type Node ¶
type Node struct { Keys [][]byte KeysNum int Next *Node Address int64 // contains filtered or unexported fields }
Node records keys and pointers and parent node.
type Option ¶ added in v0.10.0
type Option func(*Options)
func WithCleanFdsCacheThreshold ¶ added in v0.10.0
func WithEntryIdxMode ¶ added in v0.10.0
func WithEntryIdxMode(entryIdxMode EntryIdxMode) Option
func WithMaxFdNumsInCache ¶ added in v0.10.0
func WithNodeNum ¶ added in v0.10.0
func WithRWMode ¶ added in v0.10.0
func WithSegmentSize ¶ added in v0.10.0
func WithSyncEnable ¶ added in v0.10.0
type Options ¶
type Options struct { // Dir represents Open the database located in which dir. Dir string // EntryIdxMode represents using which mode to index the entries. EntryIdxMode EntryIdxMode // RWMode represents the read and write mode. // RWMode includes two options: FileIO and MMap. // FileIO represents the read and write mode using standard I/O. // MMap represents the read and write mode using mmap. RWMode RWMode SegmentSize int64 // NodeNum represents the node number. // Default NodeNum is 1. NodeNum range [1,1023]. NodeNum int64 // SyncEnable represents if call Sync() function. // if SyncEnable is false, high write performance but potential data loss likely. // if SyncEnable is true, slower but persistent. SyncEnable bool // MaxFdNumsInCache represents the max numbers of fd in cache. MaxFdNumsInCache int // CleanFdsCacheThreshold represents the maximum threshold for recycling fd, it should be between 0 and 1. CleanFdsCacheThreshold float64 // BufferSizeOfRecovery represents the buffer size of recoveryReader buffer Size BufferSizeOfRecovery int }
Options records params for creating DB object.
type RWManager ¶ added in v0.4.0
type RWManager interface { WriteAt(b []byte, off int64) (n int, err error) ReadAt(b []byte, off int64) (n int, err error) Sync() (err error) Release() (err error) Close() (err error) }
RWManager represents an interface to a RWManager.
type Record ¶
Record records entry and hint.
type Records ¶
type Records []*Record
Records records multi-records as result when is called Range or PrefixScan.
type SortedSetIdx ¶ added in v0.2.0
SortedSetIdx represents the sorted set index
type Tx ¶
type Tx struct { ReservedStoreTxIDIdxes map[int64]*BPTree // contains filtered or unexported fields }
Tx represents a transaction.
func (*Tx) Commit ¶
Commit commits the transaction, following these steps:
1. check the length of pendingWrites.If there are no writes, return immediately.
2. check if the ActiveFile has not enough space to store entry. if not, call rotateActiveFile function.
3. write pendingWrites to disk, if a non-nil error,return the error.
4. build Hint index.
5. Unlock the database and clear the db field.
func (*Tx) DeleteBucket ¶ added in v0.7.0
DeleteBucket delete bucket depends on ds (represents the data structure)
func (*Tx) FindLeafOnDisk ¶ added in v0.5.0
func (tx *Tx) FindLeafOnDisk(fID int64, rootOff int64, key, newKey []byte) (bn *BinaryNode, err error)
FindLeafOnDisk returns binary leaf node on disk at given fId, rootOff and key.
func (*Tx) FindOnDisk ¶ added in v0.5.0
FindOnDisk returns entry on disk at given fID, rootOff and key.
func (*Tx) FindTxIDOnDisk ¶ added in v0.5.0
FindTxIDOnDisk returns if txId on disk at given fid and txID.
func (*Tx) Get ¶
Get retrieves the value for a key in the bucket. The returned value is only valid for the life of the transaction.
func (*Tx) GetAll ¶ added in v0.5.0
GetAll returns all keys and values of the bucket stored at given bucket.
func (*Tx) IterateBuckets ¶ added in v0.7.0
IterateBuckets iterate over all the bucket depends on ds (represents the data structure)
func (*Tx) LPeek ¶ added in v0.2.0
LPeek returns the first element of the list stored in the bucket at given bucket and key.
func (*Tx) LPop ¶ added in v0.2.0
LPop removes and returns the first element of the list stored in the bucket at given bucket and key.
func (*Tx) LPush ¶ added in v0.2.0
LPush inserts the values at the head of the list stored in the bucket at given bucket,key and values.
func (*Tx) LRange ¶ added in v0.2.0
LRange returns the specified elements of the list stored in the bucket at given bucket,key, start and end. The offsets start and stop are zero-based indexes 0 being the first element of the list (the head of the list), 1 being the next element and so on. Start and end can also be negative numbers indicating offsets from the end of the list, where -1 is the last element of the list, -2 the penultimate element and so on.
func (*Tx) LRem ¶ added in v0.2.0
LRem removes the first count occurrences of elements equal to value from the list stored in the bucket at given bucket,key,count. The count argument influences the operation in the following ways: count > 0: Remove elements equal to value moving from head to tail. count < 0: Remove elements equal to value moving from tail to head. count = 0: Remove all elements equal to value.
func (*Tx) LRemByIndex ¶ added in v0.10.0
LRemByIndex remove the list element at specified index
func (*Tx) LSize ¶ added in v0.2.0
LSize returns the size of key in the bucket in the bucket at given bucket and key.
func (*Tx) LTrim ¶ added in v0.2.0
LTrim trims an existing list so that it will contain only the specified range of elements specified. the offsets start and stop are zero-based indexes 0 being the first element of the list (the head of the list), 1 being the next element and so on. start and end can also be negative numbers indicating offsets from the end of the list, where -1 is the last element of the list, -2 the penultimate element and so on.
func (*Tx) PrefixScan ¶
func (tx *Tx) PrefixScan(bucket string, prefix []byte, offsetNum int, limitNum int) (es Entries, off int, err error)
PrefixScan iterates over a key prefix at given bucket, prefix and limitNum. LimitNum will limit the number of entries return.
func (*Tx) PrefixSearchScan ¶ added in v0.6.0
func (tx *Tx) PrefixSearchScan(bucket string, prefix []byte, reg string, offsetNum int, limitNum int) (es Entries, off int, err error)
PrefixSearchScan iterates over a key prefix at given bucket, prefix, match regular expression and limitNum. LimitNum will limit the number of entries return.
func (*Tx) PutWithTimestamp ¶ added in v0.6.0
func (*Tx) RPeek ¶ added in v0.2.0
RPeek returns the last element of the list stored in the bucket at given bucket and key.
func (*Tx) RPop ¶ added in v0.2.0
RPop removes and returns the last element of the list stored in the bucket at given bucket and key.
func (*Tx) RPush ¶ added in v0.2.0
RPush inserts the values at the tail of the list stored in the bucket at given bucket,key and values.
func (*Tx) SAdd ¶ added in v0.2.0
SAdd adds the specified members to the set stored int the bucket at given bucket,key and items.
func (*Tx) SAreMembers ¶ added in v0.2.0
SAreMembers returns if the specified members are the member of the set int the bucket at given bucket,key and items.
func (*Tx) SCard ¶ added in v0.2.0
SCard returns the set cardinality (number of elements) of the set stored in the bucket at given bucket and key.
func (*Tx) SDiffByOneBucket ¶ added in v0.2.0
SDiffByOneBucket returns the members of the set resulting from the difference between the first set and all the successive sets in one bucket.
func (*Tx) SDiffByTwoBuckets ¶ added in v0.2.0
func (tx *Tx) SDiffByTwoBuckets(bucket1 string, key1 []byte, bucket2 string, key2 []byte) (list [][]byte, err error)
SDiffByTwoBuckets returns the members of the set resulting from the difference between the first set and all the successive sets in two buckets.
func (*Tx) SHasKey ¶ added in v0.2.0
SHasKey returns if the set in the bucket at given bucket and key.
func (*Tx) SIsMember ¶ added in v0.2.0
SIsMember returns if member is a member of the set stored int the bucket at given bucket,key and item.
func (*Tx) SMembers ¶ added in v0.2.0
SMembers returns all the members of the set value stored int the bucket at given bucket and key.
func (*Tx) SMoveByOneBucket ¶ added in v0.2.0
SMoveByOneBucket moves member from the set at source to the set at destination in one bucket.
func (*Tx) SMoveByTwoBuckets ¶ added in v0.2.0
func (tx *Tx) SMoveByTwoBuckets(bucket1 string, key1 []byte, bucket2 string, key2, item []byte) (bool, error)
SMoveByTwoBuckets moves member from the set at source to the set at destination in two buckets.
func (*Tx) SPop ¶ added in v0.2.0
SPop removes and returns one or more random elements from the set value store in the bucket at given bucket and key.
func (*Tx) SRem ¶ added in v0.2.0
SRem removes the specified members from the set stored int the bucket at given bucket,key and items.
func (*Tx) SUnionByOneBucket ¶ added in v0.2.0
SUnionByOneBucket the members of the set resulting from the union of all the given sets in one bucket.
func (*Tx) SUnionByTwoBuckets ¶ added in v0.2.0
func (tx *Tx) SUnionByTwoBuckets(bucket1 string, key1 []byte, bucket2 string, key2 []byte) (list [][]byte, err error)
SUnionByTwoBuckets the members of the set resulting from the union of all the given sets in two buckets.
func (*Tx) ZAdd ¶ added in v0.2.0
ZAdd adds the specified member key with the specified score and specified val to the sorted set stored at bucket.
func (*Tx) ZCard ¶ added in v0.2.0
ZCard returns the sorted set cardinality (number of elements) of the sorted set stored at bucket.
func (*Tx) ZCount ¶ added in v0.2.0
func (tx *Tx) ZCount(bucket string, start, end float64, opts *zset.GetByScoreRangeOptions) (int, error)
ZCount returns the number of elements in the sorted set at bucket with a score between min and max and opts. opts includes the following parameters: Limit int // limit the max nodes to return ExcludeStart bool // exclude start value, so it search in interval (start, end] or (start, end) ExcludeEnd bool // exclude end value, so it search in interval [start, end) or (start, end)
func (*Tx) ZGetByKey ¶ added in v0.2.0
ZGetByKey returns node in the bucket at given bucket and key.
func (*Tx) ZMembers ¶ added in v0.2.0
ZMembers returns all the members of the set value stored at bucket.
func (*Tx) ZPeekMax ¶ added in v0.2.0
func (tx *Tx) ZPeekMax(bucket string) (*zset.SortedSetNode, error)
ZPeekMax returns the member with the highest score in the sorted set stored at bucket.
func (*Tx) ZPeekMin ¶ added in v0.2.0
func (tx *Tx) ZPeekMin(bucket string) (*zset.SortedSetNode, error)
ZPeekMin returns the member with the lowest score in the sorted set stored at bucket.
func (*Tx) ZPopMax ¶ added in v0.2.0
func (tx *Tx) ZPopMax(bucket string) (*zset.SortedSetNode, error)
ZPopMax removes and returns the member with the highest score in the sorted set stored at bucket.
func (*Tx) ZPopMin ¶ added in v0.2.0
func (tx *Tx) ZPopMin(bucket string) (*zset.SortedSetNode, error)
ZPopMin removes and returns the member with the lowest score in the sorted set stored at bucket.
func (*Tx) ZRangeByRank ¶ added in v0.2.0
ZRangeByRank returns all the elements in the sorted set in one bucket and key with a rank between start and end (including elements with rank equal to start or end).
func (*Tx) ZRangeByScore ¶ added in v0.2.0
func (tx *Tx) ZRangeByScore(bucket string, start, end float64, opts *zset.GetByScoreRangeOptions) ([]*zset.SortedSetNode, error)
ZRangeByScore returns all the elements in the sorted set at bucket with a score between min and max.
func (*Tx) ZRank ¶ added in v0.2.0
ZRank returns the rank of member in the sorted set stored in the bucket at given bucket and key, with the scores ordered from low to high.
func (*Tx) ZRem ¶ added in v0.2.0
ZRem removes the specified members from the sorted set stored in one bucket at given bucket and key.
func (*Tx) ZRemRangeByRank ¶ added in v0.2.0
ZRemRangeByRank removes all elements in the sorted set stored in one bucket at given bucket with rank between start and end. the rank is 1-based integer. Rank 1 means the first node; Rank -1 means the last node.