2019-06-05 17:41:02 +01:00
|
|
|
// Copyright (C) 2019 Storj Labs, Inc.
|
|
|
|
// See LICENSE for copying information.
|
|
|
|
|
|
|
|
package metainfo
|
|
|
|
|
|
|
|
import (
|
|
|
|
"bytes"
|
|
|
|
"context"
|
2019-06-24 10:52:25 +01:00
|
|
|
"regexp"
|
2019-06-05 17:41:02 +01:00
|
|
|
"sync"
|
|
|
|
"time"
|
|
|
|
|
|
|
|
"github.com/gogo/protobuf/proto"
|
2019-07-03 17:14:37 +01:00
|
|
|
"github.com/zeebo/errs"
|
2019-06-05 17:41:02 +01:00
|
|
|
"go.uber.org/zap"
|
|
|
|
"google.golang.org/grpc/codes"
|
|
|
|
"google.golang.org/grpc/status"
|
|
|
|
|
|
|
|
"storj.io/storj/pkg/auth"
|
2019-07-16 14:30:11 +01:00
|
|
|
"storj.io/storj/pkg/encryption"
|
2019-06-05 17:41:02 +01:00
|
|
|
"storj.io/storj/pkg/macaroon"
|
|
|
|
"storj.io/storj/pkg/pb"
|
|
|
|
"storj.io/storj/pkg/storj"
|
|
|
|
"storj.io/storj/satellite/console"
|
|
|
|
)
|
|
|
|
|
2019-06-24 10:52:25 +01:00
|
|
|
const (
|
|
|
|
requestTTL = time.Hour * 4
|
|
|
|
)
|
|
|
|
|
|
|
|
var (
|
|
|
|
ipRegexp = regexp.MustCompile(`^(([0-9]|[1-9][0-9]|1[0-9]{2}|2[0-4][0-9]|25[0-5])\.){3}([0-9]|[1-9][0-9]|1[0-9]{2}|2[0-4][0-9]|25[0-5])$`)
|
|
|
|
)
|
2019-06-05 17:41:02 +01:00
|
|
|
|
|
|
|
// TTLItem keeps association between serial number and ttl
|
|
|
|
type TTLItem struct {
|
|
|
|
serialNumber storj.SerialNumber
|
|
|
|
ttl time.Time
|
|
|
|
}
|
|
|
|
|
|
|
|
type createRequest struct {
|
2019-07-09 22:54:00 +01:00
|
|
|
Expiration time.Time
|
2019-06-05 17:41:02 +01:00
|
|
|
Redundancy *pb.RedundancyScheme
|
|
|
|
|
|
|
|
ttl time.Time
|
|
|
|
}
|
|
|
|
|
|
|
|
type createRequests struct {
|
|
|
|
mu sync.RWMutex
|
|
|
|
// orders limit serial number used because with CreateSegment we don't have path yet
|
|
|
|
entries map[storj.SerialNumber]*createRequest
|
|
|
|
|
|
|
|
muTTL sync.Mutex
|
|
|
|
entriesTTL []*TTLItem
|
|
|
|
}
|
|
|
|
|
|
|
|
func newCreateRequests() *createRequests {
|
|
|
|
return &createRequests{
|
|
|
|
entries: make(map[storj.SerialNumber]*createRequest),
|
|
|
|
entriesTTL: make([]*TTLItem, 0),
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
func (requests *createRequests) Put(serialNumber storj.SerialNumber, createRequest *createRequest) {
|
|
|
|
ttl := time.Now().Add(requestTTL)
|
|
|
|
|
|
|
|
go func() {
|
|
|
|
requests.muTTL.Lock()
|
|
|
|
requests.entriesTTL = append(requests.entriesTTL, &TTLItem{
|
|
|
|
serialNumber: serialNumber,
|
|
|
|
ttl: ttl,
|
|
|
|
})
|
|
|
|
requests.muTTL.Unlock()
|
|
|
|
}()
|
|
|
|
|
|
|
|
createRequest.ttl = ttl
|
|
|
|
requests.mu.Lock()
|
|
|
|
requests.entries[serialNumber] = createRequest
|
|
|
|
requests.mu.Unlock()
|
|
|
|
|
|
|
|
go requests.cleanup()
|
|
|
|
}
|
|
|
|
|
|
|
|
func (requests *createRequests) Load(serialNumber storj.SerialNumber) (*createRequest, bool) {
|
|
|
|
requests.mu.RLock()
|
|
|
|
request, found := requests.entries[serialNumber]
|
|
|
|
if request != nil && request.ttl.Before(time.Now()) {
|
|
|
|
request = nil
|
|
|
|
found = false
|
|
|
|
}
|
|
|
|
requests.mu.RUnlock()
|
|
|
|
|
|
|
|
return request, found
|
|
|
|
}
|
|
|
|
|
|
|
|
func (requests *createRequests) Remove(serialNumber storj.SerialNumber) {
|
|
|
|
requests.mu.Lock()
|
|
|
|
delete(requests.entries, serialNumber)
|
|
|
|
requests.mu.Unlock()
|
|
|
|
}
|
|
|
|
|
|
|
|
func (requests *createRequests) cleanup() {
|
|
|
|
requests.muTTL.Lock()
|
|
|
|
now := time.Now()
|
|
|
|
remove := make([]storj.SerialNumber, 0)
|
|
|
|
newStart := 0
|
|
|
|
for i, item := range requests.entriesTTL {
|
|
|
|
if item.ttl.Before(now) {
|
|
|
|
remove = append(remove, item.serialNumber)
|
|
|
|
newStart = i + 1
|
|
|
|
} else {
|
|
|
|
break
|
|
|
|
}
|
|
|
|
}
|
|
|
|
requests.entriesTTL = requests.entriesTTL[newStart:]
|
|
|
|
requests.muTTL.Unlock()
|
|
|
|
|
|
|
|
for _, serialNumber := range remove {
|
|
|
|
requests.Remove(serialNumber)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
func (endpoint *Endpoint) validateAuth(ctx context.Context, action macaroon.Action) (_ *console.APIKeyInfo, err error) {
|
|
|
|
defer mon.Task()(&ctx)(&err)
|
|
|
|
keyData, ok := auth.GetAPIKey(ctx)
|
|
|
|
if !ok {
|
2019-08-20 14:16:51 +01:00
|
|
|
endpoint.log.Debug("unauthorized request")
|
|
|
|
return nil, status.Error(codes.Unauthenticated, "Missing API credentials")
|
2019-06-05 17:41:02 +01:00
|
|
|
}
|
|
|
|
|
|
|
|
key, err := macaroon.ParseAPIKey(string(keyData))
|
|
|
|
if err != nil {
|
2019-08-20 14:16:51 +01:00
|
|
|
endpoint.log.Debug("invalid request", zap.Error(err))
|
|
|
|
return nil, status.Error(codes.InvalidArgument, "Invalid API credentials")
|
2019-06-05 17:41:02 +01:00
|
|
|
}
|
|
|
|
|
|
|
|
keyInfo, err := endpoint.apiKeys.GetByHead(ctx, key.Head())
|
|
|
|
if err != nil {
|
2019-08-20 14:16:51 +01:00
|
|
|
endpoint.log.Debug("unauthorized request", zap.Error(err))
|
|
|
|
return nil, status.Error(codes.PermissionDenied, "Unauthorized API credentials")
|
2019-06-05 17:41:02 +01:00
|
|
|
}
|
|
|
|
|
|
|
|
// Revocations are currently handled by just deleting the key.
|
|
|
|
err = key.Check(ctx, keyInfo.Secret, action, nil)
|
|
|
|
if err != nil {
|
2019-08-20 14:16:51 +01:00
|
|
|
endpoint.log.Debug("unauthorized request", zap.Error(err))
|
|
|
|
return nil, status.Error(codes.PermissionDenied, "Unauthorized API credentials")
|
2019-06-05 17:41:02 +01:00
|
|
|
}
|
|
|
|
|
|
|
|
return keyInfo, nil
|
|
|
|
}
|
|
|
|
|
2019-07-08 14:33:15 +01:00
|
|
|
func (endpoint *Endpoint) validateCreateSegment(ctx context.Context, req *pb.SegmentWriteRequestOld) (err error) {
|
2019-06-05 17:41:02 +01:00
|
|
|
defer mon.Task()(&ctx)(&err)
|
|
|
|
|
|
|
|
err = endpoint.validateBucket(ctx, req.Bucket)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
err = endpoint.validateRedundancy(ctx, req.Redundancy)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2019-07-08 14:33:15 +01:00
|
|
|
func (endpoint *Endpoint) validateCommitSegment(ctx context.Context, req *pb.SegmentCommitRequestOld) (err error) {
|
2019-06-05 17:41:02 +01:00
|
|
|
defer mon.Task()(&ctx)(&err)
|
|
|
|
|
|
|
|
err = endpoint.validateBucket(ctx, req.Bucket)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2019-07-24 12:33:23 +01:00
|
|
|
err = endpoint.validatePointer(ctx, req.Pointer, req.OriginalLimits)
|
2019-06-05 17:41:02 +01:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
if len(req.OriginalLimits) > 0 {
|
|
|
|
createRequest, found := endpoint.createRequests.Load(req.OriginalLimits[0].SerialNumber)
|
|
|
|
|
|
|
|
switch {
|
|
|
|
case !found:
|
|
|
|
return Error.New("missing create request or request expired")
|
2019-07-09 22:54:00 +01:00
|
|
|
case !createRequest.Expiration.Equal(req.Pointer.ExpirationDate):
|
2019-06-05 17:41:02 +01:00
|
|
|
return Error.New("pointer expiration date does not match requested one")
|
|
|
|
case !proto.Equal(createRequest.Redundancy, req.Pointer.Remote.Redundancy):
|
|
|
|
return Error.New("pointer redundancy scheme date does not match requested one")
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func (endpoint *Endpoint) validateBucket(ctx context.Context, bucket []byte) (err error) {
|
|
|
|
defer mon.Task()(&ctx)(&err)
|
|
|
|
|
|
|
|
if len(bucket) == 0 {
|
2019-06-24 10:52:25 +01:00
|
|
|
return Error.New("bucket not specified")
|
2019-06-05 17:41:02 +01:00
|
|
|
}
|
2019-06-24 10:52:25 +01:00
|
|
|
|
|
|
|
if len(bucket) < 3 || len(bucket) > 63 {
|
|
|
|
return Error.New("bucket name must be at least 3 and no more than 63 characters long")
|
2019-06-05 17:41:02 +01:00
|
|
|
}
|
2019-06-24 10:52:25 +01:00
|
|
|
|
|
|
|
// Regexp not used because benchmark shows it will be slower for valid bucket names
|
|
|
|
// https://gist.github.com/mniewrzal/49de3af95f36e63e88fac24f565e444c
|
|
|
|
labels := bytes.Split(bucket, []byte("."))
|
|
|
|
for _, label := range labels {
|
|
|
|
err = validateBucketLabel(label)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
if ipRegexp.MatchString(string(bucket)) {
|
|
|
|
return Error.New("bucket name cannot be formatted as an IP address")
|
|
|
|
}
|
|
|
|
|
2019-06-05 17:41:02 +01:00
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2019-06-24 10:52:25 +01:00
|
|
|
func validateBucketLabel(label []byte) error {
|
|
|
|
if len(label) == 0 {
|
|
|
|
return Error.New("bucket label cannot be empty")
|
|
|
|
}
|
|
|
|
|
|
|
|
if !isLowerLetter(label[0]) && !isDigit(label[0]) {
|
|
|
|
return Error.New("bucket label must start with a lowercase letter or number")
|
|
|
|
}
|
|
|
|
|
|
|
|
if label[0] == '-' || label[len(label)-1] == '-' {
|
|
|
|
return Error.New("bucket label cannot start or end with a hyphen")
|
|
|
|
}
|
|
|
|
|
|
|
|
for i := 1; i < len(label)-1; i++ {
|
|
|
|
if !isLowerLetter(label[i]) && !isDigit(label[i]) && (label[i] != '-') && (label[i] != '.') {
|
|
|
|
return Error.New("bucket name must contain only lowercase letters, numbers or hyphens")
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func isLowerLetter(r byte) bool {
|
|
|
|
return r >= 'a' && r <= 'z'
|
|
|
|
}
|
|
|
|
|
|
|
|
func isDigit(r byte) bool {
|
|
|
|
return r >= '0' && r <= '9'
|
|
|
|
}
|
|
|
|
|
2019-07-24 12:33:23 +01:00
|
|
|
func (endpoint *Endpoint) validatePointer(ctx context.Context, pointer *pb.Pointer, originalLimits []*pb.OrderLimit) (err error) {
|
2019-06-05 17:41:02 +01:00
|
|
|
defer mon.Task()(&ctx)(&err)
|
|
|
|
|
|
|
|
if pointer == nil {
|
|
|
|
return Error.New("no pointer specified")
|
|
|
|
}
|
|
|
|
|
|
|
|
if pointer.Type == pb.Pointer_INLINE && pointer.Remote != nil {
|
|
|
|
return Error.New("pointer type is INLINE but remote segment is set")
|
|
|
|
}
|
|
|
|
|
|
|
|
if pointer.Type == pb.Pointer_REMOTE {
|
2019-07-03 17:14:37 +01:00
|
|
|
switch {
|
|
|
|
case pointer.Remote == nil:
|
2019-06-05 17:41:02 +01:00
|
|
|
return Error.New("no remote segment specified")
|
2019-07-03 17:14:37 +01:00
|
|
|
case pointer.Remote.RemotePieces == nil:
|
2019-06-05 17:41:02 +01:00
|
|
|
return Error.New("no remote segment pieces specified")
|
2019-07-03 17:14:37 +01:00
|
|
|
case pointer.Remote.Redundancy == nil:
|
2019-06-05 17:41:02 +01:00
|
|
|
return Error.New("no redundancy scheme specified")
|
|
|
|
}
|
2019-07-24 12:33:23 +01:00
|
|
|
|
|
|
|
remote := pointer.Remote
|
|
|
|
|
|
|
|
if len(originalLimits) == 0 {
|
|
|
|
return Error.New("no order limits")
|
|
|
|
}
|
|
|
|
if int32(len(originalLimits)) != remote.Redundancy.Total {
|
|
|
|
return Error.New("invalid no order limit for piece")
|
|
|
|
}
|
|
|
|
|
2019-07-31 19:28:43 +01:00
|
|
|
maxAllowed, err := encryption.CalcEncryptedSize(endpoint.requiredRSConfig.MaxSegmentSize.Int64(), storj.EncryptionParameters{
|
2019-07-24 12:33:23 +01:00
|
|
|
CipherSuite: storj.EncAESGCM,
|
|
|
|
BlockSize: 128, // intentionally low block size to allow maximum possible encryption overhead
|
|
|
|
})
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
if pointer.SegmentSize > maxAllowed || pointer.SegmentSize < 0 {
|
|
|
|
return Error.New("segment size %v is out of range, maximum allowed is %v", pointer.SegmentSize, maxAllowed)
|
|
|
|
}
|
|
|
|
|
|
|
|
for _, piece := range remote.RemotePieces {
|
|
|
|
limit := originalLimits[piece.PieceNum]
|
|
|
|
|
|
|
|
if limit == nil {
|
|
|
|
return Error.New("empty order limit for piece")
|
|
|
|
}
|
|
|
|
|
|
|
|
err := endpoint.orders.VerifyOrderLimitSignature(ctx, limit)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
derivedPieceID := remote.RootPieceId.Derive(piece.NodeId, piece.PieceNum)
|
|
|
|
if limit.PieceId.IsZero() || limit.PieceId != derivedPieceID {
|
|
|
|
return Error.New("invalid order limit piece id")
|
|
|
|
}
|
|
|
|
if bytes.Compare(piece.NodeId.Bytes(), limit.StorageNodeId.Bytes()) != 0 {
|
|
|
|
return Error.New("piece NodeID != order limit NodeID")
|
|
|
|
}
|
|
|
|
}
|
2019-06-05 17:41:02 +01:00
|
|
|
}
|
2019-07-24 12:33:23 +01:00
|
|
|
|
2019-06-05 17:41:02 +01:00
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func (endpoint *Endpoint) validateRedundancy(ctx context.Context, redundancy *pb.RedundancyScheme) (err error) {
|
|
|
|
defer mon.Task()(&ctx)(&err)
|
|
|
|
|
2019-07-31 19:28:43 +01:00
|
|
|
if endpoint.requiredRSConfig.Validate == true {
|
|
|
|
if endpoint.requiredRSConfig.ErasureShareSize.Int32() != redundancy.ErasureShareSize ||
|
|
|
|
endpoint.requiredRSConfig.MaxThreshold != int(redundancy.Total) ||
|
|
|
|
endpoint.requiredRSConfig.MinThreshold != int(redundancy.MinReq) ||
|
|
|
|
endpoint.requiredRSConfig.RepairThreshold != int(redundancy.RepairThreshold) ||
|
|
|
|
endpoint.requiredRSConfig.SuccessThreshold != int(redundancy.SuccessThreshold) {
|
2019-06-29 16:05:46 +01:00
|
|
|
return Error.New("provided redundancy scheme parameters not allowed: want [%d, %d, %d, %d, %d] got [%d, %d, %d, %d, %d]",
|
2019-07-31 19:28:43 +01:00
|
|
|
endpoint.requiredRSConfig.MinThreshold,
|
|
|
|
endpoint.requiredRSConfig.RepairThreshold,
|
|
|
|
endpoint.requiredRSConfig.SuccessThreshold,
|
|
|
|
endpoint.requiredRSConfig.MaxThreshold,
|
|
|
|
endpoint.requiredRSConfig.ErasureShareSize.Int32(),
|
2019-06-29 16:05:46 +01:00
|
|
|
|
|
|
|
redundancy.MinReq,
|
|
|
|
redundancy.RepairThreshold,
|
|
|
|
redundancy.SuccessThreshold,
|
|
|
|
redundancy.Total,
|
|
|
|
redundancy.ErasureShareSize,
|
|
|
|
)
|
2019-06-21 19:15:58 +01:00
|
|
|
}
|
2019-06-05 17:41:02 +01:00
|
|
|
}
|
2019-06-21 19:15:58 +01:00
|
|
|
|
2019-06-05 17:41:02 +01:00
|
|
|
return nil
|
|
|
|
}
|
2019-07-03 17:14:37 +01:00
|
|
|
|
|
|
|
func (endpoint *Endpoint) validatePieceHash(ctx context.Context, piece *pb.RemotePiece, limits []*pb.OrderLimit) (err error) {
|
|
|
|
defer mon.Task()(&ctx)(&err)
|
|
|
|
|
|
|
|
if piece.Hash == nil {
|
|
|
|
return errs.New("no piece hash, removing from pointer %v (%v)", piece.NodeId, piece.PieceNum)
|
|
|
|
}
|
|
|
|
|
|
|
|
timestamp := piece.Hash.Timestamp
|
|
|
|
if timestamp.Before(time.Now().Add(-pieceHashExpiration)) {
|
|
|
|
return errs.New("piece hash timestamp is too old (%v), removing from pointer %v (num: %v)", timestamp, piece.NodeId, piece.PieceNum)
|
|
|
|
}
|
|
|
|
|
|
|
|
limit := limits[piece.PieceNum]
|
|
|
|
if limit != nil {
|
|
|
|
switch {
|
|
|
|
case limit.PieceId != piece.Hash.PieceId:
|
|
|
|
return errs.New("piece hash pieceID doesn't match limit pieceID, removing from pointer (%v != %v)", piece.Hash.PieceId, limit.PieceId)
|
|
|
|
case limit.Limit < piece.Hash.PieceSize:
|
|
|
|
return errs.New("piece hash PieceSize is larger than order limit, removing from pointer (%v > %v)", piece.Hash.PieceSize, limit.Limit)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
return nil
|
|
|
|
}
|