Documentation ¶
Overview ¶
Package cmd This file implements helper functions to validate AWS Signature Version '4' authorization header.
This package provides comprehensive helpers for following signature types. - Based on Authorization header. - Based on Query parameters. - Based on Form POST policy.
Package cmd This file implements helper functions to validate Streaming AWS Signature Version '4' authorization header.
Index ¶
- Constants
- Variables
- func AnonErrToObjectErr(statusCode int, params ...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 ComputeCompleteMultipartMD5(parts []CompletePart) string
- func CreateEndpoints(serverAddr string, foundLocal bool, args ...[]string) (Endpoints, SetupType, error)
- func DecryptBlocksRequestR(inputReader io.Reader, h http.Header, offset, length int64, seqNumber uint32, ...) (io.Reader, error)
- func DecryptCopyRequest(client io.Writer, r *http.Request, bucket, object string, ...) (io.WriteCloser, error)
- func DecryptCopyRequestR(client io.Reader, h http.Header, bucket, object string, seqNumber uint32, ...) (io.Reader, error)
- func DecryptObjectInfo(info *ObjectInfo, headers http.Header) (encrypted bool, err error)
- func DecryptRequest(client io.Writer, r *http.Request, bucket, object string, ...) (io.WriteCloser, error)
- func DecryptRequestWithSequenceNumber(client io.Writer, r *http.Request, bucket, object string, seqNumber uint32, ...) (io.WriteCloser, error)
- func DecryptRequestWithSequenceNumberR(client io.Reader, h http.Header, bucket, object string, seqNumber uint32, ...) (io.Reader, error)
- func DownloadReleaseData(timeout time.Duration, mode string) (data string, err error)
- func EncryptRequest(content io.Reader, r *http.Request, bucket, object string, ...) (reader io.Reader, objEncKey []byte, err error)
- func ErrorRespToObjectError(err error, params ...string) error
- func Fallocate(fd int, offset int64, len int64) error
- func FromMinioClientMetadata(metadata map[string][]string) map[string]string
- func GenETag() string
- func GetAllSets(customSetDriveCount uint64, args ...string) ([][]string, error)
- func GetCurrentReleaseTime() (releaseTime time.Time, err error)
- func GetLocalPeer(endpointZones EndpointZones) (localPeer string)
- func GetRemotePeers(endpointZones EndpointZones) []string
- 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, clnt *http.Client, urlStr 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 IsServerResolvable(endpoint Endpoint) error
- 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 Main(args []string)
- func NewCustomHTTPTransport() *http.Transport
- 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 Save(configFile string, data interface{}) error
- func StartGateway(ctx *cli.Context, gw Gateway)
- 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) trace.Info
- func UTCNow() time.Time
- func UTCNowNTP() (time.Time, error)
- func ValidateGatewayArguments(serverAddr, endpointAddr string) error
- type APIError
- type APIErrorCode
- type APIErrorResponse
- type AdminError
- type AllAccessDisabled
- type AssumeRoleResponse
- type AssumeRoleResult
- type AssumeRoleWithClientGrantsResponse
- type AssumeRoleWithLDAPResponse
- type AssumeRoleWithWebIdentityResponse
- type AssumedRoleUser
- type BackendDown
- type BackendType
- type BgLifecycleOpsStatus
- type BgOpsStatus
- type BitrotAlgorithm
- type BitrotVerifier
- type Bucket
- type BucketAccessPolicy
- type BucketAlreadyExists
- type BucketAlreadyOwnedByYou
- type BucketExists
- type BucketInfo
- type BucketLifecycleNotFound
- type BucketNameInvalid
- type BucketNotEmpty
- type BucketNotFound
- type BucketObjectLockConfig
- type BucketPolicyNotFound
- type CacheChecksumInfoV1
- type CacheObjectLayer
- type CacheStats
- type CacheStatusType
- type CacheStorageInfo
- type CheckCopyPreconditionFn
- type ChecksumInfo
- type ClientGrantsResult
- type CommonPrefix
- type CompleteMultipartUpload
- type CompleteMultipartUploadResponse
- type CompletePart
- type CompletedParts
- type ConfigDir
- type ConfigSys
- type ConnStats
- type ConsoleLogger
- type CopyObjectPartResponse
- type CopyObjectResponse
- type DataUsageInfo
- type DecryptBlocksReader
- type DefaultRetention
- type DeleteError
- type DeleteFileBulkErrsResp
- type DeleteObjectsRequest
- type DeleteObjectsResponse
- type DiscoveryDocResp
- type DiskInfo
- type DownloadZipArgs
- type Endpoint
- type EndpointType
- type EndpointZones
- type Endpoints
- type Erasure
- func (e Erasure) Decode(ctx context.Context, writer io.Writer, readers []io.ReaderAt, ...) 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) Heal(ctx context.Context, readers []io.ReaderAt, writers []io.Writer, size int64) error
- func (e *Erasure) ShardFileSize(totalLength int64) int64
- func (e *Erasure) ShardFileTillOffset(startOffset, length, totalLength int64) int64
- func (e *Erasure) ShardSize() int64
- type ErasureInfo
- type FSChecksumInfoV1
- type FSObjects
- func (fs *FSObjects) AbortMultipartUpload(ctx context.Context, bucket, object, uploadID string) error
- 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, e error)
- func (fs *FSObjects) CopyObjectPart(ctx context.Context, ...) (pi PartInfo, e error)
- func (fs *FSObjects) DeleteBucket(ctx context.Context, bucket string) error
- func (fs *FSObjects) DeleteBucketLifecycle(ctx context.Context, bucket string) error
- func (fs *FSObjects) DeleteBucketPolicy(ctx context.Context, bucket string) error
- func (fs *FSObjects) DeleteObject(ctx context.Context, bucket, object string) error
- func (fs *FSObjects) DeleteObjects(ctx context.Context, bucket string, objects []string) ([]error, error)
- func (fs *FSObjects) GetBucketInfo(ctx context.Context, bucket string) (bi BucketInfo, e error)
- func (fs *FSObjects) GetBucketLifecycle(ctx context.Context, bucket string) (*lifecycle.Lifecycle, error)
- func (fs *FSObjects) GetBucketPolicy(ctx context.Context, bucket string) (*policy.Policy, error)
- func (fs *FSObjects) GetMetrics(ctx context.Context) (*Metrics, error)
- func (fs *FSObjects) GetObject(ctx context.Context, bucket, object string, offset int64, length int64, ...) (err 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) HealBucket(ctx context.Context, bucket string, dryRun, remove bool) (madmin.HealResultItem, error)
- func (fs *FSObjects) HealFormat(ctx context.Context, dryRun bool) (madmin.HealResultItem, error)
- func (fs *FSObjects) HealObject(ctx context.Context, bucket, object string, dryRun, remove bool, ...) (res madmin.HealResultItem, err error)
- func (fs *FSObjects) HealObjects(ctx context.Context, bucket, prefix string, fn func(string, string) error) (e error)
- func (fs *FSObjects) IsCompressionSupported() bool
- func (fs *FSObjects) IsEncryptionSupported() bool
- func (fs *FSObjects) IsListenBucketSupported() bool
- func (fs *FSObjects) IsNotificationSupported() bool
- func (fs *FSObjects) IsReady(_ context.Context) bool
- func (fs *FSObjects) ListBuckets(ctx context.Context) ([]BucketInfo, error)
- func (fs *FSObjects) ListBucketsHeal(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) ListObjects(ctx context.Context, bucket, prefix, marker, delimiter string, maxKeys int) (loi ListObjectsInfo, e error)
- func (fs *FSObjects) ListObjectsHeal(ctx context.Context, bucket, prefix, marker, delimiter string, maxKeys int) (result ListObjectsInfo, err error)
- func (fs *FSObjects) ListObjectsV2(ctx context.Context, bucket, prefix, continuationToken, delimiter string, ...) (result ListObjectsV2Info, err error)
- func (fs *FSObjects) MakeBucketWithLocation(ctx context.Context, bucket, location string) error
- func (fs *FSObjects) NewMultipartUpload(ctx context.Context, bucket, object string, opts ObjectOptions) (string, error)
- func (fs *FSObjects) NewNSLock(ctx context.Context, bucket string, object string) RWLocker
- func (fs *FSObjects) PutObject(ctx context.Context, bucket string, object string, r *PutObjReader, ...) (objInfo ObjectInfo, retErr error)
- func (fs *FSObjects) PutObjectPart(ctx context.Context, bucket, object, uploadID string, partID int, ...) (pi PartInfo, e error)
- func (fs *FSObjects) ReloadFormat(ctx context.Context, dryRun bool) error
- func (fs *FSObjects) SetBucketLifecycle(ctx context.Context, bucket string, lifecycle *lifecycle.Lifecycle) error
- func (fs *FSObjects) SetBucketPolicy(ctx context.Context, bucket string, policy *policy.Policy) error
- func (fs *FSObjects) Shutdown(ctx context.Context) error
- func (fs *FSObjects) StorageInfo(ctx context.Context) StorageInfo
- type FileInfo
- type FileInfoCh
- type FileLogger
- type FilesInfo
- type Gateway
- type GatewayLocker
- type GatewayUnsupported
- func (a GatewayUnsupported) AbortMultipartUpload(ctx context.Context, bucket string, object string, uploadID string) error
- 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) 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) GetMetrics(ctx context.Context) (*Metrics, error)
- func (a GatewayUnsupported) HealBucket(ctx context.Context, bucket string, dryRun, remove bool) (madmin.HealResultItem, error)
- func (a GatewayUnsupported) HealFormat(ctx context.Context, dryRun bool) (madmin.HealResultItem, error)
- func (a GatewayUnsupported) HealObject(ctx context.Context, bucket, object string, dryRun, remove bool, ...) (h madmin.HealResultItem, e error)
- func (a GatewayUnsupported) HealObjects(ctx context.Context, bucket, prefix string, fn func(string, string) error) (e error)
- func (a GatewayUnsupported) IsCompressionSupported() bool
- func (a GatewayUnsupported) IsEncryptionSupported() bool
- func (a GatewayUnsupported) IsListenBucketSupported() bool
- func (a GatewayUnsupported) IsNotificationSupported() bool
- func (a GatewayUnsupported) IsReady(_ context.Context) bool
- func (a GatewayUnsupported) ListBucketsHeal(ctx context.Context) (buckets []BucketInfo, err error)
- 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) ListObjectsHeal(ctx context.Context, bucket, prefix, marker, delimiter string, maxKeys int) (result ListObjectsInfo, err error)
- func (a GatewayUnsupported) ListObjectsV2(ctx context.Context, bucket, prefix, continuationToken, delimiter string, ...) (result ListObjectsV2Info, err error)
- func (a GatewayUnsupported) NewMultipartUpload(ctx context.Context, bucket string, object string, opts ObjectOptions) (uploadID string, err error)
- func (a GatewayUnsupported) NewNSLock(ctx context.Context, bucket string, object string) RWLocker
- func (a GatewayUnsupported) PutObjectPart(ctx context.Context, bucket string, object string, uploadID string, partID int, ...) (pi PartInfo, err error)
- func (a GatewayUnsupported) ReloadFormat(ctx context.Context, dryRun bool) 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
- type GenerateAuthReply
- type GenericError
- type GetBucketPolicyArgs
- type GetBucketPolicyRep
- type GetLocksResp
- type GetObjectInfoFn
- type GetObjectReader
- type GroupInfo
- type HTTPAPIStats
- type HTTPConsoleLoggerSys
- func (sys *HTTPConsoleLoggerSys) HasLogListeners() bool
- func (sys *HTTPConsoleLoggerSys) Send(e interface{}, logKind string) error
- func (sys *HTTPConsoleLoggerSys) SetNodeName(endpointZones EndpointZones)
- func (sys *HTTPConsoleLoggerSys) Subscribe(subCh chan interface{}, doneCh chan struct{}, node string, last int, ...)
- type HTTPRangeSpec
- type HTTPStats
- type HandlerFunc
- type Help
- type IAMEtcdStore
- type IAMObjectStore
- type IAMStorageAPI
- type IAMSys
- func (sys *IAMSys) AddUsersToGroup(group string, members []string) error
- func (sys *IAMSys) DeletePolicy(policyName string) error
- func (sys *IAMSys) DeleteUser(accessKey string) error
- func (sys *IAMSys) GetGroupDescription(group string) (gd madmin.GroupDesc, err 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) ([]byte, error)
- func (sys *IAMSys) Init(objAPI ObjectLayer) error
- func (sys *IAMSys) IsAllowed(args iampolicy.Args) bool
- func (sys *IAMSys) IsAllowedSTS(args iampolicy.Args) bool
- func (sys *IAMSys) IsTempUser(name string) (bool, error)
- func (sys *IAMSys) ListGroups() (r []string, err error)
- func (sys *IAMSys) ListPolicies() (map[string][]byte, error)
- func (sys *IAMSys) ListUsers() (map[string]madmin.UserInfo, error)
- func (sys *IAMSys) Load() 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) LoadUser(objAPI ObjectLayer, accessKey string, isSTS bool) error
- func (sys *IAMSys) PolicyDBGet(name string, isGroup bool) ([]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) SetUser(accessKey string, uinfo madmin.UserInfo) error
- func (sys *IAMSys) SetUserSecretKey(accessKey string, secretKey string) error
- func (sys *IAMSys) SetUserStatus(accessKey string, status madmin.AccountStatus) error
- type IncompleteBody
- type InitiateMultipartUploadResponse
- type Initiator
- type InsufficientReadQuorum
- type InsufficientWriteQuorum
- type InvalidETag
- type InvalidMarkerPrefixCombination
- type InvalidPart
- type InvalidRange
- type InvalidUploadID
- type InvalidUploadIDKeyCombination
- type KeyValueMap
- 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) 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) Username() string
- type LDAPIdentityResult
- type LifecycleSys
- type ListAllBucketPoliciesArgs
- type ListAllBucketPoliciesRep
- type ListBucketsRep
- type ListBucketsResponse
- type ListDirFunc
- type ListMultipartUploadsResponse
- type ListMultipartsInfo
- type ListObjectsArgs
- type ListObjectsInfo
- type ListObjectsRep
- type ListObjectsResponse
- type ListObjectsV2Info
- type ListObjectsV2Response
- type ListPartsInfo
- type ListPartsResponse
- type ListVersionsResponse
- type LocationResponse
- type LockType
- type LoginArgs
- type LoginRep
- type LoginSTSArgs
- type LoginSTSRep
- type MakeBucketArgs
- type MalformedUploadID
- type MappedPolicy
- type MergeWalkPool
- type Metrics
- type MultipartInfo
- type NotImplemented
- type NotificationGroup
- type NotificationPeerErr
- type NotificationSys
- func (sys *NotificationSys) AddRemoteTarget(bucketName string, target event.Target, rulesMap event.RulesMap) error
- func (sys *NotificationSys) AddRulesMap(bucketName string, rulesMap event.RulesMap)
- func (sys *NotificationSys) BackgroundHealStatus() []madmin.BgHealState
- func (sys *NotificationSys) BackgroundOpsStatus() []BgOpsStatus
- func (sys *NotificationSys) CPUInfo() []madmin.ServerCPUHardwareInfo
- func (sys *NotificationSys) CPULoadInfo() []ServerCPULoadInfo
- func (sys *NotificationSys) CollectNetPerfInfo(size int64) map[string][]ServerNetReadPerfInfo
- func (sys *NotificationSys) ConfiguredTargetIDs() []event.TargetID
- func (sys *NotificationSys) DeleteBucket(ctx context.Context, bucketName string)
- func (sys *NotificationSys) DeletePolicy(policyName string) []NotificationPeerErr
- func (sys *NotificationSys) DeleteUser(accessKey string) []NotificationPeerErr
- func (sys *NotificationSys) DownloadProfilingData(ctx context.Context, writer io.Writer) bool
- func (sys *NotificationSys) DrivePerfInfo(size int64) []madmin.ServerDrivesPerfInfo
- func (sys *NotificationSys) GetARNList() []string
- func (sys *NotificationSys) GetLocks(ctx context.Context) []*PeerLocks
- func (sys *NotificationSys) Init(buckets []BucketInfo, objAPI ObjectLayer) error
- 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) LoadUser(accessKey string, temp bool) []NotificationPeerErr
- func (sys *NotificationSys) LoadUsers() []NotificationPeerErr
- func (sys *NotificationSys) MemUsageInfo() []ServerMemUsageInfo
- func (sys *NotificationSys) NetReadPerfInfo(size int64) []ServerNetReadPerfInfo
- func (sys *NotificationSys) NetworkInfo() []madmin.ServerNetworkHardwareInfo
- func (sys *NotificationSys) PutBucketNotification(ctx context.Context, bucketName string, rulesMap event.RulesMap)
- func (sys *NotificationSys) PutBucketObjectLockConfig(ctx context.Context, bucketName string, retention Retention)
- func (sys *NotificationSys) ReloadFormat(dryRun bool) []NotificationPeerErr
- func (sys *NotificationSys) RemoteTargetExist(bucketName string, targetID event.TargetID) bool
- func (sys *NotificationSys) RemoveAllRemoteTargets()
- func (sys *NotificationSys) RemoveBucketLifecycle(ctx context.Context, bucketName string)
- func (sys *NotificationSys) RemoveBucketObjectLockConfig(ctx context.Context, bucketName string)
- func (sys *NotificationSys) RemoveBucketPolicy(ctx context.Context, bucketName string)
- func (sys *NotificationSys) RemoveNotification(bucketName string)
- func (sys *NotificationSys) RemoveRemoteTarget(bucketName string, targetID event.TargetID)
- func (sys *NotificationSys) RemoveRulesMap(bucketName string, rulesMap event.RulesMap)
- func (sys *NotificationSys) Send(args eventArgs) []event.TargetIDErr
- func (sys *NotificationSys) ServerInfo() []madmin.ServerProperties
- func (sys *NotificationSys) ServerUpdate(updateURL, sha256Hex string, latestReleaseTime time.Time) []NotificationPeerErr
- func (sys *NotificationSys) SetBucketLifecycle(ctx context.Context, bucketName string, bucketLifecycle *lifecycle.Lifecycle)
- func (sys *NotificationSys) SetBucketPolicy(ctx context.Context, bucketName string, bucketPolicy *policy.Policy)
- func (sys *NotificationSys) SignalService(sig serviceSignal) []NotificationPeerErr
- func (sys *NotificationSys) StartProfiling(profiler string) []NotificationPeerErr
- type ObjReaderFn
- type Object
- type ObjectAlreadyExists
- type ObjectExistsAsDirectory
- type ObjectIdentifier
- type ObjectInfo
- func (o *ObjectInfo) DecryptedSize() (int64, error)
- func (o *ObjectInfo) EncryptedSize() int64
- func (o ObjectInfo) GetActualSize() int64
- func (o *ObjectInfo) GetDecryptedRange(rs *HTTPRangeSpec) (encOff, encLength, skipLen int64, seqNumber uint32, partStart int, err error)
- func (o ObjectInfo) IsCacheable() bool
- func (o ObjectInfo) IsCompressed() bool
- func (o ObjectInfo) IsCompressedOK() (bool, error)
- type ObjectLayer
- type ObjectLockConfig
- type ObjectNameInvalid
- type ObjectNamePrefixAsSlash
- type ObjectNameTooLong
- type ObjectNotFound
- type ObjectOptions
- type ObjectPartInfo
- type ObjectRetention
- type ObjectTooLarge
- type ObjectTooSmall
- type ObjectVersion
- type OperationTimedOut
- type Owner
- type ParentIsObject
- type Part
- type PartInfo
- type PartTooBig
- type PartTooSmall
- type PeerLocks
- type PeerRESTClientTarget
- func (target *PeerRESTClientTarget) Close() error
- func (target *PeerRESTClientTarget) ID() event.TargetID
- func (target *PeerRESTClientTarget) IsActive() (bool, error)
- func (target *PeerRESTClientTarget) Save(eventData event.Event) error
- func (target *PeerRESTClientTarget) Send(eventKey string) error
- type PolicySys
- type PostPolicyForm
- type PostResponse
- type PreConditionFailed
- type PrefixAccessDenied
- type PresignedGetArgs
- type PresignedGetRep
- type PutObjReader
- type RWLocker
- type RangeInfo
- type RemoveBucketArgs
- type RemoveObjectArgs
- type RequestStats
- type Retention
- type RetentionDate
- type RetentionMode
- type STSError
- type STSErrorCode
- type STSErrorResponse
- type SealMD5CurrFn
- type ServerCPULoadInfo
- type ServerConnStats
- type ServerHTTPAPIStats
- type ServerHTTPStats
- type ServerInfo
- type ServerInfoData
- type ServerInfoRep
- type ServerMemUsageInfo
- type ServerNetReadPerfInfo
- type ServerProperties
- type ServerSystemConfig
- type SetAuthArgs
- type SetAuthReply
- type SetBucketPolicyWebArgs
- type SetupType
- type SignatureDoesNotMatch
- type SlowDown
- type StartProfilingResult
- type StatInfo
- type StorageAPI
- type StorageErr
- type StorageFull
- type StorageInfo
- type StorageInfoRep
- type StringMap
- type ToKeyValuer
- type TreeWalkPool
- type TreeWalkResult
- type URLTokenReply
- type UnsupportedDelimiter
- type UnsupportedMetadata
- type Upload
- type UserIdentity
- type UsersSysType
- type VerifyFileResp
- type VolInfo
- type WebBucketInfo
- type WebGenericArgs
- type WebGenericRep
- type WebIdentityResult
- type WebObjectInfo
- type ZoneEndpoints
Constants ¶
const ( AdminUpdateUnexpectedFailure = "XMinioAdminUpdateUnexpectedFailure" AdminUpdateURLNotReachable = "XMinioAdminUpdateURLNotReachable" AdminUpdateApplyFailure = "XMinioAdminUpdateApplyFailure" )
Admin API errors
const ( GET allowedMethod = http.MethodGet PUT allowedMethod = http.MethodPut HEAD allowedMethod = http.MethodHead POST allowedMethod = http.MethodPost DELETE allowedMethod = http.MethodDelete )
Define strings
const ( // SSECustomerKeySize is the size of valid client provided encryption keys in bytes. // Currently AWS supports only AES256. So the SSE-C key size is fixed to 32 bytes. SSECustomerKeySize = 32 // SSEIVSize is the size of the IV data SSEIVSize = 32 // 32 bytes // SSEDAREPackageBlockSize - SSE dare package block size. SSEDAREPackageBlockSize = 64 * 1024 // 64KiB bytes // SSEDAREPackageMetaSize - SSE dare package meta padding bytes. SSEDAREPackageMetaSize = 32 // 32 bytes )
const ( // GlobalMultipartExpiry - Expiry duration after which the multipart uploads are deemed stale. GlobalMultipartExpiry = time.Hour * 24 * 3 // 3 days. // GlobalMultipartCleanupInterval - Cleanup interval when the stale multipart cleanup is initiated. GlobalMultipartCleanupInterval = time.Hour * 24 // 24 hrs. // GlobalServiceExecutionInterval - Executes the Lifecycle events. GlobalServiceExecutionInterval = time.Hour * 24 // 24 hrs. )
const (
DefaultBitrotAlgorithm = HighwayHash256S
)
DefaultBitrotAlgorithm is the default algorithm used for bitrot protection.
const DefaultSkewTime = 15 * time.Minute
DefaultSkewTime - skew time is 15 minutes between minio peers.
const (
// Disabled means the lifecycle rule is inactive
Disabled = "Disabled"
)
const (
EnvPrometheusAuthType = "MINIO_PROMETHEUS_AUTH_TYPE"
)
Standard env prometheus auth type
const GatewayMinioSysTmp = "minio.sys.tmp/"
GatewayMinioSysTmp prefix is used in Azure/GCS gateway for save metadata sent by Initialize Multipart Upload API.
const MaxJitter = 1.0
MaxJitter will randomize over the full exponential backoff time
const NoJitter = 0.0
NoJitter disables the use of jitter for randomizing the exponential backoff time
const ReservedMetadataPrefix = "X-Minio-Internal-"
ReservedMetadataPrefix is the prefix of a metadata key which is reserved and for internal use only.
const ( // SSECacheEncrypted is the metadata key indicating that the object // is a cache entry encrypted with cache KMS master key in globalCacheKMS. SSECacheEncrypted = "X-Minio-Internal-Encrypted-Cache" )
const SlashSeparator = "/"
SlashSeparator - slash separator.
Variables ¶
var ( // GOPATH - GOPATH value at the time of build. GOPATH = "" // GOROOT - GOROOT value at the time of build. GOROOT = "" // Version - version time.RFC3339. Version = goGetTag // ReleaseTag - release tag in TAG.%Y-%m-%dT%H-%M-%SZ. ReleaseTag = goGetTag // CommitID - latest commit id. CommitID = goGetTag // ShortCommitID - first 12 characters from CommitID. ShortCommitID = CommitID[:12] )
DO NOT EDIT THIS FILE DIRECTLY. These are build-time constants set through ‘buildscripts/gen-ldflags.go’.
var ( // CanonicalizeETag provides canonicalizeETag function alias. CanonicalizeETag = canonicalizeETag // MustGetUUID function alias. MustGetUUID = mustGetUUID // CleanMetadataKeys provides cleanMetadataKeys function alias. CleanMetadataKeys = cleanMetadataKeys // PathJoin function alias. PathJoin = pathJoin // ListObjects function alias. ListObjects = listObjects // FilterMatchingPrefix function alias. FilterMatchingPrefix = filterMatchingPrefix // IsStringEqual is string equal. IsStringEqual = isStringEqual )
var ( // GlobalKMS initialized KMS configuration GlobalKMS crypto.KMS // GlobalGatewaySSE sse options GlobalGatewaySSE gatewaySSE )
var ErrSkipFiles = errors.New("fastwalk: skip remaining files in directory")
ErrSkipFiles is a used as a return value from WalkFuncs to indicate that the callback should not be called for any other files in the current directory. Child directories will still be traversed.
var ErrTraverseLink = errors.New("fastwalk: traverse symlink, assuming target is a directory")
ErrTraverseLink is used as a return value from WalkFuncs to indicate that the symlink named in the call may be traversed.
var GlobalFlags = []cli.Flag{ cli.StringFlag{ Name: "config-dir, C", Value: defaultConfigDir.Get(), Usage: "[DEPRECATED] path to legacy configuration directory", }, cli.StringFlag{ Name: "certs-dir, S", Value: defaultCertsDir.Get(), Usage: "path to certs directory", }, cli.BoolFlag{ Name: "quiet", Usage: "disable startup information", }, cli.BoolFlag{ Name: "anonymous", Usage: "hide sensitive information from logging", }, cli.BoolFlag{ Name: "json", Usage: "output server logs and startup information in json format", }, cli.BoolFlag{ Name: "compat", Usage: "enable strict S3 compatibility by turning off certain performance optimizations", }, }
GlobalFlags - global flags for minio.
var GlobalServiceDoneCh chan struct{}
GlobalServiceDoneCh - Global service done channel.
var ObjectsHistogramIntervals = []objectHistogramInterval{
{"LESS_THAN_1024_B", -1, 1024 - 1},
{"BETWEEN_1024_B_AND_1_MB", 1024, 1024*1024 - 1},
{"BETWEEN_1_MB_AND_10_MB", 1024 * 1024, 1024*1024*10 - 1},
{"BETWEEN_10_MB_AND_64_MB", 1024 * 1024 * 10, 1024*1024*64 - 1},
{"BETWEEN_64_MB_AND_128_MB", 1024 * 1024 * 64, 1024*1024*128 - 1},
{"BETWEEN_128_MB_AND_512_MB", 1024 * 1024 * 128, 1024*1024*512 - 1},
{"GREATER_THAN_512_MB", 1024 * 1024 * 512, -1},
}
ObjectsHistogramIntervals is the list of all intervals of object sizes to be included in objects histogram.
var ServerFlags = []cli.Flag{ cli.StringFlag{ Name: "address", Value: ":" + globalMinioDefaultPort, Usage: "bind to a specific ADDRESS:PORT, ADDRESS can be an IP or hostname", }, }
ServerFlags - server command specific flags
Functions ¶
func AnonErrToObjectErr ¶
AnonErrToObjectErr - converts standard http codes into meaningful object layer errors.
func AuthMiddleware ¶
AuthMiddleware checks if the bearer token is valid and authorized.
func BucketAccessPolicyToPolicy ¶
func BucketAccessPolicyToPolicy(policyInfo *miniogopolicy.BucketAccessPolicy) (*policy.Policy, error)
BucketAccessPolicyToPolicy - converts minio-go/policy.BucketAccessPolicy to policy.Policy.
func CheckLocalServerAddr ¶
CheckLocalServerAddr - checks if serverAddr is valid and local host.
func CleanMinioInternalMetadataKeys ¶
CleanMinioInternalMetadataKeys removes X-Amz-Meta- prefix from minio internal encryption metadata that was sent by minio gateway
func ComputeCompleteMultipartMD5 ¶
func ComputeCompleteMultipartMD5(parts []CompletePart) string
ComputeCompleteMultipartMD5 calculates MD5 ETag for complete multipart responses
func CreateEndpoints ¶
func CreateEndpoints(serverAddr string, foundLocal bool, args ...[]string) (Endpoints, SetupType, error)
CreateEndpoints - validates and creates new endpoints for given args.
func DecryptBlocksRequestR ¶
func DecryptBlocksRequestR(inputReader io.Reader, h http.Header, offset, length int64, seqNumber uint32, partStart int, oi ObjectInfo, copySource bool) ( io.Reader, error)
DecryptBlocksRequestR - same as DecryptBlocksRequest but with a reader
func DecryptCopyRequest ¶
func DecryptCopyRequest(client io.Writer, r *http.Request, bucket, object string, metadata map[string]string) (io.WriteCloser, error)
DecryptCopyRequest decrypts the object with the client provided key. It also removes the client-side-encryption metadata from the object and sets the correct headers.
func DecryptCopyRequestR ¶
func DecryptCopyRequestR(client io.Reader, h http.Header, bucket, object string, seqNumber uint32, metadata map[string]string) (io.Reader, error)
DecryptCopyRequestR - same as DecryptCopyRequest, but with a Reader
func DecryptObjectInfo ¶
func DecryptObjectInfo(info *ObjectInfo, headers http.Header) (encrypted bool, err error)
DecryptObjectInfo tries to decrypt the provided object if it is encrypted. It fails if the object is encrypted and the HTTP headers don't contain SSE-C headers or the object is not encrypted but SSE-C headers are provided. (AWS behavior) DecryptObjectInfo returns 'ErrNone' if the object is not encrypted or the decryption succeeded.
DecryptObjectInfo also returns whether the object is encrypted or not.
func DecryptRequest ¶
func DecryptRequest(client io.Writer, r *http.Request, bucket, object string, metadata map[string]string) (io.WriteCloser, error)
DecryptRequest decrypts the object with client provided key for SSE-C and SSE-S3. It also removes the encryption metadata from the object and sets the correct headers.
func DecryptRequestWithSequenceNumber ¶
func DecryptRequestWithSequenceNumber(client io.Writer, r *http.Request, bucket, object string, seqNumber uint32, metadata map[string]string) (io.WriteCloser, error)
DecryptRequestWithSequenceNumber decrypts the object with the client provided key. It also removes the client-side-encryption metadata from the object and sets the correct headers.
func DecryptRequestWithSequenceNumberR ¶
func DecryptRequestWithSequenceNumberR(client io.Reader, h http.Header, bucket, object string, seqNumber uint32, metadata map[string]string) (io.Reader, error)
DecryptRequestWithSequenceNumberR - same as DecryptRequestWithSequenceNumber but with a reader
func DownloadReleaseData ¶
DownloadReleaseData - downloads release data from minio official server.
func EncryptRequest ¶
func EncryptRequest(content io.Reader, r *http.Request, bucket, object string, metadata map[string]string) (reader io.Reader, objEncKey []byte, err error)
EncryptRequest takes the client provided content and encrypts the data with the client provided key. It also marks the object as client-side-encrypted and sets the correct headers.
func ErrorRespToObjectError ¶
ErrorRespToObjectError converts MinIO errors to minio object layer errors.
func Fallocate ¶
Fallocate uses the linux Fallocate syscall, which helps us to be sure that subsequent writes on a file just created will not fail, in addition, file allocation will be contigous on the disk
func FromMinioClientMetadata ¶
FromMinioClientMetadata converts minio metadata to map[string]string
func GetAllSets ¶
GetAllSets - parses all ellipses input arguments, expands them into corresponding list of endpoints chunked evenly in accordance with a specific set size. For example: {1...64} is divided into 4 sets each of size 16. This applies to even distributed setup syntax as well.
func GetCurrentReleaseTime ¶
GetCurrentReleaseTime - returns this process's release time. If it is official minio version, parsed version is returned else minio binary's mod time is returned.
func GetLocalPeer ¶
func GetLocalPeer(endpointZones EndpointZones) (localPeer string)
GetLocalPeer - returns local peer value, returns globalMinioAddr for FS and Erasure mode. In case of distributed server return the first element from the set of peers which indicate that they are local. There is always one entry that is local even with repeated server endpoints.
func GetRemotePeers ¶
func GetRemotePeers(endpointZones EndpointZones) []string
GetRemotePeers - get hosts information other than this minio service.
func GetVersion ¶
GetVersion gets config version from backend
func HasPrefix ¶
HasPrefix - Prefix matcher string matches prefix in a platform specific way. For example on windows since its case insensitive we are supposed to do case insensitive checks.
func HasSuffix ¶
HasSuffix - Suffix matcher string matches suffix in a platform specific way. For example on windows since its case insensitive we are supposed to do case insensitive checks.
func IsBackendOnline ¶
IsBackendOnline - verifies if the backend is reachable by performing a GET request on the URL. returns 'true' if backend is reachable.
func IsDocker ¶
func IsDocker() bool
IsDocker - returns if the environment minio is running in docker or not. The check is a simple file existence check.
https://github.com/moby/moby/blob/master/daemon/initlayer/setup_unix.go#L25
"/.dockerenv": "file",
func IsErrIgnored ¶
IsErrIgnored returns whether given error is ignored or not.
func IsKubernetes ¶
func IsKubernetes() bool
IsKubernetes returns true if minio is running in kubernetes.
func IsKubernetesReplicaSet ¶
func IsKubernetesReplicaSet() bool
IsKubernetesReplicaSet returns true if minio is running in kubernetes replica set.
func IsServerResolvable ¶
IsServerResolvable - checks if the endpoint is resolvable by sending a naked HTTP request with liveness checks.
func IsSourceBuild ¶
func IsSourceBuild() bool
IsSourceBuild - returns if this binary is a non-official build from source code.
func IsValidBucketName ¶
IsValidBucketName verifies that a bucket name is in accordance with Amazon's requirements (i.e. DNS naming conventions). It must be 3-63 characters long, and it must be a sequence of one or more labels separated by periods. Each label can contain lowercase ascii letters, decimal digits and hyphens, but must not begin or end with a hyphen. See: http://docs.aws.amazon.com/AmazonS3/latest/dev/BucketRestrictions.html
func IsValidObjectName ¶
IsValidObjectName verifies an object name in accordance with Amazon's requirements. It cannot exceed 1024 characters and must be a valid UTF8 string.
See: http://docs.aws.amazon.com/AmazonS3/latest/dev/UsingMetadata.html
You should avoid the following characters in a key name because of significant special handling for consistency across all applications.
Rejects strings with following characters.
- Backslash ("\")
additionally minio does not support object names with trailing SlashSeparator.
func IsValidObjectPrefix ¶
IsValidObjectPrefix verifies whether the prefix is a valid object name. Its valid to have a empty prefix.
func LivenessCheckHandler ¶
func LivenessCheckHandler(w http.ResponseWriter, r *http.Request)
LivenessCheckHandler -- checks if server can reach its disks internally. If not, server is considered to have failed and needs to be restarted. Liveness probes are used to detect situations where application (minio) has gone into a state where it can not recover except by being restarted.
func NewCustomHTTPTransport ¶
NewCustomHTTPTransport returns a new http configuration used while communicating with the cloud backends. This sets the value for MaxIdleConnsPerHost from 2 (go default) to 256.
func ParseGatewayEndpoint ¶
ParseGatewayEndpoint - Return endpoint.
func ParseSSECopyCustomerRequest ¶
ParseSSECopyCustomerRequest parses the SSE-C header fields of the provided request. It returns the client provided key on success.
func ParseSSECustomerHeader ¶
ParseSSECustomerHeader parses the SSE-C header fields and returns the client provided key on success.
func ParseSSECustomerRequest ¶
ParseSSECustomerRequest parses the SSE-C header fields of the provided request. It returns the client provided key on success.
func PolicyToBucketAccessPolicy ¶
func PolicyToBucketAccessPolicy(bucketPolicy *policy.Policy) (*miniogopolicy.BucketAccessPolicy, error)
PolicyToBucketAccessPolicy - converts policy.Policy to minio-go/policy.BucketAccessPolicy.
func ReadinessCheckHandler ¶
func ReadinessCheckHandler(w http.ResponseWriter, r *http.Request)
ReadinessCheckHandler -- Checks if the quorum number of disks are available. For FS - Checks if the backend disk is available For Zones - Checks if all the zones have enough read quorum
func RegisterGatewayCommand ¶
RegisterGatewayCommand registers a new command for gateway.
func StartGateway ¶
StartGateway - handler for 'minio gateway <name>'.
func StorageReader ¶
func StorageReader(storage StorageAPI, volume, path string, offset int64) io.Reader
StorageReader returns a new io.Reader which reads data to the file at the given disk, volume, path and offset.
func StorageWriter ¶
func StorageWriter(storage StorageAPI, volume, path string) io.Writer
StorageWriter returns a new io.Writer which appends data to the file at the given disk, volume and path.
func ToMinioClientCompletePart ¶
func ToMinioClientCompletePart(part CompletePart) minio.CompletePart
ToMinioClientCompletePart converts CompletePart to minio CompletePart
func ToMinioClientCompleteParts ¶
func ToMinioClientCompleteParts(parts []CompletePart) []minio.CompletePart
ToMinioClientCompleteParts converts []CompletePart to minio []CompletePart
func ToMinioClientMetadata ¶
ToMinioClientMetadata converts metadata to map[string]string
func ToMinioClientObjectInfoMetadata ¶
ToMinioClientObjectInfoMetadata convertes metadata to map[string][]string
func Trace ¶
func Trace(f http.HandlerFunc, logBody bool, w http.ResponseWriter, r *http.Request) trace.Info
Trace gets trace of http request
func UTCNowNTP ¶
UTCNowNTP - is similar in functionality to UTCNow() but only used when we do not wish to rely on system time.
func ValidateGatewayArguments ¶
ValidateGatewayArguments - Validate gateway arguments.
Types ¶
type APIErrorCode ¶
type APIErrorCode int
APIErrorCode type of error status.
const ( ErrNone APIErrorCode = iota ErrAccessDenied ErrBadDigest ErrEntityTooSmall ErrEntityTooLarge ErrPolicyTooLarge ErrIncompleteBody ErrInternalError ErrInvalidAccessKeyID ErrInvalidBucketName ErrInvalidDigest ErrInvalidRange ErrInvalidCopyPartRange ErrInvalidCopyPartRangeSource ErrInvalidMaxKeys ErrInvalidEncodingMethod ErrInvalidMaxUploads ErrInvalidMaxParts ErrInvalidPartNumberMarker ErrInvalidRequestBody ErrInvalidCopySource ErrInvalidMetadataDirective ErrInvalidCopyDest ErrInvalidPolicyDocument ErrInvalidObjectState ErrMalformedXML ErrMissingContentLength ErrMissingContentMD5 ErrMissingRequestBodyError ErrNoSuchBucket ErrNoSuchBucketPolicy ErrNoSuchBucketLifecycle ErrNoSuchKey ErrNoSuchUpload ErrNoSuchVersion ErrNotImplemented ErrPreconditionFailed ErrRequestTimeTooSkewed ErrSignatureDoesNotMatch ErrMethodNotAllowed ErrInvalidPart ErrInvalidPartOrder ErrAuthorizationHeaderMalformed ErrMalformedPOSTRequest ErrPOSTFileRequired ErrSignatureVersionNotSupported ErrBucketNotEmpty ErrAllAccessDisabled ErrMalformedPolicy ErrMissingFields ErrMissingCredTag ErrCredMalformed ErrInvalidRegion ErrInvalidService ErrInvalidRequestVersion ErrMissingSignTag ErrMissingSignHeadersTag ErrMalformedDate ErrMalformedPresignedDate ErrMalformedCredentialDate ErrMalformedCredentialRegion ErrMalformedExpires ErrNegativeExpires ErrAuthHeaderEmpty ErrExpiredPresignRequest ErrRequestNotReadyYet ErrUnsignedHeaders ErrMissingDateHeader ErrInvalidQuerySignatureAlgo ErrInvalidQueryParams ErrBucketAlreadyOwnedByYou ErrInvalidDuration ErrBucketAlreadyExists ErrMetadataTooLarge ErrUnsupportedMetadata ErrMaximumExpires ErrSlowDown ErrInvalidPrefixMarker ErrBadRequest ErrKeyTooLongError ErrInvalidBucketObjectLockConfiguration ErrObjectLockConfigurationNotAllowed ErrObjectLocked ErrInvalidRetentionDate ErrPastObjectLockRetainDate ErrUnknownWORMModeDirective ErrObjectLockInvalidHeaders // SSE-S3 related API errors ErrInvalidEncryptionMethod // Server-Side-Encryption (with Customer provided key) related API errors. ErrInsecureSSECustomerRequest ErrSSEMultipartEncrypted ErrSSEEncryptedObject ErrInvalidEncryptionParameters ErrInvalidSSECustomerAlgorithm ErrInvalidSSECustomerKey ErrMissingSSECustomerKey ErrMissingSSECustomerKeyMD5 ErrSSECustomerKeyMD5Mismatch ErrInvalidSSECustomerParameters ErrIncompatibleEncryptionMethod ErrKMSNotConfigured ErrKMSAuthFailure ErrNoAccessKey ErrInvalidToken // Bucket notification related errors. ErrEventNotification ErrARNNotification ErrRegionNotification ErrOverlappingFilterNotification ErrFilterNameInvalid ErrFilterNamePrefix ErrFilterNameSuffix ErrFilterValueInvalid ErrOverlappingConfigs ErrUnsupportedNotification // S3 extended errors. ErrContentSHA256Mismatch // MinIO extended errors. ErrReadQuorum ErrWriteQuorum ErrParentIsObject ErrStorageFull ErrRequestBodyParse ErrObjectExistsAsDirectory ErrInvalidObjectName ErrInvalidObjectNamePrefixSlash ErrInvalidResourceName ErrServerNotInitialized ErrOperationTimedOut ErrInvalidRequest // MinIO storage class error codes ErrInvalidStorageClass ErrBackendDown ErrMalformedJSON ErrAdminNoSuchUser ErrAdminNoSuchGroup ErrAdminGroupNotEmpty ErrAdminNoSuchPolicy ErrAdminInvalidArgument ErrAdminInvalidAccessKey ErrAdminInvalidSecretKey ErrAdminConfigNoQuorum ErrAdminConfigTooLarge ErrAdminConfigBadJSON ErrAdminConfigDuplicateKeys ErrAdminCredentialsMismatch ErrInsecureClientRequest ErrObjectTampered ErrHealNotImplemented ErrHealNoSuchProcess ErrHealInvalidClientToken ErrHealMissingBucket ErrHealAlreadyRunning ErrHealOverlappingPaths ErrIncorrectContinuationToken // S3 Select Errors ErrEmptyRequestBody ErrUnsupportedFunction ErrInvalidExpressionType ErrBusy ErrExpressionTooLong ErrIllegalSQLFunctionArgument ErrInvalidKeyPath ErrInvalidCompressionFormat ErrInvalidFileHeaderInfo ErrInvalidJSONType ErrInvalidQuoteFields ErrInvalidRequestParameter ErrInvalidDataType ErrInvalidTextEncoding ErrInvalidDataSource ErrInvalidTableAlias ErrMissingRequiredParameter ErrObjectSerializationConflict ErrUnsupportedSQLOperation ErrUnsupportedSQLStructure ErrUnsupportedSyntax ErrUnsupportedRangeHeader ErrLexerInvalidChar ErrLexerInvalidOperator ErrLexerInvalidLiteral ErrLexerInvalidIONLiteral ErrParseExpectedDatePart ErrParseExpectedKeyword ErrParseExpectedTokenType ErrParseExpected2TokenTypes ErrParseExpectedNumber ErrParseExpectedRightParenBuiltinFunctionCall ErrParseExpectedTypeName ErrParseExpectedWhenClause ErrParseUnsupportedToken ErrParseUnsupportedLiteralsGroupBy ErrParseExpectedMember ErrParseUnsupportedSelect ErrParseUnsupportedCase ErrParseUnsupportedCaseClause ErrParseUnsupportedAlias ErrParseUnsupportedSyntax ErrParseUnknownOperator ErrParseMissingIdentAfterAt ErrParseUnexpectedOperator ErrParseUnexpectedTerm ErrParseUnexpectedToken ErrParseUnexpectedKeyword ErrParseExpectedExpression ErrParseExpectedLeftParenAfterCast ErrParseExpectedLeftParenValueConstructor ErrParseExpectedLeftParenBuiltinFunctionCall ErrParseExpectedArgumentDelimiter ErrParseCastArity ErrParseInvalidTypeParam ErrParseEmptySelect ErrParseSelectMissingFrom ErrParseExpectedIdentForGroupName ErrParseExpectedIdentForAlias ErrParseUnsupportedCallWithStar ErrParseNonUnaryAgregateFunctionCall ErrParseMalformedJoin ErrParseExpectedIdentForAt ErrParseAsteriskIsNotAloneInSelectList ErrParseCannotMixSqbAndWildcardInSelectList ErrParseInvalidContextForWildcardInSelectList ErrIncorrectSQLFunctionArgumentType ErrValueParseFailure ErrEvaluatorInvalidArguments ErrIntegerOverflow ErrLikeInvalidInputs ErrCastFailed ErrInvalidCast ErrEvaluatorInvalidTimestampFormatPattern ErrEvaluatorInvalidTimestampFormatPatternSymbolForParsing ErrEvaluatorTimestampFormatPatternDuplicateFields ErrEvaluatorTimestampFormatPatternHourClockAmPmMismatch ErrEvaluatorUnterminatedTimestampFormatPatternToken ErrEvaluatorInvalidTimestampFormatPatternToken ErrEvaluatorInvalidTimestampFormatPatternSymbol ErrEvaluatorBindingDoesNotExist ErrMissingHeaders ErrInvalidColumnIndex ErrAdminConfigNotificationTargetsFailed ErrAdminProfilerNotEnabled ErrInvalidDecompressedSize ErrAddUserInvalidArgument ErrPostPolicyConditionInvalidFormat )
Error codes, non exhaustive list - http://docs.aws.amazon.com/AmazonS3/latest/API/ErrorResponses.html
func DecryptCopyObjectInfo ¶
func DecryptCopyObjectInfo(info *ObjectInfo, headers http.Header) (errCode APIErrorCode, encrypted bool)
DecryptCopyObjectInfo tries to decrypt the provided object if it is encrypted. It fails if the object is encrypted and the HTTP headers don't contain SSE-C headers or the object is not encrypted but SSE-C headers are provided. (AWS behavior) DecryptObjectInfo returns 'ErrNone' if the object is not encrypted or the decryption succeeded.
DecryptCopyObjectInfo also returns whether the object is encrypted or not.
type APIErrorResponse ¶
type APIErrorResponse struct { XMLName xml.Name `xml:"Error" json:"-"` Code string Message string Key string `xml:"Key,omitempty" json:"Key,omitempty"` BucketName string `xml:"BucketName,omitempty" json:"BucketName,omitempty"` Resource string Region string `xml:"Region,omitempty" json:"Region,omitempty"` RequestID string `xml:"RequestId" json:"RequestId"` HostID string `xml:"HostId" json:"HostId"` }
APIErrorResponse - error response format
type AdminError ¶
AdminError - is a generic error for all admin APIs.
func (AdminError) Error ¶
func (ae AdminError) Error() string
type AllAccessDisabled ¶
type AllAccessDisabled GenericError
AllAccessDisabled All access to this object has been disabled
func (AllAccessDisabled) Error ¶
func (e AllAccessDisabled) Error() string
Return string an error formatted as the given text.
type AssumeRoleResponse ¶
type AssumeRoleResponse struct { XMLName xml.Name `xml:"https://sts.amazonaws.com/doc/2011-06-15/ AssumeRoleResponse" json:"-"` Result AssumeRoleResult `xml:"AssumeRoleResult"` ResponseMetadata struct { RequestID string `xml:"RequestId,omitempty"` } `xml:"ResponseMetadata,omitempty"` }
AssumeRoleResponse contains the result of successful AssumeRole request.
type AssumeRoleResult ¶
type AssumeRoleResult struct { // The identifiers for the temporary security credentials that the operation // returns. AssumedRoleUser AssumedRoleUser `xml:",omitempty"` // The temporary security credentials, which include an access key ID, a secret // access key, and a security (or session) token. // // Note: The size of the security token that STS APIs return is not fixed. We // strongly recommend that you make no assumptions about the maximum size. As // of this writing, the typical size is less than 4096 bytes, but that can vary. // Also, future updates to AWS might require larger sizes. Credentials auth.Credentials `xml:",omitempty"` // A percentage value that indicates the size of the policy in packed form. // The service rejects any policy with a packed size greater than 100 percent, // which means the policy exceeded the allowed space. PackedPolicySize int `xml:",omitempty"` }
AssumeRoleResult - Contains the response to a successful AssumeRole request, including temporary credentials that can be used to make MinIO API requests.
type AssumeRoleWithClientGrantsResponse ¶
type AssumeRoleWithClientGrantsResponse struct { XMLName xml.Name `xml:"https://sts.amazonaws.com/doc/2011-06-15/ AssumeRoleWithClientGrantsResponse" json:"-"` Result ClientGrantsResult `xml:"AssumeRoleWithClientGrantsResult"` ResponseMetadata struct { RequestID string `xml:"RequestId,omitempty"` } `xml:"ResponseMetadata,omitempty"` }
AssumeRoleWithClientGrantsResponse contains the result of successful AssumeRoleWithClientGrants request.
type AssumeRoleWithLDAPResponse ¶
type AssumeRoleWithLDAPResponse struct { XMLName xml.Name `xml:"https://sts.amazonaws.com/doc/2011-06-15/ AssumeRoleWithLDAPIdentityResponse" json:"-"` Result LDAPIdentityResult `xml:"AssumeRoleWithLDAPIdentityResult"` ResponseMetadata struct { RequestID string `xml:"RequestId,omitempty"` } `xml:"ResponseMetadata,omitempty"` }
AssumeRoleWithLDAPResponse contains the result of successful AssumeRoleWithLDAPIdentity request
type AssumeRoleWithWebIdentityResponse ¶
type AssumeRoleWithWebIdentityResponse struct { XMLName xml.Name `xml:"https://sts.amazonaws.com/doc/2011-06-15/ AssumeRoleWithWebIdentityResponse" json:"-"` Result WebIdentityResult `xml:"AssumeRoleWithWebIdentityResult"` ResponseMetadata struct { RequestID string `xml:"RequestId,omitempty"` } `xml:"ResponseMetadata,omitempty"` }
AssumeRoleWithWebIdentityResponse contains the result of successful AssumeRoleWithWebIdentity request.
type AssumedRoleUser ¶
type AssumedRoleUser struct { // The ARN of the temporary security credentials that are returned from the // AssumeRole action. For more information about ARNs and how to use them in // policies, see IAM Identifiers (http://docs.aws.amazon.com/IAM/latest/UserGuide/reference_identifiers.html) // in Using IAM. // // Arn is a required field Arn string // A unique identifier that contains the role ID and the role session name of // the role that is being assumed. The role ID is generated by AWS when the // role is created. // // AssumedRoleId is a required field AssumedRoleID string `xml:"AssumeRoleId"` }
AssumedRoleUser - The identifiers for the temporary security credentials that the operation returns. Please also see https://docs.aws.amazon.com/goto/WebAPI/sts-2011-06-15/AssumedRoleUser
type BackendDown ¶
type BackendDown struct{}
BackendDown is returned for network errors or if the gateway's backend is down.
func (BackendDown) Error ¶
func (e BackendDown) Error() string
type BackendType ¶
type BackendType int
BackendType - represents different backend types.
const ( Unknown BackendType = iota // Filesystem backend. BackendFS // Multi disk BackendErasure (single, distributed) backend. BackendErasure // Gateway backend. BackendGateway )
Enum for different backend types.
type BgLifecycleOpsStatus ¶
BgLifecycleOpsStatus describes the status of the background lifecycle operations
type BgOpsStatus ¶
type BgOpsStatus struct {
LifecycleOps BgLifecycleOpsStatus
}
BgOpsStatus describes the status of all operations performed in background such as auto-healing and lifecycle. Notice: We need to increase peer REST API version when adding new fields to this struct.
type BitrotAlgorithm ¶
type BitrotAlgorithm uint
BitrotAlgorithm specifies a algorithm used for bitrot protection.
const ( // SHA256 represents the SHA-256 hash function SHA256 BitrotAlgorithm = 1 + iota // HighwayHash256 represents the HighwayHash-256 hash function HighwayHash256 // HighwayHash256S represents the Streaming HighwayHash-256 hash function HighwayHash256S // BLAKE2b512 represents the BLAKE2b-512 hash function BLAKE2b512 )
func BitrotAlgorithmFromString ¶
func BitrotAlgorithmFromString(s string) (a BitrotAlgorithm)
BitrotAlgorithmFromString returns a bitrot algorithm from the given string representation. It returns 0 if the string representation does not match any supported algorithm. The zero value of a bitrot algorithm is never supported.
func (BitrotAlgorithm) Available ¶
func (a BitrotAlgorithm) Available() bool
Available reports whether the given algorithm is available.
func (BitrotAlgorithm) New ¶
func (a BitrotAlgorithm) New() hash.Hash
New returns a new hash.Hash calculating the given bitrot algorithm.
func (BitrotAlgorithm) String ¶
func (a BitrotAlgorithm) String() string
String returns the string identifier for a given bitrot algorithm. If the algorithm is not supported String panics.
type BitrotVerifier ¶
type BitrotVerifier struct {
// contains filtered or unexported fields
}
BitrotVerifier can be used to verify protected data.
func NewBitrotVerifier ¶
func NewBitrotVerifier(algorithm BitrotAlgorithm, checksum []byte) *BitrotVerifier
NewBitrotVerifier returns a new BitrotVerifier implementing the given algorithm.
type Bucket ¶
type Bucket struct { Name string CreationDate string // time string of format "2006-01-02T15:04:05.000Z" }
Bucket container for bucket metadata
type BucketAccessPolicy ¶
type BucketAccessPolicy struct { Bucket string `json:"bucket"` Prefix string `json:"prefix"` Policy miniogopolicy.BucketPolicy `json:"policy"` }
BucketAccessPolicy - Collection of canned bucket policy at a given prefix.
type BucketAlreadyExists ¶
type BucketAlreadyExists GenericError
BucketAlreadyExists the requested bucket name is not available.
func (BucketAlreadyExists) Error ¶
func (e BucketAlreadyExists) Error() string
type BucketAlreadyOwnedByYou ¶
type BucketAlreadyOwnedByYou GenericError
BucketAlreadyOwnedByYou already owned by you.
func (BucketAlreadyOwnedByYou) Error ¶
func (e BucketAlreadyOwnedByYou) Error() string
type BucketExists ¶
type BucketExists GenericError
BucketExists bucket exists.
func (BucketExists) Error ¶
func (e BucketExists) Error() string
type BucketInfo ¶
type BucketInfo struct { // Name of the bucket. Name string // Date and time when the bucket was created. Created time.Time }
BucketInfo - represents bucket metadata.
type BucketLifecycleNotFound ¶
type BucketLifecycleNotFound GenericError
BucketLifecycleNotFound - no bucket lifecycle found.
func (BucketLifecycleNotFound) Error ¶
func (e BucketLifecycleNotFound) Error() string
type BucketNameInvalid ¶
type BucketNameInvalid GenericError
BucketNameInvalid - bucketname provided is invalid.
func (BucketNameInvalid) Error ¶
func (e BucketNameInvalid) Error() string
Return string an error formatted as the given text.
type BucketNotEmpty ¶
type BucketNotEmpty GenericError
BucketNotEmpty bucket is not empty.
func (BucketNotEmpty) Error ¶
func (e BucketNotEmpty) Error() string
type BucketNotFound ¶
type BucketNotFound GenericError
BucketNotFound bucket does not exist.
func (BucketNotFound) Error ¶
func (e BucketNotFound) Error() string
type BucketObjectLockConfig ¶
BucketObjectLockConfig - map of bucket and retention configuration.
func (*BucketObjectLockConfig) Get ¶
func (config *BucketObjectLockConfig) Get(bucketName string) (r Retention, ok bool)
Get - Get retention configuration.
func (*BucketObjectLockConfig) Remove ¶
func (config *BucketObjectLockConfig) Remove(bucketName string)
Remove - removes retention configuration.
func (*BucketObjectLockConfig) Set ¶
func (config *BucketObjectLockConfig) Set(bucketName string, retention Retention)
Set - set retention configuration.
type BucketPolicyNotFound ¶
type BucketPolicyNotFound GenericError
BucketPolicyNotFound - no bucket policy found.
func (BucketPolicyNotFound) Error ¶
func (e BucketPolicyNotFound) Error() string
type CacheChecksumInfoV1 ¶
type CacheChecksumInfoV1 struct { Algorithm string `json:"algorithm"` Blocksize int64 `json:"blocksize"` }
CacheChecksumInfoV1 - carries checksums of individual blocks on disk.
type CacheObjectLayer ¶
type CacheObjectLayer interface { // Object operations. GetObjectNInfo(ctx context.Context, bucket, object string, rs *HTTPRangeSpec, h http.Header, lockType LockType, opts ObjectOptions) (gr *GetObjectReader, err error) GetObjectInfo(ctx context.Context, bucket, object string, opts ObjectOptions) (objInfo ObjectInfo, err error) DeleteObject(ctx context.Context, bucket, object string) error DeleteObjects(ctx context.Context, bucket string, objects []string) ([]error, error) PutObject(ctx context.Context, bucket, object string, data *PutObjReader, opts ObjectOptions) (objInfo ObjectInfo, err error) // Storage operations. StorageInfo(ctx context.Context) CacheStorageInfo CacheStats() *CacheStats }
CacheObjectLayer implements primitives for cache object API layer.
type CacheStats ¶
CacheStats - represents bytes served from cache, cache hits and cache misses.
type CacheStatusType ¶
type CacheStatusType string
CacheStatusType - whether the request was served from cache.
const ( // CacheHit - whether object was served from cache. CacheHit CacheStatusType = "HIT" // CacheMiss - object served from backend. CacheMiss CacheStatusType = "MISS" )
func (CacheStatusType) String ¶
func (c CacheStatusType) String() string
type CacheStorageInfo ¶
type CacheStorageInfo struct { Total uint64 // Total cache disk space. Free uint64 // Free cache available space. }
CacheStorageInfo - represents total, free capacity of underlying cache storage.
type CheckCopyPreconditionFn ¶
type CheckCopyPreconditionFn func(o ObjectInfo, encETag string) bool
CheckCopyPreconditionFn returns true if copy precondition check failed.
type ChecksumInfo ¶
type ChecksumInfo struct { Name string Algorithm BitrotAlgorithm Hash []byte }
ChecksumInfo - carries checksums of individual scattered parts per disk.
func (ChecksumInfo) MarshalJSON ¶
func (c ChecksumInfo) MarshalJSON() ([]byte, error)
MarshalJSON marshals the ChecksumInfo struct
func (*ChecksumInfo) UnmarshalJSON ¶
func (c *ChecksumInfo) UnmarshalJSON(data []byte) error
UnmarshalJSON - should never be called, instead xlMetaV1UnmarshalJSON() should be used.
type ClientGrantsResult ¶
type ClientGrantsResult struct { // The identifiers for the temporary security credentials that the operation // returns. AssumedRoleUser AssumedRoleUser `xml:",omitempty"` // The intended audience (also known as client ID) of the web identity token. // This is traditionally the client identifier issued to the application that // requested the client grants. Audience string `xml:",omitempty"` // The temporary security credentials, which include an access key ID, a secret // access key, and a security (or session) token. // // Note: The size of the security token that STS APIs return is not fixed. We // strongly recommend that you make no assumptions about the maximum size. As // of this writing, the typical size is less than 4096 bytes, but that can vary. // Also, future updates to AWS might require larger sizes. Credentials auth.Credentials `xml:",omitempty"` // A percentage value that indicates the size of the policy in packed form. // The service rejects any policy with a packed size greater than 100 percent, // which means the policy exceeded the allowed space. PackedPolicySize int `xml:",omitempty"` // The issuing authority of the web identity token presented. For OpenID Connect // ID tokens, this contains the value of the iss field. For OAuth 2.0 access tokens, // this contains the value of the ProviderId parameter that was passed in the // AssumeRoleWithClientGrants request. Provider string `xml:",omitempty"` // The unique user identifier that is returned by the identity provider. // This identifier is associated with the Token that was submitted // with the AssumeRoleWithClientGrants call. The identifier is typically unique to // the user and the application that acquired the ClientGrantsToken (pairwise identifier). // For OpenID Connect ID tokens, this field contains the value returned by the identity // provider as the token's sub (Subject) claim. SubjectFromToken string `xml:",omitempty"` }
ClientGrantsResult - Contains the response to a successful AssumeRoleWithClientGrants request, including temporary credentials that can be used to make MinIO API requests.
type CommonPrefix ¶
type CommonPrefix struct {
Prefix string
}
CommonPrefix container for prefix response in ListObjectsResponse
type CompleteMultipartUpload ¶
type CompleteMultipartUpload struct {
Parts []CompletePart `xml:"Part"`
}
CompleteMultipartUpload - represents list of parts which are completed, this is sent by the client during CompleteMultipartUpload request.
type CompleteMultipartUploadResponse ¶
type CompleteMultipartUploadResponse struct { XMLName xml.Name `xml:"http://s3.amazonaws.com/doc/2006-03-01/ CompleteMultipartUploadResult" json:"-"` Location string Bucket string Key string ETag string }
CompleteMultipartUploadResponse container for completed multipart upload response
type CompletePart ¶
type CompletePart struct { // Part number identifying the part. This is a positive integer between 1 and // 10,000 PartNumber int // Entity tag returned when the part was uploaded. ETag string }
CompletePart - represents the part that was completed, this is sent by the client during CompleteMultipartUpload request.
type CompletedParts ¶
type CompletedParts []CompletePart
CompletedParts - is a collection satisfying sort.Interface.
func (CompletedParts) Len ¶
func (a CompletedParts) Len() int
func (CompletedParts) Less ¶
func (a CompletedParts) Less(i, j int) bool
func (CompletedParts) Swap ¶
func (a CompletedParts) Swap(i, j int)
type ConfigDir ¶
type ConfigDir struct {
// contains filtered or unexported fields
}
ConfigDir - points to a user set directory.
type ConfigSys ¶
type ConfigSys struct{}
ConfigSys - config system.
func (*ConfigSys) Init ¶
func (sys *ConfigSys) Init(objAPI ObjectLayer) error
Init - initializes config system from config.json.
func (*ConfigSys) Load ¶
func (sys *ConfigSys) Load(objAPI ObjectLayer) error
Load - load config.json.
func (*ConfigSys) WatchConfigNASDisk ¶
func (sys *ConfigSys) WatchConfigNASDisk(objAPI ObjectLayer)
WatchConfigNASDisk - watches nas disk on periodic basis.
type ConnStats ¶
type ConnStats struct {
// contains filtered or unexported fields
}
ConnStats - Network statistics Count total input/output transferred bytes during the server's life.
type ConsoleLogger ¶
type ConsoleLogger struct {
Enable bool `json:"enable"`
}
ConsoleLogger is introduced to workaround the dependency about logrus
type CopyObjectPartResponse ¶
type CopyObjectPartResponse struct { XMLName xml.Name `xml:"http://s3.amazonaws.com/doc/2006-03-01/ CopyPartResult" json:"-"` LastModified string // time string of format "2006-01-02T15:04:05.000Z" ETag string // md5sum of the copied object part. }
CopyObjectPartResponse container returns ETag and LastModified of the successfully copied object
type CopyObjectResponse ¶
type CopyObjectResponse struct { XMLName xml.Name `xml:"http://s3.amazonaws.com/doc/2006-03-01/ CopyObjectResult" json:"-"` LastModified string // time string of format "2006-01-02T15:04:05.000Z" ETag string // md5sum of the copied object. }
CopyObjectResponse container returns ETag and LastModified of the successfully copied object
type DataUsageInfo ¶
type DataUsageInfo struct { // The timestamp of when the data usage info is generated LastUpdate time.Time `json:"lastUpdate"` ObjectsCount uint64 `json:"objectsCount"` // Objects total size ObjectsTotalSize uint64 `json:"objectsTotalSize"` ObjectsSizesHistogram map[string]uint64 `json:"objectsSizesHistogram"` BucketsCount uint64 `json:"bucketsCount"` BucketsSizes map[string]uint64 `json:"bucketsSizes"` }
DataUsageInfo represents data usage stats of the underlying Object API
type DecryptBlocksReader ¶
type DecryptBlocksReader struct {
// contains filtered or unexported fields
}
DecryptBlocksReader - decrypts multipart parts, while implementing a io.Reader compatible interface.
type DefaultRetention ¶
type DefaultRetention struct { XMLName xml.Name `xml:"DefaultRetention"` Mode RetentionMode `xml:"Mode"` Days *uint64 `xml:"Days"` Years *uint64 `xml:"Years"` }
DefaultRetention - default retention configuration.
func (*DefaultRetention) UnmarshalXML ¶
func (dr *DefaultRetention) UnmarshalXML(d *xml.Decoder, start xml.StartElement) error
UnmarshalXML - decodes XML data.
type DeleteError ¶
DeleteError structure.
type DeleteFileBulkErrsResp ¶
type DeleteFileBulkErrsResp struct {
Errs []error
}
DeleteFileBulkErrsResp - collection of deleteFile errors for bulk deletes
type DeleteObjectsRequest ¶
type DeleteObjectsRequest struct { // Element to enable quiet mode for the request Quiet bool // List of objects to be deleted Objects []ObjectIdentifier `xml:"Object"` }
DeleteObjectsRequest - xml carrying the object key names which needs to be deleted.
type DeleteObjectsResponse ¶
type DeleteObjectsResponse struct { XMLName xml.Name `xml:"http://s3.amazonaws.com/doc/2006-03-01/ DeleteResult" json:"-"` // Collection of all deleted objects DeletedObjects []ObjectIdentifier `xml:"Deleted,omitempty"` // Collection of errors deleting certain objects. Errors []DeleteError `xml:"Error,omitempty"` }
DeleteObjectsResponse container for multiple object deletes.
type DiscoveryDocResp ¶
type DiscoveryDocResp struct { DiscoveryDoc openid.DiscoveryDoc UIVersion string `json:"uiVersion"` ClientID string `json:"clientId"` }
DiscoveryDocResp - OpenID discovery document reply.
type DownloadZipArgs ¶
type DownloadZipArgs struct { Objects []string `json:"objects"` // can be files or sub-directories Prefix string `json:"prefix"` // current directory in the browser-ui BucketName string `json:"bucketname"` // bucket name. }
DownloadZipArgs - Argument for downloading a bunch of files as a zip file. JSON will look like: '{"bucketname":"testbucket","prefix":"john/pics/","objects":["hawaii/","maldives/","sanjose.jpg"]}'
type Endpoint ¶
Endpoint - any type of endpoint.
func NewEndpoint ¶
NewEndpoint - returns new endpoint based on given arguments.
func (Endpoint) Type ¶
func (endpoint Endpoint) Type() EndpointType
Type - returns type of endpoint.
func (*Endpoint) UpdateIsLocal ¶
UpdateIsLocal - resolves the host and updates if it is local or not.
type EndpointType ¶
type EndpointType int
EndpointType - enum for endpoint type.
const ( // PathEndpointType - path style endpoint type enum. PathEndpointType EndpointType = iota + 1 // URLEndpointType - URL style endpoint type enum. URLEndpointType )
type EndpointZones ¶
type EndpointZones []ZoneEndpoints
EndpointZones - list of list of endpoints
func (*EndpointZones) Add ¶
func (l *EndpointZones) Add(zeps ZoneEndpoints) error
Add add zone endpoints
func (EndpointZones) FirstLocal ¶
func (l EndpointZones) FirstLocal() bool
FirstLocal returns true if the first endpoint is local.
func (EndpointZones) HTTPS ¶
func (l EndpointZones) HTTPS() bool
HTTPS - returns true if secure for URLEndpointType.
func (EndpointZones) Nodes ¶
func (l EndpointZones) Nodes() (count int)
Nodes - returns all nodes count
type Endpoints ¶
type Endpoints []Endpoint
Endpoints - list of same type of endpoint.
func NewEndpoints ¶
NewEndpoints - returns new endpoint list based on input args.
func (Endpoints) GetString ¶
GetString - returns endpoint string of i-th endpoint (0-based), and empty string for invalid indexes.
func (Endpoints) UpdateIsLocal ¶
UpdateIsLocal - resolves the host and discovers the local host.
type Erasure ¶
type Erasure struct {
// contains filtered or unexported fields
}
Erasure - erasure encoding details.
func NewErasure ¶
func NewErasure(ctx context.Context, dataBlocks, parityBlocks int, blockSize int64) (e Erasure, err error)
NewErasure creates a new ErasureStorage.
func (Erasure) Decode ¶
func (e Erasure) Decode(ctx context.Context, writer io.Writer, readers []io.ReaderAt, offset, length, totalLength int64) error
Decode reads from readers, reconstructs data if needed and writes the data to the writer.
func (*Erasure) DecodeDataAndParityBlocks ¶
DecodeDataAndParityBlocks decodes the given erasure-coded data and verifies it. It returns an error if the decoding failed.
func (*Erasure) DecodeDataBlocks ¶
DecodeDataBlocks decodes the given erasure-coded data. It only decodes the data blocks but does not verify them. It returns an error if the decoding failed.
func (*Erasure) Encode ¶
func (e *Erasure) Encode(ctx context.Context, src io.Reader, writers []io.Writer, buf []byte, quorum int) (total int64, err error)
Encode reads from the reader, erasure-encodes the data and writes to the writers.
func (*Erasure) EncodeData ¶
EncodeData encodes the given data and returns the erasure-coded data. It returns an error if the erasure coding failed.
func (Erasure) Heal ¶
func (e Erasure) Heal(ctx context.Context, readers []io.ReaderAt, writers []io.Writer, size int64) error
Heal heals the shard files on non-nil writers. Note that the quorum passed is 1 as healing should continue even if it has been successful healing only one shard file.
func (*Erasure) ShardFileSize ¶
ShardFileSize - returns final erasure size from original size.
func (*Erasure) ShardFileTillOffset ¶
ShardFileTillOffset - returns the effectiv eoffset where erasure reading begins.
type ErasureInfo ¶
type ErasureInfo struct { // Algorithm is the string representation of erasure-coding-algorithm Algorithm string `json:"algorithm"` // DataBlocks is the number of data blocks for erasure-coding DataBlocks int `json:"data"` // ParityBlocks is the number of parity blocks for erasure-coding ParityBlocks int `json:"parity"` // BlockSize is the size of one erasure-coded block BlockSize int64 `json:"blockSize"` // Index is the index of the current disk Index int `json:"index"` // Distribution is the distribution of the data and parity blocks Distribution []int `json:"distribution"` // Checksums holds all bitrot checksums of all erasure encoded blocks Checksums []ChecksumInfo `json:"checksum,omitempty"` }
ErasureInfo holds erasure coding and bitrot related information.
func (*ErasureInfo) AddChecksumInfo ¶
func (e *ErasureInfo) AddChecksumInfo(ckSumInfo ChecksumInfo)
AddChecksumInfo adds a checksum of a part.
func (ErasureInfo) GetChecksumInfo ¶
func (e ErasureInfo) GetChecksumInfo(partName string) (ckSum ChecksumInfo)
GetChecksumInfo - get checksum of a part.
type FSChecksumInfoV1 ¶
FSChecksumInfoV1 - carries checksums of individual blocks on disk.
func (FSChecksumInfoV1) MarshalJSON ¶
func (c FSChecksumInfoV1) MarshalJSON() ([]byte, error)
MarshalJSON marshals the FSChecksumInfoV1 struct
func (*FSChecksumInfoV1) UnmarshalJSON ¶
func (c *FSChecksumInfoV1) UnmarshalJSON(data []byte) error
UnmarshalJSON unmarshals the the given data into the FSChecksumInfoV1 struct
type FSObjects ¶
type FSObjects struct {
// contains filtered or unexported fields
}
FSObjects - Implements fs object layer.
func (*FSObjects) AbortMultipartUpload ¶
func (fs *FSObjects) AbortMultipartUpload(ctx context.Context, bucket, object, uploadID string) error
AbortMultipartUpload - aborts an ongoing multipart operation signified by the input uploadID. This is an atomic operation doesn't require clients to initiate multiple such requests.
All parts are purged from all disks and reference to the uploadID would be removed from the system, rollback is not possible on this operation.
Implements S3 compatible Abort multipart API, slight difference is that this is an atomic idempotent operation. Subsequent calls have no affect and further requests to the same uploadID would not be honored.
func (*FSObjects) CompleteMultipartUpload ¶
func (fs *FSObjects) CompleteMultipartUpload(ctx context.Context, bucket string, object string, uploadID string, parts []CompletePart, opts ObjectOptions) (oi ObjectInfo, e error)
CompleteMultipartUpload - completes an ongoing multipart transaction after receiving all the parts indicated by the client. Returns an md5sum calculated by concatenating all the individual md5sums of all the parts.
Implements S3 compatible Complete multipart API.
func (*FSObjects) CopyObject ¶
func (fs *FSObjects) CopyObject(ctx context.Context, srcBucket, srcObject, dstBucket, dstObject string, srcInfo ObjectInfo, srcOpts, dstOpts ObjectOptions) (oi ObjectInfo, e error)
CopyObject - copy object source object to destination object. if source object and destination object are same we only update metadata.
func (*FSObjects) CopyObjectPart ¶
func (fs *FSObjects) CopyObjectPart(ctx context.Context, srcBucket, srcObject, dstBucket, dstObject, uploadID string, partID int, startOffset int64, length int64, srcInfo ObjectInfo, srcOpts, dstOpts ObjectOptions) (pi PartInfo, e error)
CopyObjectPart - similar to PutObjectPart but reads data from an existing object. Internally incoming data is written to '.minio.sys/tmp' location and safely renamed to '.minio.sys/multipart' for reach parts.
func (*FSObjects) DeleteBucket ¶
DeleteBucket - delete a bucket and all the metadata associated with the bucket including pending multipart, object metadata.
func (*FSObjects) DeleteBucketLifecycle ¶
DeleteBucketLifecycle deletes all lifecycle on bucket
func (*FSObjects) DeleteBucketPolicy ¶
DeleteBucketPolicy deletes all policies on bucket
func (*FSObjects) DeleteObject ¶
DeleteObject - deletes an object from a bucket, this operation is destructive and there are no rollbacks supported.
func (*FSObjects) DeleteObjects ¶
func (fs *FSObjects) DeleteObjects(ctx context.Context, bucket string, objects []string) ([]error, error)
DeleteObjects - deletes an object from a bucket, this operation is destructive and there are no rollbacks supported.
func (*FSObjects) GetBucketInfo ¶
GetBucketInfo - fetch bucket metadata info.
func (*FSObjects) GetBucketLifecycle ¶
func (fs *FSObjects) GetBucketLifecycle(ctx context.Context, bucket string) (*lifecycle.Lifecycle, error)
GetBucketLifecycle will get lifecycle on bucket
func (*FSObjects) GetBucketPolicy ¶
GetBucketPolicy will get policy on bucket
func (*FSObjects) GetMetrics ¶
GetMetrics - no op
func (*FSObjects) GetObject ¶
func (fs *FSObjects) GetObject(ctx context.Context, bucket, object string, offset int64, length int64, writer io.Writer, etag string, opts ObjectOptions) (err error)
GetObject - reads an object from the disk. Supports additional parameters like offset and length which are synonymous with HTTP Range requests.
startOffset indicates the starting read location of the object. length indicates the total length of the object.
func (*FSObjects) GetObjectInfo ¶
func (fs *FSObjects) GetObjectInfo(ctx context.Context, bucket, object string, opts ObjectOptions) (oi ObjectInfo, e error)
GetObjectInfo - reads object metadata and replies back ObjectInfo.
func (*FSObjects) GetObjectNInfo ¶
func (fs *FSObjects) GetObjectNInfo(ctx context.Context, bucket, object string, rs *HTTPRangeSpec, h http.Header, lockType LockType, opts ObjectOptions) (gr *GetObjectReader, err error)
GetObjectNInfo - returns object info and a reader for object content.
func (*FSObjects) HealBucket ¶
func (fs *FSObjects) HealBucket(ctx context.Context, bucket string, dryRun, remove bool) (madmin.HealResultItem, error)
HealBucket - no-op for fs, Valid only for XL.
func (*FSObjects) HealFormat ¶
HealFormat - no-op for fs, Valid only for XL.
func (*FSObjects) HealObject ¶
func (fs *FSObjects) HealObject(ctx context.Context, bucket, object string, dryRun, remove bool, scanMode madmin.HealScanMode) ( res madmin.HealResultItem, err error)
HealObject - no-op for fs. Valid only for XL.
func (*FSObjects) HealObjects ¶
func (fs *FSObjects) HealObjects(ctx context.Context, bucket, prefix string, fn func(string, string) error) (e error)
HealObjects - no-op for fs. Valid only for XL.
func (*FSObjects) IsCompressionSupported ¶
IsCompressionSupported returns whether compression is applicable for this layer.
func (*FSObjects) IsEncryptionSupported ¶
IsEncryptionSupported returns whether server side encryption is implemented for this layer.
func (*FSObjects) IsListenBucketSupported ¶
IsListenBucketSupported returns whether listen bucket notification is applicable for this layer.
func (*FSObjects) IsNotificationSupported ¶
IsNotificationSupported returns whether bucket notification is applicable for this layer.
func (*FSObjects) ListBuckets ¶
func (fs *FSObjects) ListBuckets(ctx context.Context) ([]BucketInfo, error)
ListBuckets - list all s3 compatible buckets (directories) at fsPath.
func (*FSObjects) ListBucketsHeal ¶
func (fs *FSObjects) ListBucketsHeal(ctx context.Context) ([]BucketInfo, error)
ListBucketsHeal - list all buckets to be healed. Valid only for XL
func (*FSObjects) ListMultipartUploads ¶
func (fs *FSObjects) ListMultipartUploads(ctx context.Context, bucket, object, keyMarker, uploadIDMarker, delimiter string, maxUploads int) (result ListMultipartsInfo, e error)
ListMultipartUploads - lists all the uploadIDs for the specified object. We do not support prefix based listing.
func (*FSObjects) ListObjectParts ¶
func (fs *FSObjects) ListObjectParts(ctx context.Context, bucket, object, uploadID string, partNumberMarker, maxParts int, opts ObjectOptions) (result ListPartsInfo, e error)
ListObjectParts - lists all previously uploaded parts for a given object and uploadID. Takes additional input of part-number-marker to indicate where the listing should begin from.
Implements S3 compatible ListObjectParts API. The resulting ListPartsInfo structure is unmarshalled directly into XML and replied back to the client.
func (*FSObjects) ListObjects ¶
func (fs *FSObjects) ListObjects(ctx context.Context, bucket, prefix, marker, delimiter string, maxKeys int) (loi ListObjectsInfo, e error)
ListObjects - list all objects at prefix upto maxKeys., optionally delimited by '/'. Maintains the list pool state for future re-entrant list requests.
func (*FSObjects) ListObjectsHeal ¶
func (fs *FSObjects) ListObjectsHeal(ctx context.Context, bucket, prefix, marker, delimiter string, maxKeys int) (result ListObjectsInfo, err error)
ListObjectsHeal - list all objects to be healed. Valid only for XL
func (*FSObjects) ListObjectsV2 ¶
func (fs *FSObjects) ListObjectsV2(ctx context.Context, bucket, prefix, continuationToken, delimiter string, maxKeys int, fetchOwner bool, startAfter string) (result ListObjectsV2Info, err error)
ListObjectsV2 lists all blobs in bucket filtered by prefix
func (*FSObjects) MakeBucketWithLocation ¶
MakeBucketWithLocation - create a new bucket, returns if it already exists.
func (*FSObjects) NewMultipartUpload ¶
func (fs *FSObjects) NewMultipartUpload(ctx context.Context, bucket, object string, opts ObjectOptions) (string, error)
NewMultipartUpload - initialize a new multipart upload, returns a unique id. The unique id returned here is of UUID form, for each subsequent request each UUID is unique.
Implements S3 compatible initiate multipart API.
func (*FSObjects) PutObject ¶
func (fs *FSObjects) PutObject(ctx context.Context, bucket string, object string, r *PutObjReader, opts ObjectOptions) (objInfo ObjectInfo, retErr error)
PutObject - creates an object upon reading from the input stream until EOF, writes data directly to configured filesystem path. Additionally writes `fs.json` which carries the necessary metadata for future object operations.
func (*FSObjects) PutObjectPart ¶
func (fs *FSObjects) PutObjectPart(ctx context.Context, bucket, object, uploadID string, partID int, r *PutObjReader, opts ObjectOptions) (pi PartInfo, e error)
PutObjectPart - reads incoming data until EOF for the part file on an ongoing multipart transaction. Internally incoming data is written to '.minio.sys/tmp' location and safely renamed to '.minio.sys/multipart' for reach parts.
func (*FSObjects) ReloadFormat ¶
ReloadFormat - no-op for fs, Valid only for XL.
func (*FSObjects) SetBucketLifecycle ¶
func (fs *FSObjects) SetBucketLifecycle(ctx context.Context, bucket string, lifecycle *lifecycle.Lifecycle) error
SetBucketLifecycle sets lifecycle on bucket
func (*FSObjects) SetBucketPolicy ¶
func (fs *FSObjects) SetBucketPolicy(ctx context.Context, bucket string, policy *policy.Policy) error
SetBucketPolicy sets policy on bucket
func (*FSObjects) StorageInfo ¶
func (fs *FSObjects) StorageInfo(ctx context.Context) StorageInfo
StorageInfo - returns underlying storage statistics.
type FileInfo ¶
type FileInfo struct { // Name of the volume. Volume string // Name of the file. Name string // Date and time when the file was last modified. ModTime time.Time // Total file size. Size int64 // File mode bits. Mode os.FileMode // File metadata Metadata map[string]string // All the parts per object. Parts []ObjectPartInfo Quorum int }
FileInfo - represents file stat information.
type FileInfoCh ¶
FileInfoCh - file info channel
func (*FileInfoCh) Pop ¶
func (f *FileInfoCh) Pop() (fi FileInfo, ok bool)
Pop - pops a cached entry if any, or from the cached channel.
func (*FileInfoCh) Push ¶
func (f *FileInfoCh) Push(fi FileInfo)
Push - cache an entry, for Pop() later.
type FileLogger ¶
FileLogger is introduced to workaround the dependency about logrus
type Gateway ¶
type Gateway interface { // Name returns the unique name of the gateway. Name() string // NewGatewayLayer returns a new ObjectLayer. NewGatewayLayer(creds auth.Credentials) (ObjectLayer, error) // Returns true if gateway is ready for production. Production() bool }
Gateway represents a gateway backend.
type GatewayLocker ¶
type GatewayLocker struct { ObjectLayer // contains filtered or unexported fields }
GatewayLocker implements custom NeNSLock implementation
type GatewayUnsupported ¶
type GatewayUnsupported struct{}
GatewayUnsupported list of unsupported call stubs for gateway.
func (GatewayUnsupported) AbortMultipartUpload ¶
func (a GatewayUnsupported) AbortMultipartUpload(ctx context.Context, bucket string, object string, uploadID string) error
AbortMultipartUpload aborts a ongoing multipart upload
func (GatewayUnsupported) CompleteMultipartUpload ¶
func (a GatewayUnsupported) CompleteMultipartUpload(ctx context.Context, bucket string, object string, uploadID string, uploadedParts []CompletePart, opts ObjectOptions) (oi ObjectInfo, err error)
CompleteMultipartUpload completes ongoing multipart upload and finalizes object
func (GatewayUnsupported) CopyObject ¶
func (a GatewayUnsupported) CopyObject(ctx context.Context, srcBucket string, srcObject string, destBucket string, destObject string, srcInfo ObjectInfo, srcOpts, dstOpts ObjectOptions) (objInfo ObjectInfo, err error)
CopyObject copies a blob from source container to destination container.
func (GatewayUnsupported) CopyObjectPart ¶
func (a GatewayUnsupported) CopyObjectPart(ctx context.Context, srcBucket, srcObject, destBucket, destObject, uploadID string, partID int, startOffset, length int64, srcInfo ObjectInfo, srcOpts, dstOpts ObjectOptions) (pi PartInfo, err error)
CopyObjectPart copy part of object to uploadID for another object
func (GatewayUnsupported) DeleteBucketLifecycle ¶
func (a GatewayUnsupported) DeleteBucketLifecycle(ctx context.Context, bucket string) error
DeleteBucketLifecycle deletes all lifecycle on bucket
func (GatewayUnsupported) DeleteBucketPolicy ¶
func (a GatewayUnsupported) DeleteBucketPolicy(ctx context.Context, bucket string) error
DeleteBucketPolicy deletes all policies on bucket
func (GatewayUnsupported) GetBucketLifecycle ¶
func (a GatewayUnsupported) GetBucketLifecycle(ctx context.Context, bucket string) (*lifecycle.Lifecycle, error)
GetBucketLifecycle will get lifecycle on bucket
func (GatewayUnsupported) GetBucketPolicy ¶
func (a GatewayUnsupported) GetBucketPolicy(ctx context.Context, bucket string) (bucketPolicy *policy.Policy, err error)
GetBucketPolicy will get policy on bucket
func (GatewayUnsupported) GetMetrics ¶
func (a GatewayUnsupported) GetMetrics(ctx context.Context) (*Metrics, error)
GetMetrics - no op
func (GatewayUnsupported) HealBucket ¶
func (a GatewayUnsupported) HealBucket(ctx context.Context, bucket string, dryRun, remove bool) (madmin.HealResultItem, error)
HealBucket - Not implemented stub
func (GatewayUnsupported) HealFormat ¶
func (a GatewayUnsupported) HealFormat(ctx context.Context, dryRun bool) (madmin.HealResultItem, error)
HealFormat - Not implemented stub
func (GatewayUnsupported) HealObject ¶
func (a GatewayUnsupported) HealObject(ctx context.Context, bucket, object string, dryRun, remove bool, scanMode madmin.HealScanMode) (h madmin.HealResultItem, e error)
HealObject - Not implemented stub
func (GatewayUnsupported) HealObjects ¶
func (a GatewayUnsupported) HealObjects(ctx context.Context, bucket, prefix string, fn func(string, string) error) (e error)
HealObjects - Not implemented stub
func (GatewayUnsupported) IsCompressionSupported ¶
func (a GatewayUnsupported) IsCompressionSupported() bool
IsCompressionSupported returns whether compression is applicable for this layer.
func (GatewayUnsupported) IsEncryptionSupported ¶
func (a GatewayUnsupported) IsEncryptionSupported() bool
IsEncryptionSupported returns whether server side encryption is implemented for this layer.
func (GatewayUnsupported) IsListenBucketSupported ¶
func (a GatewayUnsupported) IsListenBucketSupported() bool
IsListenBucketSupported returns whether listen bucket notification is applicable for this layer.
func (GatewayUnsupported) IsNotificationSupported ¶
func (a GatewayUnsupported) IsNotificationSupported() bool
IsNotificationSupported returns whether bucket notification is applicable for this layer.
func (GatewayUnsupported) IsReady ¶
func (a GatewayUnsupported) IsReady(_ context.Context) bool
IsReady - No Op.
func (GatewayUnsupported) ListBucketsHeal ¶
func (a GatewayUnsupported) ListBucketsHeal(ctx context.Context) (buckets []BucketInfo, err error)
ListBucketsHeal - Not implemented stub
func (GatewayUnsupported) ListMultipartUploads ¶
func (a GatewayUnsupported) ListMultipartUploads(ctx context.Context, bucket string, prefix string, keyMarker string, uploadIDMarker string, delimiter string, maxUploads int) (lmi ListMultipartsInfo, err error)
ListMultipartUploads lists all multipart uploads.
func (GatewayUnsupported) ListObjectParts ¶
func (a GatewayUnsupported) ListObjectParts(ctx context.Context, bucket string, object string, uploadID string, partNumberMarker int, maxParts int, opts ObjectOptions) (lpi ListPartsInfo, err error)
ListObjectParts returns all object parts for specified object in specified bucket
func (GatewayUnsupported) ListObjectsHeal ¶
func (a GatewayUnsupported) ListObjectsHeal(ctx context.Context, bucket, prefix, marker, delimiter string, maxKeys int) (result ListObjectsInfo, err error)
ListObjectsHeal - Not implemented stub
func (GatewayUnsupported) ListObjectsV2 ¶
func (a GatewayUnsupported) ListObjectsV2(ctx context.Context, bucket, prefix, continuationToken, delimiter string, maxKeys int, fetchOwner bool, startAfter string) (result ListObjectsV2Info, err error)
ListObjectsV2 - Not implemented stub
func (GatewayUnsupported) NewMultipartUpload ¶
func (a GatewayUnsupported) NewMultipartUpload(ctx context.Context, bucket string, object string, opts ObjectOptions) (uploadID string, err error)
NewMultipartUpload upload object in multiple parts
func (GatewayUnsupported) PutObjectPart ¶
func (a GatewayUnsupported) PutObjectPart(ctx context.Context, bucket string, object string, uploadID string, partID int, data *PutObjReader, opts ObjectOptions) (pi PartInfo, err error)
PutObjectPart puts a part of object in bucket
func (GatewayUnsupported) ReloadFormat ¶
func (a GatewayUnsupported) ReloadFormat(ctx context.Context, dryRun bool) error
ReloadFormat - Not implemented stub.
func (GatewayUnsupported) SetBucketLifecycle ¶
func (a GatewayUnsupported) SetBucketLifecycle(ctx context.Context, bucket string, lifecycle *lifecycle.Lifecycle) error
SetBucketLifecycle sets lifecycle on bucket
func (GatewayUnsupported) SetBucketPolicy ¶
func (a GatewayUnsupported) SetBucketPolicy(ctx context.Context, bucket string, bucketPolicy *policy.Policy) error
SetBucketPolicy sets policy on bucket
type GenerateAuthReply ¶
type GenerateAuthReply struct { AccessKey string `json:"accessKey"` SecretKey string `json:"secretKey"` UIVersion string `json:"uiVersion"` }
GenerateAuthReply - reply for GenerateAuth
type GenericError ¶
GenericError - generic object layer error.
type GetBucketPolicyArgs ¶
type GetBucketPolicyArgs struct { BucketName string `json:"bucketName"` Prefix string `json:"prefix"` }
GetBucketPolicyArgs - get bucket policy args.
func (*GetBucketPolicyArgs) ToKeyValue ¶
func (args *GetBucketPolicyArgs) ToKeyValue() KeyValueMap
ToKeyValue implementation for GetBucketPolicyArgs
type GetBucketPolicyRep ¶
type GetBucketPolicyRep struct { UIVersion string `json:"uiVersion"` Policy miniogopolicy.BucketPolicy `json:"policy"` }
GetBucketPolicyRep - get bucket policy reply.
type GetLocksResp ¶
type GetLocksResp []map[string][]lockRequesterInfo
GetLocksResp stores various info from the client for each lock that is requested.
type GetObjectInfoFn ¶
type GetObjectInfoFn func(ctx context.Context, bucket, object string, opts ObjectOptions) (objInfo ObjectInfo, err error)
GetObjectInfoFn is the signature of GetObjectInfo function.
type GetObjectReader ¶
type GetObjectReader struct { ObjInfo ObjectInfo // contains filtered or unexported fields }
GetObjectReader is a type that wraps a reader with a lock to provide a ReadCloser interface that unlocks on Close()
func NewGetObjectReaderFromReader ¶
func NewGetObjectReaderFromReader(r io.Reader, oi ObjectInfo, pcfn CheckCopyPreconditionFn, cleanupFns ...func()) (*GetObjectReader, error)
NewGetObjectReaderFromReader sets up a GetObjectReader with a given reader. This ignores any object properties.
func (*GetObjectReader) Close ¶
func (g *GetObjectReader) Close() error
Close - calls the cleanup actions in reverse order
type GroupInfo ¶
type GroupInfo struct { Version int `json:"version"` Status string `json:"status"` Members []string `json:"members"` }
GroupInfo contains info about a group
type HTTPAPIStats ¶
HTTPAPIStats holds statistics information about a given API in the requests.
func (*HTTPAPIStats) Dec ¶
func (stats *HTTPAPIStats) Dec(api string)
Dec increments the api stats counter.
func (*HTTPAPIStats) Inc ¶
func (stats *HTTPAPIStats) Inc(api string)
Inc increments the api stats counter.
func (*HTTPAPIStats) Load ¶
func (stats *HTTPAPIStats) Load() map[string]int
Load returns the recorded stats.
type HTTPConsoleLoggerSys ¶
HTTPConsoleLoggerSys holds global console logger state
func NewConsoleLogger ¶
func NewConsoleLogger(ctx context.Context) *HTTPConsoleLoggerSys
NewConsoleLogger - creates new HTTPConsoleLoggerSys with all nodes subscribed to the console logging pub sub system
func (*HTTPConsoleLoggerSys) HasLogListeners ¶
func (sys *HTTPConsoleLoggerSys) HasLogListeners() bool
HasLogListeners returns true if console log listeners are registered for this node or peers
func (*HTTPConsoleLoggerSys) Send ¶
func (sys *HTTPConsoleLoggerSys) Send(e interface{}, logKind string) error
Send log message 'e' to console and publish to console log pubsub system
func (*HTTPConsoleLoggerSys) SetNodeName ¶
func (sys *HTTPConsoleLoggerSys) SetNodeName(endpointZones EndpointZones)
SetNodeName - sets the node name if any after distributed setup has initialized
type HTTPRangeSpec ¶
type HTTPRangeSpec struct { // Does the range spec refer to a suffix of the object? IsSuffixLength bool // Start and end offset specified in range spec Start, End int64 }
HTTPRangeSpec represents a range specification as supported by S3 GET object request.
Case 1: Not present -> represented by a nil RangeSpec Case 2: bytes=1-10 (absolute start and end offsets) -> RangeSpec{false, 1, 10} Case 3: bytes=10- (absolute start offset with end offset unspecified) -> RangeSpec{false, 10, -1} Case 4: bytes=-30 (suffix length specification) -> RangeSpec{true, -30, -1}
func (*HTTPRangeSpec) GetLength ¶
func (h *HTTPRangeSpec) GetLength(resourceSize int64) (rangeLength int64, err error)
GetLength - get length of range
func (*HTTPRangeSpec) GetOffsetLength ¶
func (h *HTTPRangeSpec) GetOffsetLength(resourceSize int64) (start, length int64, err error)
GetOffsetLength computes the start offset and length of the range given the size of the resource
func (*HTTPRangeSpec) String ¶
func (h *HTTPRangeSpec) String(resourceSize int64) string
String returns stringified representation of range for a particular resource size.
type HTTPStats ¶
type HTTPStats struct {
// contains filtered or unexported fields
}
HTTPStats holds statistics information about HTTP requests made by all clients
type HandlerFunc ¶
HandlerFunc - useful to chain different middleware http.Handler
type Help ¶
type Help struct { SubSys string `json:"subSys"` Description string `json:"description"` MultipleTargets bool `json:"multipleTargets"` KeysHelp config.HelpKVS `json:"keysHelp"` }
Help - return sub-system level help
type IAMEtcdStore ¶
IAMEtcdStore implements IAMStorageAPI
type IAMObjectStore ¶
type IAMObjectStore struct { // Protect assignment to objAPI sync.RWMutex // contains filtered or unexported fields }
IAMObjectStore implements IAMStorageAPI
type IAMStorageAPI ¶
type IAMStorageAPI interface {
// contains filtered or unexported methods
}
IAMStorageAPI defines an interface for the IAM persistence layer
type IAMSys ¶
IAMSys - config system.
func (*IAMSys) AddUsersToGroup ¶
AddUsersToGroup - adds users to a group, creating the group if needed. No error if user(s) already are in the group.
func (*IAMSys) DeletePolicy ¶
DeletePolicy - deletes a canned policy from backend or etcd.
func (*IAMSys) DeleteUser ¶
DeleteUser - delete user (only for long-term users not STS users).
func (*IAMSys) GetGroupDescription ¶
GetGroupDescription - builds up group description
func (*IAMSys) GetUser ¶
func (sys *IAMSys) GetUser(accessKey string) (cred auth.Credentials, ok bool)
GetUser - get user credentials
func (*IAMSys) GetUserInfo ¶
GetUserInfo - get info on a user.
func (*IAMSys) InfoPolicy ¶
InfoPolicy - expands the canned policy into its JSON structure.
func (*IAMSys) Init ¶
func (sys *IAMSys) Init(objAPI ObjectLayer) error
Init - initializes config system from iam.json
func (*IAMSys) IsAllowed ¶
IsAllowed - checks given policy args is allowed to continue the Rest API.
func (*IAMSys) IsAllowedSTS ¶
IsAllowedSTS is meant for STS based temporary credentials, which implements claims validation and verification other than applying policies.
func (*IAMSys) IsTempUser ¶
IsTempUser - returns if given key is a temporary user.
func (*IAMSys) ListGroups ¶
ListGroups - lists groups.
func (*IAMSys) ListPolicies ¶
ListPolicies - lists all canned policies.
func (*IAMSys) LoadGroup ¶
func (sys *IAMSys) LoadGroup(objAPI ObjectLayer, group string) error
LoadGroup - loads a specific group from storage, and updates the memberships cache. If the specified group does not exist in storage, it is removed from in-memory maps as well - this simplifies the implementation for group removal. This is called only via IAM notifications.
func (*IAMSys) LoadPolicy ¶
func (sys *IAMSys) LoadPolicy(objAPI ObjectLayer, policyName string) error
LoadPolicy - reloads a specific canned policy from backend disks or etcd.
func (*IAMSys) LoadPolicyMapping ¶
func (sys *IAMSys) LoadPolicyMapping(objAPI ObjectLayer, userOrGroup string, isGroup bool) error
LoadPolicyMapping - loads the mapped policy for a user or group from storage into server memory.
func (*IAMSys) LoadUser ¶
func (sys *IAMSys) LoadUser(objAPI ObjectLayer, accessKey string, isSTS bool) error
LoadUser - reloads a specific user from backend disks or etcd.
func (*IAMSys) PolicyDBGet ¶
PolicyDBGet - gets policy set on a user or group. Since a user may be a member of multiple groups, this function returns an array of applicable policies (each group is mapped to at most one policy).
func (*IAMSys) PolicyDBSet ¶
PolicyDBSet - sets a policy for a user or group in the PolicyDB. This function applies only long-term users. For STS users, policy is set directly by called sys.policyDBSet().
func (*IAMSys) RemoveUsersFromGroup ¶
RemoveUsersFromGroup - remove users from group. If no users are given, and the group is empty, deletes the group as well.
func (*IAMSys) SetGroupStatus ¶
SetGroupStatus - enable/disabled a group
func (*IAMSys) SetTempUser ¶
SetTempUser - set temporary user credentials, these credentials have an expiry.
func (*IAMSys) SetUserSecretKey ¶
SetUserSecretKey - sets user secret key
func (*IAMSys) SetUserStatus ¶
func (sys *IAMSys) SetUserStatus(accessKey string, status madmin.AccountStatus) error
SetUserStatus - sets current user status, supports disabled or enabled.
type IncompleteBody ¶
type IncompleteBody GenericError
IncompleteBody You did not provide the number of bytes specified by the Content-Length HTTP header.
func (IncompleteBody) Error ¶
func (e IncompleteBody) Error() string
Return string an error formatted as the given text.
type InitiateMultipartUploadResponse ¶
type InitiateMultipartUploadResponse struct { XMLName xml.Name `xml:"http://s3.amazonaws.com/doc/2006-03-01/ InitiateMultipartUploadResult" json:"-"` Bucket string Key string UploadID string `xml:"UploadId"` }
InitiateMultipartUploadResponse container for InitiateMultiPartUpload response, provides uploadID to start MultiPart upload
type InsufficientReadQuorum ¶
type InsufficientReadQuorum struct{}
InsufficientReadQuorum storage cannot satisfy quorum for read operation.
func (InsufficientReadQuorum) Error ¶
func (e InsufficientReadQuorum) Error() string
type InsufficientWriteQuorum ¶
type InsufficientWriteQuorum struct{}
InsufficientWriteQuorum storage cannot satisfy quorum for write operation.
func (InsufficientWriteQuorum) Error ¶
func (e InsufficientWriteQuorum) Error() string
type InvalidETag ¶
type InvalidETag struct{}
InvalidETag error returned when the etag has changed on disk
func (InvalidETag) Error ¶
func (e InvalidETag) Error() string
type InvalidMarkerPrefixCombination ¶
type InvalidMarkerPrefixCombination struct {
Marker, Prefix string
}
InvalidMarkerPrefixCombination - invalid marker and prefix combination.
func (InvalidMarkerPrefixCombination) Error ¶
func (e InvalidMarkerPrefixCombination) Error() string
type InvalidPart ¶
InvalidPart One or more of the specified parts could not be found
func (InvalidPart) Error ¶
func (e InvalidPart) Error() string
type InvalidRange ¶
InvalidRange - invalid range typed error.
func (InvalidRange) Error ¶
func (e InvalidRange) Error() string
type InvalidUploadID ¶
InvalidUploadID invalid upload id.
func (InvalidUploadID) Error ¶
func (e InvalidUploadID) Error() string
type InvalidUploadIDKeyCombination ¶
type InvalidUploadIDKeyCombination struct {
UploadIDMarker, KeyMarker string
}
InvalidUploadIDKeyCombination - invalid upload id and key marker combination.
func (InvalidUploadIDKeyCombination) Error ¶
func (e InvalidUploadIDKeyCombination) Error() string
type KeyValueMap ¶
KeyValueMap extends builtin map to support setting and getting select fields like BucketName, ObjectName, Prefix, etc.
func (*KeyValueMap) SetBucket ¶
func (km *KeyValueMap) SetBucket(bucket string)
SetBucket sets the given bucket to the KeyValueMap
func (*KeyValueMap) SetExpiry ¶
func (km *KeyValueMap) SetExpiry(expiry int64)
SetExpiry sets the expiry to the KeyValueMap
func (*KeyValueMap) SetHostname ¶
func (km *KeyValueMap) SetHostname(hostname string)
SetHostname sets the hostname to the KeyValueMap
func (*KeyValueMap) SetMarker ¶
func (km *KeyValueMap) SetMarker(marker string)
SetMarker sets the given marker to the KeyValueMap
func (*KeyValueMap) SetObject ¶
func (km *KeyValueMap) SetObject(object string)
SetObject sets the given object to the KeyValueMap
func (*KeyValueMap) SetObjects ¶
func (km *KeyValueMap) SetObjects(objects []string)
SetObjects sets the list of objects to the KeyValueMap
func (*KeyValueMap) SetPolicy ¶
func (km *KeyValueMap) SetPolicy(policy string)
SetPolicy sets the given policy to the KeyValueMap
func (*KeyValueMap) SetPrefix ¶
func (km *KeyValueMap) SetPrefix(prefix string)
SetPrefix sets the given prefix to the KeyValueMap
func (*KeyValueMap) SetUsername ¶
func (km *KeyValueMap) SetUsername(username string)
SetUsername sets the username to the KeyValueMap
type LDAPIdentityResult ¶
type LDAPIdentityResult struct {
Credentials auth.Credentials `xml:",omitempty"`
}
LDAPIdentityResult - contains credentials for a successful AssumeRoleWithLDAPIdentity request.
type LifecycleSys ¶
LifecycleSys - Bucket lifecycle subsystem.
func NewLifecycleSys ¶
func NewLifecycleSys() *LifecycleSys
NewLifecycleSys - creates new lifecycle system.
func (*LifecycleSys) Get ¶
func (sys *LifecycleSys) Get(bucketName string) (lifecycle lifecycle.Lifecycle, ok bool)
Get - gets lifecycle config associated to a given bucket name.
func (*LifecycleSys) Init ¶
func (sys *LifecycleSys) Init(buckets []BucketInfo, objAPI ObjectLayer) error
Init - initializes lifecycle system from lifecycle.xml of all buckets.
func (*LifecycleSys) Remove ¶
func (sys *LifecycleSys) Remove(bucketName string)
Remove - removes policy for given bucket name.
type ListAllBucketPoliciesArgs ¶
type ListAllBucketPoliciesArgs struct {
BucketName string `json:"bucketName"`
}
ListAllBucketPoliciesArgs - get all bucket policies.
func (*ListAllBucketPoliciesArgs) ToKeyValue ¶
func (args *ListAllBucketPoliciesArgs) ToKeyValue() KeyValueMap
ToKeyValue implementation for ListAllBucketPoliciesArgs
type ListAllBucketPoliciesRep ¶
type ListAllBucketPoliciesRep struct { UIVersion string `json:"uiVersion"` Policies []BucketAccessPolicy `json:"policies"` }
ListAllBucketPoliciesRep - get all bucket policy reply.
type ListBucketsRep ¶
type ListBucketsRep struct { Buckets []WebBucketInfo `json:"buckets"` UIVersion string `json:"uiVersion"` }
ListBucketsRep - list buckets response
type ListBucketsResponse ¶
type ListBucketsResponse struct { XMLName xml.Name `xml:"http://s3.amazonaws.com/doc/2006-03-01/ ListAllMyBucketsResult" json:"-"` Owner Owner // Container for one or more buckets. Buckets struct { Buckets []Bucket `xml:"Bucket"` } // Buckets are nested }
ListBucketsResponse - format for list buckets response
type ListDirFunc ¶
ListDirFunc - "listDir" function of type listDirFunc returned by listDirFactory() - explained below.
type ListMultipartUploadsResponse ¶
type ListMultipartUploadsResponse struct { XMLName xml.Name `xml:"http://s3.amazonaws.com/doc/2006-03-01/ ListMultipartUploadsResult" json:"-"` Bucket string KeyMarker string UploadIDMarker string `xml:"UploadIdMarker"` NextKeyMarker string NextUploadIDMarker string `xml:"NextUploadIdMarker"` Delimiter string Prefix string EncodingType string `xml:"EncodingType,omitempty"` MaxUploads int IsTruncated bool // List of pending uploads. Uploads []Upload `xml:"Upload"` // Delimed common prefixes. CommonPrefixes []CommonPrefix }
ListMultipartUploadsResponse - format for list multipart uploads response.
type ListMultipartsInfo ¶
type ListMultipartsInfo struct { // Together with upload-id-marker, this parameter specifies the multipart upload // after which listing should begin. KeyMarker string // Together with key-marker, specifies the multipart upload after which listing // should begin. If key-marker is not specified, the upload-id-marker parameter // is ignored. UploadIDMarker string // When a list is truncated, this element specifies the value that should be // used for the key-marker request parameter in a subsequent request. NextKeyMarker string // When a list is truncated, this element specifies the value that should be // used for the upload-id-marker request parameter in a subsequent request. NextUploadIDMarker string // Maximum number of multipart uploads that could have been included in the // response. MaxUploads int // Indicates whether the returned list of multipart uploads is truncated. A // value of true indicates that the list was truncated. The list can be truncated // if the number of multipart uploads exceeds the limit allowed or specified // by max uploads. IsTruncated bool // List of all pending uploads. Uploads []MultipartInfo // When a prefix is provided in the request, The result contains only keys // starting with the specified prefix. Prefix string // A character used to truncate the object prefixes. // NOTE: only supported delimiter is '/'. Delimiter string // CommonPrefixes contains all (if there are any) keys between Prefix and the // next occurrence of the string specified by delimiter. CommonPrefixes []string EncodingType string // Not supported yet. }
ListMultipartsInfo - represnets bucket resources for incomplete multipart uploads.
func FromMinioClientListMultipartsInfo ¶
func FromMinioClientListMultipartsInfo(lmur minio.ListMultipartUploadsResult) ListMultipartsInfo
FromMinioClientListMultipartsInfo converts minio ListMultipartUploadsResult to ListMultipartsInfo
func (ListMultipartsInfo) Lookup ¶
func (lm ListMultipartsInfo) Lookup(uploadID string) bool
Lookup - returns if uploadID is valid
type ListObjectsArgs ¶
type ListObjectsArgs struct { BucketName string `json:"bucketName"` Prefix string `json:"prefix"` Marker string `json:"marker"` }
ListObjectsArgs - list object args.
func (*ListObjectsArgs) ToKeyValue ¶
func (args *ListObjectsArgs) ToKeyValue() KeyValueMap
ToKeyValue implementation for ListObjectsArgs
type ListObjectsInfo ¶
type ListObjectsInfo struct { // Indicates whether the returned list objects response is truncated. A // value of true indicates that the list was truncated. The list can be truncated // if the number of objects exceeds the limit allowed or specified // by max keys. IsTruncated bool // When response is truncated (the IsTruncated element value in the response is true), // you can use the key name in this field as marker in the subsequent // request to get next set of objects. // // NOTE: AWS S3 returns NextMarker only if you have delimiter request parameter specified, // MinIO always returns NextMarker. NextMarker string // List of objects info for this request. Objects []ObjectInfo // List of prefixes for this request. Prefixes []string }
ListObjectsInfo - container for list objects.
func FromMinioClientListBucketResult ¶
func FromMinioClientListBucketResult(bucket string, result minio.ListBucketResult) ListObjectsInfo
FromMinioClientListBucketResult converts minio ListBucketResult to ListObjectsInfo
type ListObjectsRep ¶
type ListObjectsRep struct { Objects []WebObjectInfo `json:"objects"` Writable bool `json:"writable"` // Used by client to show "upload file" button. UIVersion string `json:"uiVersion"` }
ListObjectsRep - list objects response.
type ListObjectsResponse ¶
type ListObjectsResponse struct { XMLName xml.Name `xml:"http://s3.amazonaws.com/doc/2006-03-01/ ListBucketResult" json:"-"` Name string Prefix string Marker string // When response is truncated (the IsTruncated element value in the response // is true), you can use the key name in this field as marker in the subsequent // request to get next set of objects. Server lists objects in alphabetical // order Note: This element is returned only if you have delimiter request parameter // specified. If response does not include the NextMaker and it is truncated, // you can use the value of the last Key in the response as the marker in the // subsequent request to get the next set of object keys. NextMarker string `xml:"NextMarker,omitempty"` MaxKeys int Delimiter string // A flag that indicates whether or not ListObjects returned all of the results // that satisfied the search criteria. IsTruncated bool Contents []Object CommonPrefixes []CommonPrefix // Encoding type used to encode object keys in the response. EncodingType string `xml:"EncodingType,omitempty"` }
ListObjectsResponse - format for list objects response.
type ListObjectsV2Info ¶
type ListObjectsV2Info struct { // Indicates whether the returned list objects response is truncated. A // value of true indicates that the list was truncated. The list can be truncated // if the number of objects exceeds the limit allowed or specified // by max keys. IsTruncated bool // When response is truncated (the IsTruncated element value in the response // is true), you can use the key name in this field as marker in the subsequent // request to get next set of objects. // // NOTE: This element is returned only if you have delimiter request parameter // specified. ContinuationToken string NextContinuationToken string // List of objects info for this request. Objects []ObjectInfo // List of prefixes for this request. Prefixes []string }
ListObjectsV2Info - container for list objects version 2.
func FromMinioClientListBucketResultToV2Info ¶
func FromMinioClientListBucketResultToV2Info(bucket string, result minio.ListBucketResult) ListObjectsV2Info
FromMinioClientListBucketResultToV2Info converts minio ListBucketResult to ListObjectsV2Info
func FromMinioClientListBucketV2Result ¶
func FromMinioClientListBucketV2Result(bucket string, result minio.ListBucketV2Result) ListObjectsV2Info
FromMinioClientListBucketV2Result converts minio ListBucketResult to ListObjectsInfo
type ListObjectsV2Response ¶
type ListObjectsV2Response struct { XMLName xml.Name `xml:"http://s3.amazonaws.com/doc/2006-03-01/ ListBucketResult" json:"-"` Name string Prefix string StartAfter string `xml:"StartAfter,omitempty"` // When response is truncated (the IsTruncated element value in the response // is true), you can use the key name in this field as marker in the subsequent // request to get next set of objects. Server lists objects in alphabetical // order Note: This element is returned only if you have delimiter request parameter // specified. If response does not include the NextMaker and it is truncated, // you can use the value of the last Key in the response as the marker in the // subsequent request to get the next set of object keys. ContinuationToken string `xml:"ContinuationToken,omitempty"` NextContinuationToken string `xml:"NextContinuationToken,omitempty"` KeyCount int MaxKeys int Delimiter string // A flag that indicates whether or not ListObjects returned all of the results // that satisfied the search criteria. IsTruncated bool Contents []Object CommonPrefixes []CommonPrefix // Encoding type used to encode object keys in the response. EncodingType string `xml:"EncodingType,omitempty"` }
ListObjectsV2Response - format for list objects response.
type ListPartsInfo ¶
type ListPartsInfo struct { // Name of the bucket. Bucket string // Name of the object. Object string // Upload ID identifying the multipart upload whose parts are being listed. UploadID string // The class of storage used to store the object. StorageClass string // Part number after which listing begins. PartNumberMarker int // When a list is truncated, this element specifies the last part in the list, // as well as the value to use for the part-number-marker request parameter // in a subsequent request. NextPartNumberMarker int // Maximum number of parts that were allowed in the response. MaxParts int // Indicates whether the returned list of parts is truncated. IsTruncated bool // List of all parts. Parts []PartInfo // Any metadata set during InitMultipartUpload, including encryption headers. UserDefined map[string]string EncodingType string // Not supported yet. }
ListPartsInfo - represents list of all parts.
func FromMinioClientListPartsInfo ¶
func FromMinioClientListPartsInfo(lopr minio.ListObjectPartsResult) ListPartsInfo
FromMinioClientListPartsInfo converts minio ListObjectPartsResult to ListPartsInfo
type ListPartsResponse ¶
type ListPartsResponse struct { XMLName xml.Name `xml:"http://s3.amazonaws.com/doc/2006-03-01/ ListPartsResult" json:"-"` Bucket string Key string UploadID string `xml:"UploadId"` Initiator Initiator Owner Owner // The class of storage used to store the object. StorageClass string PartNumberMarker int NextPartNumberMarker int MaxParts int IsTruncated bool // List of parts. Parts []Part `xml:"Part"` }
ListPartsResponse - format for list parts response.
type ListVersionsResponse ¶
type ListVersionsResponse struct { XMLName xml.Name `xml:"http://s3.amazonaws.com/doc/2006-03-01/ ListVersionsResult" json:"-"` Name string Prefix string KeyMarker string // When response is truncated (the IsTruncated element value in the response // is true), you can use the key name in this field as marker in the subsequent // request to get next set of objects. Server lists objects in alphabetical // order Note: This element is returned only if you have delimiter request parameter // specified. If response does not include the NextMaker and it is truncated, // you can use the value of the last Key in the response as the marker in the // subsequent request to get the next set of object keys. NextKeyMarker string `xml:"NextKeyMarker,omitempty"` // When the number of responses exceeds the value of MaxKeys, // NextVersionIdMarker specifies the first object version not // returned that satisfies the search criteria. Use this value // for the version-id-marker request parameter in a subsequent request. NextVersionIDMarker string `xml:"NextVersionIdMarker"` // Marks the last version of the Key returned in a truncated response. VersionIDMarker string `xml:"VersionIdMarker"` MaxKeys int Delimiter string // A flag that indicates whether or not ListObjects returned all of the results // that satisfied the search criteria. IsTruncated bool CommonPrefixes []CommonPrefix Versions []ObjectVersion // Encoding type used to encode object keys in the response. EncodingType string `xml:"EncodingType,omitempty"` }
ListVersionsResponse - format for list bucket versions response.
type LocationResponse ¶
type LocationResponse struct { XMLName xml.Name `xml:"http://s3.amazonaws.com/doc/2006-03-01/ LocationConstraint" json:"-"` Location string `xml:",chardata"` }
LocationResponse - format for location response.
type LoginArgs ¶
type LoginArgs struct { Username string `json:"username" form:"username"` Password string `json:"password" form:"password"` }
LoginArgs - login arguments.
func (*LoginArgs) ToKeyValue ¶
func (args *LoginArgs) ToKeyValue() KeyValueMap
ToKeyValue implementation for LoginArgs
type LoginSTSArgs ¶
type LoginSTSArgs struct {
Token string `json:"token" form:"token"`
}
LoginSTSArgs - login arguments.
func (*LoginSTSArgs) ToKeyValue ¶
func (args *LoginSTSArgs) ToKeyValue() KeyValueMap
ToKeyValue implementation for LoginSTSArgs
type LoginSTSRep ¶
LoginSTSRep - login reply.
type MakeBucketArgs ¶
type MakeBucketArgs struct {
BucketName string `json:"bucketName"`
}
MakeBucketArgs - make bucket args.
func (*MakeBucketArgs) ToKeyValue ¶
func (args *MakeBucketArgs) ToKeyValue() KeyValueMap
ToKeyValue implementation for MakeBucketArgs
type MalformedUploadID ¶
type MalformedUploadID struct {
UploadID string
}
MalformedUploadID malformed upload id.
func (MalformedUploadID) Error ¶
func (e MalformedUploadID) Error() string
type MappedPolicy ¶
MappedPolicy represents a policy name mapped to a user or group
type MergeWalkPool ¶
type MergeWalkPool struct {
// contains filtered or unexported fields
}
MergeWalkPool - pool of mergeWalk go routines. A mergeWalk is added to the pool by Set() and removed either by doing a Release() or if the concerned timer goes off. mergeWalkPool's purpose is to maintain active mergeWalk go-routines in a map so that it can be looked up across related list calls.
func NewMergeWalkPool ¶
func NewMergeWalkPool(timeout time.Duration) *MergeWalkPool
NewMergeWalkPool - initialize new tree walk pool.
func (MergeWalkPool) Release ¶
func (t MergeWalkPool) Release(params listParams) ([]FileInfoCh, chan struct{})
Release - selects a mergeWalk from the pool based on the input listParams, removes it from the pool, and returns the MergeWalkResult channel. Returns nil if listParams does not have an asccociated mergeWalk.
func (MergeWalkPool) Set ¶
func (t MergeWalkPool) Set(params listParams, resultChs []FileInfoCh, endWalkCh chan struct{})
Set - adds a mergeWalk to the mergeWalkPool. Also starts a timer go-routine that ends when:
- time.After() expires after t.timeOut seconds. The expiration is needed so that the mergeWalk go-routine resources are freed after a timeout if the S3 client does only partial listing of objects.
- Relase() signals the timer go-routine to end on endTimerCh. During listing the timer should not timeout and end the mergeWalk go-routine, hence the timer go-routine should be ended.
type Metrics ¶
type Metrics struct {
// contains filtered or unexported fields
}
Metrics - represents bytes served from backend only implemented for S3 Gateway
func (*Metrics) GetBytesReceived ¶
GetBytesReceived - Get total bytes received from gateway backend
func (*Metrics) GetBytesSent ¶
GetBytesSent - Get total bytes received from gateway backend
func (*Metrics) GetRequests ¶
func (s *Metrics) GetRequests() RequestStats
GetRequests - Get total number of Get & Headrequests sent to gateway backend
func (*Metrics) IncBytesReceived ¶
IncBytesReceived - Increase total bytes received from gateway backend
func (*Metrics) IncBytesSent ¶
IncBytesSent - Increase total bytes sent to gateway backend
func (*Metrics) IncRequests ¶
IncRequests - Increase request count sent to gateway backend by 1
type MultipartInfo ¶
type MultipartInfo struct { // Object name for which the multipart upload was initiated. Object string // Unique identifier for this multipart upload. UploadID string // Date and time at which the multipart upload was initiated. Initiated time.Time StorageClass string // Not supported yet. }
MultipartInfo - represents metadata in progress multipart upload.
type NotImplemented ¶
type NotImplemented struct{}
NotImplemented If a feature is not implemented
func (NotImplemented) Error ¶
func (e NotImplemented) Error() string
type NotificationGroup ¶
type NotificationGroup struct {
// contains filtered or unexported fields
}
A NotificationGroup is a collection of goroutines working on subtasks that are part of the same overall task.
A zero NotificationGroup is valid and does not cancel on error.
func WithNPeers ¶
func WithNPeers(nerrs int) *NotificationGroup
WithNPeers returns a new NotificationGroup with length of errs slice upto nerrs, upon Wait() errors are returned collected from all tasks.
func (*NotificationGroup) Go ¶
Go calls the given function in a new goroutine.
The first call to return a non-nil error will be collected in errs slice and returned by Wait().
func (*NotificationGroup) Wait ¶
func (g *NotificationGroup) Wait() []NotificationPeerErr
Wait blocks until all function calls from the Go method have returned, then returns the slice of errors from all function calls.
type NotificationPeerErr ¶
type NotificationPeerErr struct { Host xnet.Host // Remote host on which the rpc call was initiated Err error // Error returned by the remote peer for an rpc call }
NotificationPeerErr returns error associated for a remote peer.
type NotificationSys ¶
NotificationSys - notification system.
func NewNotificationSys ¶
func NewNotificationSys(endpoints EndpointZones) *NotificationSys
NewNotificationSys - creates new notification system object.
func (*NotificationSys) AddRemoteTarget ¶
func (sys *NotificationSys) AddRemoteTarget(bucketName string, target event.Target, rulesMap event.RulesMap) error
AddRemoteTarget - adds event rules map, HTTP/PeerRPC client target to bucket name.
func (*NotificationSys) AddRulesMap ¶
func (sys *NotificationSys) AddRulesMap(bucketName string, rulesMap event.RulesMap)
AddRulesMap - adds rules map for bucket name.
func (*NotificationSys) BackgroundHealStatus ¶
func (sys *NotificationSys) BackgroundHealStatus() []madmin.BgHealState
BackgroundHealStatus - returns background heal status of all peers
func (*NotificationSys) BackgroundOpsStatus ¶
func (sys *NotificationSys) BackgroundOpsStatus() []BgOpsStatus
BackgroundOpsStatus - returns the status of all background operations of all peers
func (*NotificationSys) CPUInfo ¶
func (sys *NotificationSys) CPUInfo() []madmin.ServerCPUHardwareInfo
CPUInfo - CPU Hardware info
func (*NotificationSys) CPULoadInfo ¶
func (sys *NotificationSys) CPULoadInfo() []ServerCPULoadInfo
CPULoadInfo - CPU utilization information
func (*NotificationSys) CollectNetPerfInfo ¶
func (sys *NotificationSys) CollectNetPerfInfo(size int64) map[string][]ServerNetReadPerfInfo
CollectNetPerfInfo - Collect network performance information of all peers.
func (*NotificationSys) ConfiguredTargetIDs ¶
func (sys *NotificationSys) ConfiguredTargetIDs() []event.TargetID
ConfiguredTargetIDs - returns list of configured target id's
func (*NotificationSys) DeleteBucket ¶
func (sys *NotificationSys) DeleteBucket(ctx context.Context, bucketName string)
DeleteBucket - calls DeleteBucket RPC call on all peers.
func (*NotificationSys) DeletePolicy ¶
func (sys *NotificationSys) DeletePolicy(policyName string) []NotificationPeerErr
DeletePolicy - deletes policy across all peers.
func (*NotificationSys) DeleteUser ¶
func (sys *NotificationSys) DeleteUser(accessKey string) []NotificationPeerErr
DeleteUser - deletes a specific user across all peers
func (*NotificationSys) DownloadProfilingData ¶
DownloadProfilingData - download profiling data from all remote peers.
func (*NotificationSys) DrivePerfInfo ¶
func (sys *NotificationSys) DrivePerfInfo(size int64) []madmin.ServerDrivesPerfInfo
DrivePerfInfo - Drive speed (read and write) information
func (*NotificationSys) GetARNList ¶
func (sys *NotificationSys) GetARNList() []string
GetARNList - returns available ARNs.
func (*NotificationSys) GetLocks ¶
func (sys *NotificationSys) GetLocks(ctx context.Context) []*PeerLocks
GetLocks - makes GetLocks RPC call on all peers.
func (*NotificationSys) Init ¶
func (sys *NotificationSys) Init(buckets []BucketInfo, objAPI ObjectLayer) error
Init - initializes notification system from notification.xml and listener.json of all buckets.
func (*NotificationSys) LoadGroup ¶
func (sys *NotificationSys) LoadGroup(group string) []NotificationPeerErr
LoadGroup - loads a specific group on all peers.
func (*NotificationSys) LoadPolicy ¶
func (sys *NotificationSys) LoadPolicy(policyName string) []NotificationPeerErr
LoadPolicy - reloads a specific modified policy across all peers
func (*NotificationSys) LoadPolicyMapping ¶
func (sys *NotificationSys) LoadPolicyMapping(userOrGroup string, isGroup bool) []NotificationPeerErr
LoadPolicyMapping - reloads a policy mapping across all peers
func (*NotificationSys) LoadUser ¶
func (sys *NotificationSys) LoadUser(accessKey string, temp bool) []NotificationPeerErr
LoadUser - reloads a specific user across all peers
func (*NotificationSys) LoadUsers ¶
func (sys *NotificationSys) LoadUsers() []NotificationPeerErr
LoadUsers - calls LoadUsers RPC call on all peers.
func (*NotificationSys) MemUsageInfo ¶
func (sys *NotificationSys) MemUsageInfo() []ServerMemUsageInfo
MemUsageInfo - Mem utilization information
func (*NotificationSys) NetReadPerfInfo ¶
func (sys *NotificationSys) NetReadPerfInfo(size int64) []ServerNetReadPerfInfo
NetReadPerfInfo - Network read performance information.
func (*NotificationSys) NetworkInfo ¶
func (sys *NotificationSys) NetworkInfo() []madmin.ServerNetworkHardwareInfo
NetworkInfo - Network Hardware info
func (*NotificationSys) PutBucketNotification ¶
func (sys *NotificationSys) PutBucketNotification(ctx context.Context, bucketName string, rulesMap event.RulesMap)
PutBucketNotification - calls PutBucketNotification RPC call on all peers.
func (*NotificationSys) PutBucketObjectLockConfig ¶
func (sys *NotificationSys) PutBucketObjectLockConfig(ctx context.Context, bucketName string, retention Retention)
PutBucketObjectLockConfig - put bucket object lock configuration to all peers.
func (*NotificationSys) ReloadFormat ¶
func (sys *NotificationSys) ReloadFormat(dryRun bool) []NotificationPeerErr
ReloadFormat - calls ReloadFormat REST call on all peers.
func (*NotificationSys) RemoteTargetExist ¶
func (sys *NotificationSys) RemoteTargetExist(bucketName string, targetID event.TargetID) bool
RemoteTargetExist - checks whether given target ID is a HTTP/PeerRPC client target or not.
func (*NotificationSys) RemoveAllRemoteTargets ¶
func (sys *NotificationSys) RemoveAllRemoteTargets()
RemoveAllRemoteTargets - closes and removes all HTTP/PeerRPC client targets.
func (*NotificationSys) RemoveBucketLifecycle ¶
func (sys *NotificationSys) RemoveBucketLifecycle(ctx context.Context, bucketName string)
RemoveBucketLifecycle - calls RemoveLifecycle on all peers.
func (*NotificationSys) RemoveBucketObjectLockConfig ¶
func (sys *NotificationSys) RemoveBucketObjectLockConfig(ctx context.Context, bucketName string)
RemoveBucketObjectLockConfig - calls RemoveBucketObjectLockConfig RPC call on all peers.
func (*NotificationSys) RemoveBucketPolicy ¶
func (sys *NotificationSys) RemoveBucketPolicy(ctx context.Context, bucketName string)
RemoveBucketPolicy - calls RemoveBucketPolicy RPC call on all peers.
func (*NotificationSys) RemoveNotification ¶
func (sys *NotificationSys) RemoveNotification(bucketName string)
RemoveNotification - removes all notification configuration for bucket name.
func (*NotificationSys) RemoveRemoteTarget ¶
func (sys *NotificationSys) RemoveRemoteTarget(bucketName string, targetID event.TargetID)
RemoveRemoteTarget - closes and removes target by target ID.
func (*NotificationSys) RemoveRulesMap ¶
func (sys *NotificationSys) RemoveRulesMap(bucketName string, rulesMap event.RulesMap)
RemoveRulesMap - removes rules map for bucket name.
func (*NotificationSys) Send ¶
func (sys *NotificationSys) Send(args eventArgs) []event.TargetIDErr
Send - sends event data to all matching targets.
func (*NotificationSys) ServerInfo ¶
func (sys *NotificationSys) ServerInfo() []madmin.ServerProperties
ServerInfo - calls ServerInfo RPC call on all peers.
func (*NotificationSys) ServerUpdate ¶
func (sys *NotificationSys) ServerUpdate(updateURL, sha256Hex string, latestReleaseTime time.Time) []NotificationPeerErr
ServerUpdate - updates remote peers.
func (*NotificationSys) SetBucketLifecycle ¶
func (sys *NotificationSys) SetBucketLifecycle(ctx context.Context, bucketName string, bucketLifecycle *lifecycle.Lifecycle)
SetBucketLifecycle - calls SetBucketLifecycle on all peers.
func (*NotificationSys) SetBucketPolicy ¶
func (sys *NotificationSys) SetBucketPolicy(ctx context.Context, bucketName string, bucketPolicy *policy.Policy)
SetBucketPolicy - calls SetBucketPolicy RPC call on all peers.
func (*NotificationSys) SignalService ¶
func (sys *NotificationSys) SignalService(sig serviceSignal) []NotificationPeerErr
SignalService - calls signal service RPC call on all peers.
func (*NotificationSys) StartProfiling ¶
func (sys *NotificationSys) StartProfiling(profiler string) []NotificationPeerErr
StartProfiling - start profiling on remote peers, by initiating a remote RPC.
type ObjReaderFn ¶
type ObjReaderFn func(inputReader io.Reader, h http.Header, pcfn CheckCopyPreconditionFn, cleanupFns ...func()) (r *GetObjectReader, err error)
ObjReaderFn is a function type that takes a reader and returns GetObjectReader and an error. Request headers are passed to provide encryption parameters. cleanupFns allow cleanup funcs to be registered for calling after usage of the reader.
func NewGetObjectReader ¶
func NewGetObjectReader(rs *HTTPRangeSpec, oi ObjectInfo, pcfn CheckCopyPreconditionFn, cleanUpFns ...func()) ( fn ObjReaderFn, off, length int64, err error)
NewGetObjectReader creates a new GetObjectReader. The cleanUpFns are called on Close() in reverse order as passed here. NOTE: It is assumed that clean up functions do not panic (otherwise, they may not all run!).
type Object ¶
type Object struct { Key string LastModified string // time string of format "2006-01-02T15:04:05.000Z" ETag string Size int64 // Owner of the object. Owner Owner // The class of storage used to store the object. StorageClass string // UserMetadata user-defined metadata UserMetadata StringMap `xml:"UserMetadata,omitempty"` }
Object container for object metadata
type ObjectAlreadyExists ¶
type ObjectAlreadyExists GenericError
ObjectAlreadyExists object already exists.
func (ObjectAlreadyExists) Error ¶
func (e ObjectAlreadyExists) Error() string
type ObjectExistsAsDirectory ¶
type ObjectExistsAsDirectory GenericError
ObjectExistsAsDirectory object already exists as a directory.
func (ObjectExistsAsDirectory) Error ¶
func (e ObjectExistsAsDirectory) Error() string
type ObjectIdentifier ¶
type ObjectIdentifier struct {
ObjectName string `xml:"Key"`
}
ObjectIdentifier carries key name for the object to delete.
type ObjectInfo ¶
type ObjectInfo struct { // Name of the bucket. Bucket string // Name of the object. Name string // Date and time when the object was last modified. ModTime time.Time // Total object size. Size int64 // IsDir indicates if the object is prefix. IsDir bool // Hex encoded unique entity tag of the object. ETag string // A standard MIME type describing the format of the object. ContentType string // Specifies what content encodings have been applied to the object and thus // what decoding mechanisms must be applied to obtain the object referenced // by the Content-Type header field. ContentEncoding string // Date and time at which the object is no longer able to be cached Expires time.Time // CacheStatus sets status of whether this is a cache hit/miss CacheStatus CacheStatusType // CacheLookupStatus sets whether a cacheable response is present in the cache CacheLookupStatus CacheStatusType // Specify object storage class StorageClass string // User-Defined metadata UserDefined map[string]string // List of individual parts, maximum size of upto 10,000 Parts []ObjectPartInfo `json:"-"` // Implements writer and reader used by CopyObject API Writer io.WriteCloser `json:"-"` Reader *hash.Reader `json:"-"` PutObjReader *PutObjReader `json:"-"` // Date and time when the object was last accessed. AccTime time.Time // contains filtered or unexported fields }
ObjectInfo - represents object metadata.
func FromMinioClientObjectInfo ¶
func FromMinioClientObjectInfo(bucket string, oi minio.ObjectInfo) ObjectInfo
FromMinioClientObjectInfo converts minio ObjectInfo to gateway ObjectInfo
func (*ObjectInfo) DecryptedSize ¶
func (o *ObjectInfo) DecryptedSize() (int64, error)
DecryptedSize returns the size of the object after decryption in bytes. It returns an error if the object is not encrypted or marked as encrypted but has an invalid size.
func (*ObjectInfo) EncryptedSize ¶
func (o *ObjectInfo) EncryptedSize() int64
EncryptedSize returns the size of the object after encryption. An encrypted object is always larger than a plain object except for zero size objects.
func (ObjectInfo) GetActualSize ¶
func (o ObjectInfo) GetActualSize() int64
GetActualSize - read the decompressed size from the meta json.
func (*ObjectInfo) GetDecryptedRange ¶
func (o *ObjectInfo) GetDecryptedRange(rs *HTTPRangeSpec) (encOff, encLength, skipLen int64, seqNumber uint32, partStart int, err error)
GetDecryptedRange - To decrypt the range (off, length) of the decrypted object stream, we need to read the range (encOff, encLength) of the encrypted object stream to decrypt it, and compute skipLen, the number of bytes to skip in the beginning of the encrypted range.
In addition we also compute the object part number for where the requested range starts, along with the DARE sequence number within that part. For single part objects, the partStart will be 0.
func (ObjectInfo) IsCacheable ¶
func (o ObjectInfo) IsCacheable() bool
IsCacheable returns if the object should be saved in the cache.
func (ObjectInfo) IsCompressed ¶
func (o ObjectInfo) IsCompressed() bool
IsCompressed returns true if the object is marked as compressed.
func (ObjectInfo) IsCompressedOK ¶
func (o ObjectInfo) IsCompressedOK() (bool, error)
IsCompressedOK returns whether the object is compressed and can be decompressed.
type ObjectLayer ¶
type ObjectLayer interface { // Locking operations on object. NewNSLock(ctx context.Context, bucket string, object string) RWLocker // Storage operations. Shutdown(context.Context) error StorageInfo(context.Context) StorageInfo // Bucket operations. MakeBucketWithLocation(ctx context.Context, bucket string, location string) error GetBucketInfo(ctx context.Context, bucket string) (bucketInfo BucketInfo, err error) ListBuckets(ctx context.Context) (buckets []BucketInfo, err error) DeleteBucket(ctx context.Context, bucket string) error ListObjects(ctx context.Context, bucket, prefix, marker, delimiter string, maxKeys int) (result ListObjectsInfo, err error) ListObjectsV2(ctx context.Context, bucket, prefix, continuationToken, delimiter string, maxKeys int, fetchOwner bool, startAfter string) (result ListObjectsV2Info, err error) // GetObjectNInfo returns a GetObjectReader that satisfies the // ReadCloser interface. The Close method unlocks the object // after reading, so it must always be called after usage. // // IMPORTANTLY, when implementations return err != nil, this // function MUST NOT return a non-nil ReadCloser. GetObjectNInfo(ctx context.Context, bucket, object string, rs *HTTPRangeSpec, h http.Header, lockType LockType, opts ObjectOptions) (reader *GetObjectReader, err error) GetObject(ctx context.Context, bucket, object string, startOffset int64, length int64, writer io.Writer, etag string, opts ObjectOptions) (err error) GetObjectInfo(ctx context.Context, bucket, object string, opts ObjectOptions) (objInfo ObjectInfo, err error) PutObject(ctx context.Context, bucket, object string, data *PutObjReader, opts ObjectOptions) (objInfo ObjectInfo, err error) CopyObject(ctx context.Context, srcBucket, srcObject, destBucket, destObject string, srcInfo ObjectInfo, srcOpts, dstOpts ObjectOptions) (objInfo ObjectInfo, err error) DeleteObject(ctx context.Context, bucket, object string) error DeleteObjects(ctx context.Context, bucket string, objects []string) ([]error, error) // Multipart operations. ListMultipartUploads(ctx context.Context, bucket, prefix, keyMarker, uploadIDMarker, delimiter string, maxUploads int) (result ListMultipartsInfo, err error) NewMultipartUpload(ctx context.Context, bucket, object string, opts ObjectOptions) (uploadID string, err error) CopyObjectPart(ctx context.Context, srcBucket, srcObject, destBucket, destObject string, uploadID string, partID int, startOffset int64, length int64, srcInfo ObjectInfo, srcOpts, dstOpts ObjectOptions) (info PartInfo, err error) PutObjectPart(ctx context.Context, bucket, object, uploadID string, partID int, data *PutObjReader, opts ObjectOptions) (info PartInfo, err error) ListObjectParts(ctx context.Context, bucket, object, uploadID string, partNumberMarker int, maxParts int, opts ObjectOptions) (result ListPartsInfo, err error) AbortMultipartUpload(ctx context.Context, bucket, object, uploadID string) error CompleteMultipartUpload(ctx context.Context, bucket, object, uploadID string, uploadedParts []CompletePart, opts ObjectOptions) (objInfo ObjectInfo, err error) // Healing operations. ReloadFormat(ctx context.Context, dryRun bool) error HealFormat(ctx context.Context, dryRun bool) (madmin.HealResultItem, error) HealBucket(ctx context.Context, bucket string, dryRun, remove bool) (madmin.HealResultItem, error) HealObject(ctx context.Context, bucket, object string, dryRun, remove bool, scanMode madmin.HealScanMode) (madmin.HealResultItem, error) HealObjects(ctx context.Context, bucket, prefix string, healObjectFn func(string, string) error) error ListBucketsHeal(ctx context.Context) (buckets []BucketInfo, err error) ListObjectsHeal(ctx context.Context, bucket, prefix, marker, delimiter string, maxKeys int) (result ListObjectsInfo, err error) // Policy operations SetBucketPolicy(context.Context, string, *policy.Policy) error GetBucketPolicy(context.Context, string) (*policy.Policy, error) DeleteBucketPolicy(context.Context, string) error // Supported operations check IsNotificationSupported() bool IsListenBucketSupported() bool IsEncryptionSupported() bool // Compression support check. IsCompressionSupported() bool // Lifecycle operations SetBucketLifecycle(context.Context, string, *lifecycle.Lifecycle) error GetBucketLifecycle(context.Context, string) (*lifecycle.Lifecycle, error) DeleteBucketLifecycle(context.Context, string) error // Backend related metrics GetMetrics(ctx context.Context) (*Metrics, error) // Check Readiness IsReady(ctx context.Context) bool }
ObjectLayer implements primitives for object API layer.
func NewFSObjectLayer ¶
func NewFSObjectLayer(fsPath string) (ObjectLayer, error)
NewFSObjectLayer - initialize new fs object layer.
func NewGatewayLayerWithLocker ¶
func NewGatewayLayerWithLocker(gwLayer ObjectLayer) ObjectLayer
NewGatewayLayerWithLocker - initialize gateway with locker.
type ObjectLockConfig ¶
type ObjectLockConfig struct { XMLNS string `xml:"xmlns,attr,omitempty"` XMLName xml.Name `xml:"ObjectLockConfiguration"` ObjectLockEnabled string `xml:"ObjectLockEnabled"` Rule *struct { DefaultRetention DefaultRetention `xml:"DefaultRetention"` } `xml:"Rule,omitempty"` }
ObjectLockConfig - object lock configuration specified in https://docs.aws.amazon.com/AmazonS3/latest/API/Type_API_ObjectLockConfiguration.html
func (*ObjectLockConfig) ToRetention ¶
func (config *ObjectLockConfig) ToRetention() (r Retention)
ToRetention - convert to Retention type.
func (*ObjectLockConfig) UnmarshalXML ¶
func (config *ObjectLockConfig) UnmarshalXML(d *xml.Decoder, start xml.StartElement) error
UnmarshalXML - decodes XML data.
type ObjectNameInvalid ¶
type ObjectNameInvalid GenericError
ObjectNameInvalid - object name provided is invalid.
func (ObjectNameInvalid) Error ¶
func (e ObjectNameInvalid) Error() string
Return string an error formatted as the given text.
type ObjectNamePrefixAsSlash ¶
type ObjectNamePrefixAsSlash GenericError
ObjectNamePrefixAsSlash - object name has a slash as prefix.
func (ObjectNamePrefixAsSlash) Error ¶
func (e ObjectNamePrefixAsSlash) Error() string
Return string an error formatted as the given text.
type ObjectNameTooLong ¶
type ObjectNameTooLong GenericError
ObjectNameTooLong - object name too long.
func (ObjectNameTooLong) Error ¶
func (e ObjectNameTooLong) Error() string
Return string an error formatted as the given text.
type ObjectNotFound ¶
type ObjectNotFound GenericError
ObjectNotFound object does not exist.
func (ObjectNotFound) Error ¶
func (e ObjectNotFound) Error() string
type ObjectOptions ¶
type ObjectOptions struct { ServerSideEncryption encrypt.ServerSide UserDefined map[string]string CheckCopyPrecondFn CheckCopyPreconditionFn }
ObjectOptions represents object options for ObjectLayer operations
type ObjectPartInfo ¶
type ObjectPartInfo struct { Number int `json:"number"` Name string `json:"name"` ETag string `json:"etag"` Size int64 `json:"size"` ActualSize int64 `json:"actualSize"` }
ObjectPartInfo Info of each part kept in the multipart metadata file after CompleteMultipartUpload() is called.
type ObjectRetention ¶
type ObjectRetention struct { XMLNS string `xml:"xmlns,attr,omitempty"` XMLName xml.Name `xml:"Retention"` Mode RetentionMode `xml:"Mode,omitempty"` RetainUntilDate RetentionDate `xml:"RetainUntilDate,omitempty"` }
ObjectRetention specified in https://docs.aws.amazon.com/AmazonS3/latest/API/API_PutObjectRetention.html
type ObjectTooLarge ¶
type ObjectTooLarge GenericError
ObjectTooLarge error returned when the size of the object > max object size allowed (5G) per request.
func (ObjectTooLarge) Error ¶
func (e ObjectTooLarge) Error() string
type ObjectTooSmall ¶
type ObjectTooSmall GenericError
ObjectTooSmall error returned when the size of the object < what is expected.
func (ObjectTooSmall) Error ¶
func (e ObjectTooSmall) Error() string
type ObjectVersion ¶
type ObjectVersion struct { XMLName xml.Name `xml:"http://s3.amazonaws.com/doc/2006-03-01/ Version" json:"-"` Object VersionID string `xml:"VersionId"` IsLatest bool }
ObjectVersion container for object version metadata
type OperationTimedOut ¶
type OperationTimedOut struct {
Path string
}
OperationTimedOut - a timeout occurred.
func (OperationTimedOut) Error ¶
func (e OperationTimedOut) Error() string
type ParentIsObject ¶
type ParentIsObject GenericError
ParentIsObject object access is denied.
func (ParentIsObject) Error ¶
func (e ParentIsObject) Error() string
type PartInfo ¶
type PartInfo struct { // Part number that identifies the part. This is a positive integer between // 1 and 10,000. PartNumber int // Date and time at which the part was uploaded. LastModified time.Time // Entity tag returned when the part was initially uploaded. ETag string // Size in bytes of the part. Size int64 // Decompressed Size. ActualSize int64 }
PartInfo - represents individual part metadata.
func FromMinioClientObjectPart ¶
func FromMinioClientObjectPart(op minio.ObjectPart) PartInfo
FromMinioClientObjectPart converts minio ObjectPart to PartInfo
type PartTooBig ¶
type PartTooBig struct{}
PartTooBig returned if size of part is bigger than the allowed limit.
func (PartTooBig) Error ¶
func (e PartTooBig) Error() string
type PartTooSmall ¶
PartTooSmall - error if part size is less than 5MB.
func (PartTooSmall) Error ¶
func (e PartTooSmall) Error() string
type PeerLocks ¶
type PeerLocks struct { Addr string Locks GetLocksResp }
PeerLocks holds server information result of one node
type PeerRESTClientTarget ¶
type PeerRESTClientTarget struct {
// contains filtered or unexported fields
}
PeerRESTClientTarget - RPCClient is an event.Target which sends event to target of remote peer.
func NewPeerRESTClientTarget ¶
func NewPeerRESTClientTarget(bucketName string, targetID event.TargetID, restClient *peerRESTClient) *PeerRESTClientTarget
NewPeerRESTClientTarget - creates RPCClient target with given target ID available in remote peer.
func (*PeerRESTClientTarget) Close ¶
func (target *PeerRESTClientTarget) Close() error
Close - does nothing and available for interface compatibility.
func (*PeerRESTClientTarget) ID ¶
func (target *PeerRESTClientTarget) ID() event.TargetID
ID - returns target ID.
func (*PeerRESTClientTarget) IsActive ¶
func (target *PeerRESTClientTarget) IsActive() (bool, error)
IsActive - does nothing and available for interface compatibility.
func (*PeerRESTClientTarget) Save ¶
func (target *PeerRESTClientTarget) Save(eventData event.Event) error
Save - Sends event directly without persisting.
func (*PeerRESTClientTarget) Send ¶
func (target *PeerRESTClientTarget) Send(eventKey string) error
Send - interface compatible method does no-op.
type PolicySys ¶
PolicySys - policy subsystem.
func (*PolicySys) Init ¶
func (sys *PolicySys) Init(buckets []BucketInfo, objAPI ObjectLayer) error
Init - initializes policy system from policy.json of all buckets.
func (*PolicySys) IsAllowed ¶
IsAllowed - checks given policy args is allowed to continue the Rest API.
type PostPolicyForm ¶
type PostPolicyForm struct { Expiration time.Time // Expiration date and time of the POST policy. Conditions struct { Policies []struct { Operator string Key string Value string } ContentLengthRange contentLengthRange } }
PostPolicyForm provides strict static type conversion and validation for Amazon S3's POST policy JSON string.
type PostResponse ¶
PostResponse container for POST object request when success_action_status is set to 201
type PreConditionFailed ¶
type PreConditionFailed struct{}
PreConditionFailed - Check if copy precondition failed
func (PreConditionFailed) Error ¶
func (e PreConditionFailed) Error() string
type PrefixAccessDenied ¶
type PrefixAccessDenied GenericError
PrefixAccessDenied object access is denied.
func (PrefixAccessDenied) Error ¶
func (e PrefixAccessDenied) Error() string
type PresignedGetArgs ¶
type PresignedGetArgs struct { // Host header required for signed headers. HostName string `json:"host"` // Bucket name of the object to be presigned. BucketName string `json:"bucket"` // Object name to be presigned. ObjectName string `json:"object"` // Expiry in seconds. Expiry int64 `json:"expiry"` }
PresignedGetArgs - presigned-get API args.
func (*PresignedGetArgs) ToKeyValue ¶
func (args *PresignedGetArgs) ToKeyValue() KeyValueMap
ToKeyValue implementation for PresignedGetArgs
type PresignedGetRep ¶
type PresignedGetRep struct { UIVersion string `json:"uiVersion"` // Presigned URL of the object. URL string `json:"url"` }
PresignedGetRep - presigned-get URL reply.
type PutObjReader ¶
type PutObjReader struct { *hash.Reader // actual data stream // contains filtered or unexported fields }
PutObjReader is a type that wraps sio.EncryptReader and underlying hash.Reader in a struct
func NewPutObjReader ¶
NewPutObjReader returns a new PutObjReader and holds reference to underlying data stream from client and the encrypted data reader
func (*PutObjReader) MD5CurrentHexString ¶
func (p *PutObjReader) MD5CurrentHexString() string
MD5CurrentHexString returns the current MD5Sum or encrypted MD5Sum as a hex encoded string
func (*PutObjReader) Size ¶
func (p *PutObjReader) Size() int64
Size returns the absolute number of bytes the Reader will return during reading. It returns -1 for unlimited data.
type RWLocker ¶
type RWLocker interface { GetLock(timeout *dynamicTimeout) (timedOutErr error) Unlock() GetRLock(timeout *dynamicTimeout) (timedOutErr error) RUnlock() }
RWLocker - locker interface to introduce GetRLock, RUnlock.
type RemoveBucketArgs ¶
type RemoveBucketArgs struct {
BucketName string `json:"bucketName"`
}
RemoveBucketArgs - remove bucket args.
func (*RemoveBucketArgs) ToKeyValue ¶
func (args *RemoveBucketArgs) ToKeyValue() KeyValueMap
ToKeyValue implementation for RemoveBucketArgs
type RemoveObjectArgs ¶
type RemoveObjectArgs struct { Objects []string `json:"objects"` // Contains objects, prefixes. BucketName string `json:"bucketname"` // Contains bucket name. }
RemoveObjectArgs - args to remove an object, JSON will look like.
{ "bucketname": "testbucket", "objects": [ "photos/hawaii/", "photos/maldives/", "photos/sanjose.jpg" ] }
func (*RemoveObjectArgs) ToKeyValue ¶
func (args *RemoveObjectArgs) ToKeyValue() KeyValueMap
ToKeyValue implementation for RemoveObjectArgs
type RequestStats ¶
RequestStats - counts for Get and Head requests
type Retention ¶
type Retention struct { Mode RetentionMode Validity time.Duration }
Retention - bucket level retention configuration.
type RetentionDate ¶
RetentionDate is a embedded type containing time.Time to unmarshal Date in Retention
func (*RetentionDate) MarshalXML ¶
func (rDate *RetentionDate) MarshalXML(e *xml.Encoder, startElement xml.StartElement) error
MarshalXML encodes expiration date if it is non-zero and encodes empty string otherwise
func (*RetentionDate) UnmarshalXML ¶
func (rDate *RetentionDate) UnmarshalXML(d *xml.Decoder, startElement xml.StartElement) error
UnmarshalXML parses date from Expiration and validates date format
type RetentionMode ¶
type RetentionMode string
RetentionMode - object retention mode.
const ( // Governance - governance mode. Governance RetentionMode = "GOVERNANCE" // Compliance - compliance mode. Compliance RetentionMode = "COMPLIANCE" // Invalid - invalid retention mode. Invalid RetentionMode = "" )
type STSErrorCode ¶
type STSErrorCode int
STSErrorCode type of error status.
const ( ErrSTSNone STSErrorCode = iota ErrSTSAccessDenied ErrSTSMissingParameter ErrSTSInvalidParameterValue ErrSTSWebIdentityExpiredToken ErrSTSClientGrantsExpiredToken ErrSTSInvalidClientGrantsToken ErrSTSMalformedPolicyDocument ErrSTSNotInitialized ErrSTSInternalError )
Error codes, non exhaustive list - http://docs.aws.amazon.com/STS/latest/APIReference/API_AssumeRoleWithSAML.html
type STSErrorResponse ¶
type STSErrorResponse struct { XMLName xml.Name `xml:"https://sts.amazonaws.com/doc/2011-06-15/ ErrorResponse" json:"-"` Error struct { Type string `xml:"Type"` Code string `xml:"Code"` Message string `xml:"Message"` } `xml:"Error"` RequestID string `xml:"RequestId"` }
STSErrorResponse - error response format
type SealMD5CurrFn ¶
SealMD5CurrFn seals md5sum with object encryption key and returns sealed md5sum
type ServerCPULoadInfo ¶
type ServerCPULoadInfo struct { Addr string `json:"addr"` Error string `json:"error,omitempty"` Load []cpu.Load `json:"load"` HistoricLoad []cpu.Load `json:"historicLoad"` }
ServerCPULoadInfo holds informantion about cpu utilization of one minio node. It also reports any errors if encountered while trying to reach this server.
type ServerConnStats ¶
type ServerConnStats struct { TotalInputBytes uint64 `json:"transferred"` TotalOutputBytes uint64 `json:"received"` Throughput uint64 `json:"throughput,omitempty"` S3InputBytes uint64 `json:"transferredS3"` S3OutputBytes uint64 `json:"receivedS3"` }
ServerConnStats holds transferred bytes from/to the server
type ServerHTTPAPIStats ¶
ServerHTTPAPIStats holds total number of HTTP operations from/to the server, including the average duration the call was spent.
type ServerHTTPStats ¶
type ServerHTTPStats struct { CurrentS3Requests ServerHTTPAPIStats `json:"currentS3Requests"` TotalS3Requests ServerHTTPAPIStats `json:"totalS3Requests"` TotalS3Errors ServerHTTPAPIStats `json:"totalS3Errors"` }
ServerHTTPStats holds all type of http operations performed to/from the server including their average execution time.
type ServerInfo ¶
type ServerInfo struct { Error string `json:"error"` Addr string `json:"addr"` Data *ServerInfoData `json:"data"` }
ServerInfo holds server information result of one node
type ServerInfoData ¶
type ServerInfoData struct { ConnStats ServerConnStats `json:"network"` HTTPStats ServerHTTPStats `json:"http"` Properties ServerProperties `json:"server"` }
ServerInfoData holds storage, connections and other information of a given server.
type ServerInfoRep ¶
type ServerInfoRep struct { MinioVersion string MinioMemory string MinioPlatform string MinioRuntime string MinioGlobalInfo map[string]interface{} MinioUserInfo map[string]interface{} UIVersion string `json:"uiVersion"` }
ServerInfoRep - server info reply.
type ServerMemUsageInfo ¶
type ServerMemUsageInfo struct { Addr string `json:"addr"` Error string `json:"error,omitempty"` Usage []mem.Usage `json:"usage"` HistoricUsage []mem.Usage `json:"historicUsage"` }
ServerMemUsageInfo holds informantion about memory utilization of one minio node. It also reports any errors if encountered while trying to reach this server.
type ServerNetReadPerfInfo ¶
type ServerNetReadPerfInfo struct { Addr string `json:"addr"` ReadThroughput uint64 `json:"readThroughput"` Error string `json:"error,omitempty"` }
ServerNetReadPerfInfo network read performance information.
type ServerProperties ¶
type ServerProperties struct { Uptime int64 `json:"uptime"` Version string `json:"version"` CommitID string `json:"commitID"` DeploymentID string `json:"deploymentID"` Region string `json:"region"` SQSARN []string `json:"sqsARN"` }
ServerProperties holds some server information such as, version, region uptime, etc..
type ServerSystemConfig ¶
type ServerSystemConfig struct { MinioPlatform string MinioRuntime string MinioEndpoints EndpointZones }
ServerSystemConfig - captures information about server configuration.
func (ServerSystemConfig) Diff ¶
func (s1 ServerSystemConfig) Diff(s2 ServerSystemConfig) error
Diff - returns error on first difference found in two configs.
type SetAuthArgs ¶
type SetAuthArgs struct { CurrentAccessKey string `json:"currentAccessKey"` CurrentSecretKey string `json:"currentSecretKey"` NewAccessKey string `json:"newAccessKey"` NewSecretKey string `json:"newSecretKey"` }
SetAuthArgs - argument for SetAuth
func (*SetAuthArgs) ToKeyValue ¶
func (args *SetAuthArgs) ToKeyValue() KeyValueMap
ToKeyValue implementation for SetAuthArgs SetAuthArgs doesn't implement the ToKeyValue interface that will be used by logger subsystem down the line, to avoid leaking credentials to an external log target
type SetAuthReply ¶
type SetAuthReply struct { Token string `json:"token"` UIVersion string `json:"uiVersion"` PeerErrMsgs map[string]string `json:"peerErrMsgs"` }
SetAuthReply - reply for SetAuth
type SetBucketPolicyWebArgs ¶
type SetBucketPolicyWebArgs struct { BucketName string `json:"bucketName"` Prefix string `json:"prefix"` Policy string `json:"policy"` }
SetBucketPolicyWebArgs - set bucket policy args.
func (*SetBucketPolicyWebArgs) ToKeyValue ¶
func (args *SetBucketPolicyWebArgs) ToKeyValue() KeyValueMap
ToKeyValue implementation for SetBucketPolicyWebArgs
type SetupType ¶
type SetupType int
SetupType - enum for setup type.
const ( // UnknownSetupType - starts with unknown setup type. UnknownSetupType SetupType = iota // FSSetupType - FS setup type enum. FSSetupType // XLSetupType - XL setup type enum. XLSetupType // DistXLSetupType - Distributed XL setup type enum. DistXLSetupType // GatewaySetupType - gateway setup type enum. GatewaySetupType )
type SignatureDoesNotMatch ¶
type SignatureDoesNotMatch struct{}
SignatureDoesNotMatch - when content md5 does not match with what was sent from client.
func (SignatureDoesNotMatch) Error ¶
func (e SignatureDoesNotMatch) Error() string
type StartProfilingResult ¶
type StartProfilingResult struct { NodeName string `json:"nodeName"` Success bool `json:"success"` Error string `json:"error"` }
StartProfilingResult contains the status of the starting profiling action in a given server
type StatInfo ¶
type StatInfo struct {
// contains filtered or unexported fields
}
StatInfo - alias for statInfo
type StorageAPI ¶
type StorageAPI interface { // Stringified version of disk. String() string // Storage operations. IsOnline() bool // Returns true if disk is online. Hostname() string // Returns host name if remote host. Close() error SetDiskID(id string) DiskInfo() (info DiskInfo, err error) CrawlAndGetDataUsage(endCh <-chan struct{}) (DataUsageInfo, error) // Volume operations. MakeVol(volume string) (err error) MakeVolBulk(volumes ...string) (err error) ListVols() (vols []VolInfo, err error) StatVol(volume string) (vol VolInfo, err error) DeleteVol(volume string) (err error) // Walk in sorted order directly on disk. Walk(volume, dirPath string, marker string, recursive bool, leafFile string, readMetadataFn readMetadataFunc, endWalkCh chan struct{}) (chan FileInfo, error) // File operations. ListDir(volume, dirPath string, count int, leafFile string) ([]string, error) ReadFile(volume string, path string, offset int64, buf []byte, verifier *BitrotVerifier) (n int64, err error) AppendFile(volume string, path string, buf []byte) (err error) CreateFile(volume, path string, size int64, reader io.Reader) error ReadFileStream(volume, path string, offset, length int64) (io.ReadCloser, error) RenameFile(srcVolume, srcPath, dstVolume, dstPath string) error StatFile(volume string, path string) (file FileInfo, err error) DeleteFile(volume string, path string) (err error) DeleteFileBulk(volume string, paths []string) (errs []error, err error) VerifyFile(volume, path string, size int64, algo BitrotAlgorithm, sum []byte, shardSize int64) error // Write all data, syncs the data to disk. WriteAll(volume string, path string, reader io.Reader) (err error) // Read all. ReadAll(volume string, path string) (buf []byte, err error) }
StorageAPI interface.
var OfflineDisk StorageAPI // zero value is nil
OfflineDisk represents an unavailable disk.
type StorageErr ¶
type StorageErr string
StorageErr represents error generated by posix call.
func (StorageErr) Error ¶
func (h StorageErr) Error() string
type StorageFull ¶
type StorageFull struct{}
StorageFull storage ran out of space.
func (StorageFull) Error ¶
func (e StorageFull) Error() string
type StorageInfo ¶
type StorageInfo struct { Used []uint64 // Used total used per disk. Total []uint64 // Total disk space per disk. Available []uint64 // Total disk space available per disk. MountPaths []string // Disk mountpoints // Backend type. Backend struct { // Represents various backend types, currently on FS, Erasure and Gateway Type BackendType // Following fields are only meaningful if BackendType is Gateway. GatewayOnline bool // Following fields are only meaningful if BackendType is Erasure. OnlineDisks madmin.BackendDisks // Online disks during server startup. OfflineDisks madmin.BackendDisks // Offline disks during server startup. StandardSCData int // Data disks for currently configured Standard storage class. StandardSCParity int // Parity disks for currently configured Standard storage class. RRSCData int // Data disks for currently configured Reduced Redundancy storage class. RRSCParity int // Parity disks for currently configured Reduced Redundancy storage class. // List of all disk status, this is only meaningful if BackendType is Erasure. Sets [][]madmin.DriveInfo } }
StorageInfo - represents total capacity of underlying storage.
type StorageInfoRep ¶
type StorageInfoRep struct { StorageInfo StorageInfo `json:"storageInfo"` UIVersion string `json:"uiVersion"` }
StorageInfoRep - contains storage usage statistics.
type StringMap ¶
StringMap is a map[string]string.
func (StringMap) MarshalXML ¶
MarshalXML - StringMap marshals into XML.
type ToKeyValuer ¶
type ToKeyValuer interface {
ToKeyValue() KeyValueMap
}
ToKeyValuer interface wraps ToKeyValue method that allows types to marshal their values as a map of structure member names to their values, as strings
type TreeWalkPool ¶
type TreeWalkPool struct {
// contains filtered or unexported fields
}
TreeWalkPool - pool of treeWalk go routines. A treeWalk is added to the pool by Set() and removed either by doing a Release() or if the concerned timer goes off. treeWalkPool's purpose is to maintain active treeWalk go-routines in a map so that it can be looked up across related list calls.
func NewTreeWalkPool ¶
func NewTreeWalkPool(timeout time.Duration) *TreeWalkPool
NewTreeWalkPool - initialize new tree walk pool.
func (TreeWalkPool) Release ¶
func (t TreeWalkPool) Release(params listParams) (resultCh chan TreeWalkResult, endWalkCh chan struct{})
Release - selects a treeWalk from the pool based on the input listParams, removes it from the pool, and returns the TreeWalkResult channel. Returns nil if listParams does not have an asccociated treeWalk.
func (TreeWalkPool) Set ¶
func (t TreeWalkPool) Set(params listParams, resultCh chan TreeWalkResult, endWalkCh chan struct{})
Set - adds a treeWalk to the treeWalkPool. Also starts a timer go-routine that ends when:
- time.After() expires after t.timeOut seconds. The expiration is needed so that the treeWalk go-routine resources are freed after a timeout if the S3 client does only partial listing of objects.
- Relase() signals the timer go-routine to end on endTimerCh. During listing the timer should not timeout and end the treeWalk go-routine, hence the timer go-routine should be ended.
type TreeWalkResult ¶
type TreeWalkResult struct {
// contains filtered or unexported fields
}
TreeWalkResult - Tree walk result carries results of tree walking.
type URLTokenReply ¶
URLTokenReply contains the reply for CreateURLToken.
type UnsupportedDelimiter ¶
type UnsupportedDelimiter struct {
Delimiter string
}
UnsupportedDelimiter - unsupported delimiter.
func (UnsupportedDelimiter) Error ¶
func (e UnsupportedDelimiter) Error() string
type UnsupportedMetadata ¶
type UnsupportedMetadata struct{}
UnsupportedMetadata - unsupported metadata
func (UnsupportedMetadata) Error ¶
func (e UnsupportedMetadata) Error() string
type Upload ¶
type Upload struct { Key string UploadID string `xml:"UploadId"` Initiator Initiator Owner Owner StorageClass string Initiated string }
Upload container for in progress multipart upload
type UserIdentity ¶
type UserIdentity struct { Version int `json:"version"` Credentials auth.Credentials `json:"credentials"` }
UserIdentity represents a user's secret key and their status
type UsersSysType ¶
type UsersSysType string
UsersSysType - defines the type of users and groups system that is active on the server.
const ( // This mode uses the internal users system in MinIO. MinIOUsersSysType UsersSysType = "MinIOUsersSys" // This mode uses users and groups from a configured LDAP // server. LDAPUsersSysType UsersSysType = "LDAPUsersSys" )
Types of users configured in the server.
type VerifyFileResp ¶
type VerifyFileResp struct {
Err error
}
VerifyFileResp - VerifyFile()'s response.
type VolInfo ¶
type VolInfo struct { // Name of the volume. Name string // Date and time when the volume was created. Created time.Time }
VolInfo - represents volume stat information.
type WebBucketInfo ¶
type WebBucketInfo struct { // The name of the bucket. Name string `json:"name"` // Date the bucket was created. CreationDate time.Time `json:"creationDate"` }
WebBucketInfo container for list buckets metadata.
type WebGenericArgs ¶
type WebGenericArgs struct{}
WebGenericArgs - empty struct for calls that don't accept arguments for ex. ServerInfo, GenerateAuth
func (*WebGenericArgs) ToKeyValue ¶
func (args *WebGenericArgs) ToKeyValue() KeyValueMap
ToKeyValue implementation for WebGenericArgs
type WebGenericRep ¶
type WebGenericRep struct {
UIVersion string `json:"uiVersion"`
}
WebGenericRep - reply structure for calls for which reply is success/failure for ex. RemoveObject MakeBucket
type WebIdentityResult ¶
type WebIdentityResult struct { // The identifiers for the temporary security credentials that the operation // returns. AssumedRoleUser AssumedRoleUser `xml:",omitempty"` // The intended audience (also known as client ID) of the web identity token. // This is traditionally the client identifier issued to the application that // requested the client grants. Audience string `xml:",omitempty"` // The temporary security credentials, which include an access key ID, a secret // access key, and a security (or session) token. // // Note: The size of the security token that STS APIs return is not fixed. We // strongly recommend that you make no assumptions about the maximum size. As // of this writing, the typical size is less than 4096 bytes, but that can vary. // Also, future updates to AWS might require larger sizes. Credentials auth.Credentials `xml:",omitempty"` // A percentage value that indicates the size of the policy in packed form. // The service rejects any policy with a packed size greater than 100 percent, // which means the policy exceeded the allowed space. PackedPolicySize int `xml:",omitempty"` // The issuing authority of the web identity token presented. For OpenID Connect // ID tokens, this contains the value of the iss field. For OAuth 2.0 access tokens, // this contains the value of the ProviderId parameter that was passed in the // AssumeRoleWithWebIdentity request. Provider string `xml:",omitempty"` // The unique user identifier that is returned by the identity provider. // This identifier is associated with the Token that was submitted // with the AssumeRoleWithWebIdentity call. The identifier is typically unique to // the user and the application that acquired the WebIdentityToken (pairwise identifier). // For OpenID Connect ID tokens, this field contains the value returned by the identity // provider as the token's sub (Subject) claim. SubjectFromWebIdentityToken string `xml:",omitempty"` }
WebIdentityResult - Contains the response to a successful AssumeRoleWithWebIdentity request, including temporary credentials that can be used to make MinIO API requests.
type WebObjectInfo ¶
type WebObjectInfo struct { // Name of the object Key string `json:"name"` // Date and time the object was last modified. LastModified time.Time `json:"lastModified"` // Size in bytes of the object. Size int64 `json:"size"` // ContentType is mime type of the object. ContentType string `json:"contentType"` }
WebObjectInfo container for list objects metadata.
type ZoneEndpoints ¶
ZoneEndpoints represent endpoints in a given zone along with its setCount and drivesPerSet.
Source Files ¶
- acl-handlers.go
- admin-handlers-config-kv.go
- admin-handlers-users.go
- admin-handlers.go
- admin-heal-ops.go
- admin-router.go
- admin-server-info.go
- api-datatypes.go
- api-errors.go
- api-headers.go
- api-resources.go
- api-response.go
- api-router.go
- api-utils.go
- auth-handler.go
- background-heal-ops.go
- background-newdisks-heal-ops.go
- bitrot-streaming.go
- bitrot-whole.go
- bitrot.go
- bootstrap-peer-server.go
- bucket-handlers-listobjects.go
- bucket-handlers.go
- bucket-lifecycle-handler.go
- bucket-notification-handlers.go
- bucket-policy-handlers.go
- build-constants.go
- common-main.go
- config-common.go
- config-current.go
- config-dir.go
- config-encrypted.go
- config-migrate.go
- config-versions.go
- config.go
- consolelogger.go
- copy-part-range.go
- crossdomain-xml-handler.go
- daily-lifecycle-ops.go
- data-usage.go
- disk-cache-backend.go
- disk-cache-stats.go
- disk-cache-utils.go
- disk-cache.go
- dummy-handlers.go
- dynamic-timeouts.go
- encryption-v1.go
- endpoint-ellipses.go
- endpoint.go
- erasure-decode.go
- erasure-encode.go
- erasure-heal.go
- erasure-utils.go
- erasure.go
- etcd.go
- fallocate_linux.go
- fastwalk.go
- format-disk-cache.go
- format-fs.go
- format-meta.go
- format-xl.go
- fs-v1-helpers.go
- fs-v1-metadata.go
- fs-v1-multipart.go
- fs-v1-rwpool.go
- fs-v1.go
- gateway-common.go
- gateway-env.go
- gateway-interface.go
- gateway-main.go
- gateway-metrics.go
- gateway-startup-msg.go
- gateway-unsupported.go
- generic-handlers.go
- global-heal.go
- globals.go
- handler-utils.go
- hasher.go
- healthcheck-handler.go
- healthcheck-router.go
- http-stats.go
- http-tracer.go
- http-traffic-recorder.go
- httprange.go
- iam-etcd-store.go
- iam-object-store.go
- iam.go
- jwt.go
- lifecycle.go
- local-locker.go
- lock-rest-client.go
- lock-rest-server-common.go
- lock-rest-server.go
- main.go
- merge-walk-pool.go
- metrics-router.go
- metrics.go
- namespace-lock.go
- net.go
- notification.go
- object-api-common.go
- object-api-datatypes.go
- object-api-errors.go
- object-api-input-checks.go
- object-api-interface.go
- object-api-utils.go
- object-handlers-common.go
- object-handlers.go
- object-lock.go
- os-reliable.go
- peer-rest-client-target.go
- peer-rest-client.go
- peer-rest-common.go
- peer-rest-server.go
- policy.go
- posix-dirent_ino.go
- posix-dirent_namelen_linux.go
- posix-diskid-check.go
- posix-errors.go
- posix-list-dir_unix.go
- posix.go
- postpolicyform.go
- prepare-storage.go
- retry.go
- routers.go
- server-main.go
- server-rlimit.go
- server-startup-msg.go
- service.go
- setup-type.go
- signals.go
- signature-v2.go
- signature-v4-parser.go
- signature-v4-utils.go
- signature-v4.go
- storage-datatypes.go
- storage-errors.go
- storage-interface.go
- storage-rest-client.go
- storage-rest-common.go
- storage-rest-server.go
- streaming-signature-v4.go
- sts-datatypes.go
- sts-errors.go
- sts-handlers.go
- tree-walk-pool.go
- tree-walk.go
- typed-errors.go
- update-notifier.go
- update.go
- utils.go
- web-handler-context.go
- web-handlers.go
- web-router.go
- xl-sets.go
- xl-v1-bucket.go
- xl-v1-common.go
- xl-v1-errors.go
- xl-v1-healing-common.go
- xl-v1-healing.go
- xl-v1-list-objects-heal.go
- xl-v1-list-objects.go
- xl-v1-metadata.go
- xl-v1-multipart.go
- xl-v1-object.go
- xl-v1-utils.go
- xl-v1.go
- xl-zones.go
Directories ¶
Path | Synopsis |
---|---|
Package crypto implements AWS S3 related cryptographic building blocks for implementing Server-Side-Encryption (SSE-S3) and Server-Side-Encryption with customer provided keys (SSE-C).
|
Package crypto implements AWS S3 related cryptographic building blocks for implementing Server-Side-Encryption (SSE-S3) and Server-Side-Encryption with customer provided keys (SSE-C). |