topology

package
v0.0.0-...-5c6c1e7 Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: Jul 29, 2022 License: Apache-2.0 Imports: 32 Imported by: 0

Documentation

Index

Constants

This section is empty.

Variables

This section is empty.

Functions

func AllocateVolume

func AllocateVolume(dn *DataNode, grpcDialOption grpc.DialOption, vid needle.VolumeId, option *VolumeGrowOption) error

func DistributedOperation

func DistributedOperation(locations []operation.Location, op func(location operation.Location) error) error

func ExistCopies

func ExistCopies() stateIndicator

func GetWritableRemoteReplications

func GetWritableRemoteReplications(s *storage.Store, grpcDialOption grpc.DialOption, volumeId needle.VolumeId, masterFn operation.GetMasterFn) (remoteLocations []operation.Location, err error)

func NewVolumesBinaryState

func NewVolumesBinaryState(name volumeState, rp *super_block.ReplicaPlacement, indicator stateIndicator) *volumesBinaryState

func NoCopies

func NoCopies() stateIndicator

func ReplicatedDelete

func ReplicatedDelete(masterFn operation.GetMasterFn, grpcDialOption grpc.DialOption, store *storage.Store, volumeId needle.VolumeId, n *needle.Needle, r *http.Request) (size types.Size, err error)

func ReplicatedWrite

func ReplicatedWrite(masterFn operation.GetMasterFn, grpcDialOption grpc.DialOption, s *storage.Store, volumeId needle.VolumeId, n *needle.Needle, r *http.Request) (isUnchanged bool, err error)

Types

type AllocateVolumeResult

type AllocateVolumeResult struct {
	Error string
}

type Collection

type Collection struct {
	Name string
	// contains filtered or unexported fields
}

func NewCollection

func NewCollection(name string, volumeSizeLimit uint64, replicationAsMin bool) *Collection

func (*Collection) DeleteVolumeLayout

func (c *Collection) DeleteVolumeLayout(rp *super_block.ReplicaPlacement, ttl *needle.TTL, diskType types.DiskType)

func (*Collection) GetOrCreateVolumeLayout

func (c *Collection) GetOrCreateVolumeLayout(rp *super_block.ReplicaPlacement, ttl *needle.TTL, diskType types.DiskType) *VolumeLayout

func (*Collection) ListVolumeServers

func (c *Collection) ListVolumeServers() (nodes []*DataNode)

func (*Collection) Lookup

func (c *Collection) Lookup(vid needle.VolumeId) []*DataNode

func (*Collection) String

func (c *Collection) String() string

type Configuration

type Configuration struct {
	XMLName xml.Name `xml:"Configuration"`
	Topo    topology `xml:"Topology"`
	// contains filtered or unexported fields
}

func (*Configuration) Locate

func (c *Configuration) Locate(ip string, dcName string, rackName string) (dc string, rack string)

func (*Configuration) String

func (c *Configuration) String() string

type DataCenter

type DataCenter struct {
	NodeImpl
}

func NewDataCenter

func NewDataCenter(id string) *DataCenter

func (*DataCenter) GetOrCreateRack

func (dc *DataCenter) GetOrCreateRack(rackName string) *Rack

func (*DataCenter) ToDataCenterInfo

func (dc *DataCenter) ToDataCenterInfo() *master_pb.DataCenterInfo

func (*DataCenter) ToInfo

func (dc *DataCenter) ToInfo() (info DataCenterInfo)

type DataCenterInfo

type DataCenterInfo struct {
	Id    NodeId     `json:"Id"`
	Racks []RackInfo `json:"Racks"`
}

type DataNode

type DataNode struct {
	NodeImpl
	Ip        string
	Port      int
	GrpcPort  int
	PublicUrl string
	LastSeen  int64 // unix time in seconds
	Counter   int   // in race condition, the previous dataNode was not dead
}

func NewDataNode

func NewDataNode(id string) *DataNode

func (*DataNode) AddOrUpdateEcShard

func (dn *DataNode) AddOrUpdateEcShard(s *erasure_coding.EcVolumeInfo)

