Versions in this module Expand all Collapse all v6 v6.0.57 Jun 4, 2020 Changes in this version + const CSVFileHeaderInfoIgnore + const CSVFileHeaderInfoNone + const CSVFileHeaderInfoUse + const DefaultRetryCap + const DefaultRetryUnit + const MaxJitter + const NoJitter + const ObjectAccessedAll + const ObjectAccessedGet + const ObjectAccessedHead + const ObjectCreatedAll + const ObjectCreatedCompleteMultipartUpload + const ObjectCreatedCopy + const ObjectCreatedPost + const ObjectCreatedPut + const ObjectReducedRedundancyLostObject + const ObjectRemovedAll + const ObjectRemovedDelete + const ObjectRemovedDeleteMarkerCreated + const SelectCompressionBZIP + const SelectCompressionGZIP + const SelectCompressionNONE + const SelectObjectTypeCSV + const SelectObjectTypeJSON + const SelectObjectTypeParquet + var DefaultTransport = func(secure bool) (http.RoundTripper, error) + var ErrInvalidObjectPrefix = ErrInvalidObjectName + var ErrNoNotificationConfigMatch = errors.New("no notification configuration matched") + var MaxRetry = 10 + func EqualFilterRuleList(a, b []FilterRule) bool + func EqualNotificationEventTypeList(a, b []NotificationEventType) bool + func ErrAPINotSupported(message string) error + func ErrEntityTooLarge(totalSize, maxObjectSize int64, bucketName, objectName string) error + func ErrEntityTooSmall(totalSize int64, bucketName, objectName string) error + func ErrInvalidArgument(message string) error + func ErrInvalidBucketName(message string) error + func ErrInvalidObjectName(message string) error + func ErrNoSuchBucketPolicy(message string) error + func ErrTransferAccelerationBucket(bucketName string) error + func ErrUnexpectedEOF(totalRead, totalSize int64, bucketName, objectName string) error + type ApplyServerSideEncryptionByDefault struct + KmsMasterKeyID string + SSEAlgorithm string + type Arn struct + AccountID string + Partition string + Region string + Resource string + Service string + func NewArn(partition, service, region, accountID, resource string) Arn + func (arn Arn) String() string + type BucketInfo struct + CreationDate time.Time + Name string + type BucketLookupType int + const BucketLookupAuto + const BucketLookupDNS + const BucketLookupPath + type BucketNotification struct + LambdaConfigs []LambdaConfig + QueueConfigs []QueueConfig + TopicConfigs []TopicConfig + XMLName xml.Name + func (b *BucketNotification) AddLambda(lambdaConfig NotificationConfig) bool + func (b *BucketNotification) AddQueue(queueConfig NotificationConfig) bool + func (b *BucketNotification) AddTopic(topicConfig NotificationConfig) bool + func (b *BucketNotification) RemoveLambdaByArn(arn Arn) + func (b *BucketNotification) RemoveLambdaByArnEventsPrefixSuffix(arn Arn, events []NotificationEventType, prefix, suffix string) error + func (b *BucketNotification) RemoveQueueByArn(arn Arn) + func (b *BucketNotification) RemoveQueueByArnEventsPrefixSuffix(arn Arn, events []NotificationEventType, prefix, suffix string) error + func (b *BucketNotification) RemoveTopicByArn(arn Arn) + func (b *BucketNotification) RemoveTopicByArnEventsPrefixSuffix(arn Arn, events []NotificationEventType, prefix, suffix string) error + type BucketVersioningConfiguration struct + MfaDelete string + Status string + XMLName xml.Name + type CSVFileHeaderInfo string + type CSVInputOptions struct + Comments string + FieldDelimiter string + FileHeaderInfo CSVFileHeaderInfo + QuoteCharacter string + QuoteEscapeCharacter string + RecordDelimiter string + func (c *CSVInputOptions) SetComments(val string) + func (c *CSVInputOptions) SetFieldDelimiter(val string) + func (c *CSVInputOptions) SetFileHeaderInfo(val CSVFileHeaderInfo) + func (c *CSVInputOptions) SetQuoteCharacter(val string) + func (c *CSVInputOptions) SetQuoteEscapeCharacter(val string) + func (c *CSVInputOptions) SetRecordDelimiter(val string) + func (c CSVInputOptions) MarshalXML(e *xml.Encoder, start xml.StartElement) error + type CSVOutputOptions struct + FieldDelimiter string + QuoteCharacter string + QuoteEscapeCharacter string + QuoteFields CSVQuoteFields + RecordDelimiter string + func (c *CSVOutputOptions) SetFieldDelimiter(val string) + func (c *CSVOutputOptions) SetQuoteCharacter(val string) + func (c *CSVOutputOptions) SetQuoteEscapeCharacter(val string) + func (c *CSVOutputOptions) SetQuoteFields(val CSVQuoteFields) + func (c *CSVOutputOptions) SetRecordDelimiter(val string) + func (c CSVOutputOptions) MarshalXML(e *xml.Encoder, start xml.StartElement) error + type CSVQuoteFields string + const CSVQuoteFieldsAlways + const CSVQuoteFieldsAsNeeded + type Client struct + func New(endpoint, accessKeyID, secretAccessKey string, secure bool) (*Client, error) + func NewV2(endpoint string, accessKeyID, secretAccessKey string, secure bool) (*Client, error) + func NewV4(endpoint string, accessKeyID, secretAccessKey string, secure bool) (*Client, error) + func NewWithCredentials(endpoint string, creds *credentials.Credentials, secure bool, region string) (*Client, error) + func NewWithOptions(endpoint string, opts *Options) (*Client, error) + func NewWithRegion(endpoint, accessKeyID, secretAccessKey string, secure bool, region string) (*Client, error) + func (c *Client) EndpointURL() *url.URL + func (c *Client) SetAppInfo(appName string, appVersion string) + func (c *Client) SetCustomTransport(customHTTPTransport http.RoundTripper) + func (c *Client) SetS3TransferAccelerate(accelerateEndpoint string) + func (c *Client) TraceErrorsOnlyOff() + func (c *Client) TraceErrorsOnlyOn(outputStream io.Writer) + func (c *Client) TraceOff() + func (c *Client) TraceOn(outputStream io.Writer) + func (c Client) BucketExists(bucketName string) (bool, error) + func (c Client) BucketExistsWithContext(ctx context.Context, bucketName string) (bool, error) + func (c Client) ComposeObject(dst DestinationInfo, srcs []SourceInfo) error + func (c Client) ComposeObjectWithProgress(dst DestinationInfo, srcs []SourceInfo, progress io.Reader) error + func (c Client) CopyObject(dst DestinationInfo, src SourceInfo) error + func (c Client) CopyObjectWithProgress(dst DestinationInfo, src SourceInfo, progress io.Reader) error + func (c Client) DeleteBucketEncryption(bucketName string) error + func (c Client) DeleteBucketEncryptionWithContext(ctx context.Context, bucketName string) error + func (c Client) DeleteBucketTagging(bucketName string) error + func (c Client) DeleteBucketTaggingWithContext(ctx context.Context, bucketName string) error + func (c Client) DisableVersioning(bucketName string) error + func (c Client) DisableVersioningWithContext(ctx context.Context, bucketName string) error + func (c Client) EnableVersioning(bucketName string) error + func (c Client) EnableVersioningWithContext(ctx context.Context, bucketName string) error + func (c Client) FGetObject(bucketName, objectName, filePath string, opts GetObjectOptions) error + func (c Client) FGetObjectWithContext(ctx context.Context, bucketName, objectName, filePath string, ...) error + func (c Client) FPutObject(bucketName, objectName, filePath string, opts PutObjectOptions) (n int64, err error) + func (c Client) FPutObjectWithContext(ctx context.Context, bucketName, objectName, filePath string, ...) (n int64, err error) + func (c Client) GetBucketEncryption(bucketName string) (ServerSideEncryptionConfiguration, error) + func (c Client) GetBucketEncryptionWithContext(ctx context.Context, bucketName string) (ServerSideEncryptionConfiguration, error) + func (c Client) GetBucketLifecycle(bucketName string) (string, error) + func (c Client) GetBucketLocation(bucketName string) (string, error) + func (c Client) GetBucketNotification(bucketName string) (bucketNotification BucketNotification, err error) + func (c Client) GetBucketObjectLockConfig(bucketName string) (mode *RetentionMode, validity *uint, unit *ValidityUnit, err error) + func (c Client) GetBucketPolicy(bucketName string) (string, error) + func (c Client) GetBucketTagging(bucketName string) (*tags.Tags, error) + func (c Client) GetBucketTaggingWithContext(ctx context.Context, bucketName string) (*tags.Tags, error) + func (c Client) GetBucketVersioning(bucketName string) (BucketVersioningConfiguration, error) + func (c Client) GetBucketVersioningWithContext(ctx context.Context, bucketName string) (BucketVersioningConfiguration, error) + func (c Client) GetObject(bucketName, objectName string, opts GetObjectOptions) (*Object, error) + func (c Client) GetObjectACL(bucketName, objectName string) (*ObjectInfo, error) + func (c Client) GetObjectACLWithContext(ctx context.Context, bucketName, objectName string) (*ObjectInfo, error) + func (c Client) GetObjectLegalHold(bucketName, objectName string, opts GetObjectLegalHoldOptions) (status *LegalHoldStatus, err error) + func (c Client) GetObjectLockConfig(bucketName string) (objectLock string, mode *RetentionMode, validity *uint, unit *ValidityUnit, ...) + func (c Client) GetObjectRetention(bucketName, objectName, versionID string) (mode *RetentionMode, retainUntilDate *time.Time, err error) + func (c Client) GetObjectTagging(bucketName, objectName string) (string, error) + func (c Client) GetObjectTaggingWithContext(ctx context.Context, bucketName, objectName string) (string, error) + func (c Client) GetObjectWithContext(ctx context.Context, bucketName, objectName string, opts GetObjectOptions) (*Object, error) + func (c Client) ListBuckets() ([]BucketInfo, error) + func (c Client) ListBucketsWithContext(ctx context.Context) ([]BucketInfo, error) + func (c Client) ListIncompleteUploads(bucketName, objectPrefix string, recursive bool, doneCh <-chan struct{}) <-chan ObjectMultipartInfo + func (c Client) ListObjects(bucketName, objectPrefix string, recursive bool, doneCh <-chan struct{}) <-chan ObjectInfo + func (c Client) ListObjectsV2(bucketName, objectPrefix string, recursive bool, doneCh <-chan struct{}) <-chan ObjectInfo + func (c Client) ListObjectsV2WithMetadata(bucketName, objectPrefix string, recursive bool, doneCh <-chan struct{}) <-chan ObjectInfo + func (c Client) ListenBucketNotification(bucketName, prefix, suffix string, events []string, doneCh <-chan struct{}) <-chan NotificationInfo + func (c Client) MakeBucket(bucketName string, location string) (err error) + func (c Client) MakeBucketWithContext(ctx context.Context, bucketName string, location string) (err error) + func (c Client) MakeBucketWithObjectLock(bucketName string, location string) (err error) + func (c Client) MakeBucketWithObjectLockWithContext(ctx context.Context, bucketName string, location string) (err error) + func (c Client) Presign(method string, bucketName string, objectName string, expires time.Duration, ...) (u *url.URL, err error) + func (c Client) PresignedGetObject(bucketName string, objectName string, expires time.Duration, ...) (u *url.URL, err error) + func (c Client) PresignedHeadObject(bucketName string, objectName string, expires time.Duration, ...) (u *url.URL, err error) + func (c Client) PresignedPostPolicy(p *PostPolicy) (u *url.URL, formData map[string]string, err error) + func (c Client) PresignedPutObject(bucketName string, objectName string, expires time.Duration) (u *url.URL, err error) + func (c Client) PutObject(bucketName, objectName string, reader io.Reader, objectSize int64, ...) (n int64, err error) + func (c Client) PutObjectLegalHold(bucketName, objectName string, opts PutObjectLegalHoldOptions) error + func (c Client) PutObjectRetention(bucketName, objectName string, opts PutObjectRetentionOptions) error + func (c Client) PutObjectTagging(bucketName, objectName string, objectTags map[string]string) error + func (c Client) PutObjectTaggingWithContext(ctx context.Context, bucketName, objectName string, ...) error + func (c Client) PutObjectWithContext(ctx context.Context, bucketName, objectName string, reader io.Reader, ...) (n int64, err error) + func (c Client) RemoveAllBucketNotification(bucketName string) error + func (c Client) RemoveBucket(bucketName string) error + func (c Client) RemoveIncompleteUpload(bucketName, objectName string) error + func (c Client) RemoveObject(bucketName, objectName string) error + func (c Client) RemoveObjectTagging(bucketName, objectName string) error + func (c Client) RemoveObjectTaggingWithContext(ctx context.Context, bucketName, objectName string) error + func (c Client) RemoveObjectWithOptions(bucketName, objectName string, opts RemoveObjectOptions) error + func (c Client) RemoveObjects(bucketName string, objectsCh <-chan string) <-chan RemoveObjectError + func (c Client) RemoveObjectsWithContext(ctx context.Context, bucketName string, objectsCh <-chan string) <-chan RemoveObjectError + func (c Client) RemoveObjectsWithOptions(bucketName string, objectsCh <-chan string, opts RemoveObjectsOptions) <-chan RemoveObjectError + func (c Client) RemoveObjectsWithOptionsContext(ctx context.Context, bucketName string, objectsCh <-chan string, ...) <-chan RemoveObjectError + func (c Client) SelectObjectContent(ctx context.Context, bucketName, objectName string, opts SelectObjectOptions) (*SelectResults, error) + func (c Client) SetBucketEncryption(bucketName string, configuration ServerSideEncryptionConfiguration) error + func (c Client) SetBucketEncryptionWithContext(ctx context.Context, bucketName string, ...) error + func (c Client) SetBucketLifecycle(bucketName, lifecycle string) error + func (c Client) SetBucketLifecycleWithContext(ctx context.Context, bucketName, lifecycle string) error + func (c Client) SetBucketNotification(bucketName string, bucketNotification BucketNotification) error + func (c Client) SetBucketNotificationWithContext(ctx context.Context, bucketName string, bucketNotification BucketNotification) error + func (c Client) SetBucketObjectLockConfig(bucketName string, mode *RetentionMode, validity *uint, unit *ValidityUnit) error + func (c Client) SetBucketPolicy(bucketName, policy string) error + func (c Client) SetBucketPolicyWithContext(ctx context.Context, bucketName, policy string) error + func (c Client) SetBucketTagging(bucketName string, tags *tags.Tags) error + func (c Client) SetBucketTaggingWithContext(ctx context.Context, bucketName string, tags *tags.Tags) error + func (c Client) SetObjectLockConfig(bucketName string, mode *RetentionMode, validity *uint, unit *ValidityUnit) error + func (c Client) StatObject(bucketName, objectName string, opts StatObjectOptions) (ObjectInfo, error) + func (c Client) StatObjectWithContext(ctx context.Context, bucketName, objectName string, opts StatObjectOptions) (ObjectInfo, error) + type CommonPrefix struct + Prefix string + type CompletePart struct + ETag string + PartNumber int + XMLName xml.Name + type Core struct + func NewCore(endpoint string, accessKeyID, secretAccessKey string, secure bool) (*Core, error) + func (c Core) AbortMultipartUpload(bucket, object, uploadID string) error + func (c Core) AbortMultipartUploadWithContext(ctx context.Context, bucket, object, uploadID string) error + func (c Core) CompleteMultipartUpload(bucket, object, uploadID string, parts []CompletePart) (string, error) + func (c Core) CompleteMultipartUploadWithContext(ctx context.Context, bucket, object, uploadID string, parts []CompletePart) (string, error) + func (c Core) CopyObject(sourceBucket, sourceObject, destBucket, destObject string, ...) (ObjectInfo, error) + func (c Core) CopyObjectPart(srcBucket, srcObject, destBucket, destObject string, uploadID string, ...) (p CompletePart, err error) + func (c Core) CopyObjectPartWithContext(ctx context.Context, srcBucket, srcObject, destBucket, destObject string, ...) (p CompletePart, err error) + func (c Core) CopyObjectWithContext(ctx context.Context, sourceBucket, sourceObject, destBucket, destObject string, ...) (ObjectInfo, error) + func (c Core) GetBucketPolicy(bucket string) (string, error) + func (c Core) GetObject(bucketName, objectName string, opts GetObjectOptions) (io.ReadCloser, ObjectInfo, http.Header, error) + func (c Core) GetObjectWithContext(ctx context.Context, bucketName, objectName string, opts GetObjectOptions) (io.ReadCloser, ObjectInfo, http.Header, error) + func (c Core) ListMultipartUploads(bucket, prefix, keyMarker, uploadIDMarker, delimiter string, maxUploads int) (result ListMultipartUploadsResult, err error) + func (c Core) ListObjectParts(bucket, object, uploadID string, partNumberMarker int, maxParts int) (result ListObjectPartsResult, err error) + func (c Core) ListObjects(bucket, prefix, marker, delimiter string, maxKeys int) (result ListBucketResult, err error) + func (c Core) ListObjectsV2(bucketName, objectPrefix, continuationToken string, fetchOwner bool, ...) (ListBucketV2Result, error) + func (c Core) NewMultipartUpload(bucket, object string, opts PutObjectOptions) (uploadID string, err error) + func (c Core) PutBucketPolicy(bucket, bucketPolicy string) error + func (c Core) PutBucketPolicyWithContext(ctx context.Context, bucket, bucketPolicy string) error + func (c Core) PutObject(bucket, object string, data io.Reader, size int64, md5Base64, sha256Hex string, ...) (ObjectInfo, error) + func (c Core) PutObjectPart(bucket, object, uploadID string, partID int, data io.Reader, size int64, ...) (ObjectPart, error) + func (c Core) PutObjectPartWithContext(ctx context.Context, bucket, object, uploadID string, partID int, ...) (ObjectPart, error) + func (c Core) PutObjectWithContext(ctx context.Context, bucket, object string, data io.Reader, size int64, ...) (ObjectInfo, error) + func (c Core) StatObject(bucketName, objectName string, opts StatObjectOptions) (ObjectInfo, error) + func (c Core) StatObjectWithContext(ctx context.Context, bucketName, objectName string, opts StatObjectOptions) (ObjectInfo, error) + type DestInfoOptions struct + Encryption encrypt.ServerSide + LegalHold LegalHoldStatus + Mode RetentionMode + ReplaceTags bool + RetainUntilDate time.Time + UserMeta map[string]string + UserTags map[string]string + type DestinationInfo struct + func NewDestinationInfo(bucket, object string, sse encrypt.ServerSide, userMeta map[string]string) (d DestinationInfo, err error) + func NewDestinationInfoWithOptions(bucket, object string, destOpts DestInfoOptions) (d DestinationInfo, err error) + type ErrorResponse struct + BucketName string + Code string + HostID string + Key string + Message string + Region string + RequestID string + Server string + StatusCode int + XMLName xml.Name + func ToErrorResponse(err error) ErrorResponse + func (e ErrorResponse) Error() string + type Filter struct + S3Key S3Key + type FilterRule struct + Name string + Value string + type GetObjectLegalHoldOptions struct + VersionID string + type GetObjectOptions struct + ServerSideEncryption encrypt.ServerSide + func (o *GetObjectOptions) Set(key, value string) + func (o *GetObjectOptions) SetMatchETag(etag string) error + func (o *GetObjectOptions) SetMatchETagExcept(etag string) error + func (o *GetObjectOptions) SetModified(modTime time.Time) error + func (o *GetObjectOptions) SetRange(start, end int64) error + func (o *GetObjectOptions) SetUnmodified(modTime time.Time) error + func (o GetObjectOptions) Header() http.Header + type JSONInputOptions struct + Type JSONType + func (j *JSONInputOptions) SetType(typ JSONType) + func (j JSONInputOptions) MarshalXML(e *xml.Encoder, start xml.StartElement) error + type JSONOutputOptions struct + RecordDelimiter string + func (j *JSONOutputOptions) SetRecordDelimiter(val string) + func (j JSONOutputOptions) MarshalXML(e *xml.Encoder, start xml.StartElement) error + type JSONType string + const JSONDocumentType + const JSONLinesType + type LambdaConfig struct + Lambda string + type LegalHoldStatus string + const LegalHoldDisabled + const LegalHoldEnabled + func (r LegalHoldStatus) IsValid() bool + func (r LegalHoldStatus) String() string + type ListBucketResult struct + CommonPrefixes []CommonPrefix + Contents []ObjectInfo + Delimiter string + EncodingType string + IsTruncated bool + Marker string + MaxKeys int64 + Name string + NextMarker string + Prefix string + type ListBucketV2Result struct + CommonPrefixes []CommonPrefix + Contents []ObjectInfo + ContinuationToken string + Delimiter string + EncodingType string + FetchOwner string + IsTruncated bool + MaxKeys int64 + Name string + NextContinuationToken string + Prefix string + StartAfter string + type ListMultipartUploadsResult struct + Bucket string + CommonPrefixes []CommonPrefix + Delimiter string + EncodingType string + IsTruncated bool + KeyMarker string + MaxUploads int64 + NextKeyMarker string + NextUploadIDMarker string + Prefix string + UploadIDMarker string + Uploads []ObjectMultipartInfo + type ListObjectPartsResult struct + Bucket string + EncodingType string + Initiator initiator + IsTruncated bool + Key string + MaxParts int + NextPartNumberMarker int + ObjectParts []ObjectPart + Owner owner + PartNumberMarker int + StorageClass string + UploadID string + type NotificationConfig struct + Arn Arn + Events []NotificationEventType + Filter *Filter + ID string + func NewNotificationConfig(arn Arn) NotificationConfig + func (t *NotificationConfig) AddEvents(events ...NotificationEventType) + func (t *NotificationConfig) AddFilterPrefix(prefix string) + func (t *NotificationConfig) AddFilterSuffix(suffix string) + func (t *NotificationConfig) Equal(events []NotificationEventType, prefix, suffix string) bool + type NotificationEvent struct + AwsRegion string + EventName string + EventSource string + EventTime string + EventVersion string + RequestParameters map[string]string + ResponseElements map[string]string + S3 eventMeta + Source sourceInfo + UserIdentity identity + type NotificationEventType string + type NotificationInfo struct + Err error + Records []NotificationEvent + type Object struct + func (o *Object) Close() (err error) + func (o *Object) Read(b []byte) (n int, err error) + func (o *Object) ReadAt(b []byte, offset int64) (n int, err error) + func (o *Object) Seek(offset int64, whence int) (n int64, err error) + func (o *Object) Stat() (ObjectInfo, error) + type ObjectInfo struct + ContentType string + ETag string + Err error + Expires time.Time + Grant []struct{ ... } + Key string + LastModified time.Time + Metadata http.Header + Owner struct{ ... } + Size int64 + StorageClass string + UserMetadata StringMap + UserTags map[string]string + func ToObjectInfo(bucketName string, objectName string, h http.Header) (ObjectInfo, error) + type ObjectMultipartInfo struct + Err error + Initiated time.Time + Initiator initiator + Key string + Owner owner + Size int64 + StorageClass string + UploadID string + type ObjectPart struct + ETag string + LastModified time.Time + PartNumber int + Size int64 + type Options struct + BucketLookup BucketLookupType + Creds *credentials.Credentials + CustomMD5 func() md5simd.Hasher + CustomSHA256 func() md5simd.Hasher + Region string + Secure bool + type ParquetInputOptions struct + type PostPolicy struct + func NewPostPolicy() *PostPolicy + func (p *PostPolicy) SetBucket(bucketName string) error + func (p *PostPolicy) SetCondition(matchType, condition, value string) error + func (p *PostPolicy) SetContentLengthRange(min, max int64) error + func (p *PostPolicy) SetContentType(contentType string) error + func (p *PostPolicy) SetExpires(t time.Time) error + func (p *PostPolicy) SetKey(key string) error + func (p *PostPolicy) SetKeyStartsWith(keyStartsWith string) error + func (p *PostPolicy) SetSuccessStatusAction(status string) error + func (p *PostPolicy) SetUserData(key string, value string) error + func (p *PostPolicy) SetUserMetadata(key string, value string) error + func (p PostPolicy) String() string + type ProgressMessage struct + XMLName xml.Name + type PutObjectLegalHoldOptions struct + Status *LegalHoldStatus + VersionID string + type PutObjectOptions struct + CacheControl string + ContentDisposition string + ContentEncoding string + ContentLanguage string + ContentType string + DisableMultipart bool + LegalHold LegalHoldStatus + Mode *RetentionMode + NumThreads uint + PartSize uint64 + Progress io.Reader + RetainUntilDate *time.Time + SendContentMd5 bool + ServerSideEncryption encrypt.ServerSide + StorageClass string + UserMetadata map[string]string + UserTags map[string]string + WebsiteRedirectLocation string + func (opts PutObjectOptions) Header() (header http.Header) + type PutObjectRetentionOptions struct + GovernanceBypass bool + Mode *RetentionMode + RetainUntilDate *time.Time + VersionID string + type QueryExpressionType string + const QueryExpressionTypeSQL + type QueueConfig struct + Queue string + type RemoveObjectError struct + Err error + ObjectName string + type RemoveObjectOptions struct + GovernanceBypass bool + VersionID string + type RemoveObjectsOptions struct + GovernanceBypass bool + type Retention struct + Mode RetentionMode + Validity time.Duration + func (r Retention) IsEmpty() bool + func (r Retention) String() string + type RetentionMode string + const Compliance + const Governance + func (r RetentionMode) IsValid() bool + func (r RetentionMode) String() string + type Rule struct + Apply ApplyServerSideEncryptionByDefault + type S3Key struct + FilterRules []FilterRule + type SelectCompressionType string + type SelectObjectInputSerialization struct + CSV *CSVInputOptions + CompressionType SelectCompressionType + JSON *JSONInputOptions + Parquet *ParquetInputOptions + type SelectObjectOptions struct + Expression string + ExpressionType QueryExpressionType + InputSerialization SelectObjectInputSerialization + OutputSerialization SelectObjectOutputSerialization + RequestProgress struct{ ... } + ServerSideEncryption encrypt.ServerSide + XMLName xml.Name + func (o SelectObjectOptions) Header() http.Header + type SelectObjectOutputSerialization struct + CSV *CSVOutputOptions + JSON *JSONOutputOptions + type SelectObjectType string + type SelectResults struct + func NewSelectResults(resp *http.Response, bucketName string) (*SelectResults, error) + func (s *SelectResults) Close() error + func (s *SelectResults) Progress() *ProgressMessage + func (s *SelectResults) Read(b []byte) (n int, err error) + func (s *SelectResults) Stats() *StatsMessage + type ServerSideEncryptionConfiguration struct + Rules []Rule + XMLName xml.Name + type SourceInfo struct + Headers http.Header + func NewSourceInfo(bucket, object string, sse encrypt.ServerSide) SourceInfo + func (s *SourceInfo) SetMatchETagCond(etag string) error + func (s *SourceInfo) SetMatchETagExceptCond(etag string) error + func (s *SourceInfo) SetModifiedSinceCond(modTime time.Time) error + func (s *SourceInfo) SetRange(start, end int64) error + func (s *SourceInfo) SetUnmodifiedSinceCond(modTime time.Time) error + type StatObjectOptions struct + type StatsMessage struct + BytesProcessed int64 + BytesReturned int64 + BytesScanned int64 + XMLName xml.Name + type StringMap map[string]string + func (m *StringMap) UnmarshalXML(d *xml.Decoder, start xml.StartElement) error + type TopicConfig struct + Topic string + type ValidityUnit string + const Days + const Years + func (unit ValidityUnit) String() string