Documentation ¶
Index ¶
- Constants
- Variables
- func AddBlockDownloadReq(ctx context.Context, req *BlockDownloadRequest, rb zboxutil.DownloadBuffer, ...)
- func AddCommitRequest(req *CommitRequest)
- func AddFreeStorageAssigner(name, publicKey string, individualLimit, totalLimit float64) (string, int64, error)
- func CancelAllocation(allocID string) (hash string, nonce int64, err error)
- func CollectRewards(providerId string, providerType ProviderType) (string, int64, error)
- func CommitToFabric(metaTxnData, fabricConfigJSON string) (string, error)
- func CreateAllocationForOwner(owner, ownerpublickey string, datashards, parityshards int, size int64, ...) (hash string, nonce int64, txn *transaction.Transaction, err error)
- func CreateAllocationWith(options CreateAllocationOptions) (string, int64, *transaction.Transaction, error)
- func CreateFreeAllocation(marker string, value uint64) (string, int64, error)
- func CreateReadPool() (hash string, nonce int64, err error)
- func FinalizeAllocation(allocID string) (hash string, nonce int64, err error)
- func GenerateParentPaths(path string) map[string]bool
- func GetAllocationBlobbers(datashards, parityshards int, size int64, isRestricted int, ...) ([]string, error)
- func GetAllocationMinLock(datashards, parityshards int, size int64, writePrice PriceRange) (int64, error)
- func GetAllocationUpdates(allocation *Allocation) error
- func GetBlobberIds(blobberUrls []string) ([]string, error)
- func GetClientEncryptedPublicKey() (string, error)
- func GetDStorageFileReader(alloc *Allocation, ref *ORef, sdo *StreamDownloadOption) (io.ReadSeekCloser, error)
- func GetFileRefFromBlobber(allocationID, blobberId, remotePath string) (fRef *fileref.FileRef, err error)
- func GetFreeAllocationBlobbers(request map[string]interface{}) ([]string, error)
- func GetLogger() *logger.Logger
- func GetMptData(key string) ([]byte, error)
- func GetTranscodeFile(remotePath string) (string, string)
- func GetUpdateAllocationMinLock(allocationID string, size int64, extend bool, ...) (int64, error)
- func GetVersion() string
- func InitBlockDownloader(blobbers []*blockchain.StorageNode, workerCount int)
- func InitCommitWorker(blobbers []*blockchain.StorageNode)
- func InitNetworkDetails() error
- func InitStorageSDK(walletJSON string, blockWorker, chainID, signatureScheme string, ...) error
- func IsErrCode(err error, code string) bool
- func KillProvider(providerId string, providerType ProviderType) (string, int64, error)
- func NewSignalContext(ctx context.Context) context.Context
- func ReadPoolLock(tokens, fee uint64) (hash string, nonce int64, err error)
- func ReadPoolUnlock(fee uint64) (hash string, nonce int64, err error)
- func ResetAllocationStats(allocationId string) (string, int64, error)
- func ResetBlobberStats(rbs *ResetBlobberStatsDto) (string, int64, error)
- func SetLogFile(logFile string, verbose bool)
- func SetLogLevel(lvl int)
- func SetMaxTxnQuery(num int)
- func SetMinConfirmation(num int)
- func SetMinSubmit(num int)
- func SetMultiOpBatchSize(size int)
- func SetNetwork(miners []string, sharders []string)
- func SetNumBlockDownloads(num int)
- func SetQuerySleepTime(time int)
- func SetSaveProgress(save bool)
- func SetShouldVerifyHash(verify bool)
- func SetSingleClietnMode(mode bool)
- func SetUploadMode(mode UploadMode)
- func SetWasm()
- func ShutdownProvider(providerType ProviderType, providerID string) (string, int64, error)
- func StakePoolLock(providerType ProviderType, providerID string, value, fee uint64) (hash string, nonce int64, err error)
- func StakePoolUnlock(providerType ProviderType, providerID string, fee uint64) (unstake int64, nonce int64, err error)
- func StartWriteWorker(ctx context.Context, source io.Reader, dataChan chan *DataChan, ...)
- func StorageSmartContractTxn(sn transaction.SmartContractTxnData) (hash, out string, nonce int64, txn *transaction.Transaction, err error)
- func TransferAllocation(allocationId, newOwner, newOwnerPublicKey string) (string, int64, error)
- func UpdateAllocation(size int64, extend bool, allocationID string, lock uint64, ...) (hash string, nonce int64, err error)
- func UpdateBlobberSettings(blob *UpdateBlobber) (resp string, nonce int64, err error)
- func UpdateNetworkDetails() error
- func UpdateNetworkDetailsWorker(ctx context.Context)
- func UpdateRequired(networkDetails *Network) bool
- func UpdateValidatorSettings(v *UpdateValidator) (resp string, nonce int64, err error)
- func ValidateRemoteFileName(remotePath string) error
- func WritePoolLock(allocID string, tokens, fee uint64) (hash string, nonce int64, err error)
- func WritePoolUnlock(allocID string, fee uint64) (hash string, nonce int64, err error)
- type AllocStatus
- type Allocation
- func (a *Allocation) CanCopy() bool
- func (a *Allocation) CanDelete() bool
- func (a *Allocation) CanMove() bool
- func (a *Allocation) CanRename() bool
- func (a *Allocation) CanUpdate() bool
- func (a *Allocation) CanUpload() bool
- func (a *Allocation) CancelDownload(remotepath string) error
- func (a *Allocation) CancelRepair() error
- func (a *Allocation) CancelUpload(remotePath string) error
- func (a *Allocation) CheckAllocStatus() (AllocStatus, error)
- func (a *Allocation) DeleteFile(path string) error
- func (a *Allocation) DoMultiOperation(operations []OperationRequest, opts ...MultiOperationOption) error
- func (a *Allocation) DownloadByBlocksToFileHandler(fileHandler sys.File, remotePath string, startBlock, endBlock int64, ...) error
- func (a *Allocation) DownloadByBlocksToFileHandlerFromAuthTicket(fileHandler sys.File, authTicket string, remoteLookupHash string, ...) error
- func (a *Allocation) DownloadFile(localPath string, remotePath string, verifyDownload bool, ...) error
- func (a *Allocation) DownloadFileByBlock(localPath string, remotePath string, startBlock int64, endBlock int64, ...) error
- func (a *Allocation) DownloadFileToFileHandler(fileHandler sys.File, remotePath string, verifyDownload bool, ...) error
- func (a *Allocation) DownloadFileToFileHandlerFromAuthTicket(fileHandler sys.File, authTicket string, remoteLookupHash string, ...) error
- func (a *Allocation) DownloadFromAuthTicket(localPath string, authTicket string, remoteLookupHash string, ...) error
- func (a *Allocation) DownloadFromAuthTicketByBlocks(localPath string, authTicket string, startBlock int64, endBlock int64, ...) error
- func (a *Allocation) DownloadFromBlobber(blobberID, localPath, remotePath string, status StatusCallback, ...) error
- func (a *Allocation) DownloadFromReader(remotePath, localPath, lookupHash, authTicket, contentMode string, ...) error
- func (a *Allocation) DownloadThumbnail(localPath string, remotePath string, verifyDownload bool, ...) error
- func (a *Allocation) DownloadThumbnailFromAuthTicket(localPath string, authTicket string, remoteLookupHash string, ...) error
- func (a *Allocation) DownloadThumbnailToFileHandler(fileHandler sys.File, remotePath string, verifyDownload bool, ...) error
- func (a *Allocation) DownloadThumbnailToFileHandlerFromAuthTicket(fileHandler sys.File, authTicket string, remoteLookupHash string, ...) error
- func (a *Allocation) EncryptAndUpdateFile(workdir string, localpath string, remotepath string, status StatusCallback) error
- func (a *Allocation) EncryptAndUpdateFileWithThumbnail(workdir string, localpath string, remotepath string, thumbnailpath string, ...) error
- func (a *Allocation) EncryptAndUploadFile(workdir string, localpath string, remotepath string, status StatusCallback) error
- func (a *Allocation) EncryptAndUploadFileWithThumbnail(workdir string, localpath string, remotepath string, thumbnailpath string, ...) error
- func (a *Allocation) GetAllocationDiff(lastSyncCachePath string, localRootPath string, localFileFilters []string, ...) ([]FileDiff, error)
- func (a *Allocation) GetAllocationFileReader(remotePath, lookupHash, authTicket, contentMode string, verifyDownload bool, ...) (io.ReadSeekCloser, error)
- func (a *Allocation) GetAuthTicket(path, filename string, ...) (string, error)
- func (a *Allocation) GetAuthTicketForShare(path, filename, referenceType, refereeClientID string) (string, error)
- func (a *Allocation) GetBlobberStats() map[string]*BlobberAllocationStats
- func (a *Allocation) GetChunkReadSize(encrypt bool) int64
- func (a *Allocation) GetCurrentVersion() (bool, error)
- func (a *Allocation) GetFileMeta(path string) (*ConsolidatedFileMeta, error)
- func (a *Allocation) GetFileMetaFromAuthTicket(authTicket string, lookupHash string) (*ConsolidatedFileMeta, error)
- func (a *Allocation) GetFileStats(path string) (map[string]*FileStats, error)
- func (a *Allocation) GetMaxStorageCost(size int64) (float64, error)
- func (a *Allocation) GetMaxStorageCostFromBlobbers(size int64, blobbers []*BlobberAllocation) (float64, error)
- func (a *Allocation) GetMaxWriteRead() (maxW float64, maxR float64, err error)
- func (a *Allocation) GetMaxWriteReadFromBlobbers(blobbers []*BlobberAllocation) (maxW float64, maxR float64, err error)
- func (a *Allocation) GetMinStorageCost(size int64) (common.Balance, error)
- func (a *Allocation) GetMinWriteRead() (minW float64, minR float64, err error)
- func (a *Allocation) GetRecentlyAddedRefs(page int, fromDate int64, pageLimit int) (*RecentlyAddedRefResult, error)
- func (a *Allocation) GetRefs(path, offsetPath, updatedDate, offsetDate, fileType, refType string, ...) (*ObjectTreeResult, error)
- func (a *Allocation) GetRefsFromLookupHash(pathHash, offsetPath, updatedDate, offsetDate, fileType, refType string, ...) (*ObjectTreeResult, error)
- func (a *Allocation) GetRefsWithAuthTicket(authToken, offsetPath, updatedDate, offsetDate, fileType, refType string, ...) (*ObjectTreeResult, error)
- func (a *Allocation) GetRemoteFileMap(exclMap map[string]int, remotepath string) (map[string]FileInfo, error)
- func (a *Allocation) GetStats() *AllocationStats
- func (a *Allocation) InitAllocation()
- func (a *Allocation) ListDir(path string, opts ...ListRequestOptions) (*ListResult, error)
- func (a *Allocation) ListDirFromAuthTicket(authTicket string, lookupHash string, opts ...ListRequestOptions) (*ListResult, error)
- func (a *Allocation) PauseUpload(remotePath string) error
- func (a *Allocation) RepairAlloc(statusCB StatusCallback) (err error)
- func (a *Allocation) RepairFile(file sys.File, remotepath string, statusCallback StatusCallback, ...) *OperationRequest
- func (a *Allocation) RepairRequired(remotepath string) (zboxutil.Uint128, zboxutil.Uint128, bool, *fileref.FileRef, error)
- func (a *Allocation) RevokeShare(path string, refereeClientID string) error
- func (a *Allocation) RollbackWithMask(mask zboxutil.Uint128)
- func (a *Allocation) SaveRemoteSnapshot(pathToSave string, remoteExcludePath []string) error
- func (a *Allocation) SetConsensusThreshold()
- func (a *Allocation) StartChunkedUpload(workdir, localPath string, remotePath string, status StatusCallback, ...) error
- func (a *Allocation) StartMultiUpload(workdir string, localPaths []string, fileNames []string, ...) error
- func (a *Allocation) StartRepair(localRootPath, pathToRepair string, statusCB StatusCallback) error
- func (a *Allocation) UpdateFile(workdir, localpath string, remotepath string, status StatusCallback) error
- func (a *Allocation) UpdateFileWithThumbnail(workdir, localpath string, remotepath string, thumbnailpath string, ...) error
- func (a *Allocation) UpdateWithRepair(size int64, extend bool, lock uint64, ...) (string, error)
- func (a *Allocation) UploadAuthTicketToBlobber(authTicket string, clientEncPubKey string, availableAfter *time.Time) error
- func (a *Allocation) UploadFile(workdir, localpath string, remotepath string, status StatusCallback) error
- func (a *Allocation) UploadFileWithThumbnail(workdir string, localpath string, remotepath string, thumbnailpath string, ...) error
- type AllocationStats
- type AuthTicket
- type BackPool
- type Blobber
- type BlobberAllocation
- type BlobberAllocationStats
- type BlockDownloadRequest
- type ChallengePoolInfo
- type ChunkData
- type ChunkedUpload
- type ChunkedUploadBlobber
- type ChunkedUploadChunkReader
- type ChunkedUploadFormBuilder
- type ChunkedUploadFormMetadata
- type ChunkedUploadOption
- func WithActualHash(hash string) ChunkedUploadOption
- func WithChunkNumber(num int) ChunkedUploadOption
- func WithCommitTimeout(t time.Duration) ChunkedUploadOption
- func WithEncrypt(on bool) ChunkedUploadOption
- func WithEncryptedPoint(point string) ChunkedUploadOption
- func WithMask(mask zboxutil.Uint128) ChunkedUploadOption
- func WithProgressStorer(progressStorer ChunkedUploadProgressStorer) ChunkedUploadOption
- func WithStatusCallback(callback StatusCallback) ChunkedUploadOption
- func WithThumbnail(buf []byte) ChunkedUploadOption
- func WithThumbnailFile(fileName string) ChunkedUploadOption
- func WithUploadTimeout(t time.Duration) ChunkedUploadOption
- type ChunkedUploadProgressStorer
- type CommitMetaData
- type CommitMetaResponse
- type CommitRequest
- type CommitResult
- type Consensus
- type ConsolidatedFileMeta
- type CopyOperation
- func (co *CopyOperation) Completed(allocObj *Allocation)
- func (co *CopyOperation) Error(allocObj *Allocation, consensus int, err error)
- func (co *CopyOperation) Process(allocObj *Allocation, connectionID string) ([]fileref.RefEntity, zboxutil.Uint128, error)
- func (co *CopyOperation) Verify(a *Allocation) error
- type CopyRequest
- type CreateAllocationOptions
- type DataChan
- type DeleteOperation
- func (dop *DeleteOperation) Completed(allocObj *Allocation)
- func (dop *DeleteOperation) Error(allocObj *Allocation, consensus int, err error)
- func (dop *DeleteOperation) Process(allocObj *Allocation, connectionID string) ([]fileref.RefEntity, zboxutil.Uint128, error)
- func (dop *DeleteOperation) Verify(a *Allocation) error
- type DeleteRequest
- type DirOperation
- func (dirOp *DirOperation) Completed(allocObj *Allocation)
- func (dirOp *DirOperation) Error(allocObj *Allocation, consensus int, err error)
- func (dirOp *DirOperation) Process(allocObj *Allocation, connectionID string) ([]fileref.RefEntity, zboxutil.Uint128, error)
- func (dirOp *DirOperation) Verify(a *Allocation) error
- type DirRequest
- type DownloadOption
- func WithAllocation(obj *Allocation) DownloadOption
- func WithAuthticket(authTicket, lookupHash string) DownloadOption
- func WithBlocks(start, end int64, blocksPerMarker int) DownloadOption
- func WithFileHandler(fileHandler sys.File) DownloadOption
- func WithOnlyThumbnail(thumbnail bool) DownloadOption
- func WithVerifyDownload(shouldVerify bool) DownloadOption
- type DownloadOptions
- type DownloadProgress
- type DownloadProgressStorer
- type DownloadRequest
- type DownloadRequestHeader
- type DownloadRequestOption
- type Downloader
- type FfmpegRecorder
- func (r *FfmpegRecorder) Close() (err error)
- func (r *FfmpegRecorder) GetClipsFile(clipsIndex int) string
- func (r *FfmpegRecorder) GetClipsFileName(clipsIndex int) string
- func (r *FfmpegRecorder) GetFileContentType() (string, error)
- func (r *FfmpegRecorder) Read(p []byte) (int, error)
- func (r *FfmpegRecorder) Size() int64
- type FileDiff
- type FileInfo
- type FileMeta
- type FileNameBuilder
- type FileOptionParam
- type FileOptionsParameters
- type FileStats
- type FsDownloadProgressStorer
- func (ds *FsDownloadProgressStorer) Load(progressID string, numBlocks int) *DownloadProgress
- func (ds *FsDownloadProgressStorer) Remove() error
- func (ds *FsDownloadProgressStorer) Save(dp *DownloadProgress)
- func (ds *FsDownloadProgressStorer) Start(ctx context.Context)
- func (ds *FsDownloadProgressStorer) Update(writtenBlock int)
- type Hasher
- type InputMap
- type LatestPrevWriteMarker
- type ListRequest
- type ListRequestOptions
- type ListResult
- type LiveMeta
- type LiveUpload
- type LiveUploadOption
- type LiveUploadReader
- type M3u8Writer
- type MediaPlaylist
- type MoveOperation
- func (mo *MoveOperation) Completed(allocObj *Allocation)
- func (mo *MoveOperation) Error(allocObj *Allocation, consensus int, err error)
- func (mo *MoveOperation) Process(allocObj *Allocation, connectionID string) ([]fileref.RefEntity, zboxutil.Uint128, error)
- func (mo *MoveOperation) Verify(a *Allocation) error
- type MoveRequest
- type MultiOperation
- type MultiOperationOption
- type Network
- type ORef
- type ObjectTreeRequest
- type ObjectTreeResult
- type OperationRequest
- type Operationer
- type PlaylistFile
- func GetPlaylist(ctx context.Context, alloc *Allocation, path, since string) ([]PlaylistFile, error)
- func GetPlaylistByAuthTicket(ctx context.Context, alloc *Allocation, authTicket, lookupHash, since string) ([]PlaylistFile, error)
- func GetPlaylistFile(ctx context.Context, alloc *Allocation, path string) (*PlaylistFile, error)
- func GetPlaylistFileByAuthTicket(ctx context.Context, alloc *Allocation, authTicket, lookupHash string) (*PlaylistFile, error)
- type PriceRange
- type ProcessResult
- type ProviderType
- type ReadPool
- type RecentlyAddedRefRequest
- type RecentlyAddedRefResponse
- type RecentlyAddedRefResult
- type ReferencePathResult
- type RenameOperation
- func (ro *RenameOperation) Completed(allocObj *Allocation)
- func (ro *RenameOperation) Error(allocObj *Allocation, consensus int, err error)
- func (ro *RenameOperation) Process(allocObj *Allocation, connectionID string) ([]fileref.RefEntity, zboxutil.Uint128, error)
- func (ro *RenameOperation) Verify(a *Allocation) error
- type RenameRequest
- type RepairRequest
- type RepairStatusCB
- func (cb *RepairStatusCB) Completed(allocationId, filePath string, filename string, mimetype string, size int, ...)
- func (cb *RepairStatusCB) Error(allocationID string, filePath string, op int, err error)
- func (cb *RepairStatusCB) InProgress(allocationId, filePath string, op int, completedBytes int, data []byte)
- func (cb *RepairStatusCB) RepairCompleted(filesRepaired int)
- func (cb *RepairStatusCB) Started(allocationId, filePath string, op int, totalBytes int)
- type ResetBlobberStatsDto
- type RollbackBlobber
- type ShareRequest
- type SignalContext
- type SimilarField
- type StakePoolDelegatePoolInfo
- type StakePoolInfo
- type StakePoolOfferInfo
- type StakePoolRewardsInfo
- type StakePoolUserInfo
- type StatusBar
- func (s *StatusBar) Completed(allocationId, filePath string, filename string, mimetype string, size int, ...)
- func (s *StatusBar) Error(allocationID string, filePath string, op int, err error)
- func (s *StatusBar) InProgress(allocationId, filePath string, op int, completedBytes int, data []byte)
- func (s *StatusBar) RepairCompleted(filesRepaired int)
- func (s *StatusBar) Started(allocationId, filePath string, op int, totalBytes int)
- type StatusCallback
- type StreamDownload
- type StreamDownloadOption
- type StreamReader
- type Terms
- type UpdateBlobber
- type UpdateTerms
- type UpdateValidator
- type UploadBlobberStatus
- type UploadData
- type UploadFileMeta
- type UploadFormData
- type UploadMode
- type UploadOperation
- func (uo *UploadOperation) Completed(allocObj *Allocation)
- func (uo *UploadOperation) Error(allocObj *Allocation, consensus int, err error)
- func (uo *UploadOperation) Process(allocObj *Allocation, connectionID string) ([]fileref.RefEntity, zboxutil.Uint128, error)
- func (uo *UploadOperation) Verify(allocationObj *Allocation) error
- type UploadProgress
- type UploadResult
- type Validator
- type WMLockResult
- type WMLockStatus
- type WriteMarkerMutex
- func (wmMu *WriteMarkerMutex) Lock(ctx context.Context, mask *zboxutil.Uint128, maskMu *sync.Mutex, ...) error
- func (wmMu *WriteMarkerMutex) Unlock(ctx context.Context, mask zboxutil.Uint128, blobbers []*blockchain.StorageNode, ...)
- func (wmMu *WriteMarkerMutex) UnlockBlobber(ctx context.Context, b *blockchain.StorageNode, connID string, ...)
- type YoutubeDL
Constants ¶
const ( KB = 1024 MB = 1024 * KB GB = 1024 * MB )
const ( CanUploadMask = uint16(1) // 0000 0001 CanDeleteMask = uint16(2) // 0000 0010 CanUpdateMask = uint16(4) // 0000 0100 CanMoveMask = uint16(8) // 0000 1000 CanCopyMask = uint16(16) // 0001 0000 CanRenameMask = uint16(32) // 0010 0000 )
const ( LockExists = "lock_exists" RateLimitError = "rate_limit_error" )
const ( // EncryptedDataPaddingSize additional bytes to save encrypted data EncryptedDataPaddingSize = 16 // EncryptionHeaderSize encryption header size in chunk: PRE.MessageChecksum(128)+PRE.OverallChecksum(128) EncryptionHeaderSize = 128 + 128 // ReEncryptionHeaderSize re-encryption header size in chunk ReEncryptionHeaderSize = 256 )
const ( DOWNLOAD_CONTENT_FULL = "full" DOWNLOAD_CONTENT_THUMB = "thumbnail" EXTRA_COUNT = 2 )
const ( // EncryptionOverHead File size increases by 16 bytes after encryption. Two checksums i.e. MessageChecksum and OverallChecksum has // 128 bytes size each. // So total overhead for each encrypted data is 16 + 128*2 = 272 EncryptionOverHead = 272 ChecksumSize = 256 HeaderSize = 128 BlockSize = 64 * KB )
const ( NotEnoughTokens = "not_enough_tokens" InvalidAuthTicket = "invalid_authticket" InvalidRead = "invalid_read" ExceededMaxOffsetValue = "exceeded_max_offset_value" NegativeOffsetResultantValue = "negative_offset_resultant_value" InvalidWhenceValue = "invalid_whence_value" )
error codes
const ( OpUpload int = 0 OpDownload int = 1 OpRepair int = 2 OpUpdate int = 3 )
const ( Upload = "Upload" Download = "Download" Update = "Update" Delete = "Delete" Conflict = "Conflict" LocalDelete = "LocalDelete" )
For sync app
const ( // BlocksFor10MB is number of blocks required for to make 10MB data. // It is simply calculated as 10MB / 64KB = 160 // If blobber cannot respond with 10MB data then client can use numBlocks field // in StreamDownload struct BlocksFor10MB = 160 )
const CHUNK_SIZE = 64 * 1024
const DefaultBlocksPerMarker int = 100
const DefaultChunkSize = 64 * 1024
DefaultChunkSize default chunk size for file and thumbnail
const (
DefaultCreateConnectionTimeOut = 10 * time.Second
)
const (
DefaultUploadTimeOut = 120 * time.Second
)
const (
DirectoryExists = "directory_exists"
)
const INVALID_PATH = "invalid_path"
const MARKER_VERSION = "v2"
const MAX_BLOCKS = 80 // 5MB(CHUNK_SIZE*80)
const MINERSC_SCADDRESS = "6dba10422e368813802877a85039d3985d96760ed844092319743fb3a76712d9"
const NETWORK_ENDPOINT = "/network"
const STORAGE_SCADDRESS = "6dba10422e368813802877a85039d3985d96760ed844092319743fb3a76712d7"
const WMLockWaitTime = 2 * time.Second
const ZCNSC_SCADDRESS = "6dba10422e368813802877a85039d3985d96760ed844092319743fb3a76712e0"
Variables ¶
var ( IsWasm = false MultiOpBatchSize = 50 Workdir string )
var ( CmdFFmpeg = "ffmpeg" // DefaultHashFunc default hash method for stream merkle tree DefaultHashFunc = func(left, right string) string { return coreEncryption.Hash(left + right) } ErrInvalidChunkSize = errors.New("chunk: chunk size is too small. it must greater than 272 if file is uploaded with encryption") ErrNoEnoughSpaceLeftInAllocation = errors.New("alloc: no enough space left in allocation") CancelOpCtx = make(map[string]context.CancelCauseFunc) CurrentMode = UploadModeMedium )
var BatchSize = 6
var ( // ErrClispIsNotReady clips file is not ready ErrClispIsNotReady = errors.New("live: clips is not ready") )
var ErrFileNameTooLong = errors.New("invalid_parameter", "filename is longer than 100 characters")
var ErrInvalidRead = errors.New(InvalidRead, "want_size is <= 0")
errors
var ErrPauseUpload = errors.New("upload paused by user")
var ErrRetryOperation = errors.New("retry_operation")
Functions ¶
func AddBlockDownloadReq ¶
func AddBlockDownloadReq(ctx context.Context, req *BlockDownloadRequest, rb zboxutil.DownloadBuffer, effectiveBlockSize int)
func AddCommitRequest ¶
func AddCommitRequest(req *CommitRequest)
func AddFreeStorageAssigner ¶
func CollectRewards ¶ added in v1.7.1
func CollectRewards(providerId string, providerType ProviderType) (string, int64, error)
func CommitToFabric ¶
func CreateAllocationForOwner ¶
func CreateAllocationForOwner( owner, ownerpublickey string, datashards, parityshards int, size int64, readPrice, writePrice PriceRange, lock uint64, preferredBlobberIds, blobberAuthTickets []string, thirdPartyExtendable, force bool, fileOptionsParams *FileOptionsParameters, ) (hash string, nonce int64, txn *transaction.Transaction, err error)
func CreateAllocationWith ¶ added in v1.8.7
func CreateAllocationWith(options CreateAllocationOptions) ( string, int64, *transaction.Transaction, error)
func CreateFreeAllocation ¶
func CreateReadPool ¶
func FinalizeAllocation ¶
func GenerateParentPaths ¶ added in v1.8.17
func GetAllocationBlobbers ¶ added in v1.8.6
func GetAllocationMinLock ¶
func GetAllocationMinLock( datashards, parityshards int, size int64, writePrice PriceRange, ) (int64, error)
expire in milliseconds
func GetAllocationUpdates ¶ added in v1.4.0
func GetAllocationUpdates(allocation *Allocation) error
func GetBlobberIds ¶ added in v1.8.6
func GetDStorageFileReader ¶ added in v1.8.16
func GetDStorageFileReader(alloc *Allocation, ref *ORef, sdo *StreamDownloadOption) (io.ReadSeekCloser, error)
GetDStorageFileReader will initialize erasure decoder, decrypter if file is encrypted and other necessary fields and returns a reader that comply with io.ReadSeekCloser interface.
func GetFileRefFromBlobber ¶ added in v1.8.17
func GetFreeAllocationBlobbers ¶ added in v1.12.1
func GetMptData ¶ added in v1.2.82
func GetTranscodeFile ¶ added in v1.11.0
func GetUpdateAllocationMinLock ¶ added in v1.8.17
func InitBlockDownloader ¶
func InitBlockDownloader(blobbers []*blockchain.StorageNode, workerCount int)
func InitCommitWorker ¶
func InitCommitWorker(blobbers []*blockchain.StorageNode)
func InitNetworkDetails ¶ added in v1.11.0
func InitNetworkDetails() error
func InitStorageSDK ¶
func KillProvider ¶ added in v1.8.16
func KillProvider(providerId string, providerType ProviderType) (string, int64, error)
func NewSignalContext ¶ added in v1.3.0
NewSignalContext create SignalContext instance
func ReadPoolLock ¶
ReadPoolLock locks given number of tokes for given duration in read pool.
func ReadPoolUnlock ¶
ReadPoolUnlock unlocks tokens in expired read pool
func ResetAllocationStats ¶ added in v1.14.0
func ResetBlobberStats ¶ added in v1.13.0
func ResetBlobberStats(rbs *ResetBlobberStatsDto) (string, int64, error)
func SetLogFile ¶
SetLogFile logFile - Log file verbose - true - console output; false - no console output
func SetLogLevel ¶
func SetLogLevel(lvl int)
SetLogLevel set the log level. lvl - 0 disabled; higher number (upto 4) more verbosity
func SetMaxTxnQuery ¶
func SetMaxTxnQuery(num int)
func SetMinConfirmation ¶
func SetMinConfirmation(num int)
func SetMinSubmit ¶
func SetMinSubmit(num int)
func SetMultiOpBatchSize ¶ added in v1.11.4
func SetMultiOpBatchSize(size int)
func SetNetwork ¶
func SetNumBlockDownloads ¶
func SetNumBlockDownloads(num int)
func SetQuerySleepTime ¶
func SetQuerySleepTime(time int)
func SetSaveProgress ¶ added in v1.14.6
func SetSaveProgress(save bool)
func SetShouldVerifyHash ¶ added in v1.14.0
func SetShouldVerifyHash(verify bool)
func SetSingleClietnMode ¶ added in v1.14.0
func SetSingleClietnMode(mode bool)
func SetUploadMode ¶ added in v1.14.0
func SetUploadMode(mode UploadMode)
func ShutdownProvider ¶ added in v1.8.16
func ShutdownProvider(providerType ProviderType, providerID string) (string, int64, error)
func StakePoolLock ¶
func StakePoolLock(providerType ProviderType, providerID string, value, fee uint64) (hash string, nonce int64, err error)
StakePoolLock locks tokens lack in stake pool
func StakePoolUnlock ¶
func StakePoolUnlock(providerType ProviderType, providerID string, fee uint64) (unstake int64, nonce int64, err error)
StakePoolUnlock unlocks a stake pool tokens. If tokens can't be unlocked due to opened offers, then it returns time where the tokens can be unlocked, marking the pool as 'want to unlock' to avoid its usage in offers in the future. The time is maximal time that can be lesser in some cases. To unlock tokens can't be unlocked now, wait the time and unlock them (call this function again).
func StartWriteWorker ¶ added in v1.8.17
func StorageSmartContractTxn ¶ added in v1.12.1
func StorageSmartContractTxn(sn transaction.SmartContractTxnData) ( hash, out string, nonce int64, txn *transaction.Transaction, err error)
func TransferAllocation ¶ added in v1.8.14
func UpdateAllocation ¶
func UpdateBlobberSettings ¶
func UpdateBlobberSettings(blob *UpdateBlobber) (resp string, nonce int64, err error)
func UpdateNetworkDetails ¶
func UpdateNetworkDetails() error
func UpdateRequired ¶
func UpdateValidatorSettings ¶ added in v1.8.5
func UpdateValidatorSettings(v *UpdateValidator) (resp string, nonce int64, err error)
func ValidateRemoteFileName ¶ added in v1.8.10
func WritePoolLock ¶
WritePoolLock locks given number of tokes for given duration in read pool.
Types ¶
type AllocStatus ¶ added in v1.8.17
type AllocStatus byte
const ( Commit AllocStatus = iota Repair Broken Rollback )
type Allocation ¶
type Allocation struct { ID string `json:"id"` Tx string `json:"tx"` DataShards int `json:"data_shards"` ParityShards int `json:"parity_shards"` Size int64 `json:"size"` Expiration int64 `json:"expiration_date"` Owner string `json:"owner_id"` OwnerPublicKey string `json:"owner_public_key"` Payer string `json:"payer_id"` Blobbers []*blockchain.StorageNode `json:"blobbers"` Stats *AllocationStats `json:"stats"` TimeUnit time.Duration `json:"time_unit"` WritePool common.Balance `json:"write_pool"` // BlobberDetails contains real terms used for the allocation. // If the allocation has updated, then terms calculated using // weighted average values. BlobberDetails []*BlobberAllocation `json:"blobber_details"` // ReadPriceRange is requested reading prices range. ReadPriceRange PriceRange `json:"read_price_range"` // WritePriceRange is requested writing prices range. WritePriceRange PriceRange `json:"write_price_range"` MinLockDemand float64 `json:"min_lock_demand"` ChallengeCompletionTime time.Duration `json:"challenge_completion_time"` StartTime common.Timestamp `json:"start_time"` Finalized bool `json:"finalized,omitempty"` Canceled bool `json:"canceled,omitempty"` MovedToChallenge common.Balance `json:"moved_to_challenge,omitempty"` MovedBack common.Balance `json:"moved_back,omitempty"` MovedToValidators common.Balance `json:"moved_to_validators,omitempty"` FileOptions uint16 `json:"file_options"` ThirdPartyExtendable bool `json:"third_party_extendable"` // contains filtered or unexported fields }
func GetAllocation ¶
func GetAllocation(allocationID string) (*Allocation, error)
func GetAllocationFromAuthTicket ¶
func GetAllocationFromAuthTicket(authTicket string) (*Allocation, error)
func GetAllocations ¶
func GetAllocations() ([]*Allocation, error)
func GetAllocationsForClient ¶
func GetAllocationsForClient(clientID string) ([]*Allocation, error)
get paginated results
func (*Allocation) CanCopy ¶ added in v1.8.13
func (a *Allocation) CanCopy() bool
func (*Allocation) CanDelete ¶ added in v1.8.13
func (a *Allocation) CanDelete() bool
func (*Allocation) CanMove ¶ added in v1.8.13
func (a *Allocation) CanMove() bool
func (*Allocation) CanRename ¶ added in v1.8.13
func (a *Allocation) CanRename() bool
func (*Allocation) CanUpdate ¶ added in v1.8.13
func (a *Allocation) CanUpdate() bool
func (*Allocation) CanUpload ¶ added in v1.8.13
func (a *Allocation) CanUpload() bool
func (*Allocation) CancelDownload ¶
func (a *Allocation) CancelDownload(remotepath string) error
func (*Allocation) CancelRepair ¶
func (a *Allocation) CancelRepair() error
func (*Allocation) CancelUpload ¶
func (a *Allocation) CancelUpload(remotePath string) error
func (*Allocation) CheckAllocStatus ¶ added in v1.8.17
func (a *Allocation) CheckAllocStatus() (AllocStatus, error)
func (*Allocation) DeleteFile ¶
func (a *Allocation) DeleteFile(path string) error
func (*Allocation) DoMultiOperation ¶ added in v1.8.17
func (a *Allocation) DoMultiOperation(operations []OperationRequest, opts ...MultiOperationOption) error
func (*Allocation) DownloadByBlocksToFileHandler ¶ added in v1.8.17
func (a *Allocation) DownloadByBlocksToFileHandler( fileHandler sys.File, remotePath string, startBlock, endBlock int64, numBlocks int, verifyDownload bool, status StatusCallback, isFinal bool, downloadReqOpts ...DownloadRequestOption, ) error
func (*Allocation) DownloadByBlocksToFileHandlerFromAuthTicket ¶ added in v1.8.17
func (a *Allocation) DownloadByBlocksToFileHandlerFromAuthTicket( fileHandler sys.File, authTicket string, remoteLookupHash string, startBlock, endBlock int64, numBlocks int, remoteFilename string, verifyDownload bool, status StatusCallback, isFinal bool, downloadReqOpts ...DownloadRequestOption, ) error
func (*Allocation) DownloadFile ¶
func (a *Allocation) DownloadFile(localPath string, remotePath string, verifyDownload bool, status StatusCallback, isFinal bool, downloadReqOpts ...DownloadRequestOption) error
func (*Allocation) DownloadFileByBlock ¶
func (a *Allocation) DownloadFileByBlock( localPath string, remotePath string, startBlock int64, endBlock int64, numBlocks int, verifyDownload bool, status StatusCallback, isFinal bool, downloadReqOpts ...DownloadRequestOption) error
TODO: Use a map to store the download request and use flag isFinal to start the download, calculate readCount in parallel if possible
func (*Allocation) DownloadFileToFileHandler ¶ added in v1.8.17
func (a *Allocation) DownloadFileToFileHandler( fileHandler sys.File, remotePath string, verifyDownload bool, status StatusCallback, isFinal bool, downloadReqOpts ...DownloadRequestOption, ) error
func (*Allocation) DownloadFileToFileHandlerFromAuthTicket ¶ added in v1.8.17
func (a *Allocation) DownloadFileToFileHandlerFromAuthTicket( fileHandler sys.File, authTicket string, remoteLookupHash string, remoteFilename string, verifyDownload bool, status StatusCallback, isFinal bool, downloadReqOpts ...DownloadRequestOption, ) error
func (*Allocation) DownloadFromAuthTicket ¶
func (a *Allocation) DownloadFromAuthTicket(localPath string, authTicket string, remoteLookupHash string, remoteFilename string, verifyDownload bool, status StatusCallback, isFinal bool, downloadReqOpts ...DownloadRequestOption) error
func (*Allocation) DownloadFromAuthTicketByBlocks ¶
func (a *Allocation) DownloadFromAuthTicketByBlocks(localPath string, authTicket string, startBlock int64, endBlock int64, numBlocks int, remoteLookupHash string, remoteFilename string, verifyDownload bool, status StatusCallback, isFinal bool, downloadReqOpts ...DownloadRequestOption) error
func (*Allocation) DownloadFromBlobber ¶ added in v1.8.17
func (a *Allocation) DownloadFromBlobber(blobberID, localPath, remotePath string, status StatusCallback, opts ...DownloadRequestOption) error
func (*Allocation) DownloadFromReader ¶ added in v1.8.16
func (a *Allocation) DownloadFromReader( remotePath, localPath, lookupHash, authTicket, contentMode string, verifyDownload bool, blocksPerMarker uint, ) error
func (*Allocation) DownloadThumbnail ¶
func (a *Allocation) DownloadThumbnail(localPath string, remotePath string, verifyDownload bool, status StatusCallback, isFinal bool) error
func (*Allocation) DownloadThumbnailFromAuthTicket ¶
func (a *Allocation) DownloadThumbnailFromAuthTicket( localPath string, authTicket string, remoteLookupHash string, remoteFilename string, verifyDownload bool, status StatusCallback, isFinal bool, downloadReqOpts ...DownloadRequestOption, ) error
func (*Allocation) DownloadThumbnailToFileHandler ¶ added in v1.8.17
func (a *Allocation) DownloadThumbnailToFileHandler( fileHandler sys.File, remotePath string, verifyDownload bool, status StatusCallback, isFinal bool, downloadReqOpts ...DownloadRequestOption, ) error
func (*Allocation) DownloadThumbnailToFileHandlerFromAuthTicket ¶ added in v1.8.17
func (a *Allocation) DownloadThumbnailToFileHandlerFromAuthTicket( fileHandler sys.File, authTicket string, remoteLookupHash string, remoteFilename string, verifyDownload bool, status StatusCallback, isFinal bool, ) error
func (*Allocation) EncryptAndUpdateFile ¶
func (a *Allocation) EncryptAndUpdateFile(workdir string, localpath string, remotepath string, status StatusCallback) error
EncryptAndUpdateFile [Deprecated]please use CreateChunkedUpload
func (*Allocation) EncryptAndUpdateFileWithThumbnail ¶
func (a *Allocation) EncryptAndUpdateFileWithThumbnail(workdir string, localpath string, remotepath string, thumbnailpath string, status StatusCallback) error
EncryptAndUpdateFileWithThumbnail [Deprecated]please use CreateChunkedUpload
func (*Allocation) EncryptAndUploadFile ¶
func (a *Allocation) EncryptAndUploadFile(workdir string, localpath string, remotepath string, status StatusCallback) error
EncryptAndUploadFile [Deprecated]please use CreateChunkedUpload
func (*Allocation) EncryptAndUploadFileWithThumbnail ¶
func (a *Allocation) EncryptAndUploadFileWithThumbnail( workdir string, localpath string, remotepath string, thumbnailpath string, status StatusCallback, ) error
EncryptAndUploadFileWithThumbnail [Deprecated]please use CreateChunkedUpload
func (*Allocation) GetAllocationDiff ¶
func (*Allocation) GetAllocationFileReader ¶ added in v1.8.16
func (a *Allocation) GetAllocationFileReader( remotePath, lookupHash, authTicket, contentMode string, verifyDownload bool, blocksPerMarker uint, ) (io.ReadSeekCloser, error)
GetStreamDownloader will check file ref existence and returns an instance that provides io.ReadSeekerCloser interface
func (*Allocation) GetAuthTicket ¶
func (*Allocation) GetAuthTicketForShare ¶
func (a *Allocation) GetAuthTicketForShare( path, filename, referenceType, refereeClientID string) (string, error)
func (*Allocation) GetBlobberStats ¶
func (a *Allocation) GetBlobberStats() map[string]*BlobberAllocationStats
func (*Allocation) GetChunkReadSize ¶ added in v1.8.17
func (a *Allocation) GetChunkReadSize(encrypt bool) int64
func (*Allocation) GetCurrentVersion ¶ added in v1.8.17
func (a *Allocation) GetCurrentVersion() (bool, error)
func (*Allocation) GetFileMeta ¶
func (a *Allocation) GetFileMeta(path string) (*ConsolidatedFileMeta, error)
func (*Allocation) GetFileMetaFromAuthTicket ¶
func (a *Allocation) GetFileMetaFromAuthTicket(authTicket string, lookupHash string) (*ConsolidatedFileMeta, error)
func (*Allocation) GetFileStats ¶
func (a *Allocation) GetFileStats(path string) (map[string]*FileStats, error)
func (*Allocation) GetMaxStorageCost ¶
func (a *Allocation) GetMaxStorageCost(size int64) (float64, error)
func (*Allocation) GetMaxStorageCostFromBlobbers ¶ added in v1.2.82
func (a *Allocation) GetMaxStorageCostFromBlobbers(size int64, blobbers []*BlobberAllocation) (float64, error)
func (*Allocation) GetMaxWriteRead ¶
func (a *Allocation) GetMaxWriteRead() (maxW float64, maxR float64, err error)
func (*Allocation) GetMaxWriteReadFromBlobbers ¶ added in v1.2.82
func (a *Allocation) GetMaxWriteReadFromBlobbers(blobbers []*BlobberAllocation) (maxW float64, maxR float64, err error)
func (*Allocation) GetMinStorageCost ¶
func (a *Allocation) GetMinStorageCost(size int64) (common.Balance, error)
func (*Allocation) GetMinWriteRead ¶
func (a *Allocation) GetMinWriteRead() (minW float64, minR float64, err error)
func (*Allocation) GetRecentlyAddedRefs ¶ added in v1.8.7
func (a *Allocation) GetRecentlyAddedRefs(page int, fromDate int64, pageLimit int) (*RecentlyAddedRefResult, error)
func (*Allocation) GetRefs ¶ added in v1.3.0
func (a *Allocation) GetRefs(path, offsetPath, updatedDate, offsetDate, fileType, refType string, level, pageLimit int) (*ObjectTreeResult, error)
This function will retrieve paginated objectTree and will handle concensus; Required tree should be made in application side.
func (*Allocation) GetRefsFromLookupHash ¶ added in v1.8.16
func (a *Allocation) GetRefsFromLookupHash(pathHash, offsetPath, updatedDate, offsetDate, fileType, refType string, level, pageLimit int) (*ObjectTreeResult, error)
func (*Allocation) GetRefsWithAuthTicket ¶ added in v1.8.16
func (a *Allocation) GetRefsWithAuthTicket(authToken, offsetPath, updatedDate, offsetDate, fileType, refType string, level, pageLimit int) (*ObjectTreeResult, error)
GetRefsWithAuthTicket get refs that are children of shared remote path.
func (*Allocation) GetRemoteFileMap ¶
func (*Allocation) GetStats ¶
func (a *Allocation) GetStats() *AllocationStats
func (*Allocation) InitAllocation ¶
func (a *Allocation) InitAllocation()
func (*Allocation) ListDir ¶
func (a *Allocation) ListDir(path string, opts ...ListRequestOptions) (*ListResult, error)
func (*Allocation) ListDirFromAuthTicket ¶
func (a *Allocation) ListDirFromAuthTicket(authTicket string, lookupHash string, opts ...ListRequestOptions) (*ListResult, error)
func (*Allocation) PauseUpload ¶ added in v1.14.0
func (a *Allocation) PauseUpload(remotePath string) error
func (*Allocation) RepairAlloc ¶ added in v1.8.16
func (a *Allocation) RepairAlloc(statusCB StatusCallback) (err error)
RepairAlloc repairs all the files in allocation
func (*Allocation) RepairFile ¶
func (a *Allocation) RepairFile(file sys.File, remotepath string, statusCallback StatusCallback, mask zboxutil.Uint128, ref *fileref.FileRef) *OperationRequest
func (*Allocation) RepairRequired ¶
func (*Allocation) RevokeShare ¶
func (a *Allocation) RevokeShare(path string, refereeClientID string) error
func (*Allocation) RollbackWithMask ¶ added in v1.8.17
func (a *Allocation) RollbackWithMask(mask zboxutil.Uint128)
func (*Allocation) SaveRemoteSnapshot ¶
func (a *Allocation) SaveRemoteSnapshot(pathToSave string, remoteExcludePath []string) error
SaveRemoteSnapShot - Saves the remote current information to the given file This file can be passed to GetAllocationDiff to exactly find the previous sync state to current.
func (*Allocation) SetConsensusThreshold ¶ added in v1.8.17
func (a *Allocation) SetConsensusThreshold()
func (*Allocation) StartChunkedUpload ¶ added in v1.3.0
func (a *Allocation) StartChunkedUpload(workdir, localPath string, remotePath string, status StatusCallback, isUpdate bool, isRepair bool, thumbnailPath string, encryption bool, webStreaming bool, uploadOpts ...ChunkedUploadOption, ) error
func (*Allocation) StartMultiUpload ¶ added in v1.8.17
func (*Allocation) StartRepair ¶
func (a *Allocation) StartRepair(localRootPath, pathToRepair string, statusCB StatusCallback) error
func (*Allocation) UpdateFile ¶
func (a *Allocation) UpdateFile(workdir, localpath string, remotepath string, status StatusCallback) error
UpdateFile [Deprecated]please use CreateChunkedUpload
func (*Allocation) UpdateFileWithThumbnail ¶
func (a *Allocation) UpdateFileWithThumbnail(workdir, localpath string, remotepath string, thumbnailpath string, status StatusCallback) error
UpdateFileWithThumbnail [Deprecated]please use CreateChunkedUpload
func (*Allocation) UpdateWithRepair ¶ added in v1.8.16
func (a *Allocation) UpdateWithRepair( size int64, extend bool, lock uint64, addBlobberId, addBlobberAuthTicket, removeBlobberId string, setThirdPartyExtendable bool, fileOptionsParams *FileOptionsParameters, statusCB StatusCallback, ) (string, error)
func (*Allocation) UploadAuthTicketToBlobber ¶
func (*Allocation) UploadFile ¶
func (a *Allocation) UploadFile(workdir, localpath string, remotepath string, status StatusCallback) error
UploadFile [Deprecated]please use CreateChunkedUpload
func (*Allocation) UploadFileWithThumbnail ¶
func (a *Allocation) UploadFileWithThumbnail(workdir string, localpath string, remotepath string, thumbnailpath string, status StatusCallback) error
UploadFileWithThumbnail [Deprecated]please use CreateChunkedUpload
type AllocationStats ¶
type AllocationStats struct { UsedSize int64 `json:"used_size"` NumWrites int64 `json:"num_of_writes"` NumReads int64 `json:"num_of_reads"` TotalChallenges int64 `json:"total_challenges"` OpenChallenges int64 `json:"num_open_challenges"` SuccessChallenges int64 `json:"num_success_challenges"` FailedChallenges int64 `json:"num_failed_challenges"` LastestClosedChallengeTxn string `json:"latest_closed_challenge"` }
type AuthTicket ¶
type AuthTicket struct {
// contains filtered or unexported fields
}
func InitAuthTicket ¶
func InitAuthTicket(authTicket string) *AuthTicket
func (*AuthTicket) GetFileName ¶
func (at *AuthTicket) GetFileName() (string, error)
func (*AuthTicket) GetLookupHash ¶
func (at *AuthTicket) GetLookupHash() (string, error)
func (*AuthTicket) IsDir ¶
func (at *AuthTicket) IsDir() (bool, error)
func (*AuthTicket) Unmarshall ¶
func (at *AuthTicket) Unmarshall() (*marker.AuthTicket, error)
type Blobber ¶
type Blobber struct { ID common.Key `json:"id"` BaseURL string `json:"url"` Terms Terms `json:"terms"` Capacity common.Size `json:"capacity"` Allocated common.Size `json:"allocated"` LastHealthCheck common.Timestamp `json:"last_health_check"` PublicKey string `json:"-"` StakePoolSettings blockchain.StakePoolSettings `json:"stake_pool_settings"` TotalStake int64 `json:"total_stake"` UsedAllocation int64 `json:"used_allocation"` TotalOffers int64 `json:"total_offers"` TotalServiceCharge int64 `json:"total_service_charge"` UncollectedServiceCharge int64 `json:"uncollected_service_charge"` IsKilled bool `json:"is_killed"` IsShutdown bool `json:"is_shutdown"` NotAvailable bool `json:"not_available"` IsRestricted bool `json:"is_restricted"` }
func GetBlobbers ¶
type BlobberAllocation ¶
type BlobberAllocation struct { BlobberID string `json:"blobber_id"` Size int64 `json:"size"` Terms Terms `json:"terms"` MinLockDemand common.Balance `json:"min_lock_demand"` Spent common.Balance `json:"spent"` Penalty common.Balance `json:"penalty"` ReadReward common.Balance `json:"read_reward"` Returned common.Balance `json:"returned"` ChallengeReward common.Balance `json:"challenge_reward"` FinalReward common.Balance `json:"final_reward"` }
type BlobberAllocationStats ¶
type BlobberAllocationStats struct { BlobberID string BlobberURL string ID string `json:"ID"` Tx string `json:"Tx"` TotalSize int64 `json:"TotalSize"` UsedSize int `json:"UsedSize"` OwnerID string `json:"OwnerID"` OwnerPublicKey string `json:"OwnerPublicKey"` Expiration int `json:"Expiration"` AllocationRoot string `json:"AllocationRoot"` BlobberSize int `json:"BlobberSize"` BlobberSizeUsed int `json:"BlobberSizeUsed"` LatestRedeemedWM string `json:"LatestRedeemedWM"` IsRedeemRequired bool `json:"IsRedeemRequired"` CleanedUp bool `json:"CleanedUp"` Finalized bool `json:"Finalized"` Terms []struct { ID int `json:"ID"` BlobberID string `json:"BlobberID"` AllocationID string `json:"AllocationID"` ReadPrice int `json:"ReadPrice"` WritePrice int `json:"WritePrice"` } `json:"Terms"` }
type BlockDownloadRequest ¶
type BlockDownloadRequest struct {
// contains filtered or unexported fields
}
type ChallengePoolInfo ¶
type ChallengePoolInfo struct { ID string `json:"id"` Balance common.Balance `json:"balance"` StartTime common.Timestamp `json:"start_time"` Expiration common.Timestamp `json:"expiration"` Finalized bool `json:"finalized"` }
ChallengePoolInfo represents a challenge pool stat.
func GetChallengePoolInfo ¶
func GetChallengePoolInfo(allocID string) (info *ChallengePoolInfo, err error)
GetChallengePoolInfo for given allocation.
type ChunkData ¶ added in v1.2.88
type ChunkData struct { // Index current index of chunks Index int // IsFinal last chunk or not IsFinal bool // ReadSize total size read from original reader (un-encoded, un-encrypted) ReadSize int64 // FragmentSize fragment size for a blobber (un-encrypted) FragmentSize int64 // Fragments data shared for bloobers Fragments [][]byte }
ChunkData data of a chunk
type ChunkedUpload ¶ added in v1.2.88
type ChunkedUpload struct {
// contains filtered or unexported fields
}
ChunkedUpload upload manager with chunked upload feature
func CreateChunkedUpload ¶ added in v1.2.88
func CreateChunkedUpload( ctx context.Context, workdir string, allocationObj *Allocation, fileMeta FileMeta, fileReader io.Reader, isUpdate, isRepair bool, webStreaming bool, connectionId string, opts ...ChunkedUploadOption, ) (*ChunkedUpload, error)
func (*ChunkedUpload) Start ¶ added in v1.2.88
func (su *ChunkedUpload) Start() error
Start start/resume upload
type ChunkedUploadBlobber ¶ added in v1.3.5
type ChunkedUploadBlobber struct {
// contains filtered or unexported fields
}
ChunkedUploadBlobber client of blobber's upload
type ChunkedUploadChunkReader ¶ added in v1.2.88
type ChunkedUploadFormBuilder ¶ added in v1.2.88
type ChunkedUploadFormBuilder interface { // build form data Build( fileMeta *FileMeta, hasher Hasher, connectionID string, chunkSize int64, chunkStartIndex, chunkEndIndex int, isFinal bool, encryptedKey, encryptedKeyPoint string, fileChunksData [][]byte, thumbnailChunkData []byte, shardSize int64, ) (blobberData, error) }
ChunkedUploadFormBuilder build form data for uploading
func CreateChunkedUploadFormBuilder ¶ added in v1.2.88
func CreateChunkedUploadFormBuilder() ChunkedUploadFormBuilder
CreateChunkedUploadFormBuilder create ChunkedUploadFormBuilder instance
type ChunkedUploadFormMetadata ¶ added in v1.2.88
type ChunkedUploadFormMetadata struct { FileBytesLen int ThumbnailBytesLen int ContentType string FixedMerkleRoot string ValidationRoot string ThumbnailContentHash string }
ChunkedUploadFormMetadata upload form metadata
type ChunkedUploadOption ¶ added in v1.2.88
type ChunkedUploadOption func(su *ChunkedUpload)
ChunkedUploadOption set stream option
func WithActualHash ¶ added in v1.11.0
func WithActualHash(hash string) ChunkedUploadOption
func WithChunkNumber ¶ added in v1.7.7
func WithChunkNumber(num int) ChunkedUploadOption
WithChunkNumber set the number of chunks should be upload in a request. ignore if size <=0
func WithCommitTimeout ¶ added in v1.8.9
func WithCommitTimeout(t time.Duration) ChunkedUploadOption
func WithEncrypt ¶ added in v1.2.88
func WithEncrypt(on bool) ChunkedUploadOption
WithEncrypt turn on/off encrypt on upload. It is turn off as default.
func WithEncryptedPoint ¶ added in v1.10.0
func WithEncryptedPoint(point string) ChunkedUploadOption
func WithMask ¶ added in v1.8.17
func WithMask(mask zboxutil.Uint128) ChunkedUploadOption
func WithProgressStorer ¶ added in v1.3.6
func WithProgressStorer(progressStorer ChunkedUploadProgressStorer) ChunkedUploadOption
func WithStatusCallback ¶ added in v1.2.88
func WithStatusCallback(callback StatusCallback) ChunkedUploadOption
WithStatusCallback register StatusCallback instance
func WithThumbnail ¶ added in v1.2.88
func WithThumbnail(buf []byte) ChunkedUploadOption
WithThumbnail add thumbnail. stream mode is unnecessary for thumbnail
func WithThumbnailFile ¶ added in v1.2.88
func WithThumbnailFile(fileName string) ChunkedUploadOption
WithThumbnailFile add thumbnail from file. stream mode is unnecessary for thumbnail
func WithUploadTimeout ¶ added in v1.8.9
func WithUploadTimeout(t time.Duration) ChunkedUploadOption
type ChunkedUploadProgressStorer ¶ added in v1.2.88
type ChunkedUploadProgressStorer interface { // Load load upload progress by id Load(id string) *UploadProgress // Save save upload progress Save(up UploadProgress) // Remove remove upload progress by id Remove(id string) error // Update update upload progress Update(id string, chunkIndex int) }
ChunkedUploadProgressStorer load and save upload progress
type CommitMetaData ¶
type CommitMetaData struct { CrudType string MetaData *ConsolidatedFileMeta }
type CommitMetaResponse ¶
type CommitMetaResponse struct { TxnID string MetaData *ConsolidatedFileMeta }
type CommitRequest ¶
type CommitRequest struct {
// contains filtered or unexported fields
}
type CommitResult ¶
type CommitResult struct { Success bool `json:"success"` ErrorMessage string `json:"error_msg,omitempty"` }
func ErrorCommitResult ¶
func ErrorCommitResult(errMsg string) *CommitResult
func SuccessCommitResult ¶
func SuccessCommitResult() *CommitResult
type ConsolidatedFileMeta ¶
type CopyOperation ¶ added in v1.8.17
type CopyOperation struct { Consensus // contains filtered or unexported fields }
func NewCopyOperation ¶ added in v1.8.17
func (*CopyOperation) Completed ¶ added in v1.8.17
func (co *CopyOperation) Completed(allocObj *Allocation)
func (*CopyOperation) Error ¶ added in v1.8.17
func (co *CopyOperation) Error(allocObj *Allocation, consensus int, err error)
func (*CopyOperation) Process ¶ added in v1.8.17
func (co *CopyOperation) Process(allocObj *Allocation, connectionID string) ([]fileref.RefEntity, zboxutil.Uint128, error)
func (*CopyOperation) Verify ¶ added in v1.8.17
func (co *CopyOperation) Verify(a *Allocation) error
type CopyRequest ¶
type CopyRequest struct { Consensus // contains filtered or unexported fields }
func (*CopyRequest) ProcessCopy ¶
func (req *CopyRequest) ProcessCopy() error
func (*CopyRequest) ProcessWithBlobbers ¶ added in v1.8.17
func (req *CopyRequest) ProcessWithBlobbers() ([]fileref.RefEntity, []error)
type CreateAllocationOptions ¶ added in v1.8.7
type CreateAllocationOptions struct { DataShards int ParityShards int Size int64 ReadPrice PriceRange WritePrice PriceRange Lock uint64 BlobberIds []string BlobberAuthTickets []string ThirdPartyExtendable bool FileOptionsParams *FileOptionsParameters Force bool }
type DataChan ¶ added in v1.8.17
type DataChan struct {
// contains filtered or unexported fields
}
Example implementation of a reader
type DeleteOperation ¶ added in v1.8.17
type DeleteOperation struct {
// contains filtered or unexported fields
}
func NewDeleteOperation ¶ added in v1.8.17
func (*DeleteOperation) Completed ¶ added in v1.8.17
func (dop *DeleteOperation) Completed(allocObj *Allocation)
func (*DeleteOperation) Error ¶ added in v1.8.17
func (dop *DeleteOperation) Error(allocObj *Allocation, consensus int, err error)
func (*DeleteOperation) Process ¶ added in v1.8.17
func (dop *DeleteOperation) Process(allocObj *Allocation, connectionID string) ([]fileref.RefEntity, zboxutil.Uint128, error)
func (*DeleteOperation) Verify ¶ added in v1.8.17
func (dop *DeleteOperation) Verify(a *Allocation) error
type DeleteRequest ¶
type DeleteRequest struct {
// contains filtered or unexported fields
}
func (*DeleteRequest) ProcessDelete ¶
func (req *DeleteRequest) ProcessDelete() (err error)
type DirOperation ¶ added in v1.8.17
type DirOperation struct { Consensus // contains filtered or unexported fields }
func NewDirOperation ¶ added in v1.8.17
func (*DirOperation) Completed ¶ added in v1.8.17
func (dirOp *DirOperation) Completed(allocObj *Allocation)
func (*DirOperation) Error ¶ added in v1.8.17
func (dirOp *DirOperation) Error(allocObj *Allocation, consensus int, err error)
func (*DirOperation) Process ¶ added in v1.8.17
func (dirOp *DirOperation) Process(allocObj *Allocation, connectionID string) ([]fileref.RefEntity, zboxutil.Uint128, error)
func (*DirOperation) Verify ¶ added in v1.8.17
func (dirOp *DirOperation) Verify(a *Allocation) error
type DirRequest ¶
type DirRequest struct { Consensus // contains filtered or unexported fields }
func (*DirRequest) ProcessDir ¶
func (req *DirRequest) ProcessDir(a *Allocation) error
func (*DirRequest) ProcessWithBlobbers ¶ added in v1.8.17
func (req *DirRequest) ProcessWithBlobbers(a *Allocation) int
type DownloadOption ¶ added in v1.4.3
type DownloadOption func(do *DownloadOptions)
DownloadOption set download option
func WithAllocation ¶ added in v1.4.3
func WithAllocation(obj *Allocation) DownloadOption
func WithAuthticket ¶ added in v1.4.3
func WithAuthticket(authTicket, lookupHash string) DownloadOption
func WithBlocks ¶ added in v1.4.3
func WithBlocks(start, end int64, blocksPerMarker int) DownloadOption
func WithFileHandler ¶ added in v1.8.17
func WithFileHandler(fileHandler sys.File) DownloadOption
func WithOnlyThumbnail ¶ added in v1.4.3
func WithOnlyThumbnail(thumbnail bool) DownloadOption
func WithVerifyDownload ¶ added in v1.8.14
func WithVerifyDownload(shouldVerify bool) DownloadOption
type DownloadOptions ¶ added in v1.4.3
type DownloadOptions struct {
// contains filtered or unexported fields
}
DownloadOptions download options
type DownloadProgress ¶ added in v1.13.0
type DownloadProgressStorer ¶ added in v1.13.0
type DownloadProgressStorer interface { // Load load download progress by id Load(id string, numBlocks int) *DownloadProgress // Update download progress Update(writtenBlock int) // Remove remove download progress by id Remove() error // Start start download progress Start(ctx context.Context) // Save download progress Save(dp *DownloadProgress) }
type DownloadRequest ¶
type DownloadRequest struct { Consensus // contains filtered or unexported fields }
type DownloadRequestHeader ¶ added in v1.7.2
type DownloadRequestHeader struct { ClientID string PathHash string BlockNum int64 NumBlocks int64 ReadMarker []byte AuthToken []byte DownloadMode string VerifyDownload bool ConnectionID string Version string }
DownloadRequestHeader download request header
func (*DownloadRequestHeader) ToFastHeader ¶ added in v1.13.0
func (h *DownloadRequestHeader) ToFastHeader(req *fasthttp.Request)
func (*DownloadRequestHeader) ToHeader ¶ added in v1.7.2
func (h *DownloadRequestHeader) ToHeader(req *http.Request)
ToHeader update header
type DownloadRequestOption ¶ added in v1.13.0
type DownloadRequestOption func(dr *DownloadRequest)
func WithDownloadProgressStorer ¶ added in v1.13.0
func WithDownloadProgressStorer(storer DownloadProgressStorer) DownloadRequestOption
func WithFileCallback ¶ added in v1.13.0
func WithFileCallback(cb func()) DownloadRequestOption
func WithWorkDir ¶ added in v1.13.0
func WithWorkDir(workdir string) DownloadRequestOption
type Downloader ¶ added in v1.4.3
type Downloader interface { GetAllocation() *Allocation GetFileName() string Start(status StatusCallback, isFinal bool) error }
Downloader downloader for file, blocks and thumbnail
func CreateDownloader ¶ added in v1.4.3
func CreateDownloader(allocationID, localPath, remotePath string, opts ...DownloadOption) (Downloader, error)
CreateDownloader create a downloander
type FfmpegRecorder ¶ added in v1.2.88
type FfmpegRecorder struct {
// contains filtered or unexported fields
}
FfmpegRecorder wrap ffmpeg command to capture video and audio from local camera and microphone
func CreateFfmpegRecorder ¶ added in v1.2.88
func CreateFfmpegRecorder(file string, delay int) (*FfmpegRecorder, error)
CreateFfmpegRecorder create a ffmpeg commander to capture video and audio local camera and microphone
func (*FfmpegRecorder) Close ¶ added in v1.2.88
func (r *FfmpegRecorder) Close() (err error)
Close implements io.Closer
func (*FfmpegRecorder) GetClipsFile ¶ added in v1.2.88
GetClipsFile get clips file
func (*FfmpegRecorder) GetClipsFileName ¶ added in v1.2.88
GetClipsFileName get clips file name
func (*FfmpegRecorder) GetFileContentType ¶ added in v1.2.88
GetFileContentType get MIME type
type FileInfo ¶ added in v1.8.13
type FileInfo struct { Size int64 `json:"size"` MimeType string `json:"mimetype"` ActualSize int64 `json:"actual_size"` Hash string `json:"hash"` Type string `json:"type"` EncryptedKey string `json:"encrypted_key"` LookupHash string `json:"lookup_hash"` CreatedAt common.Timestamp `json:"created_at"` UpdatedAt common.Timestamp `json:"updated_at"` }
type FileMeta ¶ added in v1.0.3
type FileMeta struct { // Mimetype mime type of source file MimeType string // Path local path of source file Path string // ThumbnailPath local path of source thumbnail ThumbnailPath string // ActualHash hash of original file (un-encoded, un-encrypted) ActualHash string // ActualSize total bytes of original file (unencoded, un-encrypted). it is 0 if input is live stream. ActualSize int64 // ActualThumbnailSize total bytes of original thumbnail (un-encoded, un-encrypted) ActualThumbnailSize int64 // ActualThumbnailHash hash of original thumbnail (un-encoded, un-encrypted) ActualThumbnailHash string //RemoteName remote file name RemoteName string // RemotePath remote path RemotePath string }
FileMeta metadata of stream input/local
type FileNameBuilder ¶ added in v1.2.88
type FileNameBuilder interface { OutDir() string FileExt() string OutFile() string ClipsFile(index int) string ClipsFileName(index int) string }
FileNameBuilder build file name based output format
type FileOptionParam ¶ added in v1.8.13
type FileOptionsParameters ¶ added in v1.8.13
type FileOptionsParameters struct { ForbidUpload FileOptionParam ForbidDelete FileOptionParam ForbidUpdate FileOptionParam ForbidMove FileOptionParam ForbidCopy FileOptionParam ForbidRename FileOptionParam }
type FileStats ¶
type FileStats struct { Name string `json:"name"` Size int64 `json:"size"` PathHash string `json:"path_hash"` Path string `json:"path"` NumBlocks int64 `json:"num_of_blocks"` NumUpdates int64 `json:"num_of_updates"` NumBlockDownloads int64 `json:"num_of_block_downloads"` SuccessChallenges int64 `json:"num_of_challenges"` FailedChallenges int64 `json:"num_of_failed_challenges"` LastChallengeResponseTxn string `json:"last_challenge_txn"` WriteMarkerRedeemTxn string `json:"write_marker_txn"` BlobberID string `json:"blobber_id"` BlobberURL string `json:"blobber_url"` BlockchainAware bool `json:"blockchain_aware"` CreatedAt time.Time `json:"CreatedAt"` FileID string `json:"file_id"` }
type FsDownloadProgressStorer ¶ added in v1.13.0
func CreateFsDownloadProgress ¶ added in v1.13.0
func CreateFsDownloadProgress() *FsDownloadProgressStorer
func (*FsDownloadProgressStorer) Load ¶ added in v1.13.0
func (ds *FsDownloadProgressStorer) Load(progressID string, numBlocks int) *DownloadProgress
func (*FsDownloadProgressStorer) Remove ¶ added in v1.13.0
func (ds *FsDownloadProgressStorer) Remove() error
func (*FsDownloadProgressStorer) Save ¶ added in v1.13.0
func (ds *FsDownloadProgressStorer) Save(dp *DownloadProgress)
func (*FsDownloadProgressStorer) Start ¶ added in v1.13.0
func (ds *FsDownloadProgressStorer) Start(ctx context.Context)
func (*FsDownloadProgressStorer) Update ¶ added in v1.13.0
func (ds *FsDownloadProgressStorer) Update(writtenBlock int)
type Hasher ¶ added in v1.2.88
type Hasher interface { // GetFileHash get file hash GetFileHash() (string, error) // WriteToFile write bytes to file hasher WriteToFile(buf []byte) error GetFixedMerkleRoot() (string, error) // WriteToFixedMT write bytes to FMT hasher WriteToFixedMT(buf []byte) error GetValidationRoot() (string, error) // WriteToValidationMT write bytes Validation Tree hasher WriteToValidationMT(buf []byte) error // Finalize will let merkle tree know that tree is finalized with the content it has received Finalize() error }
func CreateHasher ¶ added in v1.2.88
CreateHasher creat Hasher instance
type InputMap ¶ added in v1.2.86
type InputMap struct {
Fields map[string]interface{} `json:"fields"`
}
func GetStorageSCConfig ¶
type LatestPrevWriteMarker ¶ added in v1.8.17
type LatestPrevWriteMarker struct { LatestWM *marker.WriteMarker `json:"latest_write_marker"` PrevWM *marker.WriteMarker `json:"prev_write_marker"` Version string `json:"version"` }
func GetWritemarker ¶ added in v1.8.17
func GetWritemarker(allocID, allocTx, id, baseUrl string) (*LatestPrevWriteMarker, error)
type ListRequest ¶
type ListRequest struct { Consensus // contains filtered or unexported fields }
func (*ListRequest) GetListFromBlobbers ¶
func (req *ListRequest) GetListFromBlobbers() (*ListResult, error)
type ListRequestOptions ¶ added in v1.12.1
type ListRequestOptions func(req *ListRequest)
func WithListRequestForRepair ¶ added in v1.12.1
func WithListRequestForRepair(forRepair bool) ListRequestOptions
func WithListRequestOffset ¶ added in v1.12.1
func WithListRequestOffset(offset int) ListRequestOptions
func WithListRequestPageLimit ¶ added in v1.12.1
func WithListRequestPageLimit(pageLimit int) ListRequestOptions
type ListResult ¶
type ListResult struct { Name string `json:"name"` Path string `json:"path,omitempty"` Type string `json:"type"` Size int64 `json:"size"` Hash string `json:"hash,omitempty"` FileMetaHash string `json:"file_meta_hash,omitempty"` MimeType string `json:"mimetype,omitempty"` NumBlocks int64 `json:"num_blocks"` LookupHash string `json:"lookup_hash"` EncryptionKey string `json:"encryption_key"` ActualSize int64 `json:"actual_size"` ActualNumBlocks int64 `json:"actual_num_blocks"` ThumbnailHash string `json:"thumbnail_hash"` ThumbnailSize int64 `json:"thumbnail_size"` ActualThumbnailHash string `json:"actual_thumbnail_hash"` ActualThumbnailSize int64 `json:"actual_thumbnail_size"` CreatedAt common.Timestamp `json:"created_at"` UpdatedAt common.Timestamp `json:"updated_at"` Children []*ListResult `json:"list"` Consensus `json:"-"` // contains filtered or unexported fields }
type LiveMeta ¶ added in v1.2.88
type LiveMeta struct { // Mimetype mime type of source file MimeType string //RemoteName remote file name RemoteName string // RemotePath remote path RemotePath string }
LiveMeta metadata of live stream input
type LiveUpload ¶ added in v1.2.88
type LiveUpload struct {
// contains filtered or unexported fields
}
LiveUpload live streaming video upload manager
func CreateLiveUpload ¶ added in v1.2.88
func CreateLiveUpload(homedir string, allocationObj *Allocation, liveMeta LiveMeta, liveReader LiveUploadReader, opts ...LiveUploadOption) *LiveUpload
CreateLiveUpload create a LiveChunkedUpload instance
func (*LiveUpload) Start ¶ added in v1.2.88
func (lu *LiveUpload) Start() error
Start start live streaming upload
type LiveUploadOption ¶ added in v1.2.88
type LiveUploadOption func(lu *LiveUpload)
LiveUploadOption set live upload option
func WithLiveChunkNumber ¶ added in v1.7.7
func WithLiveChunkNumber(num int) LiveUploadOption
WithLiveChunkNumber set the number of chunks should be upload in a request. ignore if size <=0
func WithLiveDelay ¶ added in v1.2.88
func WithLiveDelay(delaySeconds int) LiveUploadOption
WithLiveDelay set delayed . ignore if delayed <=0
func WithLiveEncrypt ¶ added in v1.2.88
func WithLiveEncrypt(status bool) LiveUploadOption
WithLiveEncrypt trun on/off encrypt on upload. It is turn off as default.
func WithLiveStatusCallback ¶ added in v1.2.88
func WithLiveStatusCallback(callback func() StatusCallback) LiveUploadOption
WithLiveStatusCallback register StatusCallback instance
type LiveUploadReader ¶ added in v1.2.88
type LiveUploadReader interface { io.Reader Size() int64 GetClipsFile(clipsIndex int) string GetClipsFileName(cliipsIndex int) string }
LiveUploadReader implements io.Reader and Size for live stream upload
type M3u8Writer ¶ added in v1.2.88
type M3u8Writer interface { io.WriteSeeker Truncate(size int64) error Sync() error }
M3u8Writer m3u8 writer
type MediaPlaylist ¶ added in v1.2.88
type MediaPlaylist struct {
// contains filtered or unexported fields
}
MediaPlaylist m3u8 encoder and decoder
func NewMediaPlaylist ¶ added in v1.2.88
func NewMediaPlaylist(delay int, dir string, writer M3u8Writer) *MediaPlaylist
NewMediaPlaylist create media playlist(.m3u8)
func (*MediaPlaylist) Append ¶ added in v1.2.88
func (m *MediaPlaylist) Append(item string)
Append append new item
func (*MediaPlaylist) Encode ¶ added in v1.2.88
func (m *MediaPlaylist) Encode() []byte
Encode encode m3u8
func (*MediaPlaylist) Play ¶ added in v1.2.88
func (m *MediaPlaylist) Play()
Play start to push item into playlist
func (*MediaPlaylist) String ¶ added in v1.2.88
func (m *MediaPlaylist) String() string
String implement Stringer
type MoveOperation ¶ added in v1.8.17
type MoveOperation struct {
// contains filtered or unexported fields
}
func NewMoveOperation ¶ added in v1.8.17
func (*MoveOperation) Completed ¶ added in v1.8.17
func (mo *MoveOperation) Completed(allocObj *Allocation)
func (*MoveOperation) Error ¶ added in v1.8.17
func (mo *MoveOperation) Error(allocObj *Allocation, consensus int, err error)
func (*MoveOperation) Process ¶ added in v1.8.17
func (mo *MoveOperation) Process(allocObj *Allocation, connectionID string) ([]fileref.RefEntity, zboxutil.Uint128, error)
func (*MoveOperation) Verify ¶ added in v1.8.17
func (mo *MoveOperation) Verify(a *Allocation) error
type MoveRequest ¶ added in v1.8.10
type MoveRequest struct { Consensus // contains filtered or unexported fields }
func (*MoveRequest) ProcessMove ¶ added in v1.8.10
func (req *MoveRequest) ProcessMove() error
func (*MoveRequest) ProcessWithBlobbers ¶ added in v1.8.17
func (req *MoveRequest) ProcessWithBlobbers() ([]fileref.RefEntity, []error)
type MultiOperation ¶ added in v1.8.17
type MultiOperation struct { Consensus // contains filtered or unexported fields }
func (*MultiOperation) Process ¶ added in v1.8.17
func (mo *MultiOperation) Process() error
type MultiOperationOption ¶ added in v1.11.4
type MultiOperationOption func(mo *MultiOperation)
func WithRepair ¶ added in v1.11.4
func WithRepair() MultiOperationOption
type ORef ¶ added in v1.3.0
type ORef struct { SimilarField ID int64 `json:"id"` CreatedAt common.Timestamp `json:"created_at"` UpdatedAt common.Timestamp `json:"updated_at"` }
Blobber response will be different from each other so we should only consider similar fields i.e. we cannot calculate hash of response and have consensus on it
type ObjectTreeRequest ¶ added in v1.3.0
type ObjectTreeRequest struct { Consensus // contains filtered or unexported fields }
func (*ObjectTreeRequest) GetRefs ¶ added in v1.3.0
func (o *ObjectTreeRequest) GetRefs() (*ObjectTreeResult, error)
Paginated tree should not be collected as this will stall the client It should rather be handled by application that uses gosdk
type ObjectTreeResult ¶ added in v1.3.0
type OperationRequest ¶ added in v1.8.17
type OperationRequest struct { OperationType string LocalPath string RemotePath string DestName string // Required only for rename operation DestPath string // Required for copy and move operation IsUpdate bool IsRepair bool // Required for repair operation IsWebstreaming bool // Required for uploads Workdir string FileMeta FileMeta FileReader io.Reader Mask *zboxutil.Uint128 // Required for delete repair operation DownloadFile bool // Required for upload repair operation StreamUpload bool // Required for streaming file when actualSize is not available Opts []ChunkedUploadOption }
type Operationer ¶ added in v1.8.17
type Operationer interface { Process(allocObj *Allocation, connectionID string) ([]fileref.RefEntity, zboxutil.Uint128, error) Verify(allocObj *Allocation) error Completed(allocObj *Allocation) Error(allocObj *Allocation, consensus int, err error) // contains filtered or unexported methods }
type PlaylistFile ¶ added in v1.8.8
type PlaylistFile struct { LookupHash string `gorm:"column:lookup_hash" json:"lookup_hash"` Name string `gorm:"column:name" json:"name"` Path string `gorm:"column:path" json:"path"` NumBlocks int64 `gorm:"column:num_of_blocks" json:"num_of_blocks"` ParentPath string `gorm:"column:parent_path" json:"parent_path"` Size int64 `gorm:"column:size;" json:"size"` ActualFileSize int64 MimeType string `gorm:"column:mimetype" json:"mimetype"` Type string `gorm:"column:type" json:"type"` }
func GetPlaylist ¶ added in v1.8.8
func GetPlaylist(ctx context.Context, alloc *Allocation, path, since string) ([]PlaylistFile, error)
func GetPlaylistByAuthTicket ¶ added in v1.8.8
func GetPlaylistByAuthTicket(ctx context.Context, alloc *Allocation, authTicket, lookupHash, since string) ([]PlaylistFile, error)
func GetPlaylistFile ¶ added in v1.8.8
func GetPlaylistFile(ctx context.Context, alloc *Allocation, path string) (*PlaylistFile, error)
func GetPlaylistFileByAuthTicket ¶ added in v1.8.8
func GetPlaylistFileByAuthTicket(ctx context.Context, alloc *Allocation, authTicket, lookupHash string) (*PlaylistFile, error)
type PriceRange ¶
PriceRange represents a price range allowed by user to filter blobbers.
func GetReadPriceRange ¶ added in v1.8.16
func GetReadPriceRange() (PriceRange, error)
func GetWritePriceRange ¶ added in v1.8.16
func GetWritePriceRange() (PriceRange, error)
type ProcessResult ¶ added in v1.8.9
type ProviderType ¶ added in v1.7.1
type ProviderType int
const ( ProviderMiner ProviderType = iota + 1 ProviderSharder ProviderBlobber ProviderValidator ProviderAuthorizer )
type ReadPool ¶ added in v1.8.5
func GetReadPoolInfo ¶
GetReadPoolInfo for given client, or, if the given clientID is empty, for current client of the sdk.
type RecentlyAddedRefRequest ¶ added in v1.8.7
type RecentlyAddedRefRequest struct { Consensus // contains filtered or unexported fields }
func (*RecentlyAddedRefRequest) GetRecentlyAddedRefs ¶ added in v1.8.7
func (r *RecentlyAddedRefRequest) GetRecentlyAddedRefs() (*RecentlyAddedRefResult, error)
type RecentlyAddedRefResponse ¶ added in v1.8.7
type RecentlyAddedRefResponse struct { Result *RecentlyAddedRefResult // contains filtered or unexported fields }
type RecentlyAddedRefResult ¶ added in v1.8.7
type ReferencePathResult ¶
type ReferencePathResult struct { *fileref.ReferencePath LatestWM *marker.WriteMarker `json:"latest_write_marker"` Version string `json:"version"` }
type RenameOperation ¶ added in v1.8.17
type RenameOperation struct {
// contains filtered or unexported fields
}
func NewRenameOperation ¶ added in v1.8.17
func (*RenameOperation) Completed ¶ added in v1.8.17
func (ro *RenameOperation) Completed(allocObj *Allocation)
func (*RenameOperation) Error ¶ added in v1.8.17
func (ro *RenameOperation) Error(allocObj *Allocation, consensus int, err error)
func (*RenameOperation) Process ¶ added in v1.8.17
func (ro *RenameOperation) Process(allocObj *Allocation, connectionID string) ([]fileref.RefEntity, zboxutil.Uint128, error)
func (*RenameOperation) Verify ¶ added in v1.8.17
func (ro *RenameOperation) Verify(a *Allocation) error
type RenameRequest ¶
type RenameRequest struct {
// contains filtered or unexported fields
}
func (*RenameRequest) ProcessRename ¶
func (req *RenameRequest) ProcessRename() error
func (*RenameRequest) ProcessWithBlobbers ¶ added in v1.8.17
func (req *RenameRequest) ProcessWithBlobbers() ([]fileref.RefEntity, []error)
type RepairRequest ¶
type RepairRequest struct {
// contains filtered or unexported fields
}
type RepairStatusCB ¶
type RepairStatusCB struct {
// contains filtered or unexported fields
}
func (*RepairStatusCB) Error ¶
func (cb *RepairStatusCB) Error(allocationID string, filePath string, op int, err error)
func (*RepairStatusCB) InProgress ¶
func (cb *RepairStatusCB) InProgress(allocationId, filePath string, op int, completedBytes int, data []byte)
func (*RepairStatusCB) RepairCompleted ¶
func (cb *RepairStatusCB) RepairCompleted(filesRepaired int)
type ResetBlobberStatsDto ¶ added in v1.13.0
type RollbackBlobber ¶ added in v1.8.17
type RollbackBlobber struct {
// contains filtered or unexported fields
}
type ShareRequest ¶
type ShareRequest struct {
// contains filtered or unexported fields
}
func (*ShareRequest) GetFileRef ¶
func (req *ShareRequest) GetFileRef() (*fileref.FileRef, error)
type SignalContext ¶ added in v1.3.0
SignalContext listen syscall signal to cancel context
type SimilarField ¶ added in v1.3.0
type SimilarField struct { FileID string `json:"file_id"` FileMetaHash string `json:"file_meta_hash"` Type string `json:"type"` AllocationID string `json:"allocation_id"` LookupHash string `json:"lookup_hash"` Name string `json:"name"` Path string `json:"path"` PathHash string `json:"path_hash"` ParentPath string `json:"parent_path"` PathLevel int `json:"level"` Size int64 `json:"size"` EncryptedKey string `json:"encrypted_key"` ActualFileSize int64 `json:"actual_file_size"` ActualFileHash string `json:"actual_file_hash"` MimeType string `json:"mimetype"` ActualThumbnailSize int64 `json:"actual_thumbnail_size"` ActualThumbnailHash string `json:"actual_thumbnail_hash"` }
type StakePoolDelegatePoolInfo ¶
type StakePoolDelegatePoolInfo struct { ID common.Key `json:"id"` // blobber ID Balance common.Balance `json:"balance"` // current balance DelegateID common.Key `json:"delegate_id"` // wallet Rewards common.Balance `json:"rewards"` // current UnStake bool `json:"unstake"` // want to unstake TotalReward common.Balance `json:"total_reward"` TotalPenalty common.Balance `json:"total_penalty"` Status string `json:"status"` RoundCreated int64 `json:"round_created"` StakedAt common.Timestamp `json:"staked_at"` }
StakePoolDelegatePoolInfo represents delegate pool of a stake pool info.
type StakePoolInfo ¶
type StakePoolInfo struct { ID common.Key `json:"pool_id"` // pool ID Balance common.Balance `json:"balance"` // total balance StakeTotal common.Balance `json:"stake_total"` // delegate pools Delegate []StakePoolDelegatePoolInfo `json:"delegate"` // rewards Rewards common.Balance `json:"rewards"` // total rewards TotalRewards common.Balance `json:"total_rewards"` // Settings of the stake pool Settings blockchain.StakePoolSettings `json:"settings"` }
StakePool full info.
func GetStakePoolInfo ¶
func GetStakePoolInfo(providerType ProviderType, providerID string) (info *StakePoolInfo, err error)
GetStakePoolInfo for given client, or, if the given clientID is empty, for current client of the sdk.
type StakePoolOfferInfo ¶
type StakePoolOfferInfo struct { Lock common.Balance `json:"lock"` Expire common.Timestamp `json:"expire"` AllocationID common.Key `json:"allocation_id"` IsExpired bool `json:"is_expired"` }
StakePoolOfferInfo represents stake pool offer information.
type StakePoolRewardsInfo ¶
type StakePoolRewardsInfo struct { Charge common.Balance `json:"charge"` // total for all time Blobber common.Balance `json:"blobber"` // total for all time Validator common.Balance `json:"validator"` // total for all time }
StakePoolRewardsInfo represents stake pool rewards.
type StakePoolUserInfo ¶
type StakePoolUserInfo struct {
Pools map[common.Key][]*StakePoolDelegatePoolInfo `json:"pools"`
}
StakePoolUserInfo represents user stake pools statistic.
func GetStakePoolUserInfo ¶
func GetStakePoolUserInfo(clientID string, offset, limit int) (info *StakePoolUserInfo, err error)
GetStakePoolUserInfo obtains blobbers/validators delegate pools statistic for a user. If given clientID is empty string, then current client used.
type StatusBar ¶ added in v1.2.1
type StatusBar struct {
// contains filtered or unexported fields
}
func NewRepairBar ¶ added in v1.8.17
func (*StatusBar) InProgress ¶ added in v1.2.1
func (*StatusBar) RepairCompleted ¶ added in v1.2.1
type StatusCallback ¶
type StatusCallback interface { Started(allocationId, filePath string, op int, totalBytes int) InProgress(allocationId, filePath string, op int, completedBytes int, data []byte) Error(allocationID string, filePath string, op int, err error) Completed(allocationId, filePath string, filename string, mimetype string, size int, op int) RepairCompleted(filesRepaired int) }
type StreamDownload ¶ added in v1.8.16
type StreamDownload struct { *DownloadRequest // contains filtered or unexported fields }
func (*StreamDownload) Close ¶ added in v1.8.16
func (sd *StreamDownload) Close() error
type StreamDownloadOption ¶ added in v1.8.16
type StreamReader ¶ added in v1.8.17
type StreamReader struct {
// contains filtered or unexported fields
}
func NewStreamReader ¶ added in v1.8.17
func NewStreamReader(dataChan chan *DataChan) *StreamReader
type Terms ¶
type Terms struct { ReadPrice common.Balance `json:"read_price"` // tokens / GB WritePrice common.Balance `json:"write_price"` // tokens / GB MaxOfferDuration time.Duration `json:"max_offer_duration"` }
Terms represents Blobber terms. A Blobber can update its terms, but any existing offer will use terms of offer signing time.
type UpdateBlobber ¶ added in v1.8.17
type UpdateBlobber struct { ID common.Key `json:"id"` BaseURL *string `json:"url,omitempty"` Terms *UpdateTerms `json:"terms,omitempty"` Capacity *common.Size `json:"capacity,omitempty"` Allocated *common.Size `json:"allocated,omitempty"` LastHealthCheck *common.Timestamp `json:"last_health_check,omitempty"` StakePoolSettings *blockchain.UpdateStakePoolSettings `json:"stake_pool_settings,omitempty"` TotalStake *int64 `json:"total_stake,omitempty"` UsedAllocation *int64 `json:"used_allocation,omitempty"` TotalOffers *int64 `json:"total_offers,omitempty"` TotalServiceCharge *int64 `json:"total_service_charge,omitempty"` UncollectedServiceCharge *int64 `json:"uncollected_service_charge,omitempty"` IsKilled *bool `json:"is_killed,omitempty"` IsShutdown *bool `json:"is_shutdown,omitempty"` NotAvailable *bool `json:"not_available,omitempty"` IsRestricted *bool `json:"is_restricted,omitempty"` }
UpdateBlobber is used during update blobber settings calls. Note the types are of pointer types with omitempty json property. This is done to correctly identify which properties are actually changing.
type UpdateTerms ¶ added in v1.8.17
type UpdateTerms struct { ReadPrice *common.Balance `json:"read_price,omitempty"` // tokens / GB WritePrice *common.Balance `json:"write_price,omitempty"` // tokens / GB MaxOfferDuration *time.Duration `json:"max_offer_duration,omitempty"` }
UpdateTerms represents Blobber terms during update blobber calls. A Blobber can update its terms, but any existing offer will use terms of offer signing time.
type UpdateValidator ¶ added in v1.8.17
type UpdateValidator struct { ID common.Key `json:"validator_id"` BaseURL *string `json:"url,omitempty"` DelegateWallet *string `json:"delegate_wallet,omitempty"` MinStake *common.Balance `json:"min_stake,omitempty"` MaxStake *common.Balance `json:"max_stake,omitempty"` NumDelegates *int `json:"num_delegates,omitempty"` ServiceCharge *float64 `json:"service_charge,omitempty"` StakeTotal *int64 `json:"stake_total,omitempty"` TotalServiceCharge *int64 `json:"total_service_charge,omitempty"` UncollectedServiceCharge *int64 `json:"uncollected_service_charge,omitempty"` LastHealthCheck *common.Timestamp `json:"last_health_check,omitempty"` IsKilled *bool `json:"is_killed,omitempty"` IsShutdown *bool `json:"is_shutdown,omitempty"` }
func (*UpdateValidator) ConvertToValidationNode ¶ added in v1.8.17
func (v *UpdateValidator) ConvertToValidationNode() *blockchain.UpdateValidationNode
type UploadBlobberStatus ¶ added in v1.2.88
type UploadBlobberStatus struct { Hasher Hasher // UploadLength total bytes that has been uploaded to blobbers UploadLength int64 `json:"upload_length,omitempty"` }
UploadBlobberStatus the status of blobber's upload progress
func (*UploadBlobberStatus) UnmarshalJSON ¶ added in v1.5.2
func (s *UploadBlobberStatus) UnmarshalJSON(b []byte) error
type UploadData ¶ added in v1.11.0
type UploadData struct {
// contains filtered or unexported fields
}
type UploadFileMeta ¶
type UploadFileMeta struct { // Name remote file name Name string // Path remote path Path string // Hash hash of entire source file Hash string MimeType string // Size total bytes of entire source file Size int64 // ThumbnailSize total bytes of entire thumbnail ThumbnailSize int64 // ThumbnailHash hash code of entire thumbnail ThumbnailHash string }
type UploadFormData ¶ added in v1.2.88
type UploadFormData struct { ConnectionID string `json:"connection_id,omitempty"` // Filename remote file name Filename string `json:"filename,omitempty"` // Path remote path Path string `json:"filepath,omitempty"` // ValidationRoot is merkle root of sha256 of 64KB as leaf ValidationRoot string `json:"validation_root,omitempty"` ValidationRootSignature string `json:"validation_root_signature,omitempty"` // Hash hash of shard thumbnail (encoded,encrypted) ThumbnailContentHash string `json:"thumbnail_content_hash,omitempty"` // ChallengeHash challenge hash of shard data (encoded, encrypted) FixedMerkleRoot string `json:"fixed_merkle_root,omitempty"` // ActualHash hash of original file (un-encoded, un-encrypted) ActualHash string `json:"actual_hash,omitempty"` ActualFileHashSignature string `json:"actual_file_hash_signature,omitempty"` // ActualSize total bytes of original file (un-encoded, un-encrypted) ActualSize int64 `json:"actual_size,omitempty"` // ActualThumbnailSize total bytes of original thumbnail (un-encoded, un-encrypted) ActualThumbSize int64 `json:"actual_thumb_size,omitempty"` // ActualThumbnailHash hash of original thumbnail (un-encoded, un-encrypted) ActualThumbHash string `json:"actual_thumb_hash,omitempty"` MimeType string `json:"mimetype,omitempty"` CustomMeta string `json:"custom_meta,omitempty"` EncryptedKey string `json:"encrypted_key,omitempty"` EncryptedKeyPoint string `json:"encrypted_key_point,omitempty"` IsFinal bool `json:"is_final,omitempty"` // all of chunks are uploaded ChunkStartIndex int `json:"chunk_start_index,omitempty"` // start index of chunks. ChunkEndIndex int `json:"chunk_end_index,omitempty"` // end index of chunks. all chunks MUST be uploaded one by one because of streaming merkle hash ChunkSize int64 `json:"chunk_size,omitempty"` // the size of a chunk. 64*1024 is default UploadOffset int64 `json:"upload_offset,omitempty"` // It is next position that new incoming chunk should be append to Size int64 `json:"size"` // total size of shard }
UploadFormData form data of upload
type UploadMode ¶ added in v1.14.0
type UploadMode byte
const ( UploadModeLow UploadMode = iota UploadModeMedium UploadModeHigh )
type UploadOperation ¶ added in v1.8.17
type UploadOperation struct {
// contains filtered or unexported fields
}
func NewUploadOperation ¶ added in v1.8.17
func NewUploadOperation(ctx context.Context, workdir string, allocObj *Allocation, connectionID string, fileMeta FileMeta, fileReader io.Reader, isUpdate, isWebstreaming, isRepair, isMemoryDownload, isStreamUpload bool, opts ...ChunkedUploadOption) (*UploadOperation, string, error)
func (*UploadOperation) Completed ¶ added in v1.8.17
func (uo *UploadOperation) Completed(allocObj *Allocation)
func (*UploadOperation) Error ¶ added in v1.8.17
func (uo *UploadOperation) Error(allocObj *Allocation, consensus int, err error)
func (*UploadOperation) Process ¶ added in v1.8.17
func (uo *UploadOperation) Process(allocObj *Allocation, connectionID string) ([]fileref.RefEntity, zboxutil.Uint128, error)
func (*UploadOperation) Verify ¶ added in v1.8.17
func (uo *UploadOperation) Verify(allocationObj *Allocation) error
type UploadProgress ¶ added in v1.2.88
type UploadProgress struct { ID string `json:"id"` // Lat updated time LastUpdated common.Timestamp `json:"last_updated,omitempty"` // ChunkSize size of chunk ChunkSize int64 `json:"chunk_size,omitempty"` ActualSize int64 `json:"actual_size,omitempty"` ChunkNumber int `json:"chunk_number,omitempty"` // EncryptOnUpload encrypt data on upload or not EncryptOnUpload bool `json:"is_encrypted,omitempty"` EncryptPrivateKey string `json:"-"` EncryptedKeyPoint string `json:"encrypted_key_point,omitempty"` // ConnectionID chunked upload connection_id ConnectionID string `json:"connection_id,omitempty"` // ChunkIndex index of last updated chunk ChunkIndex int `json:"chunk_index,omitempty"` // UploadLength total bytes that has been uploaded to blobbers UploadLength int64 `json:"-"` // ReadLength total bytes that has been read from original reader (un-encoded, un-encrypted) ReadLength int64 `json:"-"` Blobbers []*UploadBlobberStatus `json:"-"` }
UploadProgress progress of upload
type UploadResult ¶ added in v1.2.88
type Validator ¶ added in v1.8.5
type Validator struct { ID common.Key `json:"validator_id"` BaseURL string `json:"url"` PublicKey string `json:"-"` DelegateWallet string `json:"delegate_wallet"` MinStake common.Balance `json:"min_stake"` MaxStake common.Balance `json:"max_stake"` NumDelegates int `json:"num_delegates"` ServiceCharge float64 `json:"service_charge"` StakeTotal int64 `json:"stake_total"` TotalServiceCharge int64 `json:"total_service_charge"` UncollectedServiceCharge int64 `json:"uncollected_service_charge"` LastHealthCheck common.Timestamp `json:"last_health_check"` IsKilled bool `json:"is_killed"` IsShutdown bool `json:"is_shutdown"` }
func GetValidator ¶ added in v1.8.5
GetValidator instance.
func GetValidators ¶ added in v1.8.5
List all validators
type WMLockResult ¶ added in v1.7.3
type WMLockResult struct { Status WMLockStatus `json:"status,omitempty"` CreatedAt int64 `json:"created_at,omitempty"` }
type WMLockStatus ¶ added in v1.7.3
type WMLockStatus int
const ( WMLockStatusFailed WMLockStatus = iota WMLockStatusPending WMLockStatusOK )
type WriteMarkerMutex ¶ added in v1.7.3
type WriteMarkerMutex struct {
// contains filtered or unexported fields
}
WriteMarkerMutex blobber WriteMarkerMutex client
func CreateWriteMarkerMutex ¶ added in v1.7.3
func CreateWriteMarkerMutex(client *client.Client, allocationObj *Allocation) (*WriteMarkerMutex, error)
CreateWriteMarkerMutex create WriteMarkerMutex for allocation
func (*WriteMarkerMutex) Lock ¶ added in v1.7.3
func (wmMu *WriteMarkerMutex) Lock( ctx context.Context, mask *zboxutil.Uint128, maskMu *sync.Mutex, blobbers []*blockchain.StorageNode, consensus *Consensus, addConsensus int, timeOut time.Duration, connID string) error
func (*WriteMarkerMutex) Unlock ¶ added in v1.7.3
func (wmMu *WriteMarkerMutex) Unlock( ctx context.Context, mask zboxutil.Uint128, blobbers []*blockchain.StorageNode, timeOut time.Duration, connID string, )
func (*WriteMarkerMutex) UnlockBlobber ¶ added in v1.8.9
func (wmMu *WriteMarkerMutex) UnlockBlobber( ctx context.Context, b *blockchain.StorageNode, connID string, timeOut time.Duration, wg *sync.WaitGroup, )
Change status code to 204
type YoutubeDL ¶ added in v1.2.88
type YoutubeDL struct {
// contains filtered or unexported fields
}
YoutubeDL wrap youtube-dl to download video from youtube
func CreateYoutubeDL ¶ added in v1.2.88
func CreateYoutubeDL(ctx context.Context, localPath string, feedURL string, downloadArgs []string, ffmpegArgs []string, delay int) (*YoutubeDL, error)
CreateYoutubeDL create a youtube-dl instance to download video file from youtube
func (*YoutubeDL) GetClipsFile ¶ added in v1.2.88
GetClipsFile get clips file
func (*YoutubeDL) GetClipsFileName ¶ added in v1.2.88
GetClipsFileName get clips file name
func (*YoutubeDL) GetFileContentType ¶ added in v1.2.88
GetFileContentType get MIME type
Source Files ¶
- allocation.go
- authticket.go
- blockdownloadworker.go
- chunk_upload_vars.go
- chunked_upload.go
- chunked_upload_blobber.go
- chunked_upload_chunk_reader.go
- chunked_upload_form_builder.go
- chunked_upload_hasher.go
- chunked_upload_model.go
- chunked_upload_option.go
- chunked_upload_progress_storer.go
- chunked_upload_web_streaming.go
- commitmetaworker.go
- commitworker.go
- common.go
- consensus.go
- copyworker.go
- deleteworker.go
- dirworker.go
- download_progress_storer.go
- download_reqeust_header.go
- downloader.go
- downloader_block.go
- downloader_file.go
- downloader_filehandler.go
- downloader_option.go
- downloader_thumbnail.go
- downloadworker.go
- filemetaworker.go
- filerefsworker.go
- filestatsworker.go
- listworker.go
- live_upload.go
- live_upload_context.go
- live_upload_model.go
- live_upload_option.go
- live_upload_reader.go
- live_upload_reader_ffmpeg.go
- live_upload_reader_ffmpeg_filename_builder.go
- live_upload_reader_ffmpeg_linux.go
- live_upload_reader_youtubedl.go
- m3u8.go
- moveworker.go
- multi_operation_worker.go
- networkworker.go
- playlist.go
- playlist_consensus.go
- read_counter_ctr.go
- reader.go
- renameworker.go
- repairCallback.go
- repairworker.go
- rollback.go
- sdk.go
- sharerequest.go
- streamreader.go
- sync.go
- upload_helper.go
- upload_worker.go
- writemarker_mutex.go