func (*DataNode) AddOrUpdateVolume

func (dn *DataNode) AddOrUpdateVolume(v storage.VolumeInfo) (isNew, isChangedRO bool)

func (*DataNode) AdjustMaxVolumeCounts

func (dn *DataNode) AdjustMaxVolumeCounts(maxVolumeCounts map[string]uint32)

func (*DataNode) DeleteEcShard

func (dn *DataNode) DeleteEcShard(s *erasure_coding.EcVolumeInfo)

func (*DataNode) DeltaUpdateEcShards

func (dn *DataNode) DeltaUpdateEcShards(newShards, deletedShards []*erasure_coding.EcVolumeInfo)

func (*DataNode) DeltaUpdateVolumes

func (dn *DataNode) DeltaUpdateVolumes(newVolumes, deletedVolumes []storage.VolumeInfo)

func (*DataNode) GetDataCenter

func (dn *DataNode) GetDataCenter() *DataCenter

func (*DataNode) GetEcShards

func (dn *DataNode) GetEcShards() (ret []*erasure_coding.EcVolumeInfo)

func (*DataNode) GetRack

func (dn *DataNode) GetRack() *Rack

func (*DataNode) GetTopology

func (dn *DataNode) GetTopology() *Topology

func (*DataNode) GetVolumeIds

func (dn *DataNode) GetVolumeIds() string

GetVolumeIds returns the human readable volume ids limited to count of max 100.

func (*DataNode) GetVolumes

func (dn *DataNode) GetVolumes() (ret []storage.VolumeInfo)

func (*DataNode) GetVolumesById

func (dn *DataNode) GetVolumesById(id needle.VolumeId) (vInfo storage.VolumeInfo, err error)

func (*DataNode) HasEcShards

func (dn *DataNode) HasEcShards(volumeId needle.VolumeId) (found bool)

func (*DataNode) HasVolumesById

func (dn *DataNode) HasVolumesById(volumeId needle.VolumeId) (hasVolumeId bool)

func (*DataNode) MatchLocation

func (dn *DataNode) MatchLocation(ip string, port int) bool

func (*DataNode) ServerAddress

func (dn *DataNode) ServerAddress() pb.ServerAddress

func (*DataNode) String

func (dn *DataNode) String() string

func (*DataNode) ToDataNodeInfo

func (dn *DataNode) ToDataNodeInfo() *master_pb.DataNodeInfo

func (*DataNode) ToInfo

func (dn *DataNode) ToInfo() (info DataNodeInfo)

func (*DataNode) UpdateEcShards

func (dn *DataNode) UpdateEcShards(actualShards []*erasure_coding.EcVolumeInfo) (newShards, deletedShards []*erasure_coding.EcVolumeInfo)

func (*DataNode) UpdateVolumes

func (dn *DataNode) UpdateVolumes(actualVolumes []storage.VolumeInfo) (newVolumes, deletedVolumes, changeRO []storage.VolumeInfo)

UpdateVolumes detects new/deleted/changed volumes on a volume server used in master to notify master clients of these changes.

func (*DataNode) Url

func (dn *DataNode) Url() string

type DataNodeInfo

type DataNodeInfo struct {
	Url       string `json:"Url"`
	PublicUrl string `json:"PublicUrl"`
	Volumes   int64  `json:"Volumes"`
	EcShards  int64  `json:"EcShards"`
	Max       int64  `json:"Max"`
	VolumeIds string `json:"VolumeIds"`
}

type Disk

type Disk struct {
	NodeImpl
	// contains filtered or unexported fields
}

func NewDisk

func NewDisk(diskType string) *Disk

func (*Disk) AddOrUpdateEcShard

func (d *Disk) AddOrUpdateEcShard(s *erasure_coding.EcVolumeInfo)

func (*Disk) AddOrUpdateVolume

func (d *Disk) AddOrUpdateVolume(v storage.VolumeInfo) (isNew, isChangedRO bool)

func (*Disk) DeleteEcShard

func (d *Disk) DeleteEcShard(s *erasure_coding.EcVolumeInfo)

