Versions in this module Expand all Collapse all v1 v1.0.1 Jun 9, 2021 v1.0.0 Jun 9, 2021 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 DefaultBitrotAlgorithm + const DefaultSkewTime + const Disabled + const EnvErasureSetDriveCount + const EnvPrometheusAuthType + const GCSBackendGateway + const GatewayMinioSysTmp + const GlobalMinioDefaultPort + const GlobalServiceExecutionInterval + const GlobalStaleUploadsCleanupInterval + const GlobalStaleUploadsExpiry + const HDFSBackendGateway + const NASBackendGateway + const ReservedMetadataPrefix + const ReservedMetadataPrefixLower + const S3BackendGateway + const SSECacheEncrypted + const SSECustomerKeySize + const SSEDAREPackageBlockSize + const SSEDAREPackageMetaSize + const SSEIVSize + const SlashSeparator + 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 GlobalServiceDoneCh <-chan struct + 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 IsKubernetesReplicaSet() 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 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, generators func() []MetricsGenerator) <-chan Metric + func Save(configFile string, data interface{}) error + func StartGateway(ctx *cli.Context, gw Gateway) + func Stat(name string) (os.FileInfo, error) + func StorageReader(storage StorageAPI, volume, path string, offset int64) io.Reader + func StorageWriter(storage StorageAPI, volume, path string) io.Writer + 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 + func WebTrace(ri *jsonrpc.RequestInfo) madmin.TraceInfo + type APIError struct + Code string + Description string + HTTPStatusCode int + type APIErrorCode int + const ErrARNNotification + const ErrAccessDenied + 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 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 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 ErrParentIsObject + 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 ErrReplicationBucketNeedsVersioningError + const ErrReplicationConfigurationNotFoundError + 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 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 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 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 BackendDown struct + 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(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(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(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(bucketName string) (*madmin.BucketQuota, error) + 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 BucketReplicationDestinationMissingLock GenericError + func (e BucketReplicationDestinationMissingLock) Error() string + type BucketReplicationSourceNotVersioned GenericError + func (e BucketReplicationSourceNotVersioned) Error() string + type BucketReplicationStats struct + FailedCount uint64 + FailedSize uint64 + PendingCount uint64 + PendingSize uint64 + ReplicaSize uint64 + ReplicatedSize uint64 + 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) (*bucketsse.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) GetRemoteBucketTargetByArn(ctx context.Context, bucket, arn string) madmin.BucketTarget + func (sys *BucketTargetSys) GetRemoteTargetClient(ctx context.Context, arn string) *TargetClient + func (sys *BucketTargetSys) Init(ctx context.Context, buckets []BucketInfo, objAPI ObjectLayer) error + 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 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 + CacheStats func() *CacheStats + CopyObject func(ctx context.Context, srcBucket, srcObject, destBucket, destObject string, ...) (objInfo ObjectInfo, err 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) + PutObject func(ctx context.Context, bucket, object string, data *PutObjReader, ...) (objInfo ObjectInfo, 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 + func (sys *ConfigSys) Load(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 DecryptBlocksReader struct + func (d *DecryptBlocksReader) Read(p []byte) (int, error) + 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 + DeleteMarkerReplicationStatus string + DeleteMarkerVersionID string + ObjectName string + VersionID string + 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 + type DiscoveryDocResp struct + ClientID string + DiscoveryDoc openid.DiscoveryDoc + UIVersion 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]string + 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 DownloadZipArgs struct + BucketName string + Objects []string + Prefix string + type Encryption struct + EncryptionType sse.SSEAlgorithm + 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) HTTPS() bool + func (l EndpointServerPools) Hostnames() []string + 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, readers []io.ReaderAt, writers []io.Writer, size int64, ...) error + type ErasureAlgo uint8 + const ReedSolomon + func (e 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 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, forceDelete bool) 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) 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, e 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<- madmin.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 + DeleteMarkerReplicationStatus string + Deleted bool + Erasure ErasureInfo + ExpireRestored bool + IsLatest bool + MarkDeleted bool + Metadata map[string]string + ModTime time.Time + Mode uint32 + Name string + NumVersions int + Parts []ObjectPartInfo + Size int64 + SuccessorModTime time.Time + TransitionStatus string + TransitionTier string + TransitionVersionID string + TransitionedObjName string + VersionID string + VersionPurgeStatus VersionPurgeStatusType + Volume string + XLV1 bool + func (fi *FileInfo) AddObjectPart(partNumber int, partETag string, partSize int64, actualSize int64) + func (fi FileInfo) IsRemote() bool + func (fi FileInfo) IsValid() bool + func (fi FileInfo) ObjectToPartOffset(ctx context.Context, offset int64) (partIndex int, partOffset int64, err error) + func (fi FileInfo) ToObjectInfo(bucket, object string) ObjectInfo + 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 + IsEmptyDir bool + LatestModTime time.Time + Name string + Versions []FileInfo + Volume string + 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 FilesInfoVersions struct + FilesVersions []FileInfoVersions + IsTruncated bool + func (z *FilesInfoVersions) DecodeMsg(dc *msgp.Reader) (err error) + func (z *FilesInfoVersions) EncodeMsg(en *msgp.Writer) (err error) + func (z *FilesInfoVersions) MarshalMsg(b []byte) (o []byte, err error) + func (z *FilesInfoVersions) Msgsize() (s int) + func (z *FilesInfoVersions) UnmarshalMsg(bts []byte) (o []byte, err error) + type Gateway interface + Name func() string + NewGatewayLayer func(creds auth.Credentials) (ObjectLayer, error) + Production func() bool + 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<- madmin.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 GetBucketPolicyArgs struct + BucketName string + Prefix string + func (args *GetBucketPolicyArgs) ToKeyValue() KeyValueMap + type GetBucketPolicyRep struct + Policy miniogopolicy.BucketPolicy + UIVersion string + 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) Content() (logs []log.Entry) + func (sys *HTTPConsoleLoggerSys) Endpoint() string + func (sys *HTTPConsoleLoggerSys) HasLogListeners() bool + 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) Validate() error + 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 + 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 IAMSys struct + func NewIAMSys() *IAMSys + func (sys *IAMSys) AddUsersToGroup(group string, members []string) error + func (sys *IAMSys) CreateUser(accessKey string, uinfo madmin.UserInfo) error + func (sys *IAMSys) CurrentPolicies(policyName string) string + func (sys *IAMSys) DeletePolicy(policyName string) error + func (sys *IAMSys) DeleteServiceAccount(ctx context.Context, accessKey string) error + func (sys *IAMSys) DeleteUser(accessKey string) error + func (sys *IAMSys) EnableLDAPSys() + func (sys *IAMSys) GetCombinedPolicy(policies ...string) iampolicy.Policy + func (sys *IAMSys) GetGroupDescription(group string) (gd madmin.GroupDesc, err error) + func (sys *IAMSys) GetServiceAccount(ctx context.Context, accessKey string) (auth.Credentials, *iampolicy.Policy, error) + func (sys *IAMSys) GetUser(accessKey string) (cred auth.Credentials, ok bool) + func (sys *IAMSys) GetUserInfo(name string) (u madmin.UserInfo, err error) + func (sys *IAMSys) InfoPolicy(policyName string) (iampolicy.Policy, error) + func (sys *IAMSys) Init(ctx context.Context, objAPI ObjectLayer) + func (sys *IAMSys) InitStore(objAPI ObjectLayer) + 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, parent 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() (r []string, err error) + func (sys *IAMSys) ListPolicies(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, store IAMStorageAPI) error + func (sys *IAMSys) LoadGroup(objAPI ObjectLayer, group string) error + func (sys *IAMSys) LoadPolicy(objAPI ObjectLayer, policyName string) error + func (sys *IAMSys) LoadPolicyMapping(objAPI ObjectLayer, userOrGroup string, isGroup bool) error + func (sys *IAMSys) LoadServiceAccount(accessKey string) error + func (sys *IAMSys) LoadUser(objAPI ObjectLayer, accessKey string, userType IAMUserType) 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(name, policy string, isGroup bool) error + func (sys *IAMSys) RemoveUsersFromGroup(group string, members []string) error + func (sys *IAMSys) SetGroupStatus(group string, enabled bool) error + func (sys *IAMSys) SetPolicy(policyName string, p iampolicy.Policy) error + func (sys *IAMSys) SetTempUser(accessKey string, cred auth.Credentials, policyName string) error + func (sys *IAMSys) SetUserSecretKey(accessKey string, secretKey string) error + func (sys *IAMSys) SetUserStatus(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 KeyValueMap map[string]string + func (km *KeyValueMap) SetBucket(bucket string) + func (km *KeyValueMap) SetExpiry(expiry int64) + func (km *KeyValueMap) SetHostname(hostname string) + func (km *KeyValueMap) SetMarker(marker string) + func (km *KeyValueMap) SetObject(object string) + func (km *KeyValueMap) SetObjects(objects []string) + func (km *KeyValueMap) SetPolicy(policy string) + func (km *KeyValueMap) SetPrefix(prefix string) + func (km *KeyValueMap) SetUsername(username string) + func (km KeyValueMap) Bucket() string + func (km KeyValueMap) Hostname() string + func (km KeyValueMap) Object() string + func (km KeyValueMap) Objects() []string + func (km KeyValueMap) Policy() string + func (km KeyValueMap) Prefix() string + func (km KeyValueMap) Username() string + type LDAPIdentityResult struct + Credentials auth.Credentials + type LifecycleSys struct + func NewLifecycleSys() *LifecycleSys + func (sys *LifecycleSys) Get(bucketName string) (lc *lifecycle.Lifecycle, err error) + type ListAllBucketPoliciesArgs struct + BucketName string + func (args *ListAllBucketPoliciesArgs) ToKeyValue() KeyValueMap + type ListAllBucketPoliciesRep struct + Policies []BucketAccessPolicy + UIVersion string + type ListBucketsRep struct + Buckets []WebBucketInfo + UIVersion string + 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 ListObjectsArgs struct + BucketName string + Marker string + Prefix string + func (args *ListObjectsArgs) ToKeyValue() KeyValueMap + type ListObjectsInfo struct + IsTruncated bool + NextMarker string + Objects []ObjectInfo + Prefixes []string + func FromMinioClientListBucketResult(bucket string, result minio.ListBucketResult) ListObjectsInfo + type ListObjectsRep struct + Objects []WebObjectInfo + UIVersion string + Writable bool + 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 LoginArgs struct + Password string + Username string + func (args *LoginArgs) ToKeyValue() KeyValueMap + type LoginRep struct + Token string + UIVersion string + type LoginSTSArgs struct + Token string + func (args *LoginSTSArgs) ToKeyValue() KeyValueMap + type MakeBucketArgs struct + BucketName string + func (args *MakeBucketArgs) ToKeyValue() KeyValueMap + 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 MetricsGenerator func() MetricsGroup + func GetAllGenerators() []MetricsGenerator + func GetGeneratorsForPeer() []MetricsGenerator + func GetGlobalGenerators() []MetricsGenerator + func GetSingleNodeGenerators() []MetricsGenerator + type MetricsGroup struct + 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 + 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) 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) 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) Init(ctx context.Context, buckets []BucketInfo, 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) 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) SignalService(sig serviceSignal) []NotificationPeerErr + func (sys *NotificationSys) StartProfiling(profiler string) []NotificationPeerErr + type ObjReaderFn func(inputReader io.Reader, h http.Header, pcfn CheckPreconditionFn, ...) (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 + RestoreExpires time.Time + RestoreOngoing bool + Size int64 + StorageClass string + SuccessorModTime time.Time + TransitionStatus string + TransitionTier string + UserDefined map[string]string + UserTags string + VersionID string + VersionPurgeStatus VersionPurgeStatusType + 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) 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 + 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, forceDelete bool) 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<- madmin.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 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 + DeleteMarkerReplicationStatus string + Expires time.Time + MTime time.Time + MaxParity bool + NoLock bool + ParentIsObject func(ctx context.Context, bucket, parent string) bool + PartNumber int + ProxyHeaderSet bool + ProxyRequest bool + ServerSideEncryption encrypt.ServerSide + Transition TransitionOptions + UserDefined map[string]string + VersionID string + VersionPurgeStatus VersionPurgeStatusType + VersionSuspended bool + Versioned bool + WalkVersions bool + 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 + DeleteMarkerVersionID string + ObjectName string + VersionID string + VersionPurgeStatus VersionPurgeStatusType + type ObjectTooLarge GenericError + func (e ObjectTooLarge) Error() string + type ObjectTooSmall GenericError + func (e ObjectTooSmall) Error() string + type ObjectVersion struct + IsLatest bool + VersionID string + func (o ObjectVersion) MarshalXML(e *xml.Encoder, start xml.StartElement) error + 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 ParentIsObject GenericError + func (e ParentIsObject) Error() 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 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 PoolEndpoints struct + DrivesPerSet int + Endpoints Endpoints + SetCount int + 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 PresignedGetArgs struct + BucketName string + Expiry int64 + HostName string + ObjectName string + func (args *PresignedGetArgs) ToKeyValue() KeyValueMap + type PresignedGetRep struct + UIVersion string + URL 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 RemoveBucketArgs struct + BucketName string + func (args *RemoveBucketArgs) ToKeyValue() KeyValueMap + type RemoveObjectArgs struct + BucketName string + Objects []string + func (args *RemoveObjectArgs) ToKeyValue() KeyValueMap + type ReplicateObjectInfo struct + OpType replication.Type + ResetID string + RetryCount uint32 + 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 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, n int64, status, prevStatus replication.StatusType, ...) + 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 S3Location struct + BucketName string + Encryption Encryption + Prefix string + StorageClass string + Tagging *tags.Tags + UserMetadata []MetadataEntry + type STSError struct + Code string + Description string + HTTPStatusCode int + type STSErrorCode int + const ErrSTSAccessDenied + const ErrSTSClientGrantsExpiredToken + const ErrSTSInternalError + 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 + TotalS3Canceled ServerHTTPAPIStats + TotalS3Errors ServerHTTPAPIStats + TotalS3RejectedAuth uint64 + TotalS3RejectedHeader uint64 + TotalS3RejectedInvalid uint64 + TotalS3RejectedTime uint64 + TotalS3Requests ServerHTTPAPIStats + type ServerInfoRep struct + MinioGlobalInfo map[string]interface{} + MinioMemory string + MinioPlatform string + MinioRuntime string + MinioUserInfo map[string]interface{} + MinioVersion string + UIVersion string + type ServerProperties struct + CommitID string + DeploymentID string + Region string + SQSARN []string + Uptime int64 + Version string + type ServerSystemConfig struct + MinioEndpoints EndpointServerPools + MinioPlatform string + MinioRuntime string + func (s1 ServerSystemConfig) Diff(s2 ServerSystemConfig) error + type SetAuthArgs struct + CurrentAccessKey string + CurrentSecretKey string + NewAccessKey string + NewSecretKey string + func (args *SetAuthArgs) ToKeyValue() KeyValueMap + type SetAuthReply struct + PeerErrMsgs map[string]string + Token string + UIVersion string + type SetBucketPolicyWebArgs struct + BucketName string + Policy string + Prefix string + func (args *SetBucketPolicyWebArgs) ToKeyValue() KeyValueMap + 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 SlowDown struct + func (e SlowDown) Error() string + type StartProfilingResult struct + Error string + NodeName string + Success bool + type StatInfo struct + ModTime time.Time + Size int64 + func (z *StatInfo) DecodeMsg(dc *msgp.Reader) (err error) + func (z *StatInfo) UnmarshalMsg(bts []byte) (o []byte, 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) + type StorageAPI interface + AppendFile func(ctx context.Context, volume string, path string, buf []byte) (err error) + CheckFile func(ctx context.Context, volume string, path string) (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 []FileInfo) []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) + 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 StorageInfoRep struct + UIVersion string + Used uint64 + type StringMap map[string]string + func (s StringMap) MarshalXML(e *xml.Encoder, start xml.StartElement) error + type TargetClient struct + Bucket string + StorageClass string + 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) 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) Reset() + func (config *TierConfigMgr) Save(ctx context.Context, objAPI ObjectLayer) 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 ToKeyValuer interface + ToKeyValue func() KeyValueMap + 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 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 URLTokenReply struct + Token string + UIVersion string + 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 (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 WebBucketInfo struct + CreationDate time.Time + Name string + type WebGenericArgs struct + func (args *WebGenericArgs) ToKeyValue() KeyValueMap + type WebGenericRep struct + UIVersion string + type WebIdentityResult struct + AssumedRoleUser AssumedRoleUser + Audience string + Credentials auth.Credentials + PackedPolicySize int + Provider string + SubjectFromWebIdentityToken string + type WebObjectInfo struct + ContentType string + Key string + LastModified time.Time + Size int64