Versions in this module Expand all Collapse all v0 v0.3.4 Aug 12, 2022 v0.3.3 Jun 8, 2022 v0.3.2 May 11, 2022 v0.3.1 Apr 25, 2022 v0.3.0 Apr 15, 2022 v0.2.6 Aug 26, 2022 v0.2.5 May 11, 2022 v0.2.4 Mar 29, 2022 v0.2.3 Mar 29, 2022 v0.2.2 Mar 29, 2022 v0.2.1 Mar 29, 2022 v0.2.0 Mar 23, 2022 v0.1.1 Mar 29, 2022 Changes in this version + func NewhashReader(src io.Reader, size int64, md5Hex string, sha256Hex string, actualSize int64) (*hash.Reader, error) v0.1.0 Mar 21, 2022 Changes in this version + const AdminUpdateApplyFailure + const AdminUpdateURLNotReachable + const AdminUpdateUnexpectedFailure + const AzureBackendGateway + const BackendErasure + const BackendFS + const BackendGateway + const CommitComplete + const CommitFailed + const CommitPending + const CommitWriteBack + const CommitWriteThrough + const DefaultBitrotAlgorithm + const DefaultSkewTime + const Disabled + const EnvErasureSetDriveCount + const EnvPrometheusAuthType + const GCSBackendGateway + const GatewayMinioSysTmp + const GlobalMinioDefaultPort + const GlobalStaleUploadsCleanupInterval + const GlobalStaleUploadsExpiry + const HDFSBackendGateway + const ILMExpiry + const ILMFreeVersionDelete + const ILMTransition + const NASBackendGateway + const ObjectLockLegalHoldTimestamp + const ObjectLockRetentionTimestamp + const ReplicaStatus + const ReplicaTimestamp + const ReplicateDelete + const ReplicateDeleteAPI + const ReplicateExisting + const ReplicateExistingDelete + const ReplicateHeal + const ReplicateIncoming + const ReplicateMRF + const ReplicateObjectAPI + const ReplicateQueued + const ReplicationReset + const ReplicationStatus + const ReplicationTimestamp + const ReplicationWorkerMultiplier + const ReservedMetadataPrefix + const ReservedMetadataPrefixLower + const S3BackendGateway + const SSECacheEncrypted + const SSECustomerKeySize + const SSEDAREPackageBlockSize + const SSEDAREPackageMetaSize + const SSEIVSize + const SlashSeparator + const TaggingTimestamp + const TransitionStatus + const TransitionTier + const TransitionedObjectName + const TransitionedVersionID + const Unknown + const VersionPurgeStatusKey + var CanonicalizeETag = canonicalizeETag + var CleanMetadataKeys = cleanMetadataKeys + var CommitID = "DEVELOPMENT.GOGET" + var FilterListEntries = filterListEntries + var GOPATH = "" + var GOROOT = "" + var GlobalContext context.Context + var GlobalFlags = []cli.Flag + var GlobalGatewaySSE gatewaySSE + var GlobalKMS kms.KMS + var IsStringEqual = isStringEqual + var ListObjects = listObjects + var MustGetUUID = mustGetUUID + var ObjectsHistogramIntervals = []objectHistogramInterval + var PathJoin = pathJoin + var ReleaseTag = "DEVELOPMENT.GOGET" + var ServerFlags = []cli.Flag + var ShortCommitID = "DEVELOPMENT.GOGET" + var Version = "DEVELOPMENT.GOGET" + func Access(name string) error + func AuthMiddleware(h http.Handler) http.Handler + func BucketAccessPolicyToPolicy(policyInfo *miniogopolicy.BucketAccessPolicy) (*policy.Policy, error) + func CheckLocalServerAddr(serverAddr string) error + func CleanMinioInternalMetadataKeys(metadata map[string]string) map[string]string + func ClusterCheckHandler(w http.ResponseWriter, r *http.Request) + func ClusterReadCheckHandler(w http.ResponseWriter, r *http.Request) + func ComputeCompleteMultipartMD5(parts []CompletePart) string + func CreateEndpoints(serverAddr string, foundLocal bool, args ...[]string) (Endpoints, SetupType, error) + func DecryptBlocksRequestR(inputReader io.Reader, h http.Header, seqNumber uint32, partStart int, ...) (io.Reader, error) + func DecryptCopyRequestR(client io.Reader, h http.Header, bucket, object string, seqNumber uint32, ...) (io.Reader, error) + func DecryptETag(key crypto.ObjectKey, object ObjectInfo) (string, error) + func DecryptObjectInfo(info *ObjectInfo, r *http.Request) (encrypted bool, err error) + func DecryptRequestWithSequenceNumberR(client io.Reader, h http.Header, bucket, object string, seqNumber uint32, ...) (io.Reader, error) + func EncryptRequest(content io.Reader, r *http.Request, bucket, object string, ...) (io.Reader, crypto.ObjectKey, error) + func ErrorRespToObjectError(err error, params ...string) error + func FromMinioClientMetadata(metadata map[string][]string) map[string]string + func GenETag() string + func GetAllSets(args ...string) ([][]string, error) + func GetCurrentReleaseTime() (releaseTime time.Time, err error) + func GetLocalPeer(endpointServerPools EndpointServerPools, host, port string) (localPeer string) + func GetObject(ctx context.Context, api ObjectLayer, bucket, object string, startOffset int64, ...) (err error) + func GetPeerOnlineCount() (nodesOnline, nodesOffline int) + func GetProxyEndpointLocalIndex(proxyEps []ProxyEndpoint) int + func GetTotalCapacity(diskInfo []madmin.Disk) (capacity uint64) + func GetTotalCapacityFree(diskInfo []madmin.Disk) (capacity uint64) + func GetTotalUsableCapacity(diskInfo []madmin.Disk, s StorageInfo) (capacity float64) + func GetTotalUsableCapacityFree(diskInfo []madmin.Disk, s StorageInfo) (capacity float64) + func GetVersion(configFile string) (string, error) + func HasPrefix(s string, prefix string) bool + func HasSuffix(s string, suffix string) bool + func IsBOSH() bool + func IsBackendOnline(ctx context.Context, host string) bool + func IsDCOS() bool + func IsDocker() bool + func IsErr(err error, errs ...error) bool + func IsErrIgnored(err error, ignoredErrs ...error) bool + func IsKubernetes() bool + func IsPCFTile() bool + func IsSourceBuild() bool + func IsValidBucketName(bucket string) bool + func IsValidObjectName(object string) bool + func IsValidObjectPrefix(object string) bool + func LivenessCheckHandler(w http.ResponseWriter, r *http.Request) + func Load(configFile string, data interface{}) (quick.Config, error) + func Lstat(name string) (os.FileInfo, error) + func Main(args []string) + func MkdirAll(dirPath string, mode os.FileMode) error + func MockOpenIDTestUserInteraction(ctx context.Context, pro OpenIDClientAppParams, username, password string) (string, error) + func NSUpdated(bucket, prefix string) + func NewGatewayHTTPTransport() *http.Transport + func NewGatewayHTTPTransportWithClientCerts(clientCert, clientKey string) *http.Transport + func NewRemoteTargetHTTPTransport() *http.Transport + func Open(name string) (*os.File, error) + func OpenFile(name string, flag int, perm os.FileMode) (*os.File, error) + func OpenFileDirectIO(name string, flag int, perm os.FileMode) (*os.File, error) + func ParseGatewayEndpoint(arg string) (endPoint string, secure bool, err error) + func ParseSSECopyCustomerRequest(h http.Header, metadata map[string]string) (key []byte, err error) + func ParseSSECustomerHeader(header http.Header) (key []byte, err error) + func ParseSSECustomerRequest(r *http.Request) (key []byte, err error) + func PolicyToBucketAccessPolicy(bucketPolicy *policy.Policy) (*miniogopolicy.BucketAccessPolicy, error) + func ReadinessCheckHandler(w http.ResponseWriter, r *http.Request) + func RegisterGatewayCommand(cmd cli.Command) error + func Remove(deletePath string) error + func RemoveAll(dirPath string) error + func Rename(src, dst string) error + func ReportMetrics(ctx context.Context, metricsGroups []*MetricsGroup) <-chan Metric + func Save(configFile string, data interface{}) error + func StartGateway(ctx *cli.Context, gw Gateway) + func Stat(name string) (os.FileInfo, error) + func ToMinioClientCompletePart(part CompletePart) minio.CompletePart + func ToMinioClientCompleteParts(parts []CompletePart) []minio.CompletePart + func ToMinioClientMetadata(metadata map[string]string) map[string]string + func ToMinioClientObjectInfoMetadata(metadata map[string]string) map[string][]string + func ToS3ETag(etag string) string + func Trace(f http.HandlerFunc, logBody bool, w http.ResponseWriter, r *http.Request) madmin.TraceInfo + func UTCNow() time.Time + func ValidateGatewayArguments(serverAddr, endpointAddr string) error + type APIError struct + Code string + Description string + HTTPStatusCode int + type APIErrorCode int + const ErrARNNotification + const ErrAccessDenied + const ErrAccessKeyDisabled + const ErrAccountNotEligible + const ErrAddUserInvalidArgument + const ErrAdminAccountNotEligible + const ErrAdminBucketQuotaExceeded + const ErrAdminConfigBadJSON + const ErrAdminConfigDuplicateKeys + const ErrAdminConfigNoQuorum + const ErrAdminConfigNotificationTargetsFailed + const ErrAdminConfigTooLarge + const ErrAdminCredentialsMismatch + const ErrAdminGroupNotEmpty + const ErrAdminInvalidAccessKey + const ErrAdminInvalidArgument + const ErrAdminInvalidSecretKey + const ErrAdminNoSuchGroup + const ErrAdminNoSuchPolicy + const ErrAdminNoSuchQuotaConfiguration + const ErrAdminNoSuchUser + const ErrAdminProfilerNotEnabled + const ErrAdminServiceAccountNotFound + const ErrAllAccessDisabled + const ErrAuthHeaderEmpty + const ErrAuthorizationHeaderMalformed + const ErrBackendDown + const ErrBadDigest + const ErrBadRequest + const ErrBucketAlreadyExists + const ErrBucketAlreadyOwnedByYou + const ErrBucketNotEmpty + const ErrBucketRemoteAlreadyExists + const ErrBucketRemoteArnInvalid + const ErrBucketRemoteArnTypeInvalid + const ErrBucketRemoteIdenticalToSource + const ErrBucketRemoteLabelInUse + const ErrBucketRemoteRemoveDisallowed + const ErrBucketTaggingNotFound + const ErrBusy + const ErrCastFailed + const ErrClientDisconnected + const ErrContentSHA256Mismatch + const ErrCredMalformed + const ErrEmptyRequestBody + const ErrEntityTooLarge + const ErrEntityTooSmall + const ErrEvaluatorBindingDoesNotExist + const ErrEvaluatorInvalidArguments + const ErrEvaluatorInvalidTimestampFormatPattern + const ErrEvaluatorInvalidTimestampFormatPatternSymbol + const ErrEvaluatorInvalidTimestampFormatPatternSymbolForParsing + const ErrEvaluatorInvalidTimestampFormatPatternToken + const ErrEvaluatorTimestampFormatPatternDuplicateFields + const ErrEvaluatorTimestampFormatPatternHourClockAmPmMismatch + const ErrEvaluatorUnterminatedTimestampFormatPatternToken + const ErrEventNotification + const ErrExpiredPresignRequest + const ErrExpressionTooLong + const ErrFilterNameInvalid + const ErrFilterNamePrefix + const ErrFilterNameSuffix + const ErrFilterValueInvalid + const ErrHealAlreadyRunning + const ErrHealInvalidClientToken + const ErrHealMissingBucket + const ErrHealNoSuchProcess + const ErrHealNotImplemented + const ErrHealOverlappingPaths + const ErrIllegalSQLFunctionArgument + const ErrIncompatibleEncryptionMethod + const ErrIncompleteBody + const ErrIncorrectContinuationToken + const ErrIncorrectSQLFunctionArgumentType + const ErrInsecureClientRequest + const ErrInsecureSSECustomerRequest + const ErrIntegerOverflow + const ErrInternalError + const ErrInvalidAccessKeyID + const ErrInvalidBucketName + const ErrInvalidBucketObjectLockConfiguration + const ErrInvalidCast + const ErrInvalidColumnIndex + const ErrInvalidCompressionFormat + const ErrInvalidCopyDest + const ErrInvalidCopyPartRange + const ErrInvalidCopyPartRangeSource + const ErrInvalidCopySource + const ErrInvalidDataSource + const ErrInvalidDataType + const ErrInvalidDecompressedSize + const ErrInvalidDigest + const ErrInvalidDuration + const ErrInvalidEncodingMethod + const ErrInvalidEncryptionMethod + const ErrInvalidEncryptionParameters + const ErrInvalidExpressionType + const ErrInvalidFileHeaderInfo + const ErrInvalidJSONType + const ErrInvalidKeyPath + const ErrInvalidLifecycleWithObjectLock + const ErrInvalidMaxKeys + const ErrInvalidMaxParts + const ErrInvalidMaxUploads + const ErrInvalidMetadataDirective + const ErrInvalidObjectName + const ErrInvalidObjectNamePrefixSlash + const ErrInvalidObjectState + const ErrInvalidPart + const ErrInvalidPartNumber + const ErrInvalidPartNumberMarker + const ErrInvalidPartOrder + const ErrInvalidPolicyDocument + const ErrInvalidPrefixMarker + const ErrInvalidQueryParams + const ErrInvalidQuerySignatureAlgo + const ErrInvalidQuoteFields + const ErrInvalidRange + const ErrInvalidRangePartNumber + const ErrInvalidRegion + const ErrInvalidRequest + const ErrInvalidRequestBody + const ErrInvalidRequestParameter + const ErrInvalidRequestVersion + const ErrInvalidResourceName + const ErrInvalidRetentionDate + const ErrInvalidSSECustomerAlgorithm + const ErrInvalidSSECustomerKey + const ErrInvalidSSECustomerParameters + const ErrInvalidServiceS3 + const ErrInvalidServiceSTS + const ErrInvalidStorageClass + const ErrInvalidTableAlias + const ErrInvalidTagDirective + const ErrInvalidTextEncoding + const ErrInvalidToken + const ErrInvalidVersionID + const ErrKMSKeyNotFoundException + const ErrKMSNotConfigured + const ErrKeyTooLongError + const ErrLexerInvalidChar + const ErrLexerInvalidIONLiteral + const ErrLexerInvalidLiteral + const ErrLexerInvalidOperator + const ErrLikeInvalidInputs + const ErrMalformedCredentialDate + const ErrMalformedCredentialRegion + const ErrMalformedDate + const ErrMalformedExpires + const ErrMalformedJSON + const ErrMalformedPOSTRequest + const ErrMalformedPolicy + const ErrMalformedPresignedDate + const ErrMalformedXML + const ErrMaximumExpires + const ErrMetadataTooLarge + const ErrMethodNotAllowed + const ErrMissingContentLength + const ErrMissingContentMD5 + const ErrMissingCredTag + const ErrMissingDateHeader + const ErrMissingFields + const ErrMissingHeaders + const ErrMissingRequestBodyError + const ErrMissingRequiredParameter + const ErrMissingSSECustomerKey + const ErrMissingSSECustomerKeyMD5 + const ErrMissingSecurityHeader + const ErrMissingSignHeadersTag + const ErrMissingSignTag + const ErrNegativeExpires + const ErrNoAccessKey + const ErrNoSuchBucket + const ErrNoSuchBucketLifecycle + const ErrNoSuchBucketPolicy + const ErrNoSuchBucketSSEConfig + const ErrNoSuchCORSConfiguration + const ErrNoSuchKey + const ErrNoSuchLifecycleConfiguration + const ErrNoSuchObjectLockConfiguration + const ErrNoSuchUpload + const ErrNoSuchVersion + const ErrNoSuchWebsiteConfiguration + const ErrNone + const ErrNotImplemented + const ErrObjectExistsAsDirectory + const ErrObjectLockConfigurationNotAllowed + const ErrObjectLockConfigurationNotFound + const ErrObjectLockInvalidHeaders + const ErrObjectLocked + const ErrObjectRestoreAlreadyInProgress + const ErrObjectSerializationConflict + const ErrObjectTampered + const ErrOperationMaxedOut + const ErrOperationTimedOut + const ErrOverlappingConfigs + const ErrOverlappingFilterNotification + const ErrPOSTFileRequired + const ErrParseAsteriskIsNotAloneInSelectList + const ErrParseCannotMixSqbAndWildcardInSelectList + const ErrParseCastArity + const ErrParseEmptySelect + const ErrParseExpected2TokenTypes + const ErrParseExpectedArgumentDelimiter + const ErrParseExpectedDatePart + const ErrParseExpectedExpression + const ErrParseExpectedIdentForAlias + const ErrParseExpectedIdentForAt + const ErrParseExpectedIdentForGroupName + const ErrParseExpectedKeyword + const ErrParseExpectedLeftParenAfterCast + const ErrParseExpectedLeftParenBuiltinFunctionCall + const ErrParseExpectedLeftParenValueConstructor + const ErrParseExpectedMember + const ErrParseExpectedNumber + const ErrParseExpectedRightParenBuiltinFunctionCall + const ErrParseExpectedTokenType + const ErrParseExpectedTypeName + const ErrParseExpectedWhenClause + const ErrParseInvalidContextForWildcardInSelectList + const ErrParseInvalidTypeParam + const ErrParseMalformedJoin + const ErrParseMissingIdentAfterAt + const ErrParseNonUnaryAgregateFunctionCall + const ErrParseSelectMissingFrom + const ErrParseUnexpectedKeyword + const ErrParseUnexpectedOperator + const ErrParseUnexpectedTerm + const ErrParseUnexpectedToken + const ErrParseUnknownOperator + const ErrParseUnsupportedAlias + const ErrParseUnsupportedCallWithStar + const ErrParseUnsupportedCase + const ErrParseUnsupportedCaseClause + const ErrParseUnsupportedLiteralsGroupBy + const ErrParseUnsupportedSelect + const ErrParseUnsupportedSyntax + const ErrParseUnsupportedToken + const ErrPastObjectLockRetainDate + const ErrPolicyTooLarge + const ErrPostPolicyConditionInvalidFormat + const ErrPreconditionFailed + const ErrReadQuorum + const ErrRegionNotification + const ErrRemoteDestinationNotFoundError + const ErrRemoteTargetNotFoundError + const ErrRemoteTargetNotVersionedError + const ErrReplicationBandwidthLimitError + const ErrReplicationBucketNeedsVersioningError + const ErrReplicationConfigurationNotFoundError + const ErrReplicationDenyEditError + const ErrReplicationDestinationMissingLock + const ErrReplicationNeedsVersioningError + const ErrReplicationNoMatchingRuleError + const ErrReplicationRemoteConnectionError + const ErrReplicationSourceNotVersionedError + const ErrRequestBodyParse + const ErrRequestNotReadyYet + const ErrRequestTimeTooSkewed + const ErrSSECustomerKeyMD5Mismatch + const ErrSSEEncryptedObject + const ErrSSEMultipartEncrypted + const ErrServerNotInitialized + const ErrSignatureDoesNotMatch + const ErrSignatureVersionNotSupported + const ErrSiteReplicationBackendIssue + const ErrSiteReplicationBucketConfigError + const ErrSiteReplicationBucketMetaError + const ErrSiteReplicationIAMError + const ErrSiteReplicationInvalidRequest + const ErrSiteReplicationPeerResp + const ErrSiteReplicationServiceAccountError + const ErrSlowDown + const ErrStorageFull + const ErrTransitionStorageClassNotFoundError + const ErrUnauthorizedAccess + const ErrUnknownWORMModeDirective + const ErrUnsignedHeaders + const ErrUnsupportedFunction + const ErrUnsupportedMetadata + const ErrUnsupportedNotification + const ErrUnsupportedRangeHeader + const ErrUnsupportedSQLOperation + const ErrUnsupportedSQLStructure + const ErrUnsupportedSyntax + const ErrValueParseFailure + const ErrWriteQuorum + func (i APIErrorCode) String() string + type APIErrorResponse struct + BucketName string + Code string + HostID string + Key string + Message string + Region string + RequestID string + Resource string + XMLName xml.Name + type AccElem struct + N int64 + Total int64 + func (z *AccElem) DecodeMsg(dc *msgp.Reader) (err error) + func (z *AccElem) UnmarshalMsg(bts []byte) (o []byte, err error) + func (z AccElem) EncodeMsg(en *msgp.Writer) (err error) + func (z AccElem) MarshalMsg(b []byte) (o []byte, err error) + func (z AccElem) Msgsize() (s int) + type AdminError struct + Code string + Message string + StatusCode int + func (ae AdminError) Error() string + type AllAccessDisabled GenericError + func (e AllAccessDisabled) Error() string + type AssumeRoleResponse struct + ResponseMetadata struct{ ... } + Result AssumeRoleResult + XMLName xml.Name + type AssumeRoleResult struct + AssumedRoleUser AssumedRoleUser + Credentials auth.Credentials + PackedPolicySize int + type AssumeRoleWithCertificateResponse struct + Metadata struct{ ... } + Result struct{ ... } + XMLName xml.Name + type AssumeRoleWithClientGrantsResponse struct + ResponseMetadata struct{ ... } + Result ClientGrantsResult + XMLName xml.Name + type AssumeRoleWithLDAPResponse struct + ResponseMetadata struct{ ... } + Result LDAPIdentityResult + XMLName xml.Name + type AssumeRoleWithWebIdentityResponse struct + ResponseMetadata struct{ ... } + Result WebIdentityResult + XMLName xml.Name + type AssumedRoleUser struct + Arn string + AssumedRoleID string + type AuditLogOptions struct + APIName string + Status string + Trigger string + VersionID string + type BackendDown struct + Err string + func (e BackendDown) Error() string + type BackendMetrics struct + func NewMetrics() *BackendMetrics + func (s *BackendMetrics) GetBytesReceived() uint64 + func (s *BackendMetrics) GetBytesSent() uint64 + func (s *BackendMetrics) GetRequests() RequestStats + func (s *BackendMetrics) IncBytesReceived(n uint64) + func (s *BackendMetrics) IncBytesSent(n uint64) + func (s *BackendMetrics) IncRequests(method string) + type BackendType int + type BitrotAlgorithm uint + const BLAKE2b512 + const HighwayHash256 + const HighwayHash256S + const SHA256 + func BitrotAlgorithmFromString(s string) (a BitrotAlgorithm) + func (a BitrotAlgorithm) Available() bool + func (a BitrotAlgorithm) New() hash.Hash + func (a BitrotAlgorithm) String() string + func (z *BitrotAlgorithm) DecodeMsg(dc *msgp.Reader) (err error) + func (z *BitrotAlgorithm) UnmarshalMsg(bts []byte) (o []byte, err error) + func (z BitrotAlgorithm) EncodeMsg(en *msgp.Writer) (err error) + func (z BitrotAlgorithm) MarshalMsg(b []byte) (o []byte, err error) + func (z BitrotAlgorithm) Msgsize() (s int) + type BitrotVerifier struct + func NewBitrotVerifier(algorithm BitrotAlgorithm, checksum []byte) *BitrotVerifier + type Bucket struct + CreationDate string + Name string + type BucketAccessPolicy struct + Bucket string + Policy miniogopolicy.BucketPolicy + Prefix string + type BucketAlreadyExists GenericError + func (e BucketAlreadyExists) Error() string + type BucketAlreadyOwnedByYou GenericError + func (e BucketAlreadyOwnedByYou) Error() string + type BucketExists GenericError + func (e BucketExists) Error() string + type BucketInfo struct + Created time.Time + Name string + type BucketLifecycleNotFound GenericError + func (e BucketLifecycleNotFound) Error() string + type BucketMetadata struct + BucketTargetsConfigJSON []byte + BucketTargetsConfigMetaJSON []byte + Created time.Time + EncryptionConfigXML []byte + LifecycleConfigXML []byte + LockEnabled bool + Name string + NotificationConfigXML []byte + ObjectLockConfigXML []byte + PolicyConfigJSON []byte + QuotaConfigJSON []byte + ReplicationConfigXML []byte + TaggingConfigXML []byte + VersioningConfigXML []byte + func (b *BucketMetadata) Load(ctx context.Context, api ObjectLayer, name string) error + func (b *BucketMetadata) Save(ctx context.Context, api ObjectLayer) error + func (z *BucketMetadata) DecodeMsg(dc *msgp.Reader) (err error) + func (z *BucketMetadata) EncodeMsg(en *msgp.Writer) (err error) + func (z *BucketMetadata) MarshalMsg(b []byte) (o []byte, err error) + func (z *BucketMetadata) Msgsize() (s int) + func (z *BucketMetadata) UnmarshalMsg(bts []byte) (o []byte, err error) + type BucketMetadataSys struct + func NewBucketMetadataSys() *BucketMetadataSys + func (sys *BucketMetadataSys) Get(bucket string) (BucketMetadata, error) + func (sys *BucketMetadataSys) GetBucketTarget(bucket string, arn string) (madmin.BucketTarget, error) + func (sys *BucketMetadataSys) GetBucketTargetsConfig(bucket string) (*madmin.BucketTargets, error) + func (sys *BucketMetadataSys) GetConfig(ctx context.Context, bucket string) (BucketMetadata, error) + func (sys *BucketMetadataSys) GetLifecycleConfig(bucket string) (*lifecycle.Lifecycle, error) + func (sys *BucketMetadataSys) GetNotificationConfig(bucket string) (*event.Config, error) + func (sys *BucketMetadataSys) GetObjectLockConfig(bucket string) (*objectlock.Config, error) + func (sys *BucketMetadataSys) GetPolicyConfig(bucket string) (*policy.Policy, error) + func (sys *BucketMetadataSys) GetQuotaConfig(ctx context.Context, bucket string) (*madmin.BucketQuota, error) + func (sys *BucketMetadataSys) GetReplicationConfig(ctx context.Context, bucket string) (*replication.Config, error) + func (sys *BucketMetadataSys) GetSSEConfig(bucket string) (*bucketsse.BucketSSEConfig, error) + func (sys *BucketMetadataSys) GetTaggingConfig(bucket string) (*tags.Tags, error) + func (sys *BucketMetadataSys) GetVersioningConfig(bucket string) (*versioning.Versioning, error) + func (sys *BucketMetadataSys) Init(ctx context.Context, buckets []BucketInfo, objAPI ObjectLayer) error + func (sys *BucketMetadataSys) Remove(bucket string) + func (sys *BucketMetadataSys) Reset() + func (sys *BucketMetadataSys) Set(bucket string, meta BucketMetadata) + func (sys *BucketMetadataSys) Update(ctx context.Context, bucket string, configFile string, configData []byte) error + type BucketNameInvalid GenericError + func (e BucketNameInvalid) Error() string + type BucketNotEmpty GenericError + func (e BucketNotEmpty) Error() string + type BucketNotFound GenericError + func (e BucketNotFound) Error() string + type BucketObjectLockConfigNotFound GenericError + func (e BucketObjectLockConfigNotFound) Error() string + type BucketObjectLockSys struct + func NewBucketObjectLockSys() *BucketObjectLockSys + func (sys *BucketObjectLockSys) Get(bucketName string) (r objectlock.Retention, err error) + type BucketOptions struct + Location string + LockEnabled bool + VersioningEnabled bool + type BucketPolicyNotFound GenericError + func (e BucketPolicyNotFound) Error() string + type BucketQuotaConfigNotFound GenericError + func (e BucketQuotaConfigNotFound) Error() string + type BucketQuotaExceeded GenericError + func (e BucketQuotaExceeded) Error() string + type BucketQuotaSys struct + func NewBucketQuotaSys() *BucketQuotaSys + func (sys *BucketQuotaSys) Get(ctx context.Context, bucketName string) (*madmin.BucketQuota, error) + func (sys *BucketQuotaSys) GetBucketUsageInfo(bucket string) (BucketUsageInfo, error) + func (sys *BucketQuotaSys) Init(objAPI ObjectLayer) + type BucketRemoteAlreadyExists GenericError + func (e BucketRemoteAlreadyExists) Error() string + type BucketRemoteArnInvalid GenericError + func (e BucketRemoteArnInvalid) Error() string + type BucketRemoteArnTypeInvalid GenericError + func (e BucketRemoteArnTypeInvalid) Error() string + type BucketRemoteConnectionErr GenericError + func (e BucketRemoteConnectionErr) Error() string + type BucketRemoteDestinationNotFound GenericError + func (e BucketRemoteDestinationNotFound) Error() string + type BucketRemoteLabelInUse GenericError + func (e BucketRemoteLabelInUse) Error() string + type BucketRemoteRemoveDisallowed GenericError + func (e BucketRemoteRemoveDisallowed) Error() string + type BucketRemoteTargetNotFound GenericError + func (e BucketRemoteTargetNotFound) Error() string + type BucketRemoteTargetNotVersioned GenericError + func (e BucketRemoteTargetNotVersioned) Error() string + type BucketReplicationConfigNotFound GenericError + func (e BucketReplicationConfigNotFound) Error() string + type BucketReplicationResyncStatus struct + ID int + LastUpdate time.Time + TargetsMap map[string]TargetReplicationResyncStatus + Version int + func (z *BucketReplicationResyncStatus) DecodeMsg(dc *msgp.Reader) (err error) + func (z *BucketReplicationResyncStatus) EncodeMsg(en *msgp.Writer) (err error) + func (z *BucketReplicationResyncStatus) MarshalMsg(b []byte) (o []byte, err error) + func (z *BucketReplicationResyncStatus) Msgsize() (s int) + func (z *BucketReplicationResyncStatus) UnmarshalMsg(bts []byte) (o []byte, err error) + type BucketReplicationSourceNotVersioned GenericError + func (e BucketReplicationSourceNotVersioned) Error() string + type BucketReplicationStat struct + FailedCount int64 + FailedSize int64 + Latency ReplicationLatency + PendingCount int64 + PendingSize int64 + ReplicaSize int64 + ReplicatedSize int64 + func (z *BucketReplicationStat) DecodeMsg(dc *msgp.Reader) (err error) + func (z *BucketReplicationStat) EncodeMsg(en *msgp.Writer) (err error) + func (z *BucketReplicationStat) MarshalMsg(b []byte) (o []byte, err error) + func (z *BucketReplicationStat) Msgsize() (s int) + func (z *BucketReplicationStat) UnmarshalMsg(bts []byte) (o []byte, err error) + type BucketReplicationStats struct + FailedCount int64 + FailedSize int64 + PendingCount int64 + PendingSize int64 + ReplicaSize int64 + ReplicatedSize int64 + Stats map[string]*BucketReplicationStat + func (brs *BucketReplicationStats) Empty() bool + func (brs BucketReplicationStats) Clone() (c BucketReplicationStats) + func (z *BucketReplicationStats) DecodeMsg(dc *msgp.Reader) (err error) + func (z *BucketReplicationStats) EncodeMsg(en *msgp.Writer) (err error) + func (z *BucketReplicationStats) MarshalMsg(b []byte) (o []byte, err error) + func (z *BucketReplicationStats) Msgsize() (s int) + func (z *BucketReplicationStats) UnmarshalMsg(bts []byte) (o []byte, err error) + type BucketSSEConfigNotFound GenericError + func (e BucketSSEConfigNotFound) Error() string + type BucketSSEConfigSys struct + func NewBucketSSEConfigSys() *BucketSSEConfigSys + func (sys *BucketSSEConfigSys) Get(bucket string) (*sse.BucketSSEConfig, error) + type BucketStats struct + ReplicationStats BucketReplicationStats + func (z *BucketStats) DecodeMsg(dc *msgp.Reader) (err error) + func (z *BucketStats) EncodeMsg(en *msgp.Writer) (err error) + func (z *BucketStats) MarshalMsg(b []byte) (o []byte, err error) + func (z *BucketStats) Msgsize() (s int) + func (z *BucketStats) UnmarshalMsg(bts []byte) (o []byte, err error) + type BucketTaggingNotFound GenericError + func (e BucketTaggingNotFound) Error() string + type BucketTargetSys struct + func NewBucketTargetSys() *BucketTargetSys + func (sys *BucketTargetSys) Delete(bucket string) + func (sys *BucketTargetSys) GetRemoteBucketTargetByArn(ctx context.Context, bucket, arn string) madmin.BucketTarget + func (sys *BucketTargetSys) GetRemoteTargetClient(ctx context.Context, arn string) *TargetClient + func (sys *BucketTargetSys) ListBucketTargets(ctx context.Context, bucket string) (*madmin.BucketTargets, error) + func (sys *BucketTargetSys) ListTargets(ctx context.Context, bucket, arnType string) (targets []madmin.BucketTarget) + func (sys *BucketTargetSys) RemoveTarget(ctx context.Context, bucket, arnStr string) error + func (sys *BucketTargetSys) SetTarget(ctx context.Context, bucket string, tgt *madmin.BucketTarget, update bool) error + func (sys *BucketTargetSys) UpdateAllTargets(bucket string, tgts *madmin.BucketTargets) + type BucketTargetUsageInfo struct + ReplicaSize uint64 + ReplicatedSize uint64 + ReplicationFailedCount uint64 + ReplicationFailedSize uint64 + ReplicationPendingCount uint64 + ReplicationPendingSize uint64 + type BucketUsageInfo struct + ObjectSizesHistogram map[string]uint64 + ObjectsCount uint64 + ReplicaSize uint64 + ReplicatedSizeV1 uint64 + ReplicationFailedCountV1 uint64 + ReplicationFailedSizeV1 uint64 + ReplicationInfo map[string]BucketTargetUsageInfo + ReplicationPendingCountV1 uint64 + ReplicationPendingSizeV1 uint64 + Size uint64 + type BucketVersioningSys struct + func NewBucketVersioningSys() *BucketVersioningSys + func (sys *BucketVersioningSys) Enabled(bucket string) bool + func (sys *BucketVersioningSys) Get(bucket string) (*versioning.Versioning, error) + func (sys *BucketVersioningSys) Reset() + func (sys *BucketVersioningSys) Suspended(bucket string) bool + type CacheChecksumInfoV1 struct + Algorithm string + Blocksize int64 + type CacheDiskStats struct + Dir string + TotalCapacity uint64 + UsagePercent uint64 + UsageSize uint64 + UsageState int32 + func (c *CacheDiskStats) GetUsageLevelString() (u string) + type CacheObjectLayer interface + AbortMultipartUpload func(ctx context.Context, bucket, object, uploadID string, opts ObjectOptions) error + CacheStats func() *CacheStats + CompleteMultipartUpload func(ctx context.Context, bucket, object, uploadID string, ...) (objInfo ObjectInfo, err error) + CopyObject func(ctx context.Context, srcBucket, srcObject, destBucket, destObject string, ...) (objInfo ObjectInfo, err error) + CopyObjectPart func(ctx context.Context, ...) (pi PartInfo, e error) + DeleteObject func(ctx context.Context, bucket, object string, opts ObjectOptions) (ObjectInfo, error) + DeleteObjects func(ctx context.Context, bucket string, objects []ObjectToDelete, ...) ([]DeletedObject, []error) + GetObjectInfo func(ctx context.Context, bucket, object string, opts ObjectOptions) (objInfo ObjectInfo, err error) + GetObjectNInfo func(ctx context.Context, bucket, object string, rs *HTTPRangeSpec, h http.Header, ...) (gr *GetObjectReader, err error) + NewMultipartUpload func(ctx context.Context, bucket, object string, opts ObjectOptions) (uploadID string, err error) + PutObject func(ctx context.Context, bucket, object string, data *PutObjReader, ...) (objInfo ObjectInfo, err error) + PutObjectPart func(ctx context.Context, bucket, object, uploadID string, partID int, ...) (info PartInfo, err error) + StorageInfo func(ctx context.Context) CacheStorageInfo + type CacheStats struct + BytesServed uint64 + GetDiskStats func() []CacheDiskStats + Hits uint64 + Misses uint64 + type CacheStatusType string + const CacheHit + const CacheMiss + func (c CacheStatusType) String() string + type CacheStorageInfo struct + Free uint64 + Total uint64 + type CheckPreconditionFn func(o ObjectInfo) bool + type ChecksumAlgo uint8 + const HighwayHash + func (z *ChecksumAlgo) DecodeMsg(dc *msgp.Reader) (err error) + func (z *ChecksumAlgo) UnmarshalMsg(bts []byte) (o []byte, err error) + func (z ChecksumAlgo) EncodeMsg(en *msgp.Writer) (err error) + func (z ChecksumAlgo) MarshalMsg(b []byte) (o []byte, err error) + func (z ChecksumAlgo) Msgsize() (s int) + type ChecksumInfo struct + Algorithm BitrotAlgorithm + Hash []byte + PartNumber int + func (c *ChecksumInfo) UnmarshalJSON(data []byte) error + func (c ChecksumInfo) MarshalJSON() ([]byte, error) + func (z *ChecksumInfo) DecodeMsg(dc *msgp.Reader) (err error) + func (z *ChecksumInfo) EncodeMsg(en *msgp.Writer) (err error) + func (z *ChecksumInfo) MarshalMsg(b []byte) (o []byte, err error) + func (z *ChecksumInfo) Msgsize() (s int) + func (z *ChecksumInfo) UnmarshalMsg(bts []byte) (o []byte, err error) + type ClientGrantsResult struct + AssumedRoleUser AssumedRoleUser + Audience string + Credentials auth.Credentials + PackedPolicySize int + Provider string + SubjectFromToken string + type CommonPrefix struct + Prefix string + type CompleteMultipartUpload struct + Parts []CompletePart + type CompleteMultipartUploadResponse struct + Bucket string + ETag string + Key string + Location string + XMLName xml.Name + type CompletePart struct + ETag string + PartNumber int + type CompletedParts []CompletePart + func (a CompletedParts) Len() int + func (a CompletedParts) Less(i, j int) bool + func (a CompletedParts) Swap(i, j int) + type ConfigDir struct + func (dir *ConfigDir) Get() string + type ConfigSys struct + func NewConfigSys() *ConfigSys + func (sys *ConfigSys) Init(objAPI ObjectLayer) error + type ConnStats struct + type ConsoleLogger struct + Enable bool + type CopyObjectPartResponse struct + ETag string + LastModified string + XMLName xml.Name + type CopyObjectResponse struct + ETag string + LastModified string + XMLName xml.Name + type DataUsageInfo struct + BucketSizes map[string]uint64 + BucketsCount uint64 + BucketsUsage map[string]BucketUsageInfo + LastUpdate time.Time + ObjectsTotalCount uint64 + ObjectsTotalSize uint64 + ReplicationInfo map[string]BucketTargetUsageInfo + TierStats *allTierStats + type DecryptBlocksReader struct + func (d *DecryptBlocksReader) Read(p []byte) (int, error) + type DeleteBucketOptions struct + Force bool + NoRecreate bool + type DeleteError struct + Code string + Key string + Message string + VersionID string + type DeleteMarkerMTime struct + func (t DeleteMarkerMTime) MarshalXML(e *xml.Encoder, startElement xml.StartElement) error + type DeleteObjectsRequest struct + Objects []ObjectToDelete + Quiet bool + type DeleteObjectsResponse struct + DeletedObjects []DeletedObject + Errors []DeleteError + XMLName xml.Name + type DeleteVersionsErrsResp struct + Errs []error + type DeletedObject struct + DeleteMarker bool + DeleteMarkerMTime DeleteMarkerMTime + DeleteMarkerVersionID string + ObjectName string + ReplicationState ReplicationState + VersionID string + func (d *DeletedObject) DeleteMarkerReplicationStatus() replication.StatusType + func (d *DeletedObject) VersionPurgeStatus() VersionPurgeStatusType + type DeletedObjectInfo struct + Bucket string + IsLatest bool + ModTime time.Time + Name string + VersionID string + type DeletedObjectReplicationInfo struct + Bucket string + OpType replication.Type + ResetID string + TargetArn string + type DiskInfo struct + Endpoint string + Error string + FSType string + Free uint64 + FreeInodes uint64 + Healing bool + ID string + Metrics DiskMetrics + MountPath string + RootDisk bool + Total uint64 + Used uint64 + UsedInodes uint64 + func (z *DiskInfo) DecodeMsg(dc *msgp.Reader) (err error) + func (z *DiskInfo) EncodeMsg(en *msgp.Writer) (err error) + func (z *DiskInfo) MarshalMsg(b []byte) (o []byte, err error) + func (z *DiskInfo) Msgsize() (s int) + func (z *DiskInfo) UnmarshalMsg(bts []byte) (o []byte, err error) + type DiskMetrics struct + APICalls map[string]uint64 + APILatencies map[string]uint64 + func (z *DiskMetrics) DecodeMsg(dc *msgp.Reader) (err error) + func (z *DiskMetrics) EncodeMsg(en *msgp.Writer) (err error) + func (z *DiskMetrics) MarshalMsg(b []byte) (o []byte, err error) + func (z *DiskMetrics) Msgsize() (s int) + func (z *DiskMetrics) UnmarshalMsg(bts []byte) (o []byte, err error) + type Encryption struct + EncryptionType sse.Algorithm + KMSContext string + KMSKeyID string + type Endpoint struct + IsLocal bool + func NewEndpoint(arg string) (ep Endpoint, e error) + func (endpoint *Endpoint) UpdateIsLocal() (err error) + func (endpoint Endpoint) HTTPS() bool + func (endpoint Endpoint) String() string + func (endpoint Endpoint) Type() EndpointType + type EndpointServerPools []PoolEndpoints + func (l *EndpointServerPools) Add(zeps PoolEndpoints) error + func (l EndpointServerPools) FirstLocal() bool + func (l EndpointServerPools) GetLocalPoolIdx(ep Endpoint) int + func (l EndpointServerPools) GetPoolIdx(pool string) int + func (l EndpointServerPools) HTTPS() bool + func (l EndpointServerPools) Hostnames() []string + func (l EndpointServerPools) Legacy() bool + func (l EndpointServerPools) LocalDisksPaths() []string + func (l EndpointServerPools) Localhost() string + func (l EndpointServerPools) NEndpoints() (count int) + type EndpointType int + const PathEndpointType + const URLEndpointType + type Endpoints []Endpoint + func NewEndpoints(args ...string) (endpoints Endpoints, err error) + func (endpoints Endpoints) GetAllStrings() (all []string) + func (endpoints Endpoints) GetString(i int) string + func (endpoints Endpoints) HTTPS() bool + func (endpoints Endpoints) UpdateIsLocal(foundPrevLocal bool) error + type Erasure struct + func NewErasure(ctx context.Context, dataBlocks, parityBlocks int, blockSize int64) (e Erasure, err error) + func (e *Erasure) DecodeDataAndParityBlocks(ctx context.Context, data [][]byte) error + func (e *Erasure) DecodeDataBlocks(data [][]byte) error + func (e *Erasure) Encode(ctx context.Context, src io.Reader, writers []io.Writer, buf []byte, ...) (total int64, err error) + func (e *Erasure) EncodeData(ctx context.Context, data []byte) ([][]byte, error) + func (e *Erasure) ShardFileOffset(startOffset, length, totalLength int64) int64 + func (e *Erasure) ShardFileSize(totalLength int64) int64 + func (e *Erasure) ShardSize() int64 + func (e Erasure) Decode(ctx context.Context, writer io.Writer, readers []io.ReaderAt, ...) (written int64, derr error) + func (e Erasure) Heal(ctx context.Context, writers []io.Writer, readers []io.ReaderAt, ...) (derr error) + type ErasureAlgo uint8 + const ReedSolomon + func (i ErasureAlgo) String() string + func (z *ErasureAlgo) DecodeMsg(dc *msgp.Reader) (err error) + func (z *ErasureAlgo) UnmarshalMsg(bts []byte) (o []byte, err error) + func (z ErasureAlgo) EncodeMsg(en *msgp.Writer) (err error) + func (z ErasureAlgo) MarshalMsg(b []byte) (o []byte, err error) + func (z ErasureAlgo) Msgsize() (s int) + type ErasureInfo struct + Algorithm string + BlockSize int64 + Checksums []ChecksumInfo + DataBlocks int + Distribution []int + Index int + ParityBlocks int + func (e *ErasureInfo) AddChecksumInfo(ckSumInfo ChecksumInfo) + func (e ErasureInfo) GetChecksumInfo(partNumber int) (ckSum ChecksumInfo) + func (e ErasureInfo) ShardFileSize(totalLength int64) int64 + func (e ErasureInfo) ShardSize() int64 + func (z *ErasureInfo) DecodeMsg(dc *msgp.Reader) (err error) + func (z *ErasureInfo) EncodeMsg(en *msgp.Writer) (err error) + func (z *ErasureInfo) MarshalMsg(b []byte) (o []byte, err error) + func (z *ErasureInfo) Msgsize() (s int) + func (z *ErasureInfo) UnmarshalMsg(bts []byte) (o []byte, err error) + type EvalMetadataFn func(o ObjectInfo) error + type ExpirationOptions struct + Expire bool + type FSChecksumInfoV1 struct + Algorithm string + Blocksize int64 + Hashes [][]byte + func (c *FSChecksumInfoV1) UnmarshalJSON(data []byte) error + func (c FSChecksumInfoV1) MarshalJSON() ([]byte, error) + type FSObjects struct + func (fs *FSObjects) AbortMultipartUpload(ctx context.Context, bucket, object, uploadID string, opts ObjectOptions) error + func (fs *FSObjects) BackendInfo() madmin.BackendInfo + func (fs *FSObjects) CompleteMultipartUpload(ctx context.Context, bucket string, object string, uploadID string, ...) (oi ObjectInfo, e error) + func (fs *FSObjects) CopyObject(ctx context.Context, srcBucket, srcObject, dstBucket, dstObject string, ...) (oi ObjectInfo, err error) + func (fs *FSObjects) CopyObjectPart(ctx context.Context, ...) (pi PartInfo, e error) + func (fs *FSObjects) DeleteBucket(ctx context.Context, bucket string, opts DeleteBucketOptions) error + func (fs *FSObjects) DeleteBucketPolicy(ctx context.Context, bucket string) error + func (fs *FSObjects) DeleteObject(ctx context.Context, bucket, object string, opts ObjectOptions) (objInfo ObjectInfo, err error) + func (fs *FSObjects) DeleteObjectTags(ctx context.Context, bucket, object string, opts ObjectOptions) (ObjectInfo, error) + func (fs *FSObjects) DeleteObjects(ctx context.Context, bucket string, objects []ObjectToDelete, ...) ([]DeletedObject, []error) + func (fs *FSObjects) GetBucketInfo(ctx context.Context, bucket string) (bi BucketInfo, e error) + func (fs *FSObjects) GetBucketPolicy(ctx context.Context, bucket string) (*policy.Policy, error) + func (fs *FSObjects) GetMetrics(ctx context.Context) (*BackendMetrics, error) + func (fs *FSObjects) GetMultipartInfo(ctx context.Context, bucket, object, uploadID string, opts ObjectOptions) (MultipartInfo, error) + func (fs *FSObjects) GetObjectInfo(ctx context.Context, bucket, object string, opts ObjectOptions) (oi ObjectInfo, e error) + func (fs *FSObjects) GetObjectNInfo(ctx context.Context, bucket, object string, rs *HTTPRangeSpec, h http.Header, ...) (gr *GetObjectReader, err error) + func (fs *FSObjects) GetObjectTags(ctx context.Context, bucket, object string, opts ObjectOptions) (*tags.Tags, error) + func (fs *FSObjects) GetRawData(ctx context.Context, volume, file string, ...) error + func (fs *FSObjects) HealBucket(ctx context.Context, bucket string, opts madmin.HealOpts) (madmin.HealResultItem, error) + func (fs *FSObjects) HealFormat(ctx context.Context, dryRun bool) (madmin.HealResultItem, error) + func (fs *FSObjects) HealObject(ctx context.Context, bucket, object, versionID string, opts madmin.HealOpts) (res madmin.HealResultItem, err error) + func (fs *FSObjects) HealObjects(ctx context.Context, bucket, prefix string, opts madmin.HealOpts, ...) (e error) + func (fs *FSObjects) Health(ctx context.Context, opts HealthOptions) HealthResult + func (fs *FSObjects) IsCompressionSupported() bool + func (fs *FSObjects) IsEncryptionSupported() bool + func (fs *FSObjects) IsListenSupported() bool + func (fs *FSObjects) IsNotificationSupported() bool + func (fs *FSObjects) IsTaggingSupported() bool + func (fs *FSObjects) ListBuckets(ctx context.Context) ([]BucketInfo, error) + func (fs *FSObjects) ListMultipartUploads(ctx context.Context, ...) (result ListMultipartsInfo, e error) + func (fs *FSObjects) ListObjectParts(ctx context.Context, bucket, object, uploadID string, ...) (result ListPartsInfo, e error) + func (fs *FSObjects) ListObjectVersions(ctx context.Context, bucket, prefix, marker, versionMarker, delimiter string, ...) (loi ListObjectVersionsInfo, e error) + func (fs *FSObjects) ListObjects(ctx context.Context, bucket, prefix, marker, delimiter string, maxKeys int) (loi ListObjectsInfo, err error) + func (fs *FSObjects) ListObjectsV2(ctx context.Context, bucket, prefix, continuationToken, delimiter string, ...) (result ListObjectsV2Info, err error) + func (fs *FSObjects) LocalStorageInfo(ctx context.Context) (StorageInfo, []error) + func (fs *FSObjects) MakeBucketWithLocation(ctx context.Context, bucket string, opts BucketOptions) error + func (fs *FSObjects) NSScanner(ctx context.Context, bf *bloomFilter, updates chan<- DataUsageInfo, ...) error + func (fs *FSObjects) NewMultipartUpload(ctx context.Context, bucket, object string, opts ObjectOptions) (string, error) + func (fs *FSObjects) NewNSLock(bucket string, objects ...string) RWLocker + func (fs *FSObjects) PutObject(ctx context.Context, bucket string, object string, r *PutObjReader, ...) (objInfo ObjectInfo, err error) + func (fs *FSObjects) PutObjectPart(ctx context.Context, bucket, object, uploadID string, partID int, ...) (pi PartInfo, e error) + func (fs *FSObjects) PutObjectTags(ctx context.Context, bucket, object string, tags string, opts ObjectOptions) (ObjectInfo, error) + func (fs *FSObjects) ReadHealth(ctx context.Context) bool + func (fs *FSObjects) RestoreTransitionedObject(ctx context.Context, bucket, object string, opts ObjectOptions) error + func (fs *FSObjects) SetBucketPolicy(ctx context.Context, bucket string, p *policy.Policy) error + func (fs *FSObjects) SetDriveCounts() []int + func (fs *FSObjects) Shutdown(ctx context.Context) error + func (fs *FSObjects) StorageInfo(ctx context.Context) (StorageInfo, []error) + func (fs *FSObjects) TransitionObject(ctx context.Context, bucket, object string, opts ObjectOptions) error + func (fs *FSObjects) Walk(ctx context.Context, bucket, prefix string, results chan<- ObjectInfo, ...) error + type FileInfo struct + Data []byte + DataDir string + Deleted bool + DiskMTime time.Time + Erasure ErasureInfo + ExpireRestored bool + Fresh bool + Idx int + IsLatest bool + MarkDeleted bool + Metadata map[string]string + ModTime time.Time + Mode uint32 + Name string + NumVersions int + Parts []ObjectPartInfo + ReplicationState ReplicationState + Size int64 + SuccessorModTime time.Time + TransitionStatus string + TransitionTier string + TransitionVersionID string + TransitionedObjName string + VersionID string + Volume string + XLV1 bool + func (fi *FileInfo) AddObjectPart(partNumber int, partETag string, partSize int64, actualSize int64) + func (fi *FileInfo) DeleteMarkerReplicationStatus() replication.StatusType + func (fi *FileInfo) IsRestoreObjReq() bool + func (fi *FileInfo) SetInlineData() + func (fi *FileInfo) SetTierFreeVersion() + func (fi *FileInfo) SetTierFreeVersionID(versionID string) + func (fi *FileInfo) TierFreeVersion() bool + func (fi *FileInfo) TierFreeVersionID() string + func (fi *FileInfo) VersionPurgeStatus() VersionPurgeStatusType + func (fi FileInfo) AcceptableDelta(maxTime time.Time, delta time.Duration) bool + func (fi FileInfo) DataShardFixed() bool + func (fi FileInfo) Equals(ofi FileInfo) (ok bool) + func (fi FileInfo) GetDataDir() string + func (fi FileInfo) InlineData() bool + func (fi FileInfo) IsRemote() bool + func (fi FileInfo) IsValid() bool + func (fi FileInfo) MetadataEquals(ofi FileInfo) bool + func (fi FileInfo) ObjectToPartOffset(ctx context.Context, offset int64) (partIndex int, partOffset int64, err error) + func (fi FileInfo) ReplicationInfoEquals(ofi FileInfo) bool + func (fi FileInfo) ToObjectInfo(bucket, object string) ObjectInfo + func (fi FileInfo) TransitionInfoEquals(ofi FileInfo) bool + func (z *FileInfo) DecodeMsg(dc *msgp.Reader) (err error) + func (z *FileInfo) EncodeMsg(en *msgp.Writer) (err error) + func (z *FileInfo) MarshalMsg(b []byte) (o []byte, err error) + func (z *FileInfo) Msgsize() (s int) + func (z *FileInfo) UnmarshalMsg(bts []byte) (o []byte, err error) + type FileInfoVersions struct + FreeVersions []FileInfo + LatestModTime time.Time + Name string + Versions []FileInfo + Volume string + func (f FileInfoVersions) Size() (size int64) + func (z *FileInfoVersions) DecodeMsg(dc *msgp.Reader) (err error) + func (z *FileInfoVersions) EncodeMsg(en *msgp.Writer) (err error) + func (z *FileInfoVersions) MarshalMsg(b []byte) (o []byte, err error) + func (z *FileInfoVersions) Msgsize() (s int) + func (z *FileInfoVersions) UnmarshalMsg(bts []byte) (o []byte, err error) + type FileLogger struct + Enable bool + Filename string + type FilesInfo struct + Files []FileInfo + IsTruncated bool + func (z *FilesInfo) DecodeMsg(dc *msgp.Reader) (err error) + func (z *FilesInfo) EncodeMsg(en *msgp.Writer) (err error) + func (z *FilesInfo) MarshalMsg(b []byte) (o []byte, err error) + func (z *FilesInfo) Msgsize() (s int) + func (z *FilesInfo) UnmarshalMsg(bts []byte) (o []byte, err error) + type Gateway interface + Name func() string + NewGatewayLayer func(creds madmin.Credentials) (ObjectLayer, error) + type GatewayLocker struct + func (l *GatewayLocker) NewNSLock(bucket string, objects ...string) RWLocker + func (l *GatewayLocker) Walk(ctx context.Context, bucket, prefix string, results chan<- ObjectInfo, ...) error + type GatewayUnsupported struct + func (a GatewayUnsupported) AbortMultipartUpload(ctx context.Context, bucket string, object string, uploadID string, ...) error + func (a GatewayUnsupported) BackendInfo() madmin.BackendInfo + func (a GatewayUnsupported) CompleteMultipartUpload(ctx context.Context, bucket string, object string, uploadID string, ...) (oi ObjectInfo, err error) + func (a GatewayUnsupported) CopyObject(ctx context.Context, srcBucket string, srcObject string, destBucket string, ...) (objInfo ObjectInfo, err error) + func (a GatewayUnsupported) CopyObjectPart(ctx context.Context, ...) (pi PartInfo, err error) + func (a GatewayUnsupported) DeleteBucketLifecycle(ctx context.Context, bucket string) error + func (a GatewayUnsupported) DeleteBucketPolicy(ctx context.Context, bucket string) error + func (a GatewayUnsupported) DeleteBucketSSEConfig(ctx context.Context, bucket string) error + func (a GatewayUnsupported) DeleteObjectTags(ctx context.Context, bucket, object string, opts ObjectOptions) (ObjectInfo, error) + func (a GatewayUnsupported) GetBucketLifecycle(ctx context.Context, bucket string) (*lifecycle.Lifecycle, error) + func (a GatewayUnsupported) GetBucketPolicy(ctx context.Context, bucket string) (bucketPolicy *policy.Policy, err error) + func (a GatewayUnsupported) GetBucketSSEConfig(ctx context.Context, bucket string) (*bucketsse.BucketSSEConfig, error) + func (a GatewayUnsupported) GetBucketVersioning(ctx context.Context, bucket string) (*versioning.Versioning, error) + func (a GatewayUnsupported) GetMetrics(ctx context.Context) (*BackendMetrics, error) + func (a GatewayUnsupported) GetMultipartInfo(ctx context.Context, bucket string, object string, uploadID string, ...) (MultipartInfo, error) + func (a GatewayUnsupported) GetObjectTags(ctx context.Context, bucket, object string, opts ObjectOptions) (*tags.Tags, error) + func (a GatewayUnsupported) HealBucket(ctx context.Context, bucket string, opts madmin.HealOpts) (madmin.HealResultItem, error) + func (a GatewayUnsupported) HealFormat(ctx context.Context, dryRun bool) (madmin.HealResultItem, error) + func (a GatewayUnsupported) HealObject(ctx context.Context, bucket, object, versionID string, opts madmin.HealOpts) (h madmin.HealResultItem, e error) + func (a GatewayUnsupported) HealObjects(ctx context.Context, bucket, prefix string, opts madmin.HealOpts, ...) (e error) + func (a GatewayUnsupported) Health(_ context.Context, _ HealthOptions) HealthResult + func (a GatewayUnsupported) IsCompressionSupported() bool + func (a GatewayUnsupported) IsEncryptionSupported() bool + func (a GatewayUnsupported) IsListenSupported() bool + func (a GatewayUnsupported) IsNotificationSupported() bool + func (a GatewayUnsupported) IsTaggingSupported() bool + func (a GatewayUnsupported) ListMultipartUploads(ctx context.Context, bucket string, prefix string, keyMarker string, ...) (lmi ListMultipartsInfo, err error) + func (a GatewayUnsupported) ListObjectParts(ctx context.Context, bucket string, object string, uploadID string, ...) (lpi ListPartsInfo, err error) + func (a GatewayUnsupported) ListObjectVersions(ctx context.Context, bucket, prefix, marker, versionMarker, delimiter string, ...) (ListObjectVersionsInfo, error) + func (a GatewayUnsupported) ListObjectsV2(ctx context.Context, bucket, prefix, continuationToken, delimiter string, ...) (result ListObjectsV2Info, err error) + func (a GatewayUnsupported) LocalStorageInfo(ctx context.Context) (StorageInfo, []error) + func (a GatewayUnsupported) NSScanner(ctx context.Context, bf *bloomFilter, updates chan<- DataUsageInfo, ...) error + func (a GatewayUnsupported) NewMultipartUpload(ctx context.Context, bucket string, object string, opts ObjectOptions) (uploadID string, err error) + func (a GatewayUnsupported) NewNSLock(bucket string, objects ...string) RWLocker + func (a GatewayUnsupported) PutObjectMetadata(ctx context.Context, bucket, object string, opts ObjectOptions) (ObjectInfo, error) + func (a GatewayUnsupported) PutObjectPart(ctx context.Context, bucket string, object string, uploadID string, partID int, ...) (pi PartInfo, err error) + func (a GatewayUnsupported) PutObjectTags(ctx context.Context, bucket, object string, tags string, opts ObjectOptions) (ObjectInfo, error) + func (a GatewayUnsupported) ReadHealth(_ context.Context) bool + func (a GatewayUnsupported) RestoreTransitionedObject(ctx context.Context, bucket, object string, opts ObjectOptions) error + func (a GatewayUnsupported) SetBucketLifecycle(ctx context.Context, bucket string, lifecycle *lifecycle.Lifecycle) error + func (a GatewayUnsupported) SetBucketPolicy(ctx context.Context, bucket string, bucketPolicy *policy.Policy) error + func (a GatewayUnsupported) SetBucketSSEConfig(ctx context.Context, bucket string, config *bucketsse.BucketSSEConfig) error + func (a GatewayUnsupported) SetBucketVersioning(ctx context.Context, bucket string, v *versioning.Versioning) error + func (a GatewayUnsupported) SetDriveCounts() []int + func (a GatewayUnsupported) TransitionObject(ctx context.Context, bucket, object string, opts ObjectOptions) error + func (a GatewayUnsupported) Walk(ctx context.Context, bucket, prefix string, results chan<- ObjectInfo, ...) error + type GenericError struct + Bucket string + Err error + Object string + VersionID string + func (e GenericError) Unwrap() error + type GetObjectInfoFn func(ctx context.Context, bucket, object string, opts ObjectOptions) (ObjectInfo, error) + type GetObjectReader struct + ObjInfo ObjectInfo + func NewGetObjectReaderFromReader(r io.Reader, oi ObjectInfo, opts ObjectOptions, cleanupFns ...func()) (*GetObjectReader, error) + func (g *GetObjectReader) Close() error + func (g *GetObjectReader) WithCleanupFuncs(fns ...func()) *GetObjectReader + type GroupInfo struct + Members []string + Status string + Version int + type HTTPAPIStats struct + func (stats *HTTPAPIStats) Dec(api string) + func (stats *HTTPAPIStats) Inc(api string) + func (stats *HTTPAPIStats) Load() map[string]int + type HTTPConsoleLoggerSys struct + func NewConsoleLogger(ctx context.Context) *HTTPConsoleLoggerSys + func (sys *HTTPConsoleLoggerSys) Cancel() + func (sys *HTTPConsoleLoggerSys) Content() (logs []log.Entry) + func (sys *HTTPConsoleLoggerSys) Endpoint() string + func (sys *HTTPConsoleLoggerSys) HasLogListeners() bool + func (sys *HTTPConsoleLoggerSys) Init() error + func (sys *HTTPConsoleLoggerSys) Send(e interface{}, logKind string) error + func (sys *HTTPConsoleLoggerSys) SetNodeName(nodeName string) + func (sys *HTTPConsoleLoggerSys) String() string + func (sys *HTTPConsoleLoggerSys) Subscribe(subCh chan interface{}, doneCh <-chan struct{}, node string, last int, ...) + func (sys *HTTPConsoleLoggerSys) Type() types.TargetType + type HTTPRangeSpec struct + End int64 + IsSuffixLength bool + Start int64 + func (h *HTTPRangeSpec) GetLength(resourceSize int64) (rangeLength int64, err error) + func (h *HTTPRangeSpec) GetOffsetLength(resourceSize int64) (start, length int64, err error) + func (h *HTTPRangeSpec) String(resourceSize int64) string + func (h *HTTPRangeSpec) ToHeader() (string, error) + type HTTPStats struct + type HealObjectFn func(bucket, object, versionID string) error + type HealthOptions struct + Maintenance bool + type HealthResult struct + HealingDrives int + Healthy bool + PoolID int + SetID int + WriteQuorum int + type Help struct + Description string + KeysHelp config.HelpKVS + MultipleTargets bool + SubSys string + func GetHelp(subSys, key string, envOnly bool) (Help, error) + type IAMEtcdStore struct + type IAMObjectStore struct + type IAMStorageAPI interface + type IAMStoreSys struct + func (store *IAMStoreSys) AddServiceAccount(ctx context.Context, cred auth.Credentials) error + func (store *IAMStoreSys) AddUser(ctx context.Context, accessKey string, ureq madmin.AddOrUpdateUserReq) error + func (store *IAMStoreSys) AddUsersToGroup(ctx context.Context, group string, members []string) error + func (store *IAMStoreSys) DeletePolicy(ctx context.Context, policy string) error + func (store *IAMStoreSys) DeleteUser(ctx context.Context, accessKey string, userType IAMUserType) error + func (store *IAMStoreSys) DeleteUsers(ctx context.Context, users []string) error + func (store *IAMStoreSys) FilterPolicies(policyName string, bucketName string) (string, iampolicy.Policy) + func (store *IAMStoreSys) GetAllParentUsers() map[string]string + func (store *IAMStoreSys) GetBucketUsers(bucket string) (map[string]madmin.UserInfo, error) + func (store *IAMStoreSys) GetGroupDescription(group string) (gd madmin.GroupDesc, err error) + func (store *IAMStoreSys) GetMappedPolicy(name string, isGroup bool) (MappedPolicy, bool) + func (store *IAMStoreSys) GetPolicy(name string) (iampolicy.Policy, error) + func (store *IAMStoreSys) GetPolicyDoc(name string) (r PolicyDoc, err error) + func (store *IAMStoreSys) GetSTSAndServiceAccounts() []auth.Credentials + func (store *IAMStoreSys) GetUser(user string) (auth.Credentials, bool) + func (store *IAMStoreSys) GetUserInfo(name string) (u madmin.UserInfo, err error) + func (store *IAMStoreSys) GetUsers() map[string]madmin.UserInfo + func (store *IAMStoreSys) GroupNotificationHandler(ctx context.Context, group string) error + func (store *IAMStoreSys) HasWatcher() bool + func (store *IAMStoreSys) ListGroups(ctx context.Context) (res []string, err error) + func (store *IAMStoreSys) ListPolicies(ctx context.Context, bucketName string) (map[string]iampolicy.Policy, error) + func (store *IAMStoreSys) ListServiceAccounts(ctx context.Context, accessKey string) ([]auth.Credentials, error) + func (store *IAMStoreSys) LoadIAMCache(ctx context.Context) error + func (store *IAMStoreSys) LoadUser(ctx context.Context, accessKey string) + func (store *IAMStoreSys) PolicyDBGet(name string, isGroup bool, groups ...string) ([]string, error) + func (store *IAMStoreSys) PolicyDBSet(ctx context.Context, name, policy string, userType IAMUserType, isGroup bool) error + func (store *IAMStoreSys) PolicyMappingNotificationHandler(ctx context.Context, userOrGroup string, isGroup bool, userType IAMUserType) error + func (store *IAMStoreSys) PolicyNotificationHandler(ctx context.Context, policy string) error + func (store *IAMStoreSys) RemoveUsersFromGroup(ctx context.Context, group string, members []string) error + func (store *IAMStoreSys) SetGroupStatus(ctx context.Context, group string, enabled bool) error + func (store *IAMStoreSys) SetPolicy(ctx context.Context, name string, policy iampolicy.Policy) error + func (store *IAMStoreSys) SetTempUser(ctx context.Context, accessKey string, cred auth.Credentials, ...) error + func (store *IAMStoreSys) SetUserStatus(ctx context.Context, accessKey string, status madmin.AccountStatus) error + func (store *IAMStoreSys) UpdateServiceAccount(ctx context.Context, accessKey string, opts updateServiceAccountOpts) error + func (store *IAMStoreSys) UpdateUserIdentity(ctx context.Context, cred auth.Credentials) error + func (store *IAMStoreSys) UpdateUserSecretKey(ctx context.Context, accessKey, secretKey string) error + func (store *IAMStoreSys) UserNotificationHandler(ctx context.Context, accessKey string, userType IAMUserType) error + type IAMSys struct + func NewIAMSys() *IAMSys + func (sys *IAMSys) AddUsersToGroup(ctx context.Context, group string, members []string) error + func (sys *IAMSys) CreateUser(ctx context.Context, accessKey string, ureq madmin.AddOrUpdateUserReq) error + func (sys *IAMSys) CurrentPolicies(policyName string) string + func (sys *IAMSys) DeletePolicy(ctx context.Context, policyName string, notifyPeers bool) error + func (sys *IAMSys) DeleteServiceAccount(ctx context.Context, accessKey string, notifyPeers bool) error + func (sys *IAMSys) DeleteUser(ctx context.Context, accessKey string, notifyPeers bool) error + func (sys *IAMSys) EnableLDAPSys() + func (sys *IAMSys) GetClaimsForSvcAcc(ctx context.Context, accessKey string) (map[string]interface{}, error) + func (sys *IAMSys) GetCombinedPolicy(policies ...string) iampolicy.Policy + func (sys *IAMSys) GetGroupDescription(group string) (gd madmin.GroupDesc, err error) + func (sys *IAMSys) GetRolePolicy(arnStr string) (string, error) + func (sys *IAMSys) GetServiceAccount(ctx context.Context, accessKey string) (auth.Credentials, *iampolicy.Policy, error) + func (sys *IAMSys) GetUser(ctx context.Context, accessKey string) (cred auth.Credentials, ok bool) + func (sys *IAMSys) GetUserInfo(ctx context.Context, name string) (u madmin.UserInfo, err error) + func (sys *IAMSys) HasRolePolicy() bool + func (sys *IAMSys) HasWatcher() bool + func (sys *IAMSys) InfoPolicy(policyName string) (*madmin.PolicyInfo, error) + func (sys *IAMSys) Init(ctx context.Context, objAPI ObjectLayer, etcdClient *etcd.Client, ...) + func (sys *IAMSys) Initialized() bool + func (sys *IAMSys) IsAllowed(args iampolicy.Args) bool + func (sys *IAMSys) IsAllowedLDAPSTS(args iampolicy.Args, parentUser string) bool + func (sys *IAMSys) IsAllowedSTS(args iampolicy.Args, parentUser string) bool + func (sys *IAMSys) IsAllowedServiceAccount(args iampolicy.Args, parentUser string) bool + func (sys *IAMSys) IsServiceAccount(name string) (bool, string, error) + func (sys *IAMSys) IsTempUser(name string) (bool, string, error) + func (sys *IAMSys) ListBucketUsers(bucket string) (map[string]madmin.UserInfo, error) + func (sys *IAMSys) ListGroups(ctx context.Context) (r []string, err error) + func (sys *IAMSys) ListPolicies(ctx context.Context, bucketName string) (map[string]iampolicy.Policy, error) + func (sys *IAMSys) ListServiceAccounts(ctx context.Context, accessKey string) ([]auth.Credentials, error) + func (sys *IAMSys) ListUsers() (map[string]madmin.UserInfo, error) + func (sys *IAMSys) Load(ctx context.Context) error + func (sys *IAMSys) LoadGroup(ctx context.Context, objAPI ObjectLayer, group string) error + func (sys *IAMSys) LoadPolicy(ctx context.Context, objAPI ObjectLayer, policyName string) error + func (sys *IAMSys) LoadPolicyMapping(ctx context.Context, objAPI ObjectLayer, userOrGroup string, isGroup bool) error + func (sys *IAMSys) LoadServiceAccount(ctx context.Context, accessKey string) error + func (sys *IAMSys) LoadUser(ctx context.Context, objAPI ObjectLayer, accessKey string, ...) error + func (sys *IAMSys) NewServiceAccount(ctx context.Context, parentUser string, groups []string, ...) (auth.Credentials, error) + func (sys *IAMSys) PolicyDBGet(name string, isGroup bool, groups ...string) ([]string, error) + func (sys *IAMSys) PolicyDBSet(ctx context.Context, name, policy string, isGroup bool) error + func (sys *IAMSys) RemoveUsersFromGroup(ctx context.Context, group string, members []string) error + func (sys *IAMSys) SetGroupStatus(ctx context.Context, group string, enabled bool) error + func (sys *IAMSys) SetPolicy(ctx context.Context, policyName string, p iampolicy.Policy) error + func (sys *IAMSys) SetTempUser(ctx context.Context, accessKey string, cred auth.Credentials, ...) error + func (sys *IAMSys) SetUserSecretKey(ctx context.Context, accessKey string, secretKey string) error + func (sys *IAMSys) SetUserStatus(ctx context.Context, accessKey string, status madmin.AccountStatus) error + func (sys *IAMSys) UpdateServiceAccount(ctx context.Context, accessKey string, opts updateServiceAccountOpts) error + type IAMUserType int + type IncompleteBody GenericError + func (e IncompleteBody) Error() string + type InitiateMultipartUploadResponse struct + Bucket string + Key string + UploadID string + XMLName xml.Name + type Initiator Owner + type InsufficientReadQuorum GenericError + func (e InsufficientReadQuorum) Error() string + func (e InsufficientReadQuorum) Unwrap() error + type InsufficientWriteQuorum GenericError + func (e InsufficientWriteQuorum) Error() string + func (e InsufficientWriteQuorum) Unwrap() error + type InvalidArgument GenericError + func (e InvalidArgument) Error() string + type InvalidETag struct + func (e InvalidETag) Error() string + type InvalidMarkerPrefixCombination struct + Marker string + Prefix string + func (e InvalidMarkerPrefixCombination) Error() string + type InvalidObjectState GenericError + func (e InvalidObjectState) Error() string + type InvalidPart struct + ExpETag string + GotETag string + PartNumber int + func (e InvalidPart) Error() string + type InvalidRange struct + OffsetBegin int64 + OffsetEnd int64 + ResourceSize int64 + func (e InvalidRange) Error() string + type InvalidUploadID struct + Bucket string + Object string + UploadID string + func (e InvalidUploadID) Error() string + type InvalidUploadIDKeyCombination struct + KeyMarker string + UploadIDMarker string + func (e InvalidUploadIDKeyCombination) Error() string + type InvalidVersionID GenericError + func (e InvalidVersionID) Error() string + type IsLeafDirFunc func(string, string) bool + type IsLeafFunc func(string, string) bool + type LDAPIdentityResult struct + Credentials auth.Credentials + type LastMinuteLatencies [sizeLastElemMarker]lastMinuteLatency + func (l *LastMinuteLatencies) Add(size int64, t time.Duration) + func (l *LastMinuteLatencies) GetAvgData() [sizeLastElemMarker]AccElem + func (l LastMinuteLatencies) Merge(o LastMinuteLatencies) (merged LastMinuteLatencies) + func (z *LastMinuteLatencies) DecodeMsg(dc *msgp.Reader) (err error) + func (z *LastMinuteLatencies) EncodeMsg(en *msgp.Writer) (err error) + func (z *LastMinuteLatencies) MarshalMsg(b []byte) (o []byte, err error) + func (z *LastMinuteLatencies) Msgsize() (s int) + func (z *LastMinuteLatencies) UnmarshalMsg(bts []byte) (o []byte, err error) + type LifecycleSys struct + func NewLifecycleSys() *LifecycleSys + func (sys *LifecycleSys) Get(bucketName string) (lc *lifecycle.Lifecycle, err error) + type ListBucketsResponse struct + Buckets struct{ ... } + Owner Owner + XMLName xml.Name + type ListDirFunc func(bucket, prefixDir, prefixEntry string) (emptyDir bool, entries []string, delayIsLeaf bool) + type ListMultipartUploadsResponse struct + Bucket string + CommonPrefixes []CommonPrefix + Delimiter string + EncodingType string + IsTruncated bool + KeyMarker string + MaxUploads int + NextKeyMarker string + NextUploadIDMarker string + Prefix string + UploadIDMarker string + Uploads []Upload + XMLName xml.Name + type ListMultipartsInfo struct + CommonPrefixes []string + Delimiter string + EncodingType string + IsTruncated bool + KeyMarker string + MaxUploads int + NextKeyMarker string + NextUploadIDMarker string + Prefix string + UploadIDMarker string + Uploads []MultipartInfo + func FromMinioClientListMultipartsInfo(lmur minio.ListMultipartUploadsResult) ListMultipartsInfo + func (lm ListMultipartsInfo) Lookup(uploadID string) bool + type ListObjectVersionsInfo struct + IsTruncated bool + NextMarker string + NextVersionIDMarker string + Objects []ObjectInfo + Prefixes []string + type ListObjectsInfo struct + IsTruncated bool + NextMarker string + Objects []ObjectInfo + Prefixes []string + func FromMinioClientListBucketResult(bucket string, result minio.ListBucketResult) ListObjectsInfo + type ListObjectsResponse struct + CommonPrefixes []CommonPrefix + Contents []Object + Delimiter string + EncodingType string + IsTruncated bool + Marker string + MaxKeys int + Name string + NextMarker string + Prefix string + XMLName xml.Name + type ListObjectsV2Info struct + ContinuationToken string + IsTruncated bool + NextContinuationToken string + Objects []ObjectInfo + Prefixes []string + func FromMinioClientListBucketResultToV2Info(bucket string, result minio.ListBucketResult) ListObjectsV2Info + func FromMinioClientListBucketV2Result(bucket string, result minio.ListBucketV2Result) ListObjectsV2Info + type ListObjectsV2Response struct + CommonPrefixes []CommonPrefix + Contents []Object + ContinuationToken string + Delimiter string + EncodingType string + IsTruncated bool + KeyCount int + MaxKeys int + Name string + NextContinuationToken string + Prefix string + StartAfter string + XMLName xml.Name + type ListPartsInfo struct + Bucket string + IsTruncated bool + MaxParts int + NextPartNumberMarker int + Object string + PartNumberMarker int + Parts []PartInfo + StorageClass string + UploadID string + UserDefined map[string]string + func FromMinioClientListPartsInfo(lopr minio.ListObjectPartsResult) ListPartsInfo + type ListPartsResponse struct + Bucket string + Initiator Initiator + IsTruncated bool + Key string + MaxParts int + NextPartNumberMarker int + Owner Owner + PartNumberMarker int + Parts []Part + StorageClass string + UploadID string + XMLName xml.Name + type ListVersionsResponse struct + CommonPrefixes []CommonPrefix + Delimiter string + EncodingType string + IsTruncated bool + KeyMarker string + MaxKeys int + Name string + NextKeyMarker string + NextVersionIDMarker string + Prefix string + VersionIDMarker string + Versions []ObjectVersion + XMLName xml.Name + type LocationResponse struct + Location string + XMLName xml.Name + type LockContext struct + func (l LockContext) Cancel() + func (l LockContext) Context() context.Context + type LockType int + type MalformedUploadID struct + UploadID string + func (e MalformedUploadID) Error() string + type MappedPolicy struct + Policies string + Version int + type MetadataEntry struct + Name string + Value string + type MethodNotAllowed GenericError + func (e MethodNotAllowed) Error() string + type Metric struct + Description MetricDescription + Histogram map[string]uint64 + HistogramBucketLabel string + StaticLabels map[string]string + Value float64 + VariableLabels map[string]string + type MetricDescription struct + Help string + Name MetricName + Namespace MetricNamespace + Subsystem MetricSubsystem + Type MetricType + type MetricName string + type MetricNamespace string + type MetricSubsystem string + type MetricType string + type MetricsGroup struct + func (g *MetricsGroup) Get() (metrics []Metric) + func (g *MetricsGroup) RegisterRead(read func(ctx context.Context) []Metric) + type MetricsTransport struct + Metrics *BackendMetrics + Transport *http.Transport + func (m MetricsTransport) RoundTrip(r *http.Request) (*http.Response, error) + type MultipartInfo struct + Bucket string + Initiated time.Time + Object string + UploadID string + UserDefined map[string]string + func (o *MultipartInfo) KMSKeyID() string + type NotImplemented struct + Message string + func (e NotImplemented) Error() string + type NotificationGroup struct + func WithNPeers(nerrs int) *NotificationGroup + func (g *NotificationGroup) Go(ctx context.Context, f func() error, index int, addr xnet.Host) + func (g *NotificationGroup) Wait() []NotificationPeerErr + type NotificationPeerErr struct + Err error + Host xnet.Host + type NotificationSys struct + func NewNotificationSys(endpoints EndpointServerPools) *NotificationSys + func (sys *NotificationSys) AddRulesMap(bucketName string, rulesMap event.RulesMap) + func (sys *NotificationSys) BackgroundHealStatus() ([]madmin.BgHealState, []NotificationPeerErr) + func (sys *NotificationSys) ConfiguredTargetIDs() []event.TargetID + func (sys *NotificationSys) DeleteBucketMetadata(ctx context.Context, bucketName string) + func (sys *NotificationSys) DeletePolicy(policyName string) []NotificationPeerErr + func (sys *NotificationSys) DeleteServiceAccount(accessKey string) []NotificationPeerErr + func (sys *NotificationSys) DeleteUser(accessKey string) []NotificationPeerErr + func (sys *NotificationSys) DispatchNetPerfChan(ctx context.Context) chan madmin.NetPerfInfo + func (sys *NotificationSys) DispatchNetPerfInfo(ctx context.Context) []madmin.NetPerfInfo + func (sys *NotificationSys) DownloadProfilingData(ctx context.Context, writer io.Writer) bool + func (sys *NotificationSys) DriveSpeedTest(ctx context.Context, opts madmin.DriveSpeedTestOpts) chan madmin.DriveSpeedTestResult + func (sys *NotificationSys) GetARNList(onlyActive bool) []string + func (sys *NotificationSys) GetBandwidthReports(ctx context.Context, buckets ...string) madmin.BucketBandwidthReport + func (sys *NotificationSys) GetCPUs(ctx context.Context) []madmin.CPUs + func (sys *NotificationSys) GetClusterBucketStats(ctx context.Context, bucketName string) []BucketStats + func (sys *NotificationSys) GetClusterMetrics(ctx context.Context) chan Metric + func (sys *NotificationSys) GetDrivePerfInfos(ctx context.Context) chan madmin.DrivePerfInfos + func (sys *NotificationSys) GetLastDayTierStats(ctx context.Context) dailyAllTierStats + func (sys *NotificationSys) GetLocalDiskIDs(ctx context.Context) (localDiskIDs [][]string) + func (sys *NotificationSys) GetLocks(ctx context.Context, r *http.Request) []*PeerLocks + func (sys *NotificationSys) GetMemInfo(ctx context.Context) []madmin.MemInfo + func (sys *NotificationSys) GetNetPerfInfo(ctx context.Context) madmin.NetPerfInfo + func (sys *NotificationSys) GetOSInfo(ctx context.Context) []madmin.OSInfo + func (sys *NotificationSys) GetParallelNetPerfInfo(ctx context.Context) madmin.NetPerfInfo + func (sys *NotificationSys) GetPartitions(ctx context.Context) []madmin.Partitions + func (sys *NotificationSys) GetProcInfo(ctx context.Context) []madmin.ProcInfo + func (sys *NotificationSys) GetSysConfig(ctx context.Context) []madmin.SysConfig + func (sys *NotificationSys) GetSysErrors(ctx context.Context) []madmin.SysErrors + func (sys *NotificationSys) GetSysServices(ctx context.Context) []madmin.SysServices + func (sys *NotificationSys) InitBucketTargets(ctx context.Context, objAPI ObjectLayer) error + func (sys *NotificationSys) LoadBucketMetadata(ctx context.Context, bucketName string) + func (sys *NotificationSys) LoadGroup(group string) []NotificationPeerErr + func (sys *NotificationSys) LoadPolicy(policyName string) []NotificationPeerErr + func (sys *NotificationSys) LoadPolicyMapping(userOrGroup string, isGroup bool) []NotificationPeerErr + func (sys *NotificationSys) LoadServiceAccount(accessKey string) []NotificationPeerErr + func (sys *NotificationSys) LoadTransitionTierConfig(ctx context.Context) + func (sys *NotificationSys) LoadUser(accessKey string, temp bool) []NotificationPeerErr + func (sys *NotificationSys) Netperf(ctx context.Context, duration time.Duration) []madmin.NetperfNodeResult + func (sys *NotificationSys) ReloadPoolMeta(ctx context.Context) + func (sys *NotificationSys) ReloadSiteReplicationConfig(ctx context.Context) []error + func (sys *NotificationSys) RemoveAllRemoteTargets() + func (sys *NotificationSys) RemoveNotification(bucketName string) + func (sys *NotificationSys) RemoveRulesMap(bucketName string, rulesMap event.RulesMap) + func (sys *NotificationSys) Send(args eventArgs) + func (sys *NotificationSys) ServerInfo() []madmin.ServerProperties + func (sys *NotificationSys) ServerUpdate(ctx context.Context, u *url.URL, sha256Sum []byte, lrTime time.Time, ...) []NotificationPeerErr + func (sys *NotificationSys) ServiceFreeze(ctx context.Context, freeze bool) []NotificationPeerErr + func (sys *NotificationSys) SignalService(sig serviceSignal) []NotificationPeerErr + func (sys *NotificationSys) Speedtest(ctx context.Context, size int, concurrent int, duration time.Duration, ...) []SpeedtestResult + func (sys *NotificationSys) StartProfiling(profiler string) []NotificationPeerErr + type ObjReaderFn func(inputReader io.Reader, h http.Header, cleanupFns ...func()) (r *GetObjectReader, err error) + func NewGetObjectReader(rs *HTTPRangeSpec, oi ObjectInfo, opts ObjectOptions) (fn ObjReaderFn, off, length int64, err error) + type Object struct + ETag string + Key string + LastModified string + Owner Owner + Size int64 + StorageClass string + UserMetadata StringMap + type ObjectAlreadyExists GenericError + func (e ObjectAlreadyExists) Error() string + type ObjectExistsAsDirectory GenericError + func (e ObjectExistsAsDirectory) Error() string + type ObjectInfo struct + AccTime time.Time + Bucket string + CacheLookupStatus CacheStatusType + CacheStatus CacheStatusType + ContentEncoding string + ContentType string + DeleteMarker bool + ETag string + Expires time.Time + InnerETag string + IsDir bool + IsLatest bool + Legacy bool + ModTime time.Time + Name string + NumVersions int + Parts []ObjectPartInfo + PutObjReader *PutObjReader + Reader *hash.Reader + ReplicationStatus replication.StatusType + ReplicationStatusInternal string + RestoreExpires time.Time + RestoreOngoing bool + Size int64 + StorageClass string + SuccessorModTime time.Time + TransitionedObject TransitionedObject + UserDefined map[string]string + UserTags string + VersionID string + VersionPurgeStatus VersionPurgeStatusType + VersionPurgeStatusInternal string + Writer io.WriteCloser + func FromMinioClientObjectInfo(bucket string, oi minio.ObjectInfo) ObjectInfo + func (o *ObjectInfo) DecryptedSize() (int64, error) + func (o *ObjectInfo) EncryptedSize() int64 + func (o *ObjectInfo) GetDecryptedRange(rs *HTTPRangeSpec) (encOff, encLength, skipLen int64, seqNumber uint32, partStart int, err error) + func (o *ObjectInfo) KMSKeyID() string + func (o *ObjectInfo) TargetReplicationStatus(arn string) (status replication.StatusType) + func (o ObjectInfo) Clone() (cinfo ObjectInfo) + func (o ObjectInfo) GetActualETag(h http.Header) string + func (o ObjectInfo) GetActualSize() (int64, error) + func (o ObjectInfo) IsCacheable() bool + func (o ObjectInfo) IsCompressed() bool + func (o ObjectInfo) IsCompressedOK() (bool, error) + func (oi ObjectInfo) IsRemote() bool + func (oi ObjectInfo) ToLifecycleOpts() lifecycle.ObjectOpts + type ObjectLayer interface + AbortMultipartUpload func(ctx context.Context, bucket, object, uploadID string, opts ObjectOptions) error + BackendInfo func() madmin.BackendInfo + CompleteMultipartUpload func(ctx context.Context, bucket, object, uploadID string, ...) (objInfo ObjectInfo, err error) + CopyObject func(ctx context.Context, srcBucket, srcObject, destBucket, destObject string, ...) (objInfo ObjectInfo, err error) + CopyObjectPart func(ctx context.Context, srcBucket, srcObject, destBucket, destObject string, ...) (info PartInfo, err error) + DeleteBucket func(ctx context.Context, bucket string, opts DeleteBucketOptions) error + DeleteBucketPolicy func(context.Context, string) error + DeleteObject func(ctx context.Context, bucket, object string, opts ObjectOptions) (ObjectInfo, error) + DeleteObjectTags func(context.Context, string, string, ObjectOptions) (ObjectInfo, error) + DeleteObjects func(ctx context.Context, bucket string, objects []ObjectToDelete, ...) ([]DeletedObject, []error) + GetBucketInfo func(ctx context.Context, bucket string) (bucketInfo BucketInfo, err error) + GetBucketPolicy func(context.Context, string) (*policy.Policy, error) + GetMetrics func(ctx context.Context) (*BackendMetrics, error) + GetMultipartInfo func(ctx context.Context, bucket, object, uploadID string, opts ObjectOptions) (info MultipartInfo, err error) + GetObjectInfo func(ctx context.Context, bucket, object string, opts ObjectOptions) (objInfo ObjectInfo, err error) + GetObjectNInfo func(ctx context.Context, bucket, object string, rs *HTTPRangeSpec, h http.Header, ...) (reader *GetObjectReader, err error) + GetObjectTags func(context.Context, string, string, ObjectOptions) (*tags.Tags, error) + HealBucket func(ctx context.Context, bucket string, opts madmin.HealOpts) (madmin.HealResultItem, error) + HealFormat func(ctx context.Context, dryRun bool) (madmin.HealResultItem, error) + HealObject func(ctx context.Context, bucket, object, versionID string, opts madmin.HealOpts) (madmin.HealResultItem, error) + HealObjects func(ctx context.Context, bucket, prefix string, opts madmin.HealOpts, ...) error + Health func(ctx context.Context, opts HealthOptions) HealthResult + IsCompressionSupported func() bool + IsEncryptionSupported func() bool + IsListenSupported func() bool + IsNotificationSupported func() bool + IsTaggingSupported func() bool + ListBuckets func(ctx context.Context) (buckets []BucketInfo, err error) + ListMultipartUploads func(ctx context.Context, ...) (result ListMultipartsInfo, err error) + ListObjectParts func(ctx context.Context, bucket, object, uploadID string, partNumberMarker int, ...) (result ListPartsInfo, err error) + ListObjectVersions func(ctx context.Context, bucket, prefix, marker, versionMarker, delimiter string, ...) (result ListObjectVersionsInfo, err error) + ListObjects func(ctx context.Context, bucket, prefix, marker, delimiter string, maxKeys int) (result ListObjectsInfo, err error) + ListObjectsV2 func(ctx context.Context, bucket, prefix, continuationToken, delimiter string, ...) (result ListObjectsV2Info, err error) + LocalStorageInfo func(ctx context.Context) (StorageInfo, []error) + MakeBucketWithLocation func(ctx context.Context, bucket string, opts BucketOptions) error + NSScanner func(ctx context.Context, bf *bloomFilter, updates chan<- DataUsageInfo, ...) error + NewMultipartUpload func(ctx context.Context, bucket, object string, opts ObjectOptions) (uploadID string, err error) + NewNSLock func(bucket string, objects ...string) RWLocker + PutObject func(ctx context.Context, bucket, object string, data *PutObjReader, ...) (objInfo ObjectInfo, err error) + PutObjectMetadata func(context.Context, string, string, ObjectOptions) (ObjectInfo, error) + PutObjectPart func(ctx context.Context, bucket, object, uploadID string, partID int, ...) (info PartInfo, err error) + PutObjectTags func(context.Context, string, string, string, ObjectOptions) (ObjectInfo, error) + ReadHealth func(ctx context.Context) bool + RestoreTransitionedObject func(ctx context.Context, bucket, object string, opts ObjectOptions) error + SetBucketPolicy func(context.Context, string, *policy.Policy) error + SetDriveCounts func() []int + Shutdown func(context.Context) error + StorageInfo func(ctx context.Context) (StorageInfo, []error) + TransitionObject func(ctx context.Context, bucket, object string, opts ObjectOptions) error + Walk func(ctx context.Context, bucket, prefix string, results chan<- ObjectInfo, ...) error + func NewFSObjectLayer(fsPath string) (ObjectLayer, error) + func NewGatewayLayerWithLocker(gwLayer ObjectLayer) ObjectLayer + type ObjectLocked GenericError + func (e ObjectLocked) Error() string + type ObjectNameInvalid GenericError + func (e ObjectNameInvalid) Error() string + type ObjectNamePrefixAsSlash GenericError + func (e ObjectNamePrefixAsSlash) Error() string + type ObjectNameTooLong GenericError + func (e ObjectNameTooLong) Error() string + type ObjectNotFound GenericError + func (e ObjectNotFound) Error() string + type ObjectOptions struct + CheckPrecondFn CheckPreconditionFn + DeleteMarker bool + DeletePrefix bool + DeleteReplication ReplicationState + EvalMetadataFn EvalMetadataFn + Expiration ExpirationOptions + Expires time.Time + MTime time.Time + MaxParity bool + Mutate bool + NoLock bool + PartNumber int + ProxyHeaderSet bool + ProxyRequest bool + ReplicationRequest bool + ReplicationSourceLegalholdTimestamp time.Time + ReplicationSourceRetentionTimestamp time.Time + ReplicationSourceTaggingTimestamp time.Time + ServerSideEncryption encrypt.ServerSide + Speedtest bool + Transition TransitionOptions + UserDefined map[string]string + VersionID string + VersionSuspended bool + Versioned bool + WalkAscending bool + func (o *ObjectOptions) DeleteMarkerReplicationStatus() replication.StatusType + func (o *ObjectOptions) PutReplicationState() (r ReplicationState) + func (o *ObjectOptions) SetDeleteReplicationState(dsc ReplicateDecision, vID string) + func (o *ObjectOptions) SetReplicaStatus(st replication.StatusType) + func (o *ObjectOptions) VersionPurgeStatus() VersionPurgeStatusType + type ObjectPartInfo struct + ActualSize int64 + ETag string + Number int + Size int64 + func (z *ObjectPartInfo) DecodeMsg(dc *msgp.Reader) (err error) + func (z *ObjectPartInfo) EncodeMsg(en *msgp.Writer) (err error) + func (z *ObjectPartInfo) MarshalMsg(b []byte) (o []byte, err error) + func (z *ObjectPartInfo) Msgsize() (s int) + func (z *ObjectPartInfo) UnmarshalMsg(bts []byte) (o []byte, err error) + type ObjectToDelete struct + DeleteMarkerReplicationStatus string + ReplicateDecisionStr string + VersionPurgeStatus VersionPurgeStatusType + VersionPurgeStatuses string + func (o *ObjectToDelete) ReplicationState() ReplicationState + type ObjectTooLarge GenericError + func (e ObjectTooLarge) Error() string + type ObjectTooSmall GenericError + func (e ObjectTooSmall) Error() string + type ObjectV struct + ObjectName string + VersionID string + type ObjectVersion struct + IsLatest bool + VersionID string + func (o ObjectVersion) MarshalXML(e *xml.Encoder, start xml.StartElement) error + type OpenIDClientAppParams struct + ClientID string + ClientSecret string + ProviderURL string + RedirectURL string + type OperationTimedOut struct + func (e OperationTimedOut) Error() string + type OutputLocation struct + S3 S3Location + func (o *OutputLocation) IsEmpty() bool + type Owner struct + DisplayName string + ID string + type Part struct + ETag string + LastModified string + PartNumber int + Size int64 + type PartInfo struct + ActualSize int64 + ETag string + LastModified time.Time + PartNumber int + Size int64 + func FromMinioClientObjectPart(op minio.ObjectPart) PartInfo + type PartTooBig struct + func (e PartTooBig) Error() string + type PartTooSmall struct + PartETag string + PartNumber int + PartSize int64 + func (e PartTooSmall) Error() string + type PeerLocks struct + Addr string + Locks map[string][]lockRequesterInfo + type PeerSiteInfo struct + DeploymentID string + Empty bool + Replicated bool + type PolicyDoc struct + CreateDate time.Time + Policy iampolicy.Policy + UpdateDate time.Time + Version int + type PolicyStatus struct + IsPublic string + XMLName xml.Name + type PolicySys struct + func NewPolicySys() *PolicySys + func (sys *PolicySys) Get(bucket string) (*policy.Policy, error) + func (sys *PolicySys) IsAllowed(args policy.Args) bool + type PoolDecommissionInfo struct + Bucket string + BytesDone int64 + BytesFailed int64 + Canceled bool + Complete bool + CurrentSize int64 + DecommissionedBuckets []string + Failed bool + ItemsDecommissionFailed int64 + ItemsDecommissioned int64 + Object string + QueuedBuckets []string + StartSize int64 + StartTime time.Time + TotalSize int64 + func (z *PoolDecommissionInfo) DecodeMsg(dc *msgp.Reader) (err error) + func (z *PoolDecommissionInfo) EncodeMsg(en *msgp.Writer) (err error) + func (z *PoolDecommissionInfo) MarshalMsg(b []byte) (o []byte, err error) + func (z *PoolDecommissionInfo) Msgsize() (s int) + func (z *PoolDecommissionInfo) UnmarshalMsg(bts []byte) (o []byte, err error) + type PoolEndpoints struct + CmdLine string + DrivesPerSet int + Endpoints Endpoints + Legacy bool + SetCount int + type PoolStatus struct + CmdLine string + Decommission *PoolDecommissionInfo + ID int + LastUpdate time.Time + func (z *PoolStatus) DecodeMsg(dc *msgp.Reader) (err error) + func (z *PoolStatus) EncodeMsg(en *msgp.Writer) (err error) + func (z *PoolStatus) MarshalMsg(b []byte) (o []byte, err error) + func (z *PoolStatus) Msgsize() (s int) + func (z *PoolStatus) UnmarshalMsg(bts []byte) (o []byte, err error) + type PostPolicyForm struct + Conditions struct{ ... } + Expiration time.Time + type PostResponse struct + Bucket string + ETag string + Key string + Location string + type PreConditionFailed struct + func (e PreConditionFailed) Error() string + type PrefixAccessDenied GenericError + func (e PrefixAccessDenied) Error() string + type ProxyEndpoint struct + Transport http.RoundTripper + func GetProxyEndpoints(endpointServerPools EndpointServerPools) []ProxyEndpoint + type PutObjReader struct + func NewPutObjReader(rawReader *hash.Reader) *PutObjReader + func (p *PutObjReader) MD5CurrentHexString() string + func (p *PutObjReader) Size() int64 + func (p *PutObjReader) WithEncryption(encReader *hash.Reader, objEncKey *crypto.ObjectKey) (*PutObjReader, error) + type RWLocker interface + GetLock func(ctx context.Context, timeout *dynamicTimeout) (lkCtx LockContext, timedOutErr error) + GetRLock func(ctx context.Context, timeout *dynamicTimeout) (lkCtx LockContext, timedOutErr error) + RUnlock func(cancel context.CancelFunc) + Unlock func(cancel context.CancelFunc) + type RangeInfo struct + File string + Range string + Size int64 + func (r *RangeInfo) Empty() bool + type ReplicateDecision struct + func (d *ReplicateDecision) PendingStatus() string + func (d *ReplicateDecision) ReplicateAny() bool + func (d *ReplicateDecision) Set(t replicateTargetDecision) + func (d *ReplicateDecision) String() string + func (d *ReplicateDecision) Synchronous() bool + func (z *ReplicateDecision) DecodeMsg(dc *msgp.Reader) (err error) + func (z *ReplicateDecision) UnmarshalMsg(bts []byte) (o []byte, err error) + func (z ReplicateDecision) EncodeMsg(en *msgp.Writer) (err error) + func (z ReplicateDecision) MarshalMsg(b []byte) (o []byte, err error) + func (z ReplicateDecision) Msgsize() (s int) + type ReplicateObjectInfo struct + Dsc ReplicateDecision + ExistingObjResync ResyncDecision + OpType replication.Type + ResetID string + RetryCount uint32 + TargetArn string + TargetStatuses map[string]replication.StatusType + type ReplicationLatency struct + UploadHistogram LastMinuteLatencies + func (z *ReplicationLatency) DecodeMsg(dc *msgp.Reader) (err error) + func (z *ReplicationLatency) EncodeMsg(en *msgp.Writer) (err error) + func (z *ReplicationLatency) MarshalMsg(b []byte) (o []byte, err error) + func (z *ReplicationLatency) Msgsize() (s int) + func (z *ReplicationLatency) UnmarshalMsg(bts []byte) (o []byte, err error) + type ReplicationPool struct + func NewReplicationPool(ctx context.Context, o ObjectLayer, opts replicationPoolOpts) *ReplicationPool + func (p *ReplicationPool) AddExistingObjectReplicateWorker() + func (p *ReplicationPool) AddMRFWorker() + func (p *ReplicationPool) AddWorker() + func (p *ReplicationPool) ResizeFailedWorkers(n int) + func (p *ReplicationPool) ResizeWorkers(n int) + type ReplicationState struct + DeleteMarker bool + PurgeTargets map[string]VersionPurgeStatusType + ReplicaStatus replication.StatusType + ReplicaTimeStamp time.Time + ReplicateDecisionStr string + ReplicationStatusInternal string + ReplicationTimeStamp time.Time + ResetStatusesMap map[string]string + Targets map[string]replication.StatusType + VersionPurgeStatusInternal string + func GetInternalReplicationState(m map[string][]byte) ReplicationState + func (rs *ReplicationState) CompositeReplicationStatus() (st replication.StatusType) + func (rs *ReplicationState) CompositeVersionPurgeStatus() VersionPurgeStatusType + func (rs *ReplicationState) Equal(o ReplicationState) bool + func (z *ReplicationState) DecodeMsg(dc *msgp.Reader) (err error) + func (z *ReplicationState) EncodeMsg(en *msgp.Writer) (err error) + func (z *ReplicationState) MarshalMsg(b []byte) (o []byte, err error) + func (z *ReplicationState) Msgsize() (s int) + func (z *ReplicationState) UnmarshalMsg(bts []byte) (o []byte, err error) + type ReplicationStats struct + Cache map[string]*BucketReplicationStats + UsageCache map[string]*BucketReplicationStats + func NewReplicationStats(ctx context.Context, objectAPI ObjectLayer) *ReplicationStats + func (r *ReplicationStats) Delete(bucket string) + func (r *ReplicationStats) Get(bucket string) BucketReplicationStats + func (r *ReplicationStats) GetInitialUsage(bucket string) BucketReplicationStats + func (r *ReplicationStats) Update(bucket string, arn string, n int64, duration time.Duration, ...) + func (r *ReplicationStats) UpdateReplicaStat(bucket string, n int64) + type RequestStats struct + Get uint64 + Head uint64 + Post uint64 + Put uint64 + type RestoreObjectRequest struct + Days int + Description string + OutputLocation OutputLocation + SelectParameters *SelectParameters + Tier string + Type RestoreRequestType + XMLName xml.Name + type RestoreRequestType string + const SelectRestoreRequest + type ResyncDecision struct + func (r *ResyncDecision) Empty() bool + func (z *ResyncDecision) DecodeMsg(dc *msgp.Reader) (err error) + func (z *ResyncDecision) UnmarshalMsg(bts []byte) (o []byte, err error) + func (z ResyncDecision) EncodeMsg(en *msgp.Writer) (err error) + func (z ResyncDecision) MarshalMsg(b []byte) (o []byte, err error) + func (z ResyncDecision) Msgsize() (s int) + type ResyncStatusType int + const NoResync + const ResyncCompleted + const ResyncFailed + const ResyncStarted + func (rt ResyncStatusType) String() string + func (z *ResyncStatusType) DecodeMsg(dc *msgp.Reader) (err error) + func (z *ResyncStatusType) UnmarshalMsg(bts []byte) (o []byte, err error) + func (z ResyncStatusType) EncodeMsg(en *msgp.Writer) (err error) + func (z ResyncStatusType) MarshalMsg(b []byte) (o []byte, err error) + func (z ResyncStatusType) Msgsize() (s int) + type ResyncTarget struct + Arn string + Bucket string + EndTime time.Time + FailedCount int64 + FailedSize int64 + Object string + ReplicatedCount int64 + ReplicatedSize int64 + ResetID string + ResyncStatus string + StartTime time.Time + func (z *ResyncTarget) DecodeMsg(dc *msgp.Reader) (err error) + func (z *ResyncTarget) EncodeMsg(en *msgp.Writer) (err error) + func (z *ResyncTarget) MarshalMsg(b []byte) (o []byte, err error) + func (z *ResyncTarget) Msgsize() (s int) + func (z *ResyncTarget) UnmarshalMsg(bts []byte) (o []byte, err error) + type ResyncTargetDecision struct + Replicate bool + ResetBeforeDate time.Time + ResetID string + func (z *ResyncTargetDecision) DecodeMsg(dc *msgp.Reader) (err error) + func (z *ResyncTargetDecision) UnmarshalMsg(bts []byte) (o []byte, err error) + func (z ResyncTargetDecision) EncodeMsg(en *msgp.Writer) (err error) + func (z ResyncTargetDecision) MarshalMsg(b []byte) (o []byte, err error) + func (z ResyncTargetDecision) Msgsize() (s int) + type ResyncTargetsInfo struct + Targets []ResyncTarget + func (z *ResyncTargetsInfo) DecodeMsg(dc *msgp.Reader) (err error) + func (z *ResyncTargetsInfo) EncodeMsg(en *msgp.Writer) (err error) + func (z *ResyncTargetsInfo) MarshalMsg(b []byte) (o []byte, err error) + func (z *ResyncTargetsInfo) Msgsize() (s int) + func (z *ResyncTargetsInfo) UnmarshalMsg(bts []byte) (o []byte, err error) + type S3Location struct + BucketName string + Encryption Encryption + Prefix string + StorageClass string + Tagging *tags.Tags + UserMetadata []MetadataEntry + type SRError struct + Cause error + Code APIErrorCode + func (c SRError) Error() string + type STSError struct + Code string + Description string + HTTPStatusCode int + type STSErrorCode int + const ErrSTSAccessDenied + const ErrSTSClientGrantsExpiredToken + const ErrSTSInsecureConnection + const ErrSTSInternalError + const ErrSTSInvalidClientCertificate + const ErrSTSInvalidClientGrantsToken + const ErrSTSInvalidParameterValue + const ErrSTSMalformedPolicyDocument + const ErrSTSMissingParameter + const ErrSTSNone + const ErrSTSNotInitialized + const ErrSTSWebIdentityExpiredToken + func (i STSErrorCode) String() string + type STSErrorResponse struct + Error struct{ ... } + RequestID string + XMLName xml.Name + type SealMD5CurrFn func([]byte) []byte + type SelectParameters struct + func (sp *SelectParameters) IsEmpty() bool + func (sp *SelectParameters) UnmarshalXML(d *xml.Decoder, start xml.StartElement) error + type ServerConnStats struct + S3InputBytes uint64 + S3OutputBytes uint64 + Throughput uint64 + TotalInputBytes uint64 + TotalOutputBytes uint64 + type ServerHTTPAPIStats struct + APIStats map[string]int + type ServerHTTPStats struct + CurrentS3Requests ServerHTTPAPIStats + S3RequestsInQueue int32 + S3RequestsIncoming uint64 + TotalS3Canceled ServerHTTPAPIStats + TotalS3Errors ServerHTTPAPIStats + TotalS3RejectedAuth uint64 + TotalS3RejectedHeader uint64 + TotalS3RejectedInvalid uint64 + TotalS3RejectedTime uint64 + TotalS3Requests ServerHTTPAPIStats + type ServerProperties struct + CommitID string + DeploymentID string + Region string + SQSARN []string + Uptime int64 + Version string + type ServerSystemConfig struct + MinioEndpoints EndpointServerPools + MinioEnv map[string]string + MinioPlatform string + func (s1 ServerSystemConfig) Diff(s2 ServerSystemConfig) error + type SetupType int + const DistErasureSetupType + const ErasureSetupType + const FSSetupType + const GatewaySetupType + const UnknownSetupType + func (setupType SetupType) String() string + type SignatureDoesNotMatch struct + func (e SignatureDoesNotMatch) Error() string + type SiteReplicationSys struct + func (c *SiteReplicationSys) AddPeerClusters(ctx context.Context, psites []madmin.PeerSite) (madmin.ReplicateAddStatus, error) + func (c *SiteReplicationSys) BucketMetaHook(ctx context.Context, item madmin.SRBucketMeta) error + func (c *SiteReplicationSys) DeleteBucketHook(ctx context.Context, bucket string, forceDelete bool) error + func (c *SiteReplicationSys) EditPeerCluster(ctx context.Context, peer madmin.PeerInfo) (madmin.ReplicateEditStatus, error) + func (c *SiteReplicationSys) GetClusterInfo(ctx context.Context) (info madmin.SiteReplicationInfo, err error) + func (c *SiteReplicationSys) GetIDPSettings(ctx context.Context) madmin.IDPSettings + func (c *SiteReplicationSys) IAMChangeHook(ctx context.Context, item madmin.SRIAMItem) error + func (c *SiteReplicationSys) Init(ctx context.Context, objAPI ObjectLayer) error + func (c *SiteReplicationSys) InternalRemoveReq(ctx context.Context, objectAPI ObjectLayer, rreq madmin.SRRemoveReq) error + func (c *SiteReplicationSys) MakeBucketHook(ctx context.Context, bucket string, opts BucketOptions) error + func (c *SiteReplicationSys) PeerAddPolicyHandler(ctx context.Context, policyName string, p *iampolicy.Policy) error + func (c *SiteReplicationSys) PeerBucketConfigureReplHandler(ctx context.Context, bucket string) error + func (c *SiteReplicationSys) PeerBucketDeleteHandler(ctx context.Context, bucket string, forceDelete bool) error + func (c *SiteReplicationSys) PeerBucketMakeWithVersioningHandler(ctx context.Context, bucket string, opts BucketOptions) error + func (c *SiteReplicationSys) PeerBucketObjectLockConfigHandler(ctx context.Context, bucket string, objectLockData *string) error + func (c *SiteReplicationSys) PeerBucketPolicyHandler(ctx context.Context, bucket string, policy *policy.Policy) error + func (c *SiteReplicationSys) PeerBucketQuotaConfigHandler(ctx context.Context, bucket string, quota *madmin.BucketQuota) error + func (c *SiteReplicationSys) PeerBucketSSEConfigHandler(ctx context.Context, bucket string, sseConfig *string) error + func (c *SiteReplicationSys) PeerBucketTaggingHandler(ctx context.Context, bucket string, tags *string) error + func (c *SiteReplicationSys) PeerEditReq(ctx context.Context, arg madmin.PeerInfo) error + func (c *SiteReplicationSys) PeerGroupInfoChangeHandler(ctx context.Context, change *madmin.SRGroupInfo) error + func (c *SiteReplicationSys) PeerIAMUserChangeHandler(ctx context.Context, change *madmin.SRIAMUser) error + func (c *SiteReplicationSys) PeerJoinReq(ctx context.Context, arg madmin.SRPeerJoinReq) error + func (c *SiteReplicationSys) PeerPolicyMappingHandler(ctx context.Context, mapping *madmin.SRPolicyMapping) error + func (c *SiteReplicationSys) PeerSTSAccHandler(ctx context.Context, stsCred *madmin.SRSTSCredential) error + func (c *SiteReplicationSys) PeerSvcAccChangeHandler(ctx context.Context, change *madmin.SRSvcAccChange) error + func (c *SiteReplicationSys) RemovePeerCluster(ctx context.Context, objectAPI ObjectLayer, rreq madmin.SRRemoveReq) (st madmin.ReplicateRemoveStatus, err error) + func (c *SiteReplicationSys) RemoveRemoteTargetsForEndpoint(ctx context.Context, objectAPI ObjectLayer, endpoints []string, ...) (err error) + func (c *SiteReplicationSys) SiteReplicationMetaInfo(ctx context.Context, objAPI ObjectLayer, opts madmin.SRStatusOptions) (info madmin.SRInfo, err error) + func (c *SiteReplicationSys) SiteReplicationStatus(ctx context.Context, objAPI ObjectLayer, opts madmin.SRStatusOptions) (info madmin.SRStatusInfo, err error) + type SlowDown struct + func (e SlowDown) Error() string + type SpeedtestResult struct + Downloads uint64 + Endpoint string + Error string + Uploads uint64 + type StartProfilingResult struct + Error string + NodeName string + Success bool + type StatInfo struct + Dir bool + ModTime time.Time + Mode uint32 + Name string + Size int64 + func (z *StatInfo) DecodeMsg(dc *msgp.Reader) (err error) + func (z *StatInfo) EncodeMsg(en *msgp.Writer) (err error) + func (z *StatInfo) MarshalMsg(b []byte) (o []byte, err error) + func (z *StatInfo) Msgsize() (s int) + func (z *StatInfo) UnmarshalMsg(bts []byte) (o []byte, err error) + type StorageAPI interface + AppendFile func(ctx context.Context, volume string, path string, buf []byte) (err error) + CheckParts func(ctx context.Context, volume string, path string, fi FileInfo) error + Close func() error + CreateFile func(ctx context.Context, volume, path string, size int64, reader io.Reader) error + Delete func(ctx context.Context, volume string, path string, recursive bool) (err error) + DeleteVersion func(ctx context.Context, volume, path string, fi FileInfo, forceDelMarker bool) error + DeleteVersions func(ctx context.Context, volume string, versions []FileInfoVersions) []error + DeleteVol func(ctx context.Context, volume string, forceDelete bool) (err error) + DiskInfo func(ctx context.Context) (info DiskInfo, err error) + Endpoint func() Endpoint + GetDiskID func() (string, error) + GetDiskLoc func() (poolIdx, setIdx, diskIdx int) + Healing func() *healingTracker + Hostname func() string + IsLocal func() bool + IsOnline func() bool + LastConn func() time.Time + ListDir func(ctx context.Context, volume, dirPath string, count int) ([]string, error) + ListVols func(ctx context.Context) (vols []VolInfo, err error) + MakeVol func(ctx context.Context, volume string) (err error) + MakeVolBulk func(ctx context.Context, volumes ...string) (err error) + NSScanner func(ctx context.Context, cache dataUsageCache, updates chan<- dataUsageEntry) (dataUsageCache, error) + ReadAll func(ctx context.Context, volume string, path string) (buf []byte, err error) + ReadFile func(ctx context.Context, volume string, path string, offset int64, buf []byte, ...) (n int64, err error) + ReadFileStream func(ctx context.Context, volume, path string, offset, length int64) (io.ReadCloser, error) + ReadVersion func(ctx context.Context, volume, path, versionID string, readData bool) (FileInfo, error) + RenameData func(ctx context.Context, srcVolume, srcPath string, fi FileInfo, ...) error + RenameFile func(ctx context.Context, srcVolume, srcPath, dstVolume, dstPath string) error + SetDiskID func(id string) + SetDiskLoc func(poolIdx, setIdx, diskIdx int) + StatInfoFile func(ctx context.Context, volume, path string, glob bool) (stat []StatInfo, err error) + StatVol func(ctx context.Context, volume string) (vol VolInfo, err error) + String func() string + UpdateMetadata func(ctx context.Context, volume, path string, fi FileInfo) error + VerifyFile func(ctx context.Context, volume, path string, fi FileInfo) error + WalkDir func(ctx context.Context, opts WalkDirOptions, wr io.Writer) error + WriteAll func(ctx context.Context, volume string, path string, b []byte) (err error) + WriteMetadata func(ctx context.Context, volume, path string, fi FileInfo) error + var OfflineDisk StorageAPI + type StorageErr string + func (h StorageErr) Error() string + type StorageFull struct + func (e StorageFull) Error() string + type StorageInfo = madmin.StorageInfo + type StringMap map[string]string + func (s StringMap) MarshalXML(e *xml.Encoder, start xml.StartElement) error + type TargetClient struct + ARN string + Bucket string + ResetID string + StorageClass string + type TargetReplicationResyncStatus struct + Bucket string + EndTime time.Time + FailedCount int64 + FailedSize int64 + Object string + ReplicatedCount int64 + ReplicatedSize int64 + ResyncBeforeDate time.Time + ResyncID string + ResyncStatus ResyncStatusType + StartTime time.Time + func (z *TargetReplicationResyncStatus) DecodeMsg(dc *msgp.Reader) (err error) + func (z *TargetReplicationResyncStatus) EncodeMsg(en *msgp.Writer) (err error) + func (z *TargetReplicationResyncStatus) MarshalMsg(b []byte) (o []byte, err error) + func (z *TargetReplicationResyncStatus) Msgsize() (s int) + func (z *TargetReplicationResyncStatus) UnmarshalMsg(bts []byte) (o []byte, err error) + type TierConfigMgr struct + Tiers map[string]madmin.TierConfig + func NewTierConfigMgr() *TierConfigMgr + func (config *TierConfigMgr) Add(ctx context.Context, tier madmin.TierConfig) error + func (config *TierConfigMgr) Bytes() ([]byte, error) + func (config *TierConfigMgr) Edit(ctx context.Context, tierName string, creds madmin.TierCreds) error + func (config *TierConfigMgr) Empty() bool + func (config *TierConfigMgr) Init(ctx context.Context, objAPI ObjectLayer) error + func (config *TierConfigMgr) IsTierValid(tierName string) bool + func (config *TierConfigMgr) ListTiers() []madmin.TierConfig + func (config *TierConfigMgr) Reload(ctx context.Context, objAPI ObjectLayer) error + func (config *TierConfigMgr) Remove(ctx context.Context, tier string) error + func (config *TierConfigMgr) Reset() + func (config *TierConfigMgr) Save(ctx context.Context, objAPI ObjectLayer) error + func (config *TierConfigMgr) Verify(ctx context.Context, tier string) error + func (z *TierConfigMgr) DecodeMsg(dc *msgp.Reader) (err error) + func (z *TierConfigMgr) EncodeMsg(en *msgp.Writer) (err error) + func (z *TierConfigMgr) MarshalMsg(b []byte) (o []byte, err error) + func (z *TierConfigMgr) Msgsize() (s int) + func (z *TierConfigMgr) UnmarshalMsg(bts []byte) (o []byte, err error) + type TransitionOptions struct + ETag string + ExpireRestored bool + RestoreExpiry time.Time + RestoreRequest *RestoreObjectRequest + Status string + Tier string + type TransitionStorageClassNotFound GenericError + func (e TransitionStorageClassNotFound) Error() string + type TransitionedObject struct + FreeVersion bool + Name string + Status string + Tier string + VersionID string + type TreeWalkPool struct + func NewTreeWalkPool(timeout time.Duration) *TreeWalkPool + func (t *TreeWalkPool) Release(params listParams) (resultCh chan TreeWalkResult, endWalkCh chan struct{}) + func (t *TreeWalkPool) Set(params listParams, resultCh chan TreeWalkResult, endWalkCh chan struct{}) + type TreeWalkResult struct + type UnsupportedMetadata struct + func (e UnsupportedMetadata) Error() string + type Upload struct + Initiated string + Initiator Initiator + Key string + Owner Owner + StorageClass string + UploadID string + type UserIdentity struct + Credentials auth.Credentials + Version int + type UsersSysType string + const LDAPUsersSysType + const MinIOUsersSysType + type VerifyFileResp struct + Err error + type VersionNotFound GenericError + func (e VersionNotFound) Error() string + type VersionPurgeStatusType string + const Complete + const Failed + const Pending + func (v VersionPurgeStatusType) Empty() bool + func (v VersionPurgeStatusType) Pending() bool + func (z *VersionPurgeStatusType) DecodeMsg(dc *msgp.Reader) (err error) + func (z *VersionPurgeStatusType) UnmarshalMsg(bts []byte) (o []byte, err error) + func (z VersionPurgeStatusType) EncodeMsg(en *msgp.Writer) (err error) + func (z VersionPurgeStatusType) MarshalMsg(b []byte) (o []byte, err error) + func (z VersionPurgeStatusType) Msgsize() (s int) + type VersionType uint8 + const DeleteType + const LegacyType + const ObjectType + func (i VersionType) String() string + func (z *VersionType) DecodeMsg(dc *msgp.Reader) (err error) + func (z *VersionType) UnmarshalMsg(bts []byte) (o []byte, err error) + func (z VersionType) EncodeMsg(en *msgp.Writer) (err error) + func (z VersionType) MarshalMsg(b []byte) (o []byte, err error) + func (z VersionType) Msgsize() (s int) + type VolInfo struct + Created time.Time + Name string + func (z *VolInfo) DecodeMsg(dc *msgp.Reader) (err error) + func (z *VolInfo) UnmarshalMsg(bts []byte) (o []byte, err error) + func (z VolInfo) EncodeMsg(en *msgp.Writer) (err error) + func (z VolInfo) MarshalMsg(b []byte) (o []byte, err error) + func (z VolInfo) Msgsize() (s int) + type VolsInfo []VolInfo + func (z *VolsInfo) DecodeMsg(dc *msgp.Reader) (err error) + func (z *VolsInfo) UnmarshalMsg(bts []byte) (o []byte, err error) + func (z VolsInfo) EncodeMsg(en *msgp.Writer) (err error) + func (z VolsInfo) MarshalMsg(b []byte) (o []byte, err error) + func (z VolsInfo) Msgsize() (s int) + type WalkDirOptions struct + BaseDir string + Bucket string + FilterPrefix string + ForwardTo string + Recursive bool + ReportNotFound bool + type WarmBackend interface + Get func(ctx context.Context, object string, rv remoteVersionID, ...) (io.ReadCloser, error) + InUse func(ctx context.Context) (bool, error) + Put func(ctx context.Context, object string, r io.Reader, length int64) (remoteVersionID, error) + Remove func(ctx context.Context, object string, rv remoteVersionID) error + type WarmBackendGetOpts struct + type WebIdentityResult struct + AssumedRoleUser AssumedRoleUser + Audience string + Credentials auth.Credentials + PackedPolicySize int + Provider string + SubjectFromWebIdentityToken string