func (*Disk) FreeSpace

func (d *Disk) FreeSpace() int64

func (*Disk) GetDataCenter

func (d *Disk) GetDataCenter() *DataCenter

func (*Disk) GetEcShards

func (d *Disk) GetEcShards() (ret []*erasure_coding.EcVolumeInfo)

func (*Disk) GetRack

func (d *Disk) GetRack() *Rack

func (*Disk) GetTopology

func (d *Disk) GetTopology() *Topology

func (*Disk) GetVolumeIds

func (d *Disk) GetVolumeIds() string

GetVolumeIds returns the human readable volume ids limited to count of max 100.

func (*Disk) GetVolumes

func (d *Disk) GetVolumes() (ret []storage.VolumeInfo)

func (*Disk) GetVolumesById

func (d *Disk) GetVolumesById(id needle.VolumeId) (storage.VolumeInfo, error)

func (*Disk) HasVolumesById

func (d *Disk) HasVolumesById(id needle.VolumeId) (hasVolumeId bool)

func (*Disk) String

func (d *Disk) String() string

func (*Disk) ToDiskInfo

func (d *Disk) ToDiskInfo() *master_pb.DiskInfo

func (*Disk) ToMap

func (d *Disk) ToMap() interface{}

type DiskUsageCounts

type DiskUsageCounts struct {
	// contains filtered or unexported fields
}

func (*DiskUsageCounts) FreeSpace

func (a *DiskUsageCounts) FreeSpace() int64

type DiskUsages

type DiskUsages struct {
	sync.RWMutex
	// contains filtered or unexported fields
}

func (*DiskUsages) FreeSpace

func (d *DiskUsages) FreeSpace() (freeSpace int64)

func (*DiskUsages) GetMaxVolumeCount

func (d *DiskUsages) GetMaxVolumeCount() (maxVolumeCount int64)

func (*DiskUsages) ToDiskInfo

func (d *DiskUsages) ToDiskInfo() map[string]*master_pb.DiskInfo

type DistributedOperationResult

type DistributedOperationResult map[string]error

func (DistributedOperationResult) Error

func (dr DistributedOperationResult) Error() error

type EcShardLocations

type EcShardLocations struct {
	Collection string
	Locations  [erasure_coding.TotalShardsCount][]*DataNode
}

func NewEcShardLocations

func NewEcShardLocations(collection string) *EcShardLocations

func (*EcShardLocations) AddShard

func (loc *EcShardLocations) AddShard(shardId erasure_coding.ShardId, dn *DataNode) (added bool)

func (*EcShardLocations) DeleteShard

func (loc *EcShardLocations) DeleteShard(shardId erasure_coding.ShardId, dn *DataNode) (deleted bool)

type MaxVolumeIdCommand

type MaxVolumeIdCommand struct {
	MaxVolumeId needle.VolumeId `json:"maxVolumeId"`
}

func NewMaxVolumeIdCommand

func NewMaxVolumeIdCommand(value needle.VolumeId) *MaxVolumeIdCommand

func (*MaxVolumeIdCommand) Apply

func (c *MaxVolumeIdCommand) Apply(server raft.Server) (interface{}, error)

deprecatedCommandApply represents the old interface to apply a command to the server.

func (*MaxVolumeIdCommand) CommandName

func (c *MaxVolumeIdCommand) CommandName() string

func (*MaxVolumeIdCommand) Persist

func (*MaxVolumeIdCommand) Release

func (s *MaxVolumeIdCommand) Release()

type Node

type Node interface {
	Id() NodeId
	String() string
	AvailableSpaceFor(option *VolumeGrowOption) int64
	ReserveOneVolume(r int64, option *VolumeGrowOption) (*DataNode, error)
	UpAdjustDiskUsageDelta(deltaDiskUsages *DiskUsages)
	UpAdjustMaxVolumeId(vid needle.VolumeId)
	GetDiskUsages() *DiskUsages

	GetMaxVolumeId() needle.VolumeId
	SetParent(Node)
	LinkChildNode(node Node)
	UnlinkChildNode(nodeId NodeId)
	CollectDeadNodeAndFullVolumes(freshThreshHold int64, volumeSizeLimit uint64, growThreshold float64)

	IsDataNode() bool
	IsRack() bool
	IsDataCenter() bool
	Children() []Node
	Parent() Node

	GetValue() interface{} //get reference to the topology,dc,rack,datanode
}

