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 ConvertBigEndianBytesToUint64(data []byte) uint64
- func ConvertUint64ToBigEndianBytes(value uint64) []byte
- func ErrBucketAndKey(bucket string, key []byte) error
- func ErrNotFoundKeyInBucket(bucket string, key []byte) error
- func ErrSeparatorForZSetKey() error
- func GetDiskSizeFromSingleObject(obj interface{}) int64
- func GetRandomBytes(length int) []byte
- func GetTestBytes(i int) []byte
- 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, bucket string, f func(bucket string) bool) (end bool, err error)
- func OneOfUint16Array(value uint16, array []uint16) bool
- func Truncate(path string, capacity int64, f *os.File) error
- func UnmarshalInts(data []byte) ([]int, error)
- func UvarintSize(x uint64) int
- type BTree
- func (bt *BTree) All() []*Record
- func (bt *BTree) AllItems() []*Item
- func (bt *BTree) Count() int
- func (bt *BTree) Delete(key []byte) bool
- func (bt *BTree) Find(key []byte) (*Record, bool)
- func (bt *BTree) Insert(record *Record) bool
- func (bt *BTree) InsertRecord(key []byte, record *Record) bool
- func (bt *BTree) Max() (*Item, bool)
- func (bt *BTree) Min() (*Item, bool)
- func (bt *BTree) PopMax() (*Item, bool)
- func (bt *BTree) PopMin() (*Item, bool)
- func (bt *BTree) PrefixScan(prefix []byte, offset, limitNum int) []*Record
- func (bt *BTree) PrefixSearchScan(prefix []byte, reg string, offset, limitNum int) []*Record
- func (bt *BTree) Range(start, end []byte) []*Record
- type BTreeIdx
- type Bucket
- type BucketId
- type BucketManager
- func (bm *BucketManager) ExistBucket(ds Ds, name BucketName) bool
- func (bm *BucketManager) GetBucket(ds Ds, name BucketName) (b *Bucket, err error)
- func (bm *BucketManager) GetBucketById(id BucketId) (*Bucket, error)
- func (bm *BucketManager) GetBucketID(ds Ds, name BucketName) (BucketId, error)
- func (bm *BucketManager) SubmitPendingBucketChange(reqs []*bucketSubmitRequest) error
- type BucketMeta
- type BucketName
- type BucketOperation
- type BucketStatus
- type CEntries
- type DB
- func (db *DB) Backup(dir string) error
- func (db *DB) BackupTarGZ(w io.Writer) error
- func (db *DB) Begin(writable bool) (tx *Tx, err error)
- func (db *DB) Close() error
- func (db *DB) IsClose() bool
- func (db *DB) Merge() error
- func (db *DB) NewWriteBatch() (*WriteBatch, error)
- func (db *DB) Update(fn func(tx *Tx) error) error
- func (db *DB) View(fn func(tx *Tx) error) error
- type DataFile
- type DataFlag
- type DataStatus
- type DataStructure
- type Ds
- type Entries
- type Entry
- func (e *Entry) Encode() []byte
- func (e *Entry) GetCrc(buf []byte) uint32
- func (e *Entry) GetTxIDBytes() []byte
- func (e *Entry) IsBelongsToBPlusTree() bool
- func (e *Entry) IsBelongsToList() bool
- func (e *Entry) IsBelongsToSet() bool
- func (e *Entry) IsBelongsToSortSet() bool
- func (e *Entry) IsZero() bool
- func (e *Entry) ParseMeta(buf []byte) (int64, error)
- func (e *Entry) ParsePayload(data []byte) error
- func (e *Entry) Size() int64
- func (e *Entry) WithKey(key []byte) *Entry
- func (e *Entry) WithMeta(meta *MetaData) *Entry
- func (e *Entry) WithValue(value []byte) *Entry
- type EntryIdxMode
- type EntryStatus
- type EntryWhenRecovery
- type ErrorHandler
- type ErrorHandlerFunc
- type ExpiredDeleteType
- type FdInfo
- type FileIORWManager
- func (fm *FileIORWManager) Close() (err error)
- func (fm *FileIORWManager) ReadAt(b []byte, off int64) (n int, err error)
- func (fm *FileIORWManager) Release() (err error)
- func (fm *FileIORWManager) Size() int64
- func (fm *FileIORWManager) Sync() (err error)
- func (fm *FileIORWManager) WriteAt(b []byte, off int64) (n int, err error)
- type GetByScoreRangeOptions
- type HeadTailSeq
- type IDGenerator
- type IDMarkerInBucket
- type IdxType
- type InfoMapperInBucket
- type Item
- type Iterator
- type IteratorOptions
- type LRUCache
- type LessFunc
- type List
- func (l *List) GetListTTL(key string) (uint32, error)
- func (l *List) IsEmpty(key string) (bool, error)
- func (l *List) IsExpire(key string) bool
- func (l *List) LPeek(key string) (*Item, error)
- func (l *List) LPop(key string) (*Record, error)
- func (l *List) LPush(key string, r *Record) error
- func (l *List) LRange(key string, start, end int) ([]*Record, error)
- func (l *List) LRem(key string, count int, cmp func(r *Record) (bool, error)) error
- func (l *List) LRemByIndex(key string, indexes []int) error
- func (l *List) LTrim(key string, start, end int) error
- func (l *List) RPeek(key string) (*Item, error)
- func (l *List) RPop(key string) (*Record, error)
- func (l *List) RPush(key string, r *Record) error
- func (l *List) Size(key string) (int, error)
- type ListIdx
- type LruEntry
- type MMapRWManager
- func (mm *MMapRWManager) Close() (err error)
- func (mm *MMapRWManager) ReadAt(b []byte, off int64) (n int, err error)
- func (mm *MMapRWManager) Release() (err error)
- func (mm *MMapRWManager) Size() int64
- func (mm *MMapRWManager) Sync() (err error)
- func (mm *MMapRWManager) WriteAt(b []byte, off int64) (n int, err error)
- type MetaData
- func (meta *MetaData) IsBPlusTree() bool
- func (meta *MetaData) IsList() bool
- func (meta *MetaData) IsSet() bool
- func (meta *MetaData) IsSortSet() bool
- func (meta *MetaData) PayloadSize() int64
- func (meta *MetaData) Size() int64
- func (meta *MetaData) WithBucketId(bucketID uint64) *MetaData
- func (meta *MetaData) WithBucketSize(bucketSize uint32) *MetaData
- func (meta *MetaData) WithCrc(crc uint32) *MetaData
- func (meta *MetaData) WithDs(ds uint16) *MetaData
- func (meta *MetaData) WithFlag(flag uint16) *MetaData
- func (meta *MetaData) WithKeySize(keySize uint32) *MetaData
- func (meta *MetaData) WithStatus(status uint16) *MetaData
- func (meta *MetaData) WithTTL(ttl uint32) *MetaData
- func (meta *MetaData) WithTimeStamp(timestamp uint64) *MetaData
- func (meta *MetaData) WithTxID(txID uint64) *MetaData
- func (meta *MetaData) WithValueSize(valueSize uint32) *MetaData
- type Option
- func WithBufferSizeOfRecovery(size int) Option
- func WithCleanFdsCacheThreshold(threshold float64) Option
- func WithCommitBufferSize(commitBufferSize int64) Option
- func WithDir(dir string) Option
- func WithEntryIdxMode(entryIdxMode EntryIdxMode) Option
- func WithErrorHandler(errorHandler ErrorHandler) Option
- func WithGCWhenClose(enable bool) Option
- func WithHintKeyAndRAMIdxCacheSize(size int) Option
- func WithLessFunc(lessFunc LessFunc) Option
- func WithMaxBatchCount(count int64) Option
- func WithMaxBatchSize(size int64) Option
- func WithMaxFdNumsInCache(num int) Option
- func WithMaxWriteRecordCount(maxWriteRecordCount int64) 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
- func (r *Record) IsExpired() bool
- func (r *Record) WithDataPos(pos uint64) *Record
- func (r *Record) WithFileId(fid int64) *Record
- func (r *Record) WithKey(k []byte) *Record
- func (r *Record) WithTTL(ttl uint32) *Record
- func (r *Record) WithTimestamp(timestamp uint64) *Record
- func (r *Record) WithTxID(txID uint64) *Record
- func (r *Record) WithValue(v []byte) *Record
- func (r *Record) WithValueSize(valueSize uint32) *Record
- type SCORE
- type Set
- func (s *Set) SAdd(key string, values [][]byte, records []*Record) error
- func (s *Set) SAreMembers(key string, values ...[]byte) (bool, error)
- func (s *Set) SCard(key string) int
- func (s *Set) SDiff(key1, key2 string) ([]*Record, error)
- func (s *Set) SHasKey(key string) bool
- func (s *Set) SInter(key1, key2 string) ([]*Record, error)
- func (s *Set) SIsMember(key string, value []byte) (bool, error)
- func (s *Set) SMembers(key string) ([]*Record, error)
- func (s *Set) SMove(key1, key2 string, value []byte) (bool, error)
- func (s *Set) SPop(key string) *Record
- func (s *Set) SRem(key string, values ...[]byte) error
- func (s *Set) SUnion(key1, key2 string) ([]*Record, error)
- type SetIdx
- type SkipList
- func (sl *SkipList) FindRank(hash uint32) int
- func (sl *SkipList) FindRevRank(hash uint32) int
- func (sl *SkipList) GetByRank(rank int, remove bool) *SkipListNode
- func (sl *SkipList) GetByRankRange(start, end int, remove bool) []*SkipListNode
- func (sl *SkipList) GetByScoreRange(start SCORE, end SCORE, options *GetByScoreRangeOptions) []*SkipListNode
- func (sl *SkipList) GetByValue(value []byte) *SkipListNode
- func (sl *SkipList) PeekMax() *SkipListNode
- func (sl *SkipList) PeekMin() *SkipListNode
- func (sl *SkipList) PopMax() *SkipListNode
- func (sl *SkipList) PopMin() *SkipListNode
- func (sl *SkipList) Put(score SCORE, value []byte, record *Record) error
- func (sl *SkipList) Remove(hash uint32) *SkipListNode
- func (sl *SkipList) Size() int
- type SkipListLevel
- type SkipListNode
- type SortedSet
- func (z *SortedSet) ZAdd(key string, score SCORE, value []byte, record *Record) error
- func (z *SortedSet) ZCard(key string) (int, error)
- func (z *SortedSet) ZCount(key string, start SCORE, end SCORE, opts *GetByScoreRangeOptions) (int, error)
- func (z *SortedSet) ZExist(key string, value []byte) (bool, error)
- func (z *SortedSet) ZMembers(key string) (map[*Record]SCORE, error)
- func (z *SortedSet) ZPeekMax(key string) (*Record, SCORE, error)
- func (z *SortedSet) ZPeekMin(key string) (*Record, SCORE, error)
- func (z *SortedSet) ZPopMax(key string) (*Record, SCORE, error)
- func (z *SortedSet) ZPopMin(key string) (*Record, SCORE, error)
- func (z *SortedSet) ZRangeByRank(key string, start int, end int) ([]*Record, []float64, error)
- func (z *SortedSet) ZRangeByScore(key string, start SCORE, end SCORE, opts *GetByScoreRangeOptions) ([]*Record, []float64, error)
- func (z *SortedSet) ZRank(key string, value []byte) (int, error)
- func (z *SortedSet) ZRem(key string, value []byte) (*Record, error)
- func (z *SortedSet) ZRemRangeByRank(key string, start int, end int) error
- func (z *SortedSet) ZRevRank(key string, value []byte) (int, error)
- func (z *SortedSet) ZScore(key string, value []byte) (float64, error)
- type SortedSetIdx
- type SortedSetMember
- type Throttle
- type Tx
- func (tx *Tx) Append(bucket string, key, appendage []byte) error
- func (tx *Tx) CheckExpire(bucket string, key []byte) bool
- func (tx *Tx) Commit() (err error)
- func (tx *Tx) CommitWith(cb func(error))
- func (tx *Tx) Decr(bucket string, key []byte) error
- func (tx *Tx) DecrBy(bucket string, key []byte, decrement int64) error
- func (tx *Tx) Delete(bucket string, key []byte) error
- func (tx *Tx) DeleteBucket(ds uint16, bucket string) error
- func (tx *Tx) ExistBucket(ds uint16, bucket string) bool
- func (tx *Tx) ExpireList(bucket string, key []byte, ttl uint32) error
- func (tx *Tx) Get(bucket string, key []byte) (value []byte, err error)
- func (tx *Tx) GetAll(bucket string) ([][]byte, [][]byte, error)
- func (tx *Tx) GetBit(bucket string, key []byte, offset int) (byte, error)
- func (tx *Tx) GetKeys(bucket string) ([][]byte, error)
- func (tx *Tx) GetListTTL(bucket string, key []byte) (uint32, error)
- func (tx *Tx) GetMaxKey(bucket string) ([]byte, error)
- func (tx *Tx) GetMinKey(bucket string) ([]byte, error)
- func (tx *Tx) GetRange(bucket string, key []byte, start, end int) ([]byte, error)
- func (tx *Tx) GetSet(bucket string, key, value []byte) (oldValue []byte, err error)
- func (tx *Tx) GetTTL(bucket string, key []byte) (int64, error)
- func (tx *Tx) GetValues(bucket string) ([][]byte, error)
- func (tx *Tx) Incr(bucket string, key []byte) error
- func (tx *Tx) IncrBy(bucket string, key []byte, increment int64) error
- func (tx *Tx) IterateBuckets(ds uint16, pattern string, f func(bucket 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) LPushRaw(bucket string, key []byte, values ...[]byte) error
- func (tx *Tx) LRange(bucket string, key []byte, start, end int) ([][]byte, error)
- func (tx *Tx) LRem(bucket string, key []byte, count int, value []byte) error
- func (tx *Tx) LRemByIndex(bucket string, key []byte, indexes ...int) 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) MGet(bucket string, keys ...[]byte) ([][]byte, error)
- func (tx *Tx) MSet(bucket string, ttl uint32, args ...[]byte) error
- func (tx *Tx) NewBucket(ds uint16, name string) (err error)
- func (tx *Tx) NewKVBucket(name string) error
- func (tx *Tx) NewListBucket(name string) error
- func (tx *Tx) NewSetBucket(name string) error
- func (tx *Tx) NewSortSetBucket(name string) error
- func (tx *Tx) Persist(bucket string, key []byte) error
- func (tx *Tx) PrefixScan(bucket string, prefix []byte, offsetNum int, limitNum int) (values [][]byte, err error)
- func (tx *Tx) PrefixSearchScan(bucket string, prefix []byte, reg string, offsetNum int, limitNum int) (values [][]byte, err error)
- func (tx *Tx) Put(bucket string, key, value []byte, ttl uint32) error
- func (tx *Tx) PutIfExists(bucket string, key, value []byte, ttl uint32) error
- func (tx *Tx) PutIfNotExists(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) ([]byte, 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) RPushRaw(bucket string, key []byte, values ...[]byte) error
- func (tx *Tx) RangeScan(bucket string, start, end []byte) (values [][]byte, 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) ([][]byte, error)
- func (tx *Tx) SDiffByTwoBuckets(bucket1 string, key1 []byte, bucket2 string, key2 []byte) ([][]byte, 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) ([][]byte, 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) ([][]byte, error)
- func (tx *Tx) SUnionByTwoBuckets(bucket1 string, key1 []byte, bucket2 string, key2 []byte) ([][]byte, error)
- func (tx *Tx) SetBit(bucket string, key []byte, offset int, bit byte) error
- func (tx *Tx) SubmitBucket() error
- func (tx *Tx) ValueLen(bucket string, key []byte) (int, error)
- func (tx *Tx) ZAdd(bucket string, key []byte, score float64, val []byte) error
- func (tx *Tx) ZCard(bucket string, key []byte) (int, error)
- func (tx *Tx) ZCheck(bucket string) error
- func (tx *Tx) ZCount(bucket string, key []byte, start, end float64, opts *GetByScoreRangeOptions) (int, error)
- func (tx *Tx) ZKeys(bucket, pattern string, f func(key string) bool) error
- func (tx *Tx) ZMembers(bucket string, key []byte) (map[*SortedSetMember]struct{}, error)
- func (tx *Tx) ZPeekMax(bucket string, key []byte) (*SortedSetMember, error)
- func (tx *Tx) ZPeekMin(bucket string, key []byte) (*SortedSetMember, error)
- func (tx *Tx) ZPopMax(bucket string, key []byte) (*SortedSetMember, error)
- func (tx *Tx) ZPopMin(bucket string, key []byte) (*SortedSetMember, error)
- func (tx *Tx) ZRangeByRank(bucket string, key []byte, start, end int) ([]*SortedSetMember, error)
- func (tx *Tx) ZRangeByScore(bucket string, key []byte, start, end float64, opts *GetByScoreRangeOptions) ([]*SortedSetMember, error)
- func (tx *Tx) ZRank(bucket string, key, value []byte) (int, error)
- func (tx *Tx) ZRem(bucket string, key []byte, value []byte) error
- func (tx *Tx) ZRemRangeByRank(bucket string, key []byte, start, end int) error
- func (tx *Tx) ZRevRank(bucket string, key, value []byte) (int, error)
- func (tx *Tx) ZScore(bucket string, key, value []byte) (float64, error)
- type WriteBatch
- func (wb *WriteBatch) Cancel() error
- func (wb *WriteBatch) Delete(bucket string, key []byte) error
- func (wb *WriteBatch) Error() error
- func (wb *WriteBatch) Flush() error
- func (wb *WriteBatch) Put(bucket string, key, value []byte, ttl uint32) error
- func (wb *WriteBatch) Reset() error
- func (wb *WriteBatch) SetMaxPendingTxns(max int)
Constants ¶
const ( IdSize = 8 DsSize = 2 )
const ( MaxEntryHeaderSize = 4 + binary.MaxVarintLen32*3 + binary.MaxVarintLen64*3 + binary.MaxVarintLen16*3 MinEntryHeaderSize = 4 + 9 )
const ( // UnCommitted represents the tx unCommitted status UnCommitted uint16 = 0 // Committed represents the tx committed status Committed uint16 = 1 )
const ( B = 1 KB = 1024 * B MB = 1024 * KB GB = 1024 * MB )
const ( // BucketStatusExistAlready means this bucket already exists BucketStatusExistAlready = 1 // BucketStatusDeleted means this bucket is already deleted BucketStatusDeleted = 2 // BucketStatusNew means this bucket is created in current Tx BucketStatusNew = 3 // BucketStatusUpdated means this bucket is updated in current Tx BucketStatusUpdated = 4 // BucketStatusUnknown means this bucket doesn't exist BucketStatusUnknown = 5 )
const ( // SkipListMaxLevel represents the skipList max level number. SkipListMaxLevel = 32 // SkipListP represents the p parameter of the skipList. SkipListP = 0.25 )
const BucketStoreFileName = "bucket.Meta"
const (
// DataSuffix returns the data suffix
DataSuffix = ".dat"
)
const (
DefaultMaxFileNums = 256
)
const (
DefaultThrottleSize = 16
)
const FLockName = "nutsdb-flock"
const KvWriteChCapacity = 1000
const MAX_SIZE = math.MaxUint32
const Persistent uint32 = 0
Persistent represents the data persistent flag
const ScanNoLimit int = -1
ScanNoLimit represents the data scan no limit flag
const SeparatorForListKey = "|"
SeparatorForListKey represents separator for listKey
const SeparatorForZSetKey = "|"
SeparatorForZSetKey represents separator for zSet key.
const (
TooManyFileOpenErrSuffix = "too many open files"
)
Variables ¶
var ( // ErrCrc is returned when crc is error ErrCrc = errors.New("crc error") // ErrCapacity is returned when capacity is error. ErrCapacity = errors.New("capacity error") ErrEntryZero = errors.New("entry is zero ") )
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") // 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") // ErrDataStructureNotSupported is returned when pass a not supported data structure ErrDataStructureNotSupported = errors.New("this data structure is not supported for now") // ErrDirLocked is returned when can't get the file lock of dir ErrDirLocked = errors.New("the dir of db is locked") // ErrDirUnlocked is returned when the file lock already unlocked ErrDirUnlocked = errors.New("the dir of db is unlocked") // ErrIsMerging is returned when merge in progress ErrIsMerging = errors.New("merge in progress") // ErrNotSupportMergeWhenUsingList is returned calling 'Merge' when using list ErrNotSupportMergeWhenUsingList = errors.New("not support merge when using list for now") // ErrRecordIsNil is returned when Record is nil ErrRecordIsNil = errors.New("the record is nil") )
var ( ErrPayLoadSizeMismatch = errors.New("the payload size in Meta mismatch with the payload size needed") ErrHeaderSizeOutOfBounds = errors.New("the header size is out of bounds") )
var ( // ErrListNotFound is returned when the list not found. ErrListNotFound = errors.New("the list not found") // ErrCount is returned when count is error. ErrCount = errors.New("err count") // ErrEmptyList is returned when the list is empty. ErrEmptyList = errors.New("the list is empty") // ErrStartOrEnd is returned when start > end ErrStartOrEnd = errors.New("start or end error") )
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 ( // ErrSetNotExist is returned when the key does not exist. ErrSetNotExist = errors.New("set not exist") // ErrSetMemberNotExist is returned when the member of set does not exist ErrSetMemberNotExist = errors.New("set member not exist") // ErrMemberEmpty is returned when the item received is nil ErrMemberEmpty = errors.New("item empty") )
var ( ErrSortedSetNotFound = errors.New("the sortedSet does not exist") ErrSortedSetMemberNotExist = errors.New("the member of sortedSet does not exist") ErrSortedSetIsEmpty = errors.New("the sortedSet if empty") )
var ( // ErrDataSizeExceed is returned when given key and value size is too big. ErrDataSizeExceed = errors.New("data 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") // ErrCannotCommitAClosedTx is returned when the tx committing a closed tx ErrCannotCommitAClosedTx = errors.New("can not commit a closed tx") // ErrCannotRollbackACommittingTx is returned when the tx rollback a committing tx ErrCannotRollbackACommittingTx = errors.New("can not rollback a committing tx") ErrCannotRollbackAClosedTx = errors.New("can not rollback a closed tx") // ErrNotFoundBucket is returned when key not found int the bucket on an view function. ErrNotFoundBucket = errors.New("bucket not found") // ErrTxnTooBig is returned if too many writes are fit into a single transaction. ErrTxnTooBig = errors.New("Txn is too big to fit into one request") // ErrTxnExceedWriteLimit is returned when this tx's write is exceed max write record ErrTxnExceedWriteLimit = errors.New("txn is exceed max write record count") ErrBucketAlreadyExist = errors.New("bucket is already exist") ErrorBucketNotExist = errors.New("bucket is not exist yet, please use NewBucket function to create this bucket first") ErrValueNotInteger = errors.New("value is not an integer") ErrOffsetInvalid = errors.New("offset is invalid") ErrKVArgsLenNotEven = errors.New("parameters is used to represent key value pairs and cannot be odd numbers") ErrStartGreaterThanEnd = errors.New("start is greater than end") )
var BucketMetaSize int64
var DefaultOptions = func() Options { return Options{ EntryIdxMode: HintKeyValAndRAMIdxMode, SegmentSize: defaultSegmentSize, NodeNum: 1, RWMode: FileIO, SyncEnable: true, CommitBufferSize: 4 * MB, MergeInterval: 2 * time.Hour, MaxBatchSize: (15 * defaultSegmentSize / 4) / 100, MaxBatchCount: (15 * defaultSegmentSize / 4) / 100 / 100, HintKeyAndRAMIdxCacheSize: 0, ExpiredDeleteType: TimeWheel, } }()
DefaultOptions represents the default options.
var ErrBucketCrcInvalid = errors.New("bucket crc invalid")
var ErrBucketNotExist = errors.New("bucket not exist")
var ErrCommitAfterFinish = errors.New("Batch commit not permitted after finish")
ErrCommitAfterFinish indicates that write batch commit was called after
var ErrDontNeedMerge = errors.New("the number of files waiting to be merged is at least 2")
var ErrKeyNotFound = errors.New("key not found")
ErrKeyNotFound is returned when the key is not in the b tree.
var ErrSeparatorForListKey = errors.Errorf("contain separator (%s) for List key", SeparatorForListKey)
ErrSeparatorForListKey returns when list key contains the SeparatorForListKey.
Functions ¶
func ConvertBigEndianBytesToUint64 ¶ added in v0.14.2
func ConvertUint64ToBigEndianBytes ¶ added in v0.14.2
func ErrBucketAndKey ¶
ErrBucketAndKey returns when bucket or key not found.
func ErrNotFoundKeyInBucket ¶
ErrNotFoundKeyInBucket returns when key not in the bucket.
func ErrSeparatorForZSetKey ¶
func ErrSeparatorForZSetKey() error
ErrSeparatorForZSetKey returns when zSet key contains the SeparatorForZSetKey flag.
func GetDiskSizeFromSingleObject ¶ added in v0.14.2
func GetDiskSizeFromSingleObject(obj interface{}) int64
func GetRandomBytes ¶ added in v0.12.5
func GetTestBytes ¶ added in v0.12.5
func IsBucketEmpty ¶
IsBucketEmpty is true if the bucket is empty.
func IsBucketNotFound ¶
IsBucketNotFound is true if the error indicates the bucket is not exists.
func IsDBClosed ¶
IsDBClosed is true if the error indicates the db was closed.
func IsKeyNotFound ¶
IsKeyNotFound is true if the error indicates the key is not found.
func IsPrefixScan ¶
IsPrefixScan is true if prefix scanning not found the result.
func IsPrefixSearchScan ¶
IsPrefixSearchScan is true if prefix and search scanning not found the result.
func MarshalInts ¶
func MatchForRange ¶
func OneOfUint16Array ¶ added in v0.12.4
func UnmarshalInts ¶
func UvarintSize ¶ added in v1.0.0
Types ¶
type BTree ¶ added in v0.13.1
type BTree struct {
// contains filtered or unexported fields
}
func (*BTree) InsertRecord ¶ added in v0.14.2
func (*BTree) PrefixScan ¶ added in v0.13.1
func (*BTree) PrefixSearchScan ¶ added in v0.13.1
type Bucket ¶ added in v1.0.0
type Bucket struct { // Meta: the metadata for this bucket Meta *BucketMeta // Id: is the marker for this bucket, every bucket creation activity will generate a new Id for it. // for example. If you have a bucket called "bucket_1", and you just delete bucket and create it again. // the last bucket will have a different Id from the previous one. Id BucketId // Ds: the data structure for this bucket. (List, Set, SortSet, String) Ds Ds // Name: the name of this bucket. Name string }
Bucket is the disk structure of bucket
func (*Bucket) GetEntrySize ¶ added in v1.0.0
func (*Bucket) GetPayloadSize ¶ added in v1.0.0
type BucketManager ¶ added in v1.0.0
type BucketManager struct { // BucketInfoMapper BucketID => Bucket itself BucketInfoMapper InfoMapperInBucket BucketIDMarker IDMarkerInBucket // IDGenerator helps generates an ID for every single bucket Gen *IDGenerator // contains filtered or unexported fields }
func NewBucketManager ¶ added in v1.0.0
func NewBucketManager(dir string) (*BucketManager, error)
func (*BucketManager) ExistBucket ¶ added in v1.0.0
func (bm *BucketManager) ExistBucket(ds Ds, name BucketName) bool
func (*BucketManager) GetBucket ¶ added in v1.0.0
func (bm *BucketManager) GetBucket(ds Ds, name BucketName) (b *Bucket, err error)
func (*BucketManager) GetBucketById ¶ added in v1.0.0
func (bm *BucketManager) GetBucketById(id BucketId) (*Bucket, error)
func (*BucketManager) GetBucketID ¶ added in v1.0.0
func (bm *BucketManager) GetBucketID(ds Ds, name BucketName) (BucketId, error)
func (*BucketManager) SubmitPendingBucketChange ¶ added in v1.0.0
func (bm *BucketManager) SubmitPendingBucketChange(reqs []*bucketSubmitRequest) error
type BucketMeta ¶
type BucketMeta struct { Crc uint32 // Op: Mark the latest operation (e.g. delete, insert, update) for this bucket. Op BucketOperation // Size: the size of payload. Size uint32 }
BucketMeta stores the Meta info of a Bucket. E.g. the size of bucket it store in disk.
func (*BucketMeta) Decode ¶ added in v1.0.0
func (meta *BucketMeta) Decode(bytes []byte)
Decode : CRC | op | size
type BucketName ¶ added in v1.0.0
type BucketName = string
type BucketOperation ¶ added in v1.0.0
type BucketOperation uint16
const ( BucketInsertOperation BucketOperation = 1 BucketUpdateOperation BucketOperation = 2 BucketDeleteOperation BucketOperation = 3 )
type BucketStatus ¶ added in v1.0.2
type BucketStatus = uint8
BucketStatus represents the current status of bucket in current Tx
type DB ¶
type DB struct { Index *index ActiveFile *DataFile MaxFileID int64 KeyCount int // total key number ,include expired, deleted, repeated. RecordCount int64 // current valid record count, exclude deleted, repeated // contains filtered or unexported fields }
DB represents a collection of buckets that persist on disk.
func (*DB) BackupTarGZ ¶
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) NewWriteBatch ¶ added in v0.13.1
func (db *DB) NewWriteBatch() (*WriteBatch, error)
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 ¶
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.
func (*DataFile) ReadEntry ¶ added in v1.0.0
ReadEntry returns entry at the given off(offset). payloadSize = bucketSize + keySize + valueSize
type DataFlag ¶ added in v1.0.2
type DataFlag = uint16
DataFlag means the data operations have done by users.
const ( // DataDeleteFlag represents the data delete flag DataDeleteFlag DataFlag = 0 // DataSetFlag represents the data set flag DataSetFlag DataFlag = 1 // DataLPushFlag represents the data LPush flag DataLPushFlag DataFlag = 2 // DataRPushFlag represents the data RPush flag DataRPushFlag DataFlag = 3 // DataLRemFlag represents the data LRem flag DataLRemFlag DataFlag = 4 // DataLPopFlag represents the data LPop flag DataLPopFlag DataFlag = 5 // DataRPopFlag represents the data RPop flag DataRPopFlag DataFlag = 6 // DataLTrimFlag represents the data LTrim flag DataLTrimFlag DataFlag = 8 // DataZAddFlag represents the data ZAdd flag DataZAddFlag DataFlag = 9 // DataZRemFlag represents the data ZRem flag DataZRemFlag DataFlag = 10 // DataZRemRangeByRankFlag represents the data ZRemRangeByRank flag DataZRemRangeByRankFlag DataFlag = 11 // DataZPopMaxFlag represents the data ZPopMax flag DataZPopMaxFlag DataFlag = 12 // DataZPopMinFlag represents the data aZPopMin flag DataZPopMinFlag DataFlag = 13 // DataSetBucketDeleteFlag represents the delete Set bucket flag DataSetBucketDeleteFlag DataFlag = 14 // DataSortedSetBucketDeleteFlag represents the delete Sorted Set bucket flag DataSortedSetBucketDeleteFlag DataFlag = 15 // DataBTreeBucketDeleteFlag represents the delete BTree bucket flag DataBTreeBucketDeleteFlag DataFlag = 16 // DataListBucketDeleteFlag represents the delete List bucket flag DataListBucketDeleteFlag DataFlag = 17 // DataLRemByIndex represents the data LRemByIndex flag DataLRemByIndex DataFlag = 18 // DataExpireListFlag represents that set ttl for the list DataExpireListFlag DataFlag = 19 )
type DataStructure ¶ added in v1.0.2
type DataStructure = uint16
DataStructure represents the data structure we have already supported
const ( // DataStructureSet represents the data structure set flag DataStructureSet DataStructure = 0 // DataStructureSortedSet represents the data structure sorted set flag DataStructureSortedSet DataStructure = 1 // DataStructureBTree represents the data structure b tree flag DataStructureBTree DataStructure = 2 // DataStructureList represents the data structure list flag DataStructureList DataStructure = 3 )
type Entry ¶
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 | status | ds | txId | bucketId | key | value | |----------------------------------------------------------------------------------------------------------| | uint32| uint64 |uint32 | uint32 | uint16 | uint32| uint16 | uint16 |uint64 | uint64 | []byte | []byte | |----------------------------------------------------------------------------------------------------------|
func (*Entry) GetTxIDBytes ¶ added in v0.12.4
GetTxIDBytes return the bytes of TxID
func (*Entry) IsBelongsToBPlusTree ¶ added in v1.0.2
func (*Entry) IsBelongsToList ¶ added in v1.0.2
func (*Entry) IsBelongsToSet ¶ added in v1.0.2
func (*Entry) IsBelongsToSortSet ¶ added in v1.0.2
func (*Entry) ParsePayload ¶
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 )
type EntryStatus ¶ added in v1.0.3
type EntryStatus = uint8
EntryStatus represents the Entry status in the current Tx
const ( // NotFoundEntry means there is no changes for this entry in current Tx NotFoundEntry EntryStatus = 0 // EntryDeleted means this Entry has been deleted in the current Tx EntryDeleted EntryStatus = 1 // EntryUpdated means this Entry has been updated in the current Tx EntryUpdated EntryStatus = 2 )
type EntryWhenRecovery ¶ added in v0.14.0
type EntryWhenRecovery struct { Entry // contains filtered or unexported fields }
type ErrorHandler ¶ added in v0.13.0
type ErrorHandler interface {
HandleError(err error)
}
An ErrorHandler handles an error occurred during transaction.
type ErrorHandlerFunc ¶ added in v0.13.0
type ErrorHandlerFunc func(err error)
The ErrorHandlerFunc type is an adapter to ErrorHandler.
func (ErrorHandlerFunc) HandleError ¶ added in v0.13.0
func (fn ErrorHandlerFunc) HandleError(err error)
type ExpiredDeleteType ¶ added in v0.14.0
type ExpiredDeleteType uint8
const ( // TimeWheel represents use time wheel to do expired deletion TimeWheel ExpiredDeleteType = iota // TimeHeap represents use time heap to do expired deletion TimeHeap )
type FdInfo ¶
type FdInfo struct {
// contains filtered or unexported fields
}
FdInfo holds base fd info
type FileIORWManager ¶
type FileIORWManager struct {
// contains filtered or unexported fields
}
FileIORWManager represents the RWManager which using standard I/O.
func (*FileIORWManager) Close ¶
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 ¶
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 ¶
func (fm *FileIORWManager) Release() (err error)
Release is a wrapper around the reduceUsing method
func (*FileIORWManager) Size ¶ added in v1.0.0
func (fm *FileIORWManager) Size() int64
func (*FileIORWManager) Sync ¶
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 GetByScoreRangeOptions ¶ added in v0.14.0
type GetByScoreRangeOptions struct { 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) }
GetByScoreRangeOptions represents the options of the GetByScoreRange function.
type HeadTailSeq ¶ added in v0.14.2
HeadTailSeq list head and tail seq num
type IDGenerator ¶ added in v1.0.0
type IDGenerator struct {
// contains filtered or unexported fields
}
func (*IDGenerator) GenId ¶ added in v1.0.0
func (g *IDGenerator) GenId() uint64
type IDMarkerInBucket ¶ added in v1.0.2
type IDMarkerInBucket map[BucketName]map[Ds]BucketId
type InfoMapperInBucket ¶ added in v1.0.2
type Iterator ¶
type Iterator struct {
// contains filtered or unexported fields
}
func NewIterator ¶
func NewIterator(tx *Tx, bucket string, options IteratorOptions) *Iterator
type IteratorOptions ¶
type IteratorOptions struct {
Reverse bool
}
type LRUCache ¶ added in v1.0.0
type LRUCache struct {
// contains filtered or unexported fields
}
LRUCache is a least recently used (LRU) cache.
func NewLruCache ¶ added in v1.0.0
New creates a new LRUCache with the specified capacity.
func (*LRUCache) Add ¶ added in v1.0.0
func (c *LRUCache) Add(key interface{}, value interface{})
Add adds a new entry to the cache.
func (*LRUCache) Get ¶ added in v1.0.0
func (c *LRUCache) Get(key interface{}) interface{}
Get returns the entry associated with the given key, or nil if the key is not in the cache.
type List ¶ added in v0.13.0
type List struct { Items map[string]*BTree TTL map[string]uint32 TimeStamp map[string]uint64 Seq map[string]*HeadTailSeq }
List represents the list.
func (*List) LRange ¶ added in v0.13.0
LRange returns the specified elements of the list stored at key [start,end]
func (*List) LRem ¶ added in v0.13.0
LRem removes the first count occurrences of elements equal to value from the list stored at key. 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 (*List) LRemByIndex ¶ added in v0.13.0
LRemByIndex remove the list element at specified index
func (*List) LTrim ¶ added in v0.13.0
LTrim trim an existing list so that it will contain only the specified range of elements specified.
type LruEntry ¶ added in v1.0.0
type LruEntry struct { Key interface{} Value interface{} }
LruEntry is a struct that represents an entry in the LRU cache.
type MMapRWManager ¶
type MMapRWManager struct {
// contains filtered or unexported fields
}
MMapRWManager represents the RWManager which using mmap.
func (*MMapRWManager) Close ¶
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 ¶
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 ¶
func (mm *MMapRWManager) Release() (err error)
Release deletes the memory mapped region, flushes any remaining changes
func (*MMapRWManager) Size ¶ added in v1.0.0
func (mm *MMapRWManager) Size() int64
func (*MMapRWManager) Sync ¶
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 DataFlag // delete / set BucketSize uint32 TxID uint64 Status DataStatus // committed / uncommitted Ds DataStructure // data structure Crc uint32 BucketId BucketId }
func NewMetaData ¶ added in v0.12.6
func NewMetaData() *MetaData
func (*MetaData) IsBPlusTree ¶ added in v1.0.2
func (*MetaData) PayloadSize ¶
func (*MetaData) WithBucketId ¶ added in v1.0.0
func (*MetaData) WithBucketSize ¶ added in v0.12.6
func (*MetaData) WithKeySize ¶ added in v0.12.6
func (*MetaData) WithStatus ¶ added in v0.12.6
func (*MetaData) WithTimeStamp ¶ added in v0.12.6
func (*MetaData) WithValueSize ¶ added in v0.12.6
type Option ¶
type Option func(*Options)
func WithCommitBufferSize ¶ added in v0.13.0
func WithEntryIdxMode ¶
func WithEntryIdxMode(entryIdxMode EntryIdxMode) Option
func WithErrorHandler ¶ added in v0.13.0
func WithErrorHandler(errorHandler ErrorHandler) Option
func WithGCWhenClose ¶ added in v0.12.4
func WithHintKeyAndRAMIdxCacheSize ¶ added in v1.0.0
func WithLessFunc ¶ added in v0.13.0
func WithMaxBatchCount ¶ added in v0.13.1
func WithMaxBatchSize ¶ added in v0.13.1
func WithMaxFdNumsInCache ¶
func WithMaxWriteRecordCount ¶ added in v0.14.1
func WithNodeNum ¶
func WithRWMode ¶
func WithSegmentSize ¶
func WithSyncEnable ¶
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 // CcWhenClose represent initiative GC when calling db.Close() GCWhenClose bool // CommitBufferSize represent allocated memory for tx CommitBufferSize int64 // ErrorHandler handles an error occurred during transaction. // Example: // func triggerAlertError(err error) { // if errors.Is(err, targetErr) { // alertManager.TriggerAlert() // } // }) ErrorHandler ErrorHandler // LessFunc is a function that sorts keys. LessFunc LessFunc // MergeInterval represent the interval for automatic merges, with 0 meaning automatic merging is disabled. MergeInterval time.Duration // MaxBatchCount represents max entries in batch MaxBatchCount int64 // MaxBatchSize represents max batch size in bytes MaxBatchSize int64 // ExpiredDeleteType represents the data structure used for expired deletion // TimeWheel means use the time wheel, You can use it when you need high performance or low memory usage // TimeHeap means use the time heap, You can use it when you need to delete precisely or memory usage will be high ExpiredDeleteType ExpiredDeleteType // max write record num MaxWriteRecordCount int64 // cache size for HintKeyAndRAMIdxMode HintKeyAndRAMIdxCacheSize int }
Options records params for creating DB object.
type RWManager ¶
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) Size() int64 Close() (err error) }
RWManager represents an interface to a RWManager.
type Record ¶
type Record struct { Key []byte Value []byte FileID int64 DataPos uint64 ValueSize uint32 Timestamp uint64 TTL uint32 TxID uint64 }
Record means item of indexes in memory
func (*Record) WithDataPos ¶ added in v1.0.0
WithDataPos set DataPos to Record
func (*Record) WithFileId ¶ added in v1.0.0
WithFileId set FileID to Record
func (*Record) WithTimestamp ¶ added in v1.0.0
func (*Record) WithValueSize ¶ added in v1.0.0
type Set ¶ added in v0.13.1
func (*Set) SAreMembers ¶ added in v0.13.1
SAreMembers Returns if members are members of the set stored at key. For multiple items it returns true only if all the items exist.
func (*Set) SCard ¶ added in v0.13.1
SCard Returns the set cardinality (number of elements) of the set stored at key.
func (*Set) SDiff ¶ added in v0.13.1
SDiff Returns the members of the set resulting from the difference between the first set and all the successive sets.
func (*Set) SInter ¶ added in v0.13.1
SInter Returns the members of the set resulting from the intersection of all the given sets.
func (*Set) SIsMember ¶ added in v0.13.1
SIsMember Returns if member is a member of the set stored at key.
func (*Set) SMembers ¶ added in v0.13.1
SMembers returns all the members of the set value stored at key.
func (*Set) SMove ¶ added in v0.13.1
SMove moves member from the set at source to the set at destination.
func (*Set) SPop ¶ added in v0.13.1
SPop removes and returns one or more random elements from the set value store at key.
type SkipList ¶ added in v0.14.0
type SkipList struct {
// contains filtered or unexported fields
}
The SkipList represents the sorted set.
func (*SkipList) FindRank ¶ added in v0.14.0
FindRank Returns the rank of member in the sorted set stored at key, with the scores ordered from low to high. Note that the rank is 1-based integer. Rank 1 means the first node If the node is not found, 0 is returned. Otherwise rank(> 0) is returned.
Time complexity of this method is : O(log(N)).
func (*SkipList) FindRevRank ¶ added in v0.14.0
FindRevRank Returns the rank of member in the sorted set stored at key, with the scores ordered from high to low.
func (*SkipList) GetByRank ¶ added in v0.14.0
func (sl *SkipList) GetByRank(rank int, remove bool) *SkipListNode
GetByRank returns the node at given rank. Note that the rank is 1-based integer. Rank 1 means the first node; Rank -1 means the last node. If remove is true, the returned nodes are removed If node is not found at specific rank, nil is returned.
Time complexity of this method is : O(log(N)).
func (*SkipList) GetByRankRange ¶ added in v0.14.0
func (sl *SkipList) GetByRankRange(start, end int, remove bool) []*SkipListNode
GetByRankRange returns nodes within specific rank range [start, end]. Note that the rank is 1-based integer. Rank 1 means the first node; Rank -1 means the last node If start is greater than end, the returned array is in reserved order If remove is true, the returned nodes are removed.
Time complexity of this method is : O(log(N)).
func (*SkipList) GetByScoreRange ¶ added in v0.14.0
func (sl *SkipList) GetByScoreRange(start SCORE, end SCORE, options *GetByScoreRangeOptions) []*SkipListNode
GetByScoreRange returns the nodes whose score within the specific range. If options is nil, it searches in interval [start, end] without any limit by default.
Time complexity of this method is : O(log(N)).
func (*SkipList) GetByValue ¶ added in v0.14.0
func (sl *SkipList) GetByValue(value []byte) *SkipListNode
GetByValue returns the node at given key. If node is not found, nil is returned
Time complexity : O(1).
func (*SkipList) PeekMax ¶ added in v0.14.0
func (sl *SkipList) PeekMax() *SkipListNode
PeekMax returns the element with maximum score, nil if the set is empty.
Time Complexity : O(1).
func (*SkipList) PeekMin ¶ added in v0.14.0
func (sl *SkipList) PeekMin() *SkipListNode
PeekMin returns the element with minimum score, nil if the set is empty.
Time complexity of this method is : O(log(N)).
func (*SkipList) PopMax ¶ added in v0.14.0
func (sl *SkipList) PopMax() *SkipListNode
PopMax returns and remove the element with maximum score, nil if the set is empty.
Time complexity of this method is : O(log(N)).
func (*SkipList) PopMin ¶ added in v0.14.0
func (sl *SkipList) PopMin() *SkipListNode
PopMin returns and remove the element with minimal score, nil if the set is empty.
Time complexity of this method is : O(log(N)).
func (*SkipList) Put ¶ added in v0.14.0
Put puts an element into the sorted set with specific key / value / score.
Time complexity of this method is : O(log(N)).
func (*SkipList) Remove ¶ added in v0.14.0
func (sl *SkipList) Remove(hash uint32) *SkipListNode
Remove removes element specified at given key.
Time complexity of this method is : O(log(N)).
type SkipListLevel ¶ added in v0.14.0
type SkipListLevel struct {
// contains filtered or unexported fields
}
SkipListLevel records forward and span.
type SkipListNode ¶ added in v0.14.0
type SkipListNode struct {
// contains filtered or unexported fields
}
SkipListNode represents a node in the SkipList.
func (*SkipListNode) Hash ¶ added in v0.14.0
func (sln *SkipListNode) Hash() uint32
Hash returns the key of the node.
func (*SkipListNode) Score ¶ added in v0.14.0
func (sln *SkipListNode) Score() SCORE
Score returns the score of the node.
type SortedSet ¶ added in v0.14.0
func NewSortedSet ¶ added in v0.14.0
func (*SortedSet) ZRangeByRank ¶ added in v0.14.0
func (*SortedSet) ZRangeByScore ¶ added in v0.14.0
func (*SortedSet) ZRemRangeByRank ¶ added in v0.14.0
type SortedSetIdx ¶
type SortedSetIdx struct {
// contains filtered or unexported fields
}
type SortedSetMember ¶ added in v0.14.0
type Throttle ¶ added in v0.13.1
type Throttle struct {
// contains filtered or unexported fields
}
Throttle allows a limited number of workers to run at a time. It also provides a mechanism to check for errors encountered by workers and wait for them to finish.
func NewThrottle ¶ added in v0.13.1
NewThrottle creates a new throttle with a max number of workers.
func (*Throttle) Do ¶ added in v0.13.1
Do should be called by workers before they start working. It blocks if there are already maximum number of workers working. If it detects an error from previously Done workers, it would return it.
func (*Throttle) Done ¶ added in v0.13.1
Done should be called by workers when they finish working. They can also pass the error status of work done.
type Tx ¶
type Tx struct {
// 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) CommitWith ¶ added in v0.13.1
func (*Tx) DeleteBucket ¶
DeleteBucket delete bucket depends on ds (represents the data structure)
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) GetListTTL ¶ added in v0.12.1
func (*Tx) GetTTL ¶ added in v1.0.3
GetTTL returns remaining TTL of a value by key. It returns (-1, nil) If TTL is Persistent (0, ErrBucketNotFound|ErrKeyNotFound) If expired or not found (TTL, nil) If the record exists with a TTL Note: The returned remaining TTL will be in seconds. For example, remainingTTL is 500ms, It'll return 0.
func (*Tx) GetValues ¶ added in v1.0.3
GetValues returns all values of the bucket stored at given bucket.
func (*Tx) IterateBuckets ¶
IterateBuckets iterate over all the bucket depends on ds (represents the data structure)
func (*Tx) LPeek ¶
LPeek returns the first element of the list stored in the bucket at given bucket and key.
func (*Tx) LPop ¶
LPop removes and returns the first element of the list stored in the bucket at given bucket and key.
func (*Tx) LPush ¶
LPush inserts the values at the head of the list stored in the bucket at given bucket,key and values.
func (*Tx) LRange ¶
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 ¶
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 ¶
LRemByIndex remove the list element at specified index
func (*Tx) LSize ¶
LSize returns the size of key in the bucket in the bucket at given bucket and key.
func (*Tx) LTrim ¶
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) NewKVBucket ¶ added in v1.0.0
func (*Tx) NewListBucket ¶ added in v1.0.0
func (*Tx) NewSetBucket ¶ added in v1.0.0
func (*Tx) NewSortSetBucket ¶ added in v1.0.0
func (*Tx) Persist ¶ added in v1.0.3
Persist updates record's TTL as Persistent if the record exits.
func (*Tx) PrefixScan ¶
func (tx *Tx) PrefixScan(bucket string, prefix []byte, offsetNum int, limitNum int) (values [][]byte, 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 ¶
func (tx *Tx) PrefixSearchScan(bucket string, prefix []byte, reg string, offsetNum int, limitNum int) (values [][]byte, 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) PutIfExists ¶ added in v1.0.2
PutIfExits set the value for a key in the bucket only if the key already exits.
func (*Tx) PutIfNotExists ¶ added in v1.0.2
PutIfNotExists set the value for a key in the bucket only if the key doesn't exist already.
func (*Tx) PutWithTimestamp ¶
func (*Tx) RPeek ¶
RPeek returns the last element of the list stored in the bucket at given bucket and key.
func (*Tx) RPop ¶
RPop removes and returns the last element of the list stored in the bucket at given bucket and key.
func (*Tx) RPush ¶
RPush inserts the values at the tail of the list stored in the bucket at given bucket,key and values.
func (*Tx) SAdd ¶
SAdd adds the specified members to the set stored int the bucket at given bucket,key and items.
func (*Tx) SAreMembers ¶
SAreMembers returns if the specified members are the member of the set int the bucket at given bucket,key and items.
func (*Tx) SCard ¶
SCard returns the set cardinality (number of elements) of the set stored in the bucket at given bucket and key.
func (*Tx) SDiffByOneBucket ¶
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 ¶
func (tx *Tx) SDiffByTwoBuckets(bucket1 string, key1 []byte, bucket2 string, key2 []byte) ([][]byte, 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) SIsMember ¶
SIsMember returns if member is a member of the set stored int the bucket at given bucket,key and item.
func (*Tx) SMembers ¶
SMembers returns all the members of the set value stored int the bucket at given bucket and key.
func (*Tx) SMoveByOneBucket ¶
SMoveByOneBucket moves member from the set at source to the set at destination in one bucket.
func (*Tx) SMoveByTwoBuckets ¶
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 ¶
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 ¶
SRem removes the specified members from the set stored int the bucket at given bucket,key and items.
func (*Tx) SUnionByOneBucket ¶
SUnionByOneBucket the members of the set resulting from the union of all the given sets in one bucket.
func (*Tx) SUnionByTwoBuckets ¶
func (tx *Tx) SUnionByTwoBuckets(bucket1 string, key1 []byte, bucket2 string, key2 []byte) ([][]byte, error)
SUnionByTwoBuckets the members of the set resulting from the union of all the given sets in two buckets.
func (*Tx) SubmitBucket ¶ added in v1.0.0
func (*Tx) ZAdd ¶
ZAdd Adds the specified member with the specified score into the sorted set specified by key in a bucket.
func (*Tx) ZCard ¶
ZCard Returns the sorted set cardinality (number of elements) of the sorted set specified by key in a bucket.
func (*Tx) ZCount ¶
func (tx *Tx) ZCount(bucket string, key []byte, start, end float64, opts *GetByScoreRangeOptions) (int, error)
ZCount Returns the number of elements in the sorted set specified by key in a bucket with a score between min and max and opts. Opt 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) ZMembers ¶
func (tx *Tx) ZMembers(bucket string, key []byte) (map[*SortedSetMember]struct{}, error)
ZMembers Returns all the members and scores of members of the set specified by key in a bucket.
func (*Tx) ZPeekMax ¶
func (tx *Tx) ZPeekMax(bucket string, key []byte) (*SortedSetMember, error)
ZPeekMax Returns the member with the highest score in the sorted set specified by key in a bucket.
func (*Tx) ZPeekMin ¶
func (tx *Tx) ZPeekMin(bucket string, key []byte) (*SortedSetMember, error)
ZPeekMin Returns the member with the lowest score in the sorted set specified by key in a bucket.
func (*Tx) ZPopMax ¶
func (tx *Tx) ZPopMax(bucket string, key []byte) (*SortedSetMember, error)
ZPopMax Removes and returns the member with the highest score in the sorted set specified by key in a bucket.
func (*Tx) ZPopMin ¶
func (tx *Tx) ZPopMin(bucket string, key []byte) (*SortedSetMember, error)
ZPopMin Removes and returns the member with the lowest score in the sorted set specified by key in a bucket.
func (*Tx) ZRangeByRank ¶
ZRangeByRank Returns all the elements in the sorted set specified by key in a bucket with a rank between start and end (including elements with rank equal to start or end).
func (*Tx) ZRangeByScore ¶
func (tx *Tx) ZRangeByScore(bucket string, key []byte, start, end float64, opts *GetByScoreRangeOptions) ([]*SortedSetMember, error)
ZRangeByScore Returns all the elements in the sorted set specified by key in a bucket with a score between min and max. And the parameter `Opts` is the same as ZCount's.
func (*Tx) ZRank ¶
ZRank Returns the rank of member in the sorted set specified by key in a bucket, with the scores ordered from low to high.
func (*Tx) ZRem ¶
ZRem removes the specified members from the sorted set stored in one bucket at given bucket and key.
func (*Tx) ZRemRangeByRank ¶
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.
type WriteBatch ¶ added in v0.13.1
WriteBatch holds the necessary info to perform batched writes.
func (*WriteBatch) Cancel ¶ added in v0.13.1
func (wb *WriteBatch) Cancel() error
func (*WriteBatch) Delete ¶ added in v0.13.1
func (wb *WriteBatch) Delete(bucket string, key []byte) error
func (tx *Tx) Delete(bucket string, key []byte) error
func (*WriteBatch) Error ¶ added in v0.13.1
func (wb *WriteBatch) Error() error
Error returns any errors encountered so far. No commits would be run once an error is detected.
func (*WriteBatch) Flush ¶ added in v0.13.1
func (wb *WriteBatch) Flush() error
func (*WriteBatch) Put ¶ added in v0.13.1
func (wb *WriteBatch) Put(bucket string, key, value []byte, ttl uint32) error
func (*WriteBatch) Reset ¶ added in v0.13.1
func (wb *WriteBatch) Reset() error
func (*WriteBatch) SetMaxPendingTxns ¶ added in v0.13.1
func (wb *WriteBatch) SetMaxPendingTxns(max int)
SetMaxPendingTxns sets a limit on maximum number of pending transactions while writing batches. This function should be called before using WriteBatch. Default value of MaxPendingTxns is 16 to minimise memory usage.
Source Files
¶
- batch.go
- btree.go
- bucket.go
- bucket_manager.go
- const.go
- datafile.go
- db.go
- db_error.go
- doc.go
- entity_utils.go
- entry.go
- errors.go
- fd_manager.go
- file_manager.go
- index.go
- iterator.go
- list.go
- lru.go
- merge.go
- metadata.go
- options.go
- pending.go
- record.go
- recovery_reader.go
- rwmanager.go
- rwmanger_fileio.go
- rwmanger_mmap.go
- set.go
- sorted_set.go
- tar.go
- test_utils.go
- throttle.go
- ttl_manager.go
- tx.go
- tx_btree.go
- tx_bucket.go
- tx_error.go
- tx_list.go
- tx_set.go
- tx_zset.go
- utils.go
- value.go