Documentation
¶
Index ¶
- Constants
- Variables
- func ActiveWithNoTxnFilter(be *BaseEntry) bool
- func AppendableBlkFilter(be *BlockEntry) bool
- func CheckpointOp(ckpEntry *CheckpointEntry, entry *BaseEntry, item CheckpointItem, ...)
- func CheckpointSelectOp(entry *BaseEntry, minTs, maxTs uint64) bool
- func CmdName(t int16) string
- func CompareUint64(left, right uint64) int
- func EstimateBlockSize(meta *BlockEntry, rows uint32) uint32
- func EstimateColumnBlockSize(colIdx int, rows uint32, meta *BlockEntry) uint32
- func GetAttrIdx(attrs []string, name string) int
- func MarshalDefault(w *bytes.Buffer, typ types.Type, data Default) (err error)
- func MockBatch(schema *Schema, rows int) *containers.Batch
- func MockTxnFactory(catalog *Catalog) txnbase.TxnFactory
- func MockTxnStoreFactory(catalog *Catalog) txnbase.TxnStoreFactory
- func NonAppendableBlkFilter(be *BlockEntry) bool
- func OpName(op OpT) string
- func UnMarshalDefault(r io.Reader, typ types.Type, data *Default) (n int64, err error)
- type BaseEntry
- func (be *BaseEntry) ApplyCommit(index *wal.Index) error
- func (be *BaseEntry) ApplyDeleteCmd(ts uint64, index *wal.Index) error
- func (be *BaseEntry) ApplyRollback() error
- func (be *BaseEntry) Clone() *BaseEntry
- func (be *BaseEntry) CloneCreate() *BaseEntry
- func (be *BaseEntry) CreateAfter(ts uint64) bool
- func (be *BaseEntry) CreateAndDropInSameTxn() bool
- func (be *BaseEntry) CreateBefore(ts uint64) bool
- func (be *BaseEntry) DeleteAfter(ts uint64) bool
- func (be *BaseEntry) DeleteBefore(ts uint64) bool
- func (be *BaseEntry) DoCompre(oe *BaseEntry) int
- func (be *BaseEntry) DropEntryLocked(txnCtx txnif.TxnReader) error
- func (be *BaseEntry) GetID() uint64
- func (be *BaseEntry) GetLogIndex() *wal.Index
- func (be *BaseEntry) GetTxn() txnif.TxnReader
- func (be *BaseEntry) GetTxnID() uint64
- func (be *BaseEntry) HasActiveTxn() bool
- func (be *BaseEntry) HasCreated() bool
- func (be *BaseEntry) HasDropped() bool
- func (be *BaseEntry) InTxnOrRollbacked() bool
- func (be *BaseEntry) IsCommitted() bool
- func (be *BaseEntry) IsCommitting() bool
- func (be *BaseEntry) IsCreatedUncommitted() bool
- func (be *BaseEntry) IsDroppedCommitted() bool
- func (be *BaseEntry) IsDroppedUncommitted() bool
- func (be *BaseEntry) IsSameTxn(ctx txnif.TxnReader) bool
- func (be *BaseEntry) IsTerminated(waitIfcommitting bool) bool
- func (be *BaseEntry) MaxCommittedTS() uint64
- func (be *BaseEntry) PrepareCommit() error
- func (be *BaseEntry) PrepareRollback() error
- func (be *BaseEntry) PrepareWrite(txn txnif.TxnReader, rwlocker *sync.RWMutex) (err error)
- func (be *BaseEntry) ReadFrom(r io.Reader) (n int64, err error)
- func (be *BaseEntry) SameTxn(o *BaseEntry) bool
- func (be *BaseEntry) String() string
- func (be *BaseEntry) TxnCanRead(txn txnif.AsyncTxn, rwlocker *sync.RWMutex) (ok bool, err error)
- func (be *BaseEntry) WriteTo(w io.Writer) (n int64, err error)
- type BlockDataFactory
- type BlockEntry
- func (entry *BlockEntry) AsCommonID() *common.ID
- func (entry *BlockEntry) Clone() CheckpointItem
- func (entry *BlockEntry) CloneCreate() CheckpointItem
- func (entry *BlockEntry) Compare(o common.NodePayload) int
- func (entry *BlockEntry) DestroyData() (err error)
- func (entry *BlockEntry) GetBlockData() data.Block
- func (entry *BlockEntry) GetCatalog() *Catalog
- func (entry *BlockEntry) GetFileTs() (uint64, error)
- func (entry *BlockEntry) GetSchema() *Schema
- func (entry *BlockEntry) GetSegment() *SegmentEntry
- func (entry *BlockEntry) GetTerminationTS() (ts uint64, terminated bool)
- func (entry *BlockEntry) InitData(factory DataFactory)
- func (entry *BlockEntry) IsActive() bool
- func (entry *BlockEntry) IsAppendable() bool
- func (entry *BlockEntry) MakeCommand(id uint32) (cmd txnif.TxnCmd, err error)
- func (entry *BlockEntry) MakeKey() []byte
- func (entry *BlockEntry) MakeLogEntry() *EntryCommand
- func (entry *BlockEntry) PPString(level common.PPLevel, depth int, prefix string) string
- func (entry *BlockEntry) PrepareRollback() (err error)
- func (entry *BlockEntry) ReadFrom(r io.Reader) (n int64, err error)
- func (entry *BlockEntry) Repr() string
- func (entry *BlockEntry) String() string
- func (entry *BlockEntry) StringLocked() string
- func (entry *BlockEntry) WriteTo(w io.Writer) (n int64, err error)
- type Catalog
- func (catalog *Catalog) AddColumnCnt(cnt int)
- func (catalog *Catalog) AddEntryLocked(database *DBEntry) error
- func (catalog *Catalog) AddTableCnt(cnt int)
- func (catalog *Catalog) Checkpoint(maxTs uint64) (err error)
- func (catalog *Catalog) CheckpointClosure(maxTs uint64) tasks.FuncT
- func (catalog *Catalog) Close() error
- func (catalog *Catalog) CoarseColumnCnt() int
- func (catalog *Catalog) CoarseDBCnt() int
- func (catalog *Catalog) CoarseTableCnt() int
- func (catalog *Catalog) CreateDBEntry(name string, txnCtx txnif.AsyncTxn) (*DBEntry, error)
- func (catalog *Catalog) DropDBEntry(name string, txnCtx txnif.AsyncTxn) (deleted *DBEntry, err error)
- func (catalog *Catalog) GetCheckpointed() *Checkpoint
- func (catalog *Catalog) GetDBEntry(name string, txnCtx txnif.AsyncTxn) (*DBEntry, error)
- func (catalog *Catalog) GetDatabaseByID(id uint64) (db *DBEntry, err error)
- func (catalog *Catalog) GetScheduler() tasks.TaskScheduler
- func (catalog *Catalog) GetStore() store.Store
- func (catalog *Catalog) InitSystemDB()
- func (catalog *Catalog) MakeDBIt(reverse bool) *common.LinkIt
- func (catalog *Catalog) PPString(level common.PPLevel, depth int, prefix string) string
- func (catalog *Catalog) PrepareCheckpoint(startTs, endTs uint64) *CheckpointEntry
- func (catalog *Catalog) RecurLoop(processor Processor) (err error)
- func (catalog *Catalog) RemoveEntry(database *DBEntry) error
- func (catalog *Catalog) ReplayCmd(txncmd txnif.TxnCmd, dataFactory DataFactory, idxCtx *wal.Index, ...)
- func (catalog *Catalog) ReplayTableRows()
- func (catalog *Catalog) SimplePPString(level common.PPLevel) string
- type Checkpoint
- type CheckpointEntry
- func (e *CheckpointEntry) AddCommand(cmd *EntryCommand)
- func (e *CheckpointEntry) AddIndex(index *wal.Index)
- func (e *CheckpointEntry) GetMaxIndex() *wal.Index
- func (e *CheckpointEntry) MakeLogEntry() (logEntry LogEntry, err error)
- func (e *CheckpointEntry) Marshal() (buf []byte, err error)
- func (e *CheckpointEntry) PrintItems()
- func (e *CheckpointEntry) Unmarshal(buf []byte) (err error)
- type CheckpointItem
- type ColDef
- type CommitInfo
- type ComposedFilter
- type DBEntry
- func (e *DBEntry) AddEntryLocked(table *TableEntry) (err error)
- func (e *DBEntry) Clone() CheckpointItem
- func (e *DBEntry) CloneCreate() CheckpointItem
- func (e *DBEntry) CloneCreateEntry() *DBEntry
- func (e *DBEntry) CoarseTableCnt() int
- func (e *DBEntry) Compare(o common.NodePayload) int
- func (e *DBEntry) CreateTableEntry(schema *Schema, txnCtx txnif.AsyncTxn, dataFactory TableDataFactory) (created *TableEntry, err error)
- func (e *DBEntry) DropTableEntry(name string, txnCtx txnif.AsyncTxn) (deleted *TableEntry, err error)
- func (e *DBEntry) GetBlockEntryByID(id *common.ID) (blk *BlockEntry, err error)
- func (e *DBEntry) GetCatalog() *Catalog
- func (e *DBEntry) GetName() string
- func (e *DBEntry) GetTableEntry(name string, txnCtx txnif.AsyncTxn) (entry *TableEntry, err error)
- func (e *DBEntry) GetTableEntryByID(id uint64) (table *TableEntry, err error)
- func (e *DBEntry) IsActive() bool
- func (e *DBEntry) IsSystemDB() bool
- func (e *DBEntry) MakeCommand(id uint32) (txnif.TxnCmd, error)
- func (e *DBEntry) MakeLogEntry() *EntryCommand
- func (e *DBEntry) MakeTableIt(reverse bool) *common.LinkIt
- func (e *DBEntry) PPString(level common.PPLevel, depth int, prefix string) string
- func (e *DBEntry) PrepareRollback() (err error)
- func (e *DBEntry) ReadFrom(r io.Reader) (n int64, err error)
- func (e *DBEntry) RecurLoop(processor Processor) (err error)
- func (e *DBEntry) RemoveEntry(table *TableEntry) (err error)
- func (e *DBEntry) String() string
- func (e *DBEntry) StringLocked() string
- func (e *DBEntry) WriteTo(w io.Writer) (n int64, err error)
- type DataFactory
- type Default
- type EntryCommand
- func (cmd *EntryCommand) Desc() string
- func (cmd *EntryCommand) GetID() (uint64, *common.ID)
- func (cmd *EntryCommand) GetLogIndex() *wal.Index
- func (cmd *EntryCommand) GetTs() uint64
- func (cmd *EntryCommand) GetType() int16
- func (cmd *EntryCommand) IDString() string
- func (cmd *EntryCommand) Marshal() (buf []byte, err error)
- func (cmd *EntryCommand) ReadFrom(r io.Reader) (n int64, err error)
- func (cmd *EntryCommand) String() string
- func (cmd *EntryCommand) Unmarshal(buf []byte) (err error)
- func (cmd *EntryCommand) VerboseString() string
- func (cmd *EntryCommand) WriteTo(w io.Writer) (n int64, err error)
- type EntryState
- type EntryType
- type IDAlloctor
- func (alloc *IDAlloctor) CurrBlock() uint64
- func (alloc *IDAlloctor) CurrDB() uint64
- func (alloc *IDAlloctor) CurrSegment() uint64
- func (alloc *IDAlloctor) CurrTable() uint64
- func (alloc *IDAlloctor) IDStates() string
- func (alloc *IDAlloctor) Init(prevDb, prevTbl, prevSeg, prevBlk uint64)
- func (alloc *IDAlloctor) NextBlock() uint64
- func (alloc *IDAlloctor) NextDB() uint64
- func (alloc *IDAlloctor) NextSegment() uint64
- func (alloc *IDAlloctor) NextTable() uint64
- func (alloc *IDAlloctor) OnReplayBlockID(id uint64)
- func (alloc *IDAlloctor) OnReplayDBID(id uint64)
- func (alloc *IDAlloctor) OnReplaySegmentID(id uint64)
- func (alloc *IDAlloctor) OnReplayTableID(id uint64)
- type IndexInfo
- type IndexT
- type LogEntry
- type LoopProcessor
- func (p *LoopProcessor) OnBlock(block *BlockEntry) error
- func (p *LoopProcessor) OnDatabase(database *DBEntry) error
- func (p *LoopProcessor) OnPostSegment(segment *SegmentEntry) error
- func (p *LoopProcessor) OnSegment(segment *SegmentEntry) error
- func (p *LoopProcessor) OnTable(table *TableEntry) error
- type OpT
- type PersistentType
- type Processor
- type Replayer
- type Schema
- func (s *Schema) AllNames() []string
- func (s *Schema) AllNullables() []bool
- func (s *Schema) AllTypes() []types.Type
- func (s *Schema) AppendCol(name string, typ types.Type) error
- func (s *Schema) AppendColDef(def *ColDef) (err error)
- func (s *Schema) AppendColWithDefault(name string, typ types.Type, val Default) error
- func (s *Schema) AppendPKCol(name string, typ types.Type, idx int) error
- func (s *Schema) AppendSortKey(name string, typ types.Type, idx int, isPrimary bool) error
- func (s *Schema) Attrs() []string
- func (s *Schema) Clone() *Schema
- func (s *Schema) Finalize(rebuild bool) (err error)
- func (s *Schema) GetColIdx(attr string) int
- func (s *Schema) GetSingleSortKey() *ColDef
- func (s *Schema) GetSingleSortKeyIdx() int
- func (s *Schema) GetSortKeyCnt() int
- func (s *Schema) GetSortKeyType() types.Type
- func (s *Schema) HasPK() bool
- func (s *Schema) HasSortKey() bool
- func (s *Schema) IsCompoundPK() bool
- func (s *Schema) IsCompoundSortKey() bool
- func (s *Schema) IsPartOfPK(idx int) bool
- func (s *Schema) IsSinglePK() bool
- func (s *Schema) IsSingleSortKey() bool
- func (s *Schema) Marshal() (buf []byte, err error)
- func (s *Schema) Nullables() []bool
- func (s *Schema) ReadFrom(r io.Reader) (n int64, err error)
- func (s *Schema) String() string
- func (s *Schema) Types() []types.Type
- type SegmentDataFactory
- type SegmentEntry
- func (entry *SegmentEntry) AddEntryLocked(block *BlockEntry)
- func (entry *SegmentEntry) AsCommonID() *common.ID
- func (entry *SegmentEntry) BlockCnt() int
- func (entry *SegmentEntry) Clone() CheckpointItem
- func (entry *SegmentEntry) CloneCreate() CheckpointItem
- func (entry *SegmentEntry) CollectBlockEntries(commitFilter func(be *BaseEntry) bool, blockFilter func(be *BlockEntry) bool) []*BlockEntry
- func (entry *SegmentEntry) Compare(o common.NodePayload) int
- func (entry *SegmentEntry) CreateBlock(txn txnif.AsyncTxn, state EntryState, dataFactory BlockDataFactory) (created *BlockEntry, err error)
- func (entry *SegmentEntry) DestroyData() (err error)
- func (entry *SegmentEntry) DropBlockEntry(id uint64, txn txnif.AsyncTxn) (deleted *BlockEntry, err error)
- func (entry *SegmentEntry) GetAppendableBlockCnt() int
- func (entry *SegmentEntry) GetBlockEntryByID(id uint64) (blk *BlockEntry, err error)
- func (entry *SegmentEntry) GetBlockEntryByIDLocked(id uint64) (blk *BlockEntry, err error)
- func (entry *SegmentEntry) GetCatalog() *Catalog
- func (entry *SegmentEntry) GetScheduler() tasks.TaskScheduler
- func (entry *SegmentEntry) GetSegmentData() data.Segment
- func (entry *SegmentEntry) GetTable() *TableEntry
- func (entry *SegmentEntry) InitData(factory DataFactory)
- func (entry *SegmentEntry) IsActive() bool
- func (entry *SegmentEntry) IsAppendable() bool
- func (entry *SegmentEntry) LastAppendableBlock() (blk *BlockEntry)
- func (entry *SegmentEntry) MakeBlockIt(reverse bool) *common.LinkIt
- func (entry *SegmentEntry) MakeCommand(id uint32) (cmd txnif.TxnCmd, err error)
- func (entry *SegmentEntry) MakeLogEntry() *EntryCommand
- func (entry *SegmentEntry) PPString(level common.PPLevel, depth int, prefix string) string
- func (entry *SegmentEntry) PrepareRollback() (err error)
- func (entry *SegmentEntry) ReadFrom(r io.Reader) (n int64, err error)
- func (entry *SegmentEntry) RemoveEntry(block *BlockEntry) (err error)
- func (entry *SegmentEntry) Repr() string
- func (entry *SegmentEntry) String() string
- func (entry *SegmentEntry) StringLocked() string
- func (entry *SegmentEntry) TreeMaxDropCommitEntry() *BaseEntry
- func (entry *SegmentEntry) WriteTo(w io.Writer) (n int64, err error)
- type SortKey
- type TableDataFactory
- type TableEntry
- func (entry *TableEntry) AddEntryLocked(segment *SegmentEntry)
- func (entry *TableEntry) AddRows(delta uint64) uint64
- func (entry *TableEntry) AsCommonID() *common.ID
- func (entry *TableEntry) Clone() CheckpointItem
- func (entry *TableEntry) CloneCreate() CheckpointItem
- func (entry *TableEntry) CloneCreateEntry() *TableEntry
- func (entry *TableEntry) Compare(o common.NodePayload) int
- func (entry *TableEntry) CreateSegment(txn txnif.AsyncTxn, state EntryState, dataFactory SegmentDataFactory) (created *SegmentEntry, err error)
- func (entry *TableEntry) DropSegmentEntry(id uint64, txn txnif.AsyncTxn) (deleted *SegmentEntry, err error)
- func (entry *TableEntry) GetCatalog() *Catalog
- func (entry *TableEntry) GetDB() *DBEntry
- func (entry *TableEntry) GetRows() uint64
- func (entry *TableEntry) GetSchema() *Schema
- func (entry *TableEntry) GetSegmentByID(id uint64) (seg *SegmentEntry, err error)
- func (entry *TableEntry) GetTableData() data.Table
- func (entry *TableEntry) IsActive() bool
- func (entry *TableEntry) IsVirtual() bool
- func (entry *TableEntry) LastAppendableSegmemt() (seg *SegmentEntry)
- func (entry *TableEntry) MakeCommand(id uint32) (cmd txnif.TxnCmd, err error)
- func (entry *TableEntry) MakeLogEntry() *EntryCommand
- func (entry *TableEntry) MakeSegmentIt(reverse bool) *common.LinkIt
- func (entry *TableEntry) PPString(level common.PPLevel, depth int, prefix string) string
- func (entry *TableEntry) PrepareRollback() (err error)
- func (entry *TableEntry) ReadFrom(r io.Reader) (n int64, err error)
- func (entry *TableEntry) RecurLoop(processor Processor) (err error)
- func (entry *TableEntry) RemoveEntry(segment *SegmentEntry) (err error)
- func (entry *TableEntry) RemoveRows(delta uint64) uint64
- func (entry *TableEntry) String() string
- func (entry *TableEntry) StringLocked() string
- func (entry *TableEntry) WriteTo(w io.Writer) (n int64, err error)
- type TableType
Constants ¶
View Source
const ( CmdCreateDatabase = int16(256) + iota CmdDropDatabase CmdCreateTable CmdDropTable CmdCreateSegment CmdDropSegment CmdCreateBlock CmdDropBlock CmdLogDatabase CmdLogTable CmdLogSegment CmdLogBlock )
View Source
const ( HiddenColumnName = "PADDR" HiddenColumnComment = "Physical address" SortKeyNamePrefx = "_SORT_" SystemDBID = uint64(1) SystemDBName = "mo_catalog" CatalogName = "taec" SystemTable_DB_Name = "mo_database" SystemTable_Table_Name = "mo_tables" SystemTable_Columns_Name = "mo_columns" SystemTable_DB_ID = uint64(1) SystemTable_Table_ID = uint64(2) SystemTable_Columns_ID = uint64(3) SystemSegment_DB_ID = uint64(101) SystemSegment_Table_ID = uint64(102) SystemSegment_Columns_ID = uint64(103) SystemBlock_DB_ID = uint64(201) SystemBlock_Table_ID = uint64(202) SystemBlock_Columns_ID = uint64(203) SystemCatalogName = "def" SystemPersistRel = "p" SystemTransientRel = "t" SystemOrdinaryRel = "r" SystemIndexRel = "i" SystemSequenceRel = "S" SystemViewRel = "v" SystemMaterializedRel = "m" SystemColPKConstraint = "p" SystemColNoConstraint = "n" )
View Source
const ( SystemDBAttr_Name = "datname" SystemDBAttr_CatalogName = "dat_catalog_name" SystemDBAttr_CreateSQL = "dat_createsql" SystemRelAttr_Name = "relname" SystemRelAttr_DBName = "reldatabase" SystemRelAttr_Persistence = "relpersistence" SystemRelAttr_Kind = "relkind" SystemRelAttr_Comment = "rel_comment" SystemRelAttr_CreateSQL = "rel_createsql" SystemColAttr_Name = "attname" SystemColAttr_DBName = "att_database" SystemColAttr_RelName = "att_relname" SystemColAttr_Type = "atttyp" SystemColAttr_Num = "attnum" SystemColAttr_Length = "att_length" SystemColAttr_NullAbility = "attnotnull" SystemColAttr_HasExpr = "atthasdef" SystemColAttr_DefaultExpr = "att_default" SystemColAttr_IsDropped = "attisdropped" SystemColAttr_ConstraintType = "att_constraint_type" SystemColAttr_IsUnsigned = "att_is_unsigned" SystemColAttr_IsAutoIncrement = "att_is_auto_increment" SystemColAttr_IsHidden = "att_is_hidden" SystemColAttr_Comment = "att_comment" )
View Source
const ( ModelSchemaName = "_ModelSchema" ModelAttrET = "ET" ModelAttrID = "ID" ModelAttrName = "NAME" ModelAttrTS = "TS" ModelAttrOpT = "OPT" ModelAttrLogIdx = "LOGIDX" ModelAttrInfo = "INFO" ModelAttrParentID = "PARENTID" )
View Source
const DefaultReplayCacheSize = 2 * common.M
View Source
const (
ETCatalogCheckpoint = entry.ETCustomizedStart + 100 + iota
)
Variables ¶
View Source
var ( ErrNotFound = errors.New("tae catalog: not found") ErrDuplicate = errors.New("tae catalog: duplicate") ErrCheckpoint = errors.New("tae catalog: checkpoint") ErrNotPermitted = errors.New("tae catalog: operation not permitted") ErrSchemaValidation = errors.New("tae catalog: schema validation") ErrStopCurrRecur = errors.New("tae catalog: stop current recursion") )
View Source
var EmptyCheckpoint = new(Checkpoint)
View Source
var (
HiddenColumnType types.Type
)
View Source
var OpNames = map[OpT]string{ OpCreate: "Create", OpUpdate: "Update", OpSoftDelete: "SoftDelete", OpHardDelete: "HardDelete", }
Functions ¶
func ActiveWithNoTxnFilter ¶
func AppendableBlkFilter ¶
func AppendableBlkFilter(be *BlockEntry) bool
func CheckpointOp ¶
func CheckpointOp(ckpEntry *CheckpointEntry, entry *BaseEntry, item CheckpointItem, minTs, maxTs uint64)
func CheckpointSelectOp ¶
func CompareUint64 ¶
func EstimateBlockSize ¶
func EstimateBlockSize(meta *BlockEntry, rows uint32) uint32
func EstimateColumnBlockSize ¶
func EstimateColumnBlockSize(colIdx int, rows uint32, meta *BlockEntry) uint32
func GetAttrIdx ¶
func MarshalDefault ¶
func MockTxnFactory ¶
func MockTxnFactory(catalog *Catalog) txnbase.TxnFactory
func MockTxnStoreFactory ¶
func MockTxnStoreFactory(catalog *Catalog) txnbase.TxnStoreFactory
func NonAppendableBlkFilter ¶
func NonAppendableBlkFilter(be *BlockEntry) bool
Types ¶
type BaseEntry ¶
type BaseEntry struct {
*sync.RWMutex
CommitInfo
PrevCommit *CommitInfo
ID uint64
CreateAt, DeleteAt uint64
}
func NewReplayBaseEntry ¶
func NewReplayBaseEntry() *BaseEntry
func (*BaseEntry) ApplyDeleteCmd ¶
func (*BaseEntry) ApplyRollback ¶
func (*BaseEntry) CloneCreate ¶
func (*BaseEntry) CreateAfter ¶
func (*BaseEntry) CreateAndDropInSameTxn ¶
func (*BaseEntry) CreateBefore ¶
func (*BaseEntry) DeleteAfter ¶
func (*BaseEntry) DeleteBefore ¶
func (*BaseEntry) DropEntryLocked ¶
func (*BaseEntry) GetLogIndex ¶
func (*BaseEntry) HasActiveTxn ¶
func (*BaseEntry) HasCreated ¶
func (*BaseEntry) HasDropped ¶
func (*BaseEntry) InTxnOrRollbacked ¶
func (*BaseEntry) IsCommitted ¶
func (*BaseEntry) IsCommitting ¶
func (*BaseEntry) IsCreatedUncommitted ¶
func (*BaseEntry) IsDroppedCommitted ¶
func (*BaseEntry) IsDroppedUncommitted ¶
func (*BaseEntry) IsTerminated ¶
func (*BaseEntry) MaxCommittedTS ¶
func (*BaseEntry) PrepareCommit ¶
func (*BaseEntry) PrepareRollback ¶
func (*BaseEntry) PrepareWrite ¶
func (*BaseEntry) TxnCanRead ¶
type BlockDataFactory ¶
type BlockDataFactory = func(meta *BlockEntry) data.Block
type BlockEntry ¶
type BlockEntry struct {
*BaseEntry
// contains filtered or unexported fields
}
func NewBlockEntry ¶
func NewBlockEntry(segment *SegmentEntry, txn txnif.AsyncTxn, state EntryState, dataFactory BlockDataFactory) *BlockEntry
func NewReplayBlockEntry ¶
func NewReplayBlockEntry() *BlockEntry
func NewStandaloneBlock ¶
func NewStandaloneBlock(segment *SegmentEntry, id uint64, ts uint64) *BlockEntry
func NewSysBlockEntry ¶
func NewSysBlockEntry(segment *SegmentEntry, id uint64) *BlockEntry
func (*BlockEntry) AsCommonID ¶
func (entry *BlockEntry) AsCommonID() *common.ID
func (*BlockEntry) Clone ¶
func (entry *BlockEntry) Clone() CheckpointItem
func (*BlockEntry) CloneCreate ¶
func (entry *BlockEntry) CloneCreate() CheckpointItem
func (*BlockEntry) Compare ¶
func (entry *BlockEntry) Compare(o common.NodePayload) int
func (*BlockEntry) DestroyData ¶
func (entry *BlockEntry) DestroyData() (err error)
func (*BlockEntry) GetBlockData ¶
func (entry *BlockEntry) GetBlockData() data.Block
func (*BlockEntry) GetCatalog ¶
func (entry *BlockEntry) GetCatalog() *Catalog
func (*BlockEntry) GetFileTs ¶
func (entry *BlockEntry) GetFileTs() (uint64, error)
func (*BlockEntry) GetSchema ¶
func (entry *BlockEntry) GetSchema() *Schema
func (*BlockEntry) GetSegment ¶
func (entry *BlockEntry) GetSegment() *SegmentEntry
func (*BlockEntry) GetTerminationTS ¶
func (entry *BlockEntry) GetTerminationTS() (ts uint64, terminated bool)
GetTerminationTS is coarse API: no consistency check
func (*BlockEntry) InitData ¶
func (entry *BlockEntry) InitData(factory DataFactory)
func (*BlockEntry) IsActive ¶
func (entry *BlockEntry) IsActive() bool
IsActive is coarse API: no consistency check
func (*BlockEntry) IsAppendable ¶
func (entry *BlockEntry) IsAppendable() bool
func (*BlockEntry) MakeCommand ¶
func (entry *BlockEntry) MakeCommand(id uint32) (cmd txnif.TxnCmd, err error)
func (*BlockEntry) MakeKey ¶
func (entry *BlockEntry) MakeKey() []byte
func (*BlockEntry) MakeLogEntry ¶
func (entry *BlockEntry) MakeLogEntry() *EntryCommand
func (*BlockEntry) PrepareRollback ¶
func (entry *BlockEntry) PrepareRollback() (err error)
func (*BlockEntry) Repr ¶
func (entry *BlockEntry) Repr() string
func (*BlockEntry) String ¶
func (entry *BlockEntry) String() string
func (*BlockEntry) StringLocked ¶
func (entry *BlockEntry) StringLocked() string
type Catalog ¶
type Catalog struct {
*IDAlloctor
*sync.RWMutex
// contains filtered or unexported fields
}
func MockCatalog ¶
func OpenCatalog ¶
func OpenCatalog(dir, name string, cfg *store.StoreCfg, scheduler tasks.TaskScheduler, dataFactory DataFactory) (*Catalog, error)
func (*Catalog) AddColumnCnt ¶
func (*Catalog) AddEntryLocked ¶
func (*Catalog) AddTableCnt ¶
func (*Catalog) Checkpoint ¶
func (*Catalog) CheckpointClosure ¶
func (*Catalog) CoarseColumnCnt ¶
func (*Catalog) CoarseDBCnt ¶
func (*Catalog) CoarseTableCnt ¶
func (*Catalog) CreateDBEntry ¶
func (*Catalog) DropDBEntry ¶
func (*Catalog) GetCheckpointed ¶
func (catalog *Catalog) GetCheckpointed() *Checkpoint
func (*Catalog) GetDBEntry ¶
func (*Catalog) GetDatabaseByID ¶
func (*Catalog) GetScheduler ¶
func (catalog *Catalog) GetScheduler() tasks.TaskScheduler
func (*Catalog) InitSystemDB ¶
func (catalog *Catalog) InitSystemDB()
func (*Catalog) PrepareCheckpoint ¶
func (catalog *Catalog) PrepareCheckpoint(startTs, endTs uint64) *CheckpointEntry
func (*Catalog) RemoveEntry ¶
func (*Catalog) ReplayCmd ¶
func (catalog *Catalog) ReplayCmd(txncmd txnif.TxnCmd, dataFactory DataFactory, idxCtx *wal.Index, observer wal.ReplayObserver, cache *bytes.Buffer)
func (*Catalog) ReplayTableRows ¶
func (catalog *Catalog) ReplayTableRows()
type Checkpoint ¶
func (*Checkpoint) String ¶
func (ckp *Checkpoint) String() string
type CheckpointEntry ¶
type CheckpointEntry struct {
MinTS, MaxTS uint64
LogIndexes []*wal.Index
MaxIndex wal.Index
Entries []*EntryCommand
}
func NewCheckpointEntry ¶
func NewCheckpointEntry(minTs, maxTs uint64) *CheckpointEntry
func NewEmptyCheckpointEntry ¶
func NewEmptyCheckpointEntry() *CheckpointEntry
func (*CheckpointEntry) AddCommand ¶
func (e *CheckpointEntry) AddCommand(cmd *EntryCommand)
func (*CheckpointEntry) AddIndex ¶
func (e *CheckpointEntry) AddIndex(index *wal.Index)
func (*CheckpointEntry) GetMaxIndex ¶
func (e *CheckpointEntry) GetMaxIndex() *wal.Index
func (*CheckpointEntry) MakeLogEntry ¶
func (e *CheckpointEntry) MakeLogEntry() (logEntry LogEntry, err error)
func (*CheckpointEntry) Marshal ¶
func (e *CheckpointEntry) Marshal() (buf []byte, err error)
func (*CheckpointEntry) PrintItems ¶
func (e *CheckpointEntry) PrintItems()
func (*CheckpointEntry) Unmarshal ¶
func (e *CheckpointEntry) Unmarshal(buf []byte) (err error)
type CheckpointItem ¶
type CheckpointItem interface {
Clone() CheckpointItem
CloneCreate() CheckpointItem
MakeLogEntry() *EntryCommand
StringLocked() string
}
type ColDef ¶
type CommitInfo ¶
func (*CommitInfo) Clone ¶
func (info *CommitInfo) Clone() *CommitInfo
type ComposedFilter ¶
type ComposedFilter struct {
CommitFilters []func(*BaseEntry) bool
BlockFilters []func(*BlockEntry) bool
}
func NewComposedFilter ¶
func NewComposedFilter() *ComposedFilter
func (*ComposedFilter) AddBlockFilter ¶
func (filter *ComposedFilter) AddBlockFilter(f func(*BlockEntry) bool)
func (*ComposedFilter) AddCommitFilter ¶
func (filter *ComposedFilter) AddCommitFilter(f func(*BaseEntry) bool)
func (*ComposedFilter) FilteBlock ¶
func (filter *ComposedFilter) FilteBlock(be *BlockEntry) bool
func (*ComposedFilter) FilteCommit ¶
func (filter *ComposedFilter) FilteCommit(be *BaseEntry) bool
type DBEntry ¶
type DBEntry struct {
// *BaseEntry
*BaseEntry
// contains filtered or unexported fields
}
func NewReplayDBEntry ¶
func NewReplayDBEntry() *DBEntry
func NewSystemDBEntry ¶
func (*DBEntry) AddEntryLocked ¶
func (e *DBEntry) AddEntryLocked(table *TableEntry) (err error)
func (*DBEntry) Clone ¶
func (e *DBEntry) Clone() CheckpointItem
func (*DBEntry) CloneCreate ¶
func (e *DBEntry) CloneCreate() CheckpointItem
func (*DBEntry) CloneCreateEntry ¶
func (*DBEntry) CoarseTableCnt ¶
func (*DBEntry) CreateTableEntry ¶
func (e *DBEntry) CreateTableEntry(schema *Schema, txnCtx txnif.AsyncTxn, dataFactory TableDataFactory) (created *TableEntry, err error)
func (*DBEntry) DropTableEntry ¶
func (*DBEntry) GetBlockEntryByID ¶
func (e *DBEntry) GetBlockEntryByID(id *common.ID) (blk *BlockEntry, err error)
func (*DBEntry) GetCatalog ¶
func (*DBEntry) GetTableEntry ¶
func (*DBEntry) GetTableEntryByID ¶
func (e *DBEntry) GetTableEntryByID(id uint64) (table *TableEntry, err error)
func (*DBEntry) IsSystemDB ¶
func (*DBEntry) MakeLogEntry ¶
func (e *DBEntry) MakeLogEntry() *EntryCommand
func (*DBEntry) PrepareRollback ¶
func (*DBEntry) RemoveEntry ¶
func (e *DBEntry) RemoveEntry(table *TableEntry) (err error)
func (*DBEntry) StringLocked ¶
type DataFactory ¶
type DataFactory interface {
MakeTableFactory() TableDataFactory
MakeSegmentFactory() SegmentDataFactory
MakeBlockFactory(segFile file.Segment) BlockDataFactory
}
type EntryCommand ¶
type EntryCommand struct {
*txnbase.BaseCustomizedCmd
DBID uint64
TableID uint64
SegmentID uint64
DB *DBEntry
Table *TableEntry
Segment *SegmentEntry
Block *BlockEntry
// contains filtered or unexported fields
}
func (*EntryCommand) Desc ¶
func (cmd *EntryCommand) Desc() string
func (*EntryCommand) GetLogIndex ¶
func (cmd *EntryCommand) GetLogIndex() *wal.Index
func (*EntryCommand) GetTs ¶
func (cmd *EntryCommand) GetTs() uint64
func (*EntryCommand) GetType ¶
func (cmd *EntryCommand) GetType() int16
func (*EntryCommand) IDString ¶
func (cmd *EntryCommand) IDString() string
func (*EntryCommand) Marshal ¶
func (cmd *EntryCommand) Marshal() (buf []byte, err error)
func (*EntryCommand) String ¶
func (cmd *EntryCommand) String() string
func (*EntryCommand) Unmarshal ¶
func (cmd *EntryCommand) Unmarshal(buf []byte) (err error)
func (*EntryCommand) VerboseString ¶
func (cmd *EntryCommand) VerboseString() string
type EntryState ¶
type EntryState int8
const ( ES_Appendable EntryState = iota ES_NotAppendable ES_Frozen )
func (EntryState) Repr ¶
func (es EntryState) Repr() string
type IDAlloctor ¶
type IDAlloctor struct {
// contains filtered or unexported fields
}
func NewIDAllocator ¶
func NewIDAllocator() *IDAlloctor
func (*IDAlloctor) CurrBlock ¶
func (alloc *IDAlloctor) CurrBlock() uint64
func (*IDAlloctor) CurrDB ¶
func (alloc *IDAlloctor) CurrDB() uint64
func (*IDAlloctor) CurrSegment ¶
func (alloc *IDAlloctor) CurrSegment() uint64
func (*IDAlloctor) CurrTable ¶
func (alloc *IDAlloctor) CurrTable() uint64
func (*IDAlloctor) IDStates ¶
func (alloc *IDAlloctor) IDStates() string
func (*IDAlloctor) Init ¶
func (alloc *IDAlloctor) Init(prevDb, prevTbl, prevSeg, prevBlk uint64)
func (*IDAlloctor) NextBlock ¶
func (alloc *IDAlloctor) NextBlock() uint64
func (*IDAlloctor) NextDB ¶
func (alloc *IDAlloctor) NextDB() uint64
func (*IDAlloctor) NextSegment ¶
func (alloc *IDAlloctor) NextSegment() uint64
func (*IDAlloctor) NextTable ¶
func (alloc *IDAlloctor) NextTable() uint64
func (*IDAlloctor) OnReplayBlockID ¶
func (alloc *IDAlloctor) OnReplayBlockID(id uint64)
func (*IDAlloctor) OnReplayDBID ¶
func (alloc *IDAlloctor) OnReplayDBID(id uint64)
func (*IDAlloctor) OnReplaySegmentID ¶
func (alloc *IDAlloctor) OnReplaySegmentID(id uint64)
func (*IDAlloctor) OnReplayTableID ¶
func (alloc *IDAlloctor) OnReplayTableID(id uint64)
type LoopProcessor ¶
type LoopProcessor struct {
DatabaseFn func(*DBEntry) error
TableFn func(*TableEntry) error
SegmentFn func(*SegmentEntry) error
BlockFn func(*BlockEntry) error
PostSegmentFn func(*SegmentEntry) error
}
func (*LoopProcessor) OnBlock ¶
func (p *LoopProcessor) OnBlock(block *BlockEntry) error
func (*LoopProcessor) OnDatabase ¶
func (p *LoopProcessor) OnDatabase(database *DBEntry) error
func (*LoopProcessor) OnPostSegment ¶
func (p *LoopProcessor) OnPostSegment(segment *SegmentEntry) error
func (*LoopProcessor) OnSegment ¶
func (p *LoopProcessor) OnSegment(segment *SegmentEntry) error
func (*LoopProcessor) OnTable ¶
func (p *LoopProcessor) OnTable(table *TableEntry) error
type PersistentType ¶
type PersistentType int8
const ( PT_Permanent PersistentType = iota PT_Temporary )
type Processor ¶
type Processor interface {
OnDatabase(database *DBEntry) error
OnTable(table *TableEntry) error
OnPostSegment(segment *SegmentEntry) error
OnSegment(segment *SegmentEntry) error
OnBlock(block *BlockEntry) error
}
type Replayer ¶
type Replayer struct {
// contains filtered or unexported fields
}
func NewReplayer ¶
func NewReplayer(dataFactory DataFactory, catalog *Catalog) *Replayer
type Schema ¶
type Schema struct {
Name string
ColDefs []*ColDef
NameIndex map[string]int
BlockMaxRows uint32
SegmentMaxBlocks uint16
Comment string
SortKey *SortKey
HiddenKey *ColDef
}
var SystemColumnSchema *Schema
var SystemDBSchema *Schema
var SystemTableSchema *Schema
func MockCompoundSchema ¶
func MockSchema ¶
func MockSchemaAll ¶
MockSchemaAll if char/varchar is needed, colCnt = 14, otherwise colCnt = 12 pkIdx == -1 means no pk defined
func NewEmptySchema ¶
func (*Schema) AllNullables ¶
func (*Schema) AppendColDef ¶
func (*Schema) AppendColWithDefault ¶
func (*Schema) AppendPKCol ¶
func (*Schema) AppendSortKey ¶
func (*Schema) GetColIdx ¶
GetColIdx returns column index for the given column name if found, otherwise returns -1.
func (*Schema) GetSingleSortKey ¶
GetSingleSortKey should be call only if IsSinglePK is checked
func (*Schema) GetSingleSortKeyIdx ¶
func (*Schema) GetSortKeyCnt ¶
func (*Schema) GetSortKeyType ¶
func (*Schema) HasSortKey ¶
func (*Schema) IsCompoundPK ¶
func (*Schema) IsCompoundSortKey ¶
func (*Schema) IsPartOfPK ¶
func (*Schema) IsSinglePK ¶
func (*Schema) IsSingleSortKey ¶
type SegmentDataFactory ¶
type SegmentDataFactory = func(meta *SegmentEntry) data.Segment
type SegmentEntry ¶
type SegmentEntry struct {
*BaseEntry
// contains filtered or unexported fields
}
func NewReplaySegmentEntry ¶
func NewReplaySegmentEntry() *SegmentEntry
func NewSegmentEntry ¶
func NewSegmentEntry(table *TableEntry, txn txnif.AsyncTxn, state EntryState, dataFactory SegmentDataFactory) *SegmentEntry
func NewStandaloneSegment ¶
func NewStandaloneSegment(table *TableEntry, id uint64, ts uint64) *SegmentEntry
func NewSysSegmentEntry ¶
func NewSysSegmentEntry(table *TableEntry, id uint64) *SegmentEntry
func (*SegmentEntry) AddEntryLocked ¶
func (entry *SegmentEntry) AddEntryLocked(block *BlockEntry)
func (*SegmentEntry) AsCommonID ¶
func (entry *SegmentEntry) AsCommonID() *common.ID
func (*SegmentEntry) BlockCnt ¶
func (entry *SegmentEntry) BlockCnt() int
func (*SegmentEntry) Clone ¶
func (entry *SegmentEntry) Clone() CheckpointItem
func (*SegmentEntry) CloneCreate ¶
func (entry *SegmentEntry) CloneCreate() CheckpointItem
func (*SegmentEntry) CollectBlockEntries ¶
func (entry *SegmentEntry) CollectBlockEntries(commitFilter func(be *BaseEntry) bool, blockFilter func(be *BlockEntry) bool) []*BlockEntry
func (*SegmentEntry) Compare ¶
func (entry *SegmentEntry) Compare(o common.NodePayload) int
func (*SegmentEntry) CreateBlock ¶
func (entry *SegmentEntry) CreateBlock(txn txnif.AsyncTxn, state EntryState, dataFactory BlockDataFactory) (created *BlockEntry, err error)
func (*SegmentEntry) DestroyData ¶
func (entry *SegmentEntry) DestroyData() (err error)
func (*SegmentEntry) DropBlockEntry ¶
func (entry *SegmentEntry) DropBlockEntry(id uint64, txn txnif.AsyncTxn) (deleted *BlockEntry, err error)
func (*SegmentEntry) GetAppendableBlockCnt ¶
func (entry *SegmentEntry) GetAppendableBlockCnt() int
func (*SegmentEntry) GetBlockEntryByID ¶
func (entry *SegmentEntry) GetBlockEntryByID(id uint64) (blk *BlockEntry, err error)
func (*SegmentEntry) GetBlockEntryByIDLocked ¶
func (entry *SegmentEntry) GetBlockEntryByIDLocked(id uint64) (blk *BlockEntry, err error)
func (*SegmentEntry) GetCatalog ¶
func (entry *SegmentEntry) GetCatalog() *Catalog
func (*SegmentEntry) GetScheduler ¶
func (entry *SegmentEntry) GetScheduler() tasks.TaskScheduler
func (*SegmentEntry) GetSegmentData ¶
func (entry *SegmentEntry) GetSegmentData() data.Segment
func (*SegmentEntry) GetTable ¶
func (entry *SegmentEntry) GetTable() *TableEntry
func (*SegmentEntry) InitData ¶
func (entry *SegmentEntry) InitData(factory DataFactory)
func (*SegmentEntry) IsActive ¶
func (entry *SegmentEntry) IsActive() bool
IsActive is coarse API: no consistency check
func (*SegmentEntry) IsAppendable ¶
func (entry *SegmentEntry) IsAppendable() bool
func (*SegmentEntry) LastAppendableBlock ¶
func (entry *SegmentEntry) LastAppendableBlock() (blk *BlockEntry)
func (*SegmentEntry) MakeBlockIt ¶
func (entry *SegmentEntry) MakeBlockIt(reverse bool) *common.LinkIt
func (*SegmentEntry) MakeCommand ¶
func (entry *SegmentEntry) MakeCommand(id uint32) (cmd txnif.TxnCmd, err error)
func (*SegmentEntry) MakeLogEntry ¶
func (entry *SegmentEntry) MakeLogEntry() *EntryCommand
func (*SegmentEntry) PrepareRollback ¶
func (entry *SegmentEntry) PrepareRollback() (err error)
func (*SegmentEntry) ReadFrom ¶
func (entry *SegmentEntry) ReadFrom(r io.Reader) (n int64, err error)
func (*SegmentEntry) RemoveEntry ¶
func (entry *SegmentEntry) RemoveEntry(block *BlockEntry) (err error)
func (*SegmentEntry) Repr ¶
func (entry *SegmentEntry) Repr() string
func (*SegmentEntry) String ¶
func (entry *SegmentEntry) String() string
func (*SegmentEntry) StringLocked ¶
func (entry *SegmentEntry) StringLocked() string
func (*SegmentEntry) TreeMaxDropCommitEntry ¶
func (entry *SegmentEntry) TreeMaxDropCommitEntry() *BaseEntry
type SortKey ¶
type SortKey struct {
Defs []*ColDef
// contains filtered or unexported fields
}
func NewSortKey ¶
func NewSortKey() *SortKey
func (*SortKey) GetSingleIdx ¶
func (*SortKey) IsSinglePK ¶
type TableDataFactory ¶
type TableDataFactory = func(meta *TableEntry) data.Table
type TableEntry ¶
type TableEntry struct {
*BaseEntry
// contains filtered or unexported fields
}
func MockStaloneTableEntry ¶
func MockStaloneTableEntry(id uint64, schema *Schema) *TableEntry
func NewReplayTableEntry ¶
func NewReplayTableEntry() *TableEntry
func NewSystemTableEntry ¶
func NewSystemTableEntry(db *DBEntry, id uint64, schema *Schema) *TableEntry
func NewTableEntry ¶
func NewTableEntry(db *DBEntry, schema *Schema, txnCtx txnif.AsyncTxn, dataFactory TableDataFactory) *TableEntry
func (*TableEntry) AddEntryLocked ¶
func (entry *TableEntry) AddEntryLocked(segment *SegmentEntry)
func (*TableEntry) AddRows ¶
func (entry *TableEntry) AddRows(delta uint64) uint64
func (*TableEntry) AsCommonID ¶
func (entry *TableEntry) AsCommonID() *common.ID
func (*TableEntry) Clone ¶
func (entry *TableEntry) Clone() CheckpointItem
func (*TableEntry) CloneCreate ¶
func (entry *TableEntry) CloneCreate() CheckpointItem
func (*TableEntry) CloneCreateEntry ¶
func (entry *TableEntry) CloneCreateEntry() *TableEntry
CloneCreateEntry is for collect commands
func (*TableEntry) Compare ¶
func (entry *TableEntry) Compare(o common.NodePayload) int
func (*TableEntry) CreateSegment ¶
func (entry *TableEntry) CreateSegment(txn txnif.AsyncTxn, state EntryState, dataFactory SegmentDataFactory) (created *SegmentEntry, err error)
func (*TableEntry) DropSegmentEntry ¶
func (entry *TableEntry) DropSegmentEntry(id uint64, txn txnif.AsyncTxn) (deleted *SegmentEntry, err error)
func (*TableEntry) GetCatalog ¶
func (entry *TableEntry) GetCatalog() *Catalog
func (*TableEntry) GetDB ¶
func (entry *TableEntry) GetDB() *DBEntry
func (*TableEntry) GetRows ¶
func (entry *TableEntry) GetRows() uint64
func (*TableEntry) GetSchema ¶
func (entry *TableEntry) GetSchema() *Schema
func (*TableEntry) GetSegmentByID ¶
func (entry *TableEntry) GetSegmentByID(id uint64) (seg *SegmentEntry, err error)
func (*TableEntry) GetTableData ¶
func (entry *TableEntry) GetTableData() data.Table
func (*TableEntry) IsActive ¶
func (entry *TableEntry) IsActive() bool
IsActive is coarse API: no consistency check
func (*TableEntry) IsVirtual ¶
func (entry *TableEntry) IsVirtual() bool
func (*TableEntry) LastAppendableSegmemt ¶
func (entry *TableEntry) LastAppendableSegmemt() (seg *SegmentEntry)
func (*TableEntry) MakeCommand ¶
func (entry *TableEntry) MakeCommand(id uint32) (cmd txnif.TxnCmd, err error)
func (*TableEntry) MakeLogEntry ¶
func (entry *TableEntry) MakeLogEntry() *EntryCommand
func (*TableEntry) MakeSegmentIt ¶
func (entry *TableEntry) MakeSegmentIt(reverse bool) *common.LinkIt
func (*TableEntry) PrepareRollback ¶
func (entry *TableEntry) PrepareRollback() (err error)
func (*TableEntry) RecurLoop ¶
func (entry *TableEntry) RecurLoop(processor Processor) (err error)
func (*TableEntry) RemoveEntry ¶
func (entry *TableEntry) RemoveEntry(segment *SegmentEntry) (err error)
func (*TableEntry) RemoveRows ¶
func (entry *TableEntry) RemoveRows(delta uint64) uint64
func (*TableEntry) String ¶
func (entry *TableEntry) String() string
func (*TableEntry) StringLocked ¶
func (entry *TableEntry) StringLocked() string
Click to show internal directories.
Click to hide internal directories.