type NodeId

type NodeId string

type NodeImpl

type NodeImpl struct {
	sync.RWMutex // lock children
	// contains filtered or unexported fields
}

func (*NodeImpl) AvailableSpaceFor

func (n *NodeImpl) AvailableSpaceFor(option *VolumeGrowOption) int64

func (*NodeImpl) Children

func (n *NodeImpl) Children() (ret []Node)

func (*NodeImpl) CollectDeadNodeAndFullVolumes

func (n *NodeImpl) CollectDeadNodeAndFullVolumes(freshThreshHold int64, volumeSizeLimit uint64, growThreshold float64)

func (*NodeImpl) GetDiskUsages

func (n *NodeImpl) GetDiskUsages() *DiskUsages

func (*NodeImpl) GetMaxVolumeId

func (n *NodeImpl) GetMaxVolumeId() needle.VolumeId

func (*NodeImpl) GetTopology

func (n *NodeImpl) GetTopology() *Topology

func (*NodeImpl) GetValue

func (n *NodeImpl) GetValue() interface{}

func (*NodeImpl) Id

func (n *NodeImpl) Id() NodeId

func (*NodeImpl) IsDataCenter

func (n *NodeImpl) IsDataCenter() bool

func (*NodeImpl) IsDataNode

func (n *NodeImpl) IsDataNode() bool

func (*NodeImpl) IsRack

func (n *NodeImpl) IsRack() bool

func (*NodeImpl) LinkChildNode

func (n *NodeImpl) LinkChildNode(node Node)

func (*NodeImpl) Parent

func (n *NodeImpl) Parent() Node

func (*NodeImpl) PickNodesByWeight

func (n *NodeImpl) PickNodesByWeight(numberOfNodes int, option *VolumeGrowOption, filterFirstNodeFn func(dn Node) error) (firstNode Node, restNodes []Node, err error)

the first node must satisfy filterFirstNodeFn(), the rest nodes must have one free slot

func (*NodeImpl) ReserveOneVolume

func (n *NodeImpl) ReserveOneVolume(r int64, option *VolumeGrowOption) (assignedNode *DataNode, err error)

func (*NodeImpl) SetParent

func (n *NodeImpl) SetParent(node Node)

func (*NodeImpl) String

func (n *NodeImpl) String() string

func (*NodeImpl) UnlinkChildNode

func (n *NodeImpl) UnlinkChildNode(nodeId NodeId)

func (*NodeImpl) UpAdjustDiskUsageDelta

func (n *NodeImpl) UpAdjustDiskUsageDelta(deltaDiskUsages *DiskUsages)

func (*NodeImpl) UpAdjustMaxVolumeId

func (n *NodeImpl) UpAdjustMaxVolumeId(vid needle.VolumeId)

type Rack

type Rack struct {
	NodeImpl
}

func NewRack

func NewRack(id string) *Rack

func (*Rack) FindDataNode

func (r *Rack) FindDataNode(ip string, port int) *DataNode

func (*Rack) GetOrCreateDataNode

func (r *Rack) GetOrCreateDataNode(ip string, port int, grpcPort int, publicUrl string, maxVolumeCounts map[string]uint32) *DataNode

func (*Rack) ToInfo

func (r *Rack) ToInfo() (info RackInfo)

func (*Rack) ToRackInfo

func (r *Rack) ToRackInfo() *master_pb.RackInfo

type RackInfo

type RackInfo struct {
	Id        NodeId         `json:"Id"`
	DataNodes []DataNodeInfo `json:"DataNodes"`
}

type RemoteResult

type RemoteResult struct {
	Host  string
	Error error
}

type Topology

