2021-05-25 08:48:01 +00:00
|
|
|
package pool
|
|
|
|
|
|
|
|
import (
|
|
|
|
"context"
|
|
|
|
"crypto/ecdsa"
|
|
|
|
"errors"
|
|
|
|
"fmt"
|
|
|
|
"math/rand"
|
|
|
|
"sync"
|
|
|
|
"time"
|
|
|
|
|
2021-06-22 09:15:21 +00:00
|
|
|
"github.com/nspcc-dev/neofs-api-go/pkg/acl/eacl"
|
2021-05-25 08:48:01 +00:00
|
|
|
"github.com/nspcc-dev/neofs-api-go/pkg/client"
|
2021-06-22 09:15:21 +00:00
|
|
|
"github.com/nspcc-dev/neofs-api-go/pkg/container"
|
|
|
|
cid "github.com/nspcc-dev/neofs-api-go/pkg/container/id"
|
2021-06-13 12:18:43 +00:00
|
|
|
"github.com/nspcc-dev/neofs-api-go/pkg/object"
|
2021-05-28 20:12:58 +00:00
|
|
|
"github.com/nspcc-dev/neofs-api-go/pkg/owner"
|
2021-06-04 10:34:57 +00:00
|
|
|
"github.com/nspcc-dev/neofs-api-go/pkg/session"
|
2021-05-25 08:48:01 +00:00
|
|
|
)
|
|
|
|
|
2021-05-25 11:46:58 +00:00
|
|
|
// BuilderOptions contains options used to build connection pool.
|
|
|
|
type BuilderOptions struct {
|
2021-05-25 08:48:01 +00:00
|
|
|
Key *ecdsa.PrivateKey
|
|
|
|
NodeConnectionTimeout time.Duration
|
|
|
|
NodeRequestTimeout time.Duration
|
|
|
|
ClientRebalanceInterval time.Duration
|
|
|
|
SessionExpirationEpoch uint64
|
|
|
|
weights []float64
|
2021-06-09 11:56:11 +00:00
|
|
|
addresses []string
|
2021-05-25 08:48:01 +00:00
|
|
|
}
|
|
|
|
|
2021-05-25 11:46:58 +00:00
|
|
|
// Builder is an interim structure used to collect node addresses/weights and
|
2021-05-25 08:48:01 +00:00
|
|
|
// build connection pool subsequently.
|
2021-05-25 11:46:58 +00:00
|
|
|
type Builder struct {
|
2021-05-25 08:48:01 +00:00
|
|
|
addresses []string
|
|
|
|
weights []float64
|
|
|
|
}
|
|
|
|
|
2021-06-22 09:15:21 +00:00
|
|
|
// ContainerPollingParams contains parameters used in polling is a container created or not.
|
|
|
|
type ContainerPollingParams struct {
|
|
|
|
CreationTimeout time.Duration
|
|
|
|
PollInterval time.Duration
|
|
|
|
}
|
|
|
|
|
|
|
|
// DefaultPollingParams creates ContainerPollingParams with default values.
|
|
|
|
func DefaultPollingParams() *ContainerPollingParams {
|
|
|
|
return &ContainerPollingParams{
|
|
|
|
CreationTimeout: 120 * time.Second,
|
|
|
|
PollInterval: 5 * time.Second,
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2021-05-25 08:48:01 +00:00
|
|
|
// AddNode adds address/weight pair to node PoolBuilder list.
|
2021-05-25 11:46:58 +00:00
|
|
|
func (pb *Builder) AddNode(address string, weight float64) *Builder {
|
2021-05-25 08:48:01 +00:00
|
|
|
pb.addresses = append(pb.addresses, address)
|
|
|
|
pb.weights = append(pb.weights, weight)
|
|
|
|
return pb
|
|
|
|
}
|
|
|
|
|
|
|
|
// Build creates new pool based on current PoolBuilder state and options.
|
2021-05-25 11:46:58 +00:00
|
|
|
func (pb *Builder) Build(ctx context.Context, options *BuilderOptions) (Pool, error) {
|
2021-05-25 08:48:01 +00:00
|
|
|
if len(pb.addresses) == 0 {
|
|
|
|
return nil, errors.New("no NeoFS peers configured")
|
|
|
|
}
|
2021-06-09 11:56:11 +00:00
|
|
|
|
2021-06-21 11:12:08 +00:00
|
|
|
options.weights = adjustWeights(pb.weights)
|
2021-06-09 11:56:11 +00:00
|
|
|
options.addresses = pb.addresses
|
2021-05-28 20:12:58 +00:00
|
|
|
return newPool(ctx, options)
|
2021-05-25 08:48:01 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
// Pool is an interface providing connection artifacts on request.
|
|
|
|
type Pool interface {
|
2021-06-13 12:18:43 +00:00
|
|
|
client.Object
|
2021-06-22 09:15:21 +00:00
|
|
|
client.Container
|
2021-06-04 10:34:57 +00:00
|
|
|
Connection() (client.Client, *session.Token, error)
|
2021-05-28 20:12:58 +00:00
|
|
|
OwnerID() *owner.ID
|
2021-05-25 08:48:01 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
type clientPack struct {
|
|
|
|
client client.Client
|
2021-06-04 10:34:57 +00:00
|
|
|
sessionToken *session.Token
|
2021-05-25 08:48:01 +00:00
|
|
|
healthy bool
|
|
|
|
}
|
|
|
|
|
2021-06-15 07:46:44 +00:00
|
|
|
var _ Pool = (*pool)(nil)
|
|
|
|
|
2021-05-25 08:48:01 +00:00
|
|
|
type pool struct {
|
|
|
|
lock sync.RWMutex
|
|
|
|
sampler *Sampler
|
2021-05-28 20:12:58 +00:00
|
|
|
owner *owner.ID
|
2021-05-25 08:48:01 +00:00
|
|
|
clientPacks []*clientPack
|
|
|
|
}
|
|
|
|
|
2021-05-28 20:12:58 +00:00
|
|
|
func newPool(ctx context.Context, options *BuilderOptions) (Pool, error) {
|
2021-05-25 08:48:01 +00:00
|
|
|
clientPacks := make([]*clientPack, len(options.weights))
|
2021-06-09 11:56:11 +00:00
|
|
|
for i, address := range options.addresses {
|
|
|
|
c, err := client.New(client.WithDefaultPrivateKey(options.Key),
|
|
|
|
client.WithURIAddress(address, nil),
|
|
|
|
client.WithDialTimeout(options.NodeConnectionTimeout))
|
2021-05-25 08:48:01 +00:00
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
st, err := c.CreateSession(ctx, options.SessionExpirationEpoch)
|
|
|
|
if err != nil {
|
|
|
|
address := "unknown"
|
|
|
|
if epi, err := c.EndpointInfo(ctx); err == nil {
|
|
|
|
address = epi.NodeInfo().Address()
|
|
|
|
}
|
|
|
|
return nil, fmt.Errorf("failed to create neofs session token for client %s: %w", address, err)
|
|
|
|
}
|
|
|
|
clientPacks[i] = &clientPack{client: c, sessionToken: st, healthy: true}
|
|
|
|
}
|
|
|
|
source := rand.NewSource(time.Now().UnixNano())
|
|
|
|
sampler := NewSampler(options.weights, source)
|
2021-05-28 20:12:58 +00:00
|
|
|
wallet, err := owner.NEO3WalletFromPublicKey(&options.Key.PublicKey)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
ownerID := owner.NewIDFromNeo3Wallet(wallet)
|
|
|
|
|
|
|
|
pool := &pool{sampler: sampler, owner: ownerID, clientPacks: clientPacks}
|
2021-06-21 11:12:08 +00:00
|
|
|
go startRebalance(ctx, pool, options)
|
|
|
|
return pool, nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func startRebalance(ctx context.Context, p *pool, options *BuilderOptions) {
|
|
|
|
ticker := time.NewTimer(options.ClientRebalanceInterval)
|
|
|
|
buffer := make([]float64, len(options.weights))
|
|
|
|
|
|
|
|
for range ticker.C {
|
|
|
|
updateNodesHealth(ctx, p, options, buffer)
|
|
|
|
ticker.Reset(options.ClientRebalanceInterval)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
func updateNodesHealth(ctx context.Context, p *pool, options *BuilderOptions, bufferWeights []float64) {
|
|
|
|
if len(bufferWeights) != len(p.clientPacks) {
|
|
|
|
bufferWeights = make([]float64, len(p.clientPacks))
|
|
|
|
}
|
|
|
|
healthyChanged := false
|
|
|
|
wg := sync.WaitGroup{}
|
|
|
|
for i, cPack := range p.clientPacks {
|
|
|
|
wg.Add(1)
|
|
|
|
go func(i int, netmap client.Netmap) {
|
|
|
|
defer wg.Done()
|
2021-05-25 08:48:01 +00:00
|
|
|
ok := true
|
2021-06-21 11:12:08 +00:00
|
|
|
tctx, c := context.WithTimeout(ctx, options.NodeRequestTimeout)
|
|
|
|
defer c()
|
|
|
|
if _, err := netmap.EndpointInfo(tctx); err != nil {
|
|
|
|
ok = false
|
|
|
|
bufferWeights[i] = 0
|
|
|
|
}
|
|
|
|
if ok {
|
|
|
|
bufferWeights[i] = options.weights[i]
|
2021-05-25 08:48:01 +00:00
|
|
|
}
|
2021-06-21 11:12:08 +00:00
|
|
|
|
|
|
|
p.lock.Lock()
|
|
|
|
if p.clientPacks[i].healthy != ok {
|
|
|
|
p.clientPacks[i].healthy = ok
|
|
|
|
healthyChanged = true
|
|
|
|
}
|
|
|
|
p.lock.Unlock()
|
|
|
|
}(i, cPack.client)
|
|
|
|
}
|
|
|
|
wg.Wait()
|
|
|
|
|
|
|
|
if healthyChanged {
|
|
|
|
probabilities := adjustWeights(bufferWeights)
|
|
|
|
source := rand.NewSource(time.Now().UnixNano())
|
|
|
|
p.lock.Lock()
|
|
|
|
p.sampler = NewSampler(probabilities, source)
|
|
|
|
p.lock.Unlock()
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
func adjustWeights(weights []float64) []float64 {
|
|
|
|
adjusted := make([]float64, len(weights))
|
|
|
|
sum := 0.0
|
|
|
|
for _, weight := range weights {
|
|
|
|
sum += weight
|
|
|
|
}
|
|
|
|
if sum > 0 {
|
|
|
|
for i, weight := range weights {
|
|
|
|
adjusted[i] = weight / sum
|
2021-05-25 08:48:01 +00:00
|
|
|
}
|
2021-06-21 11:12:08 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
return adjusted
|
2021-05-25 08:48:01 +00:00
|
|
|
}
|
|
|
|
|
2021-06-04 10:34:57 +00:00
|
|
|
func (p *pool) Connection() (client.Client, *session.Token, error) {
|
2021-05-25 08:48:01 +00:00
|
|
|
p.lock.RLock()
|
|
|
|
defer p.lock.RUnlock()
|
|
|
|
if len(p.clientPacks) == 1 {
|
|
|
|
cp := p.clientPacks[0]
|
|
|
|
if cp.healthy {
|
|
|
|
return cp.client, cp.sessionToken, nil
|
|
|
|
}
|
|
|
|
return nil, nil, errors.New("no healthy client")
|
|
|
|
}
|
|
|
|
attempts := 3 * len(p.clientPacks)
|
|
|
|
for k := 0; k < attempts; k++ {
|
|
|
|
i := p.sampler.Next()
|
|
|
|
if cp := p.clientPacks[i]; cp.healthy {
|
|
|
|
return cp.client, cp.sessionToken, nil
|
|
|
|
}
|
|
|
|
}
|
|
|
|
return nil, nil, errors.New("no healthy client")
|
|
|
|
}
|
2021-05-28 20:12:58 +00:00
|
|
|
|
|
|
|
func (p *pool) OwnerID() *owner.ID {
|
|
|
|
return p.owner
|
|
|
|
}
|
2021-06-13 12:18:43 +00:00
|
|
|
|
|
|
|
func (p *pool) conn(option []client.CallOption) (client.Client, []client.CallOption, error) {
|
|
|
|
conn, token, err := p.Connection()
|
|
|
|
if err != nil {
|
|
|
|
return nil, nil, err
|
|
|
|
}
|
|
|
|
return conn, append(option, client.WithSession(token)), nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func (p *pool) PutObject(ctx context.Context, params *client.PutObjectParams, option ...client.CallOption) (*object.ID, error) {
|
|
|
|
conn, options, err := p.conn(option)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
return conn.PutObject(ctx, params, options...)
|
|
|
|
}
|
|
|
|
|
|
|
|
func (p *pool) DeleteObject(ctx context.Context, params *client.DeleteObjectParams, option ...client.CallOption) error {
|
|
|
|
conn, options, err := p.conn(option)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
return conn.DeleteObject(ctx, params, options...)
|
|
|
|
}
|
|
|
|
|
|
|
|
func (p *pool) GetObject(ctx context.Context, params *client.GetObjectParams, option ...client.CallOption) (*object.Object, error) {
|
|
|
|
conn, options, err := p.conn(option)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
return conn.GetObject(ctx, params, options...)
|
|
|
|
}
|
|
|
|
|
|
|
|
func (p *pool) GetObjectHeader(ctx context.Context, params *client.ObjectHeaderParams, option ...client.CallOption) (*object.Object, error) {
|
|
|
|
conn, options, err := p.conn(option)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
return conn.GetObjectHeader(ctx, params, options...)
|
|
|
|
}
|
|
|
|
|
|
|
|
func (p *pool) ObjectPayloadRangeData(ctx context.Context, params *client.RangeDataParams, option ...client.CallOption) ([]byte, error) {
|
|
|
|
conn, options, err := p.conn(option)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
return conn.ObjectPayloadRangeData(ctx, params, options...)
|
|
|
|
}
|
|
|
|
|
|
|
|
func (p *pool) ObjectPayloadRangeSHA256(ctx context.Context, params *client.RangeChecksumParams, option ...client.CallOption) ([][32]byte, error) {
|
|
|
|
conn, options, err := p.conn(option)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
return conn.ObjectPayloadRangeSHA256(ctx, params, options...)
|
|
|
|
}
|
|
|
|
|
|
|
|
func (p *pool) ObjectPayloadRangeTZ(ctx context.Context, params *client.RangeChecksumParams, option ...client.CallOption) ([][64]byte, error) {
|
|
|
|
conn, options, err := p.conn(option)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
return conn.ObjectPayloadRangeTZ(ctx, params, options...)
|
|
|
|
}
|
|
|
|
|
|
|
|
func (p *pool) SearchObject(ctx context.Context, params *client.SearchObjectParams, option ...client.CallOption) ([]*object.ID, error) {
|
|
|
|
conn, options, err := p.conn(option)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
return conn.SearchObject(ctx, params, options...)
|
|
|
|
}
|
2021-06-22 09:15:21 +00:00
|
|
|
|
|
|
|
func (p *pool) PutContainer(ctx context.Context, cnr *container.Container, option ...client.CallOption) (*cid.ID, error) {
|
|
|
|
conn, options, err := p.conn(option)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
return conn.PutContainer(ctx, cnr, options...)
|
|
|
|
}
|
|
|
|
|
|
|
|
func (p *pool) GetContainer(ctx context.Context, cid *cid.ID, option ...client.CallOption) (*container.Container, error) {
|
|
|
|
conn, options, err := p.conn(option)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
return conn.GetContainer(ctx, cid, options...)
|
|
|
|
}
|
|
|
|
|
|
|
|
func (p *pool) ListContainers(ctx context.Context, ownerID *owner.ID, option ...client.CallOption) ([]*cid.ID, error) {
|
|
|
|
conn, options, err := p.conn(option)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
return conn.ListContainers(ctx, ownerID, options...)
|
|
|
|
}
|
|
|
|
|
|
|
|
func (p *pool) DeleteContainer(ctx context.Context, cid *cid.ID, option ...client.CallOption) error {
|
|
|
|
conn, options, err := p.conn(option)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
return conn.DeleteContainer(ctx, cid, options...)
|
|
|
|
}
|
|
|
|
|
|
|
|
func (p *pool) GetEACL(ctx context.Context, cid *cid.ID, option ...client.CallOption) (*client.EACLWithSignature, error) {
|
|
|
|
conn, options, err := p.conn(option)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
return conn.GetEACL(ctx, cid, options...)
|
|
|
|
}
|
|
|
|
|
|
|
|
func (p *pool) SetEACL(ctx context.Context, table *eacl.Table, option ...client.CallOption) error {
|
|
|
|
conn, options, err := p.conn(option)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
return conn.SetEACL(ctx, table, options...)
|
|
|
|
}
|
|
|
|
|
|
|
|
func (p *pool) AnnounceContainerUsedSpace(ctx context.Context, announce []container.UsedSpaceAnnouncement, option ...client.CallOption) error {
|
|
|
|
conn, options, err := p.conn(option)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
return conn.AnnounceContainerUsedSpace(ctx, announce, options...)
|
|
|
|
}
|
|
|
|
|
|
|
|
func (p *pool) WaitForContainerPresence(ctx context.Context, cid *cid.ID, pollParams *ContainerPollingParams) error {
|
|
|
|
conn, _, err := p.Connection()
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
wctx, cancel := context.WithTimeout(ctx, pollParams.CreationTimeout)
|
|
|
|
defer cancel()
|
|
|
|
ticker := time.NewTimer(pollParams.PollInterval)
|
|
|
|
defer ticker.Stop()
|
|
|
|
wdone := wctx.Done()
|
|
|
|
done := ctx.Done()
|
|
|
|
for {
|
|
|
|
select {
|
|
|
|
case <-done:
|
|
|
|
return ctx.Err()
|
|
|
|
case <-wdone:
|
|
|
|
return wctx.Err()
|
|
|
|
case <-ticker.C:
|
|
|
|
_, err = conn.GetContainer(ctx, cid)
|
|
|
|
if err == nil {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
ticker.Reset(pollParams.PollInterval)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|