type Topology struct {
	NodeImpl

	Sequence sequence.Sequencer

	Configuration *Configuration

	RaftServer     raft.Server
	HashicorpRaft  *hashicorpRaft.Raft
	UuidAccessLock sync.RWMutex
	UuidMap        map[string][]string
	// contains filtered or unexported fields
}

func NewTopology

func NewTopology(id string, seq sequence.Sequencer, volumeSizeLimit uint64, pulse int, replicationAsMin bool) *Topology

func (*Topology) DataNodeRegistration

func (t *Topology) DataNodeRegistration(dcName, rackName string, dn *DataNode)

func (*Topology) DeleteCollection

func (t *Topology) DeleteCollection(collectionName string)

func (*Topology) DeleteEcCollection

func (t *Topology) DeleteEcCollection(collection string)

func (*Topology) DeleteLayout

func (t *Topology) DeleteLayout(collectionName string, rp *super_block.ReplicaPlacement, ttl *needle.TTL, diskType types.DiskType)

func (*Topology) FindCollection

func (t *Topology) FindCollection(collectionName string) (*Collection, bool)

func (*Topology) GetOrCreateDataCenter

func (t *Topology) GetOrCreateDataCenter(dcName string) *DataCenter

func (*Topology) GetVolumeLayout

func (t *Topology) GetVolumeLayout(collectionName string, rp *super_block.ReplicaPlacement, ttl *needle.TTL, diskType types.DiskType) *VolumeLayout

func (*Topology) HasWritableVolume

func (t *Topology) HasWritableVolume(option *VolumeGrowOption) bool

deprecated

func (*Topology) IncrementalSyncDataNodeEcShards

func (t *Topology) IncrementalSyncDataNodeEcShards(newEcShards, deletedEcShards []*master_pb.VolumeEcShardInformationMessage, dn *DataNode)

func (*Topology) IncrementalSyncDataNodeRegistration

func (t *Topology) IncrementalSyncDataNodeRegistration(newVolumes, deletedVolumes []*master_pb.VolumeShortInformationMessage, dn *DataNode)

func (*Topology) IsLeader

func (t *Topology) IsLeader() bool

func (*Topology) Leader

func (t *Topology) Leader() (pb.ServerAddress, error)

func (*Topology) ListCollections

func (t *Topology) ListCollections(includeNormalVolumes, includeEcVolumes bool) (ret []string)

func (*Topology) ListEcServersByCollection

func (t *Topology) ListEcServersByCollection(collection string) (dataNodes []pb.ServerAddress)

func (*Topology) Lookup

func (t *Topology) Lookup(collection string, vid needle.VolumeId) (dataNodes []*DataNode)

func (*Topology) LookupEcShards

func (t *Topology) LookupEcShards(vid needle.VolumeId) (locations *EcShardLocations, found bool)

func (*Topology) NextVolumeId

func (t *Topology) NextVolumeId() (needle.VolumeId, error)

func (*Topology) PickForWrite

func (t *Topology) PickForWrite(count uint64, option *VolumeGrowOption) (string, uint64, *VolumeLocationList, error)

func (*Topology) RegisterEcShards

func (t *Topology) RegisterEcShards(ecShardInfos *erasure_coding.EcVolumeInfo, dn *DataNode)

func (*Topology) RegisterVolumeLayout

func (t *Topology) RegisterVolumeLayout(v storage.VolumeInfo, dn *DataNode)

func (*Topology) SetVolumeCapacityFull

func (t *Topology) SetVolumeCapacityFull(volumeInfo storage.VolumeInfo) bool

func (*Topology) SetVolumeCrowded

func (t *Topology) SetVolumeCrowded(volumeInfo storage.VolumeInfo)

func (*Topology) StartRefreshWritableVolumes

func (t *Topology) StartRefreshWritableVolumes(grpcDialOption grpc.DialOption, garbageThreshold float64, growThreshold float64, preallocate int64)

func (*Topology) SyncDataNodeEcShards

func (t *Topology) SyncDataNodeEcShards(shardInfos []*master_pb.VolumeEcShardInformationMessage, dn *DataNode) (newShards, deletedShards []*erasure_coding.EcVolumeInfo)

func (*Topology) SyncDataNodeRegistration

func (t *Topology) SyncDataNodeRegistration(volumes []*master_pb.VolumeInformationMessage, dn *DataNode) (newVolumes, deletedVolumes []storage.VolumeInfo)

func (*Topology) ToInfo

func (t *Topology) ToInfo() (info TopologyInfo)

func (*Topology) ToTopologyInfo

func (t *Topology) ToTopologyInfo() *master_pb.TopologyInfo

func (*Topology) ToVolumeLocations

func (t *Topology) ToVolumeLocations() (volumeLocations []*master_pb.VolumeLocation)

func (*Topology) ToVolumeMap

func (t *Topology) ToVolumeMap() interface{}

func (*Topology) UnRegisterDataNode

func (t *Topology) UnRegisterDataNode(dn *DataNode)

func (*Topology) UnRegisterEcShards

func (t *Topology) UnRegisterEcShards(ecShardInfos *erasure_coding.EcVolumeInfo, dn *DataNode)

func (*Topology) UnRegisterVolumeLayout

func (t *Topology) UnRegisterVolumeLayout(v storage.VolumeInfo, dn *DataNode)

func (*Topology) Vacuum

func (t *Topology) Vacuum(grpcDialOption grpc.DialOption, garbageThreshold float64, volumeId uint32, collection string, preallocate int64)

type TopologyInfo

type TopologyInfo struct {
	Max         int64              `json:"Max"`
	Free        int64              `json:"Free"`
	DataCenters []DataCenterInfo   `json:"DataCenters"`
	Layouts     []VolumeLayoutInfo `json:"Layouts"`
}

type VolumeGrowOption

type VolumeGrowOption struct {
	Collection         string                        `json:"collection,omitempty"`
	ReplicaPlacement   *super_block.ReplicaPlacement `json:"replication,omitempty"`
	Ttl                *needle.TTL                   `json:"ttl,omitempty"`
	DiskType           types.DiskType                `json:"disk,omitempty"`
	Preallocate        int64                         `json:"preallocate,omitempty"`
	DataCenter         string                        `json:"dataCenter,omitempty"`
	Rack               string                        `json:"rack,omitempty"`
	DataNode           string                        `json:"dataNode,omitempty"`
	MemoryMapMaxSizeMb uint32                        `json:"memoryMapMaxSizeMb,omitempty"`
}

func (*VolumeGrowOption) String

func (o *VolumeGrowOption) String() string

func (*VolumeGrowOption) Threshold

func (o *VolumeGrowOption) Threshold() float64

type VolumeGrowRequest

type VolumeGrowRequest struct {
	Option *VolumeGrowOption
	Count  int
	ErrCh  chan error
}

type VolumeGrowth

type VolumeGrowth struct {
	// contains filtered or unexported fields
}

func NewDefaultVolumeGrowth

func NewDefaultVolumeGrowth() *VolumeGrowth

func (*VolumeGrowth) AutomaticGrowByType

func (vg *VolumeGrowth) AutomaticGrowByType(option *VolumeGrowOption, grpcDialOption grpc.DialOption, topo *Topology, targetCount int) (result []*master_pb.VolumeLocation, err error)

func (*VolumeGrowth) GrowByCountAndType

func (vg *VolumeGrowth) GrowByCountAndType(grpcDialOption grpc.DialOption, targetCount int, option *VolumeGrowOption, topo *Topology) (result []*master_pb.VolumeLocation, err error)

type VolumeLayout

type VolumeLayout struct {
	// contains filtered or unexported fields
}

mapping from volume to its locations, inverted from server to volume

func NewVolumeLayout

func NewVolumeLayout(rp *super_block.ReplicaPlacement, ttl *needle.TTL, diskType types.DiskType, volumeSizeLimit uint64, replicationAsMin bool) *VolumeLayout

func (*VolumeLayout) AddGrowRequest

func (vl *VolumeLayout) AddGrowRequest()

func (*VolumeLayout) DoneGrowRequest

func (vl *VolumeLayout) DoneGrowRequest()

func (*VolumeLayout) EnsureCorrectWritables

func (vl *VolumeLayout) EnsureCorrectWritables(v *storage.VolumeInfo)

func (*VolumeLayout) GetActiveVolumeCount

func (vl *VolumeLayout) GetActiveVolumeCount(option *VolumeGrowOption) (active, crowded int)

func (*VolumeLayout) HasGrowRequest

func (vl *VolumeLayout) HasGrowRequest() bool

func (*VolumeLayout) ListVolumeServers

func (vl *VolumeLayout) ListVolumeServers() (nodes []*DataNode)

func (*VolumeLayout) Lookup

func (vl *VolumeLayout) Lookup(vid needle.VolumeId) []*DataNode

func (*VolumeLayout) PickForWrite

func (vl *VolumeLayout) PickForWrite(count uint64, option *VolumeGrowOption) (*needle.VolumeId, uint64, *VolumeLocationList, error)

func (*VolumeLayout) RegisterVolume

func (vl *VolumeLayout) RegisterVolume(v *storage.VolumeInfo, dn *DataNode)

func (*VolumeLayout) SetVolumeAvailable

func (vl *VolumeLayout) SetVolumeAvailable(dn *DataNode, vid needle.VolumeId, isReadOnly bool) bool

func (*VolumeLayout) SetVolumeCapacityFull

func (vl *VolumeLayout) SetVolumeCapacityFull(vid needle.VolumeId) bool

func (*VolumeLayout) SetVolumeCrowded

func (vl *VolumeLayout) SetVolumeCrowded(vid needle.VolumeId)

func (*VolumeLayout) SetVolumeUnavailable

func (vl *VolumeLayout) SetVolumeUnavailable(dn *DataNode, vid needle.VolumeId) bool

func (*VolumeLayout) ShouldGrowVolumes

func (vl *VolumeLayout) ShouldGrowVolumes(option *VolumeGrowOption) bool

func (*VolumeLayout) Stats

func (vl *VolumeLayout) Stats() *VolumeLayoutStats

func (*VolumeLayout) String

func (vl *VolumeLayout) String() string

func (*VolumeLayout) ToInfo

func (vl *VolumeLayout) ToInfo() (info VolumeLayoutInfo)

func (*VolumeLayout) UnRegisterVolume

func (vl *VolumeLayout) UnRegisterVolume(v *storage.VolumeInfo, dn *DataNode)

type VolumeLayoutInfo

type VolumeLayoutInfo struct {
	Replication string            `json:"replication"`
	TTL         string            `json:"ttl"`
	Writables   []needle.VolumeId `json:"writables"`
	Collection  string            `json:"collection"`
}

type VolumeLayoutStats

type VolumeLayoutStats struct {
	TotalSize uint64
	UsedSize  uint64
	FileCount uint64
}

type VolumeLocationList

type VolumeLocationList struct {
	// contains filtered or unexported fields
}

func NewVolumeLocationList

func NewVolumeLocationList() *VolumeLocationList

func (*VolumeLocationList) Copy

func (dnll *VolumeLocationList) Copy() *VolumeLocationList

func (*VolumeLocationList) Head

func (dnll *VolumeLocationList) Head() *DataNode

func (*VolumeLocationList) Length

func (dnll *VolumeLocationList) Length() int

func (*VolumeLocationList) Refresh

func (dnll *VolumeLocationList) Refresh(freshThreshHold int64)

func (*VolumeLocationList) Remove

func (dnll *VolumeLocationList) Remove(loc *DataNode) bool

func (*VolumeLocationList) Rest

func (dnll *VolumeLocationList) Rest() []*DataNode

func (*VolumeLocationList) Set

func (dnll *VolumeLocationList) Set(loc *DataNode)

func (*VolumeLocationList) Stats

func (dnll *VolumeLocationList) Stats(vid needle.VolumeId, freshThreshHold int64) (size uint64, fileCount int)

Stats returns logic size and count

func (*VolumeLocationList) String

func (dnll *VolumeLocationList) String() string

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL