2017-01-10 09:01:12 +00:00
|
|
|
package weed_server
|
|
|
|
|
|
|
|
import (
|
2020-03-02 06:13:47 +00:00
|
|
|
"context"
|
2022-05-16 02:41:18 +00:00
|
|
|
"errors"
|
|
|
|
"fmt"
|
2022-07-29 07:17:28 +00:00
|
|
|
"github.com/seaweedfs/seaweedfs/weed/cluster"
|
2022-05-16 02:41:18 +00:00
|
|
|
"net"
|
|
|
|
"sort"
|
|
|
|
"time"
|
|
|
|
|
2022-07-29 07:17:28 +00:00
|
|
|
"github.com/seaweedfs/seaweedfs/weed/pb"
|
|
|
|
"github.com/seaweedfs/seaweedfs/weed/stats"
|
|
|
|
"github.com/seaweedfs/seaweedfs/weed/storage/backend"
|
|
|
|
"github.com/seaweedfs/seaweedfs/weed/util"
|
2017-01-12 21:42:53 +00:00
|
|
|
|
2022-07-27 19:12:40 +00:00
|
|
|
"github.com/seaweedfs/raft"
|
2020-02-27 01:27:49 +00:00
|
|
|
"google.golang.org/grpc/peer"
|
|
|
|
|
2022-07-29 07:17:28 +00:00
|
|
|
"github.com/seaweedfs/seaweedfs/weed/glog"
|
|
|
|
"github.com/seaweedfs/seaweedfs/weed/pb/master_pb"
|
|
|
|
"github.com/seaweedfs/seaweedfs/weed/storage/needle"
|
|
|
|
"github.com/seaweedfs/seaweedfs/weed/topology"
|
2017-01-10 09:01:12 +00:00
|
|
|
)
|
|
|
|
|
2022-05-17 06:51:01 +00:00
|
|
|
func (ms *MasterServer) RegisterUuids(heartbeat *master_pb.Heartbeat) (duplicated_uuids []string, err error) {
|
|
|
|
ms.Topo.UuidAccessLock.Lock()
|
|
|
|
defer ms.Topo.UuidAccessLock.Unlock()
|
2022-05-16 02:41:18 +00:00
|
|
|
key := fmt.Sprintf("%s:%d", heartbeat.Ip, heartbeat.Port)
|
2022-05-17 06:51:01 +00:00
|
|
|
if ms.Topo.UuidMap == nil {
|
|
|
|
ms.Topo.UuidMap = make(map[string][]string)
|
2022-05-16 02:41:18 +00:00
|
|
|
}
|
2022-05-17 06:51:01 +00:00
|
|
|
// find whether new uuid exists
|
|
|
|
for k, v := range ms.Topo.UuidMap {
|
|
|
|
sort.Strings(v)
|
|
|
|
for _, id := range heartbeat.LocationUuids {
|
2022-05-16 02:41:18 +00:00
|
|
|
index := sort.SearchStrings(v, id)
|
|
|
|
if index < len(v) && v[index] == id {
|
2022-05-17 06:51:01 +00:00
|
|
|
duplicated_uuids = append(duplicated_uuids, id)
|
|
|
|
glog.Errorf("directory of %s on %s has been loaded", id, k)
|
2022-05-16 02:41:18 +00:00
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
2022-05-17 06:51:01 +00:00
|
|
|
if len(duplicated_uuids) > 0 {
|
|
|
|
return duplicated_uuids, errors.New("volume: Duplicated volume directories were loaded")
|
|
|
|
}
|
|
|
|
|
|
|
|
ms.Topo.UuidMap[key] = heartbeat.LocationUuids
|
|
|
|
glog.V(0).Infof("found new uuid:%v %v , %v", key, heartbeat.LocationUuids, ms.Topo.UuidMap)
|
|
|
|
return nil, nil
|
2022-05-16 02:41:18 +00:00
|
|
|
}
|
|
|
|
|
2022-05-17 06:51:01 +00:00
|
|
|
func (ms *MasterServer) UnRegisterUuids(ip string, port int) {
|
|
|
|
ms.Topo.UuidAccessLock.Lock()
|
|
|
|
defer ms.Topo.UuidAccessLock.Unlock()
|
2022-05-16 02:41:18 +00:00
|
|
|
key := fmt.Sprintf("%s:%d", ip, port)
|
2022-05-17 06:51:01 +00:00
|
|
|
delete(ms.Topo.UuidMap, key)
|
|
|
|
glog.V(0).Infof("remove volume server %v, online volume server: %v", key, ms.Topo.UuidMap)
|
2022-05-16 02:41:18 +00:00
|
|
|
}
|
|
|
|
|
2018-05-27 18:58:00 +00:00
|
|
|
func (ms *MasterServer) SendHeartbeat(stream master_pb.Seaweed_SendHeartbeatServer) error {
|
2017-01-10 09:01:12 +00:00
|
|
|
var dn *topology.DataNode
|
2018-06-25 06:20:27 +00:00
|
|
|
|
|
|
|
defer func() {
|
|
|
|
if dn != nil {
|
2021-09-05 22:20:03 +00:00
|
|
|
dn.Counter--
|
2021-09-14 17:37:06 +00:00
|
|
|
if dn.Counter > 0 {
|
2021-09-05 23:18:50 +00:00
|
|
|
glog.V(0).Infof("disconnect phantom volume server %s:%d remaining %d", dn.Ip, dn.Port, dn.Counter)
|
2021-09-05 22:20:03 +00:00
|
|
|
return
|
|
|
|
}
|
2020-04-29 00:29:10 +00:00
|
|
|
// if the volume server disconnects and reconnects quickly
|
|
|
|
// the unregister and register can race with each other
|
2020-08-06 16:48:54 +00:00
|
|
|
ms.Topo.UnRegisterDataNode(dn)
|
2020-04-29 00:29:10 +00:00
|
|
|
glog.V(0).Infof("unregister disconnected volume server %s:%d", dn.Ip, dn.Port)
|
2022-05-17 06:51:01 +00:00
|
|
|
ms.UnRegisterUuids(dn.Ip, dn.Port)
|
2018-07-28 06:09:55 +00:00
|
|
|
|
|
|
|
message := &master_pb.VolumeLocation{
|
2020-11-11 23:10:06 +00:00
|
|
|
Url: dn.Url(),
|
|
|
|
PublicUrl: dn.PublicUrl,
|
2018-07-28 06:09:55 +00:00
|
|
|
}
|
|
|
|
for _, v := range dn.GetVolumes() {
|
|
|
|
message.DeletedVids = append(message.DeletedVids, uint32(v.Id))
|
|
|
|
}
|
2019-05-26 08:05:08 +00:00
|
|
|
for _, s := range dn.GetEcShards() {
|
|
|
|
message.DeletedVids = append(message.DeletedVids, uint32(s.VolumeId))
|
|
|
|
}
|
2018-07-28 06:09:55 +00:00
|
|
|
|
|
|
|
if len(message.DeletedVids) > 0 {
|
2021-11-06 11:07:38 +00:00
|
|
|
ms.broadcastToClients(&master_pb.KeepConnectedResponse{VolumeLocation: message})
|
2018-07-28 06:09:55 +00:00
|
|
|
}
|
2018-06-25 06:20:27 +00:00
|
|
|
}
|
|
|
|
}()
|
|
|
|
|
2017-01-10 09:01:12 +00:00
|
|
|
for {
|
|
|
|
heartbeat, err := stream.Recv()
|
2018-08-24 07:30:03 +00:00
|
|
|
if err != nil {
|
2019-10-25 16:35:19 +00:00
|
|
|
if dn != nil {
|
|
|
|
glog.Warningf("SendHeartbeat.Recv server %s:%d : %v", dn.Ip, dn.Port, err)
|
|
|
|
} else {
|
2019-10-25 16:44:58 +00:00
|
|
|
glog.Warningf("SendHeartbeat.Recv: %v", err)
|
2019-10-25 16:35:19 +00:00
|
|
|
}
|
2022-01-24 14:09:43 +00:00
|
|
|
stats.MasterReceivedHeartbeatCounter.WithLabelValues("error").Inc()
|
2018-08-24 07:30:03 +00:00
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2020-08-06 16:48:54 +00:00
|
|
|
ms.Topo.Sequence.SetMax(heartbeat.MaxFileKey)
|
2019-07-18 06:23:01 +00:00
|
|
|
|
2018-08-24 07:30:03 +00:00
|
|
|
if dn == nil {
|
2020-08-06 16:48:54 +00:00
|
|
|
dcName, rackName := ms.Topo.Configuration.Locate(heartbeat.Ip, heartbeat.DataCenter, heartbeat.Rack)
|
|
|
|
dc := ms.Topo.GetOrCreateDataCenter(dcName)
|
2018-08-24 07:30:03 +00:00
|
|
|
rack := dc.GetOrCreateRack(rackName)
|
2021-09-13 05:47:52 +00:00
|
|
|
dn = rack.GetOrCreateDataNode(heartbeat.Ip, int(heartbeat.Port), int(heartbeat.GrpcPort), heartbeat.PublicUrl, heartbeat.MaxVolumeCounts)
|
2022-05-17 06:51:01 +00:00
|
|
|
glog.V(0).Infof("added volume server %d: %v:%d %v", dn.Counter, heartbeat.GetIp(), heartbeat.GetPort(), heartbeat.LocationUuids)
|
|
|
|
uuidlist, err := ms.RegisterUuids(heartbeat)
|
2022-05-16 02:41:18 +00:00
|
|
|
if err != nil {
|
|
|
|
if stream_err := stream.Send(&master_pb.HeartbeatResponse{
|
2022-06-11 16:51:11 +00:00
|
|
|
DuplicatedUuids: uuidlist,
|
2022-05-16 02:41:18 +00:00
|
|
|
}); stream_err != nil {
|
|
|
|
glog.Warningf("SendHeartbeat.Send DuplicatedDirectory response to %s:%d %v", dn.Ip, dn.Port, stream_err)
|
|
|
|
return stream_err
|
|
|
|
}
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2018-08-24 07:30:03 +00:00
|
|
|
if err := stream.Send(&master_pb.HeartbeatResponse{
|
2020-09-19 21:10:26 +00:00
|
|
|
VolumeSizeLimit: uint64(ms.option.VolumeSizeLimitMB) * 1024 * 1024,
|
2018-08-24 07:30:03 +00:00
|
|
|
}); err != nil {
|
2019-10-25 16:35:19 +00:00
|
|
|
glog.Warningf("SendHeartbeat.Send volume size to %s:%d %v", dn.Ip, dn.Port, err)
|
2018-08-24 07:30:03 +00:00
|
|
|
return err
|
|
|
|
}
|
2022-01-24 14:09:43 +00:00
|
|
|
stats.MasterReceivedHeartbeatCounter.WithLabelValues("dataNode").Inc()
|
2021-09-11 09:05:55 +00:00
|
|
|
dn.Counter++
|
2018-08-24 07:30:03 +00:00
|
|
|
}
|
2017-01-10 09:01:12 +00:00
|
|
|
|
2021-02-16 10:47:02 +00:00
|
|
|
dn.AdjustMaxVolumeCounts(heartbeat.MaxVolumeCounts)
|
2020-03-22 23:21:42 +00:00
|
|
|
|
2020-08-31 03:12:04 +00:00
|
|
|
glog.V(4).Infof("master received heartbeat %s", heartbeat.String())
|
2022-01-24 14:09:43 +00:00
|
|
|
stats.MasterReceivedHeartbeatCounter.WithLabelValues("total").Inc()
|
|
|
|
|
2021-03-22 20:24:07 +00:00
|
|
|
var dataCenter string
|
|
|
|
if dc := dn.GetDataCenter(); dc != nil {
|
|
|
|
dataCenter = string(dc.Id())
|
|
|
|
}
|
2018-08-24 07:30:03 +00:00
|
|
|
message := &master_pb.VolumeLocation{
|
2020-11-11 10:03:47 +00:00
|
|
|
Url: dn.Url(),
|
|
|
|
PublicUrl: dn.PublicUrl,
|
2021-03-22 20:24:07 +00:00
|
|
|
DataCenter: dataCenter,
|
2018-08-24 07:30:03 +00:00
|
|
|
}
|
2022-01-24 14:09:43 +00:00
|
|
|
if len(heartbeat.NewVolumes) > 0 {
|
|
|
|
stats.FilerRequestCounter.WithLabelValues("newVolumes").Inc()
|
|
|
|
}
|
|
|
|
if len(heartbeat.DeletedVolumes) > 0 {
|
|
|
|
stats.FilerRequestCounter.WithLabelValues("deletedVolumes").Inc()
|
|
|
|
}
|
2019-04-20 18:35:20 +00:00
|
|
|
if len(heartbeat.NewVolumes) > 0 || len(heartbeat.DeletedVolumes) > 0 {
|
2018-08-24 08:26:56 +00:00
|
|
|
// process delta volume ids if exists for fast volume id updates
|
2019-04-30 03:22:19 +00:00
|
|
|
for _, volInfo := range heartbeat.NewVolumes {
|
2019-04-20 18:35:20 +00:00
|
|
|
message.NewVids = append(message.NewVids, volInfo.Id)
|
|
|
|
}
|
2019-04-30 03:22:19 +00:00
|
|
|
for _, volInfo := range heartbeat.DeletedVolumes {
|
2019-04-20 18:35:20 +00:00
|
|
|
message.DeletedVids = append(message.DeletedVids, volInfo.Id)
|
|
|
|
}
|
|
|
|
// update master internal volume layouts
|
2020-08-06 16:48:54 +00:00
|
|
|
ms.Topo.IncrementalSyncDataNodeRegistration(heartbeat.NewVolumes, heartbeat.DeletedVolumes, dn)
|
2019-05-23 07:42:28 +00:00
|
|
|
}
|
|
|
|
|
2019-06-05 20:32:33 +00:00
|
|
|
if len(heartbeat.Volumes) > 0 || heartbeat.HasNoVolumes {
|
2022-04-07 07:18:28 +00:00
|
|
|
dcName, rackName := ms.Topo.Configuration.Locate(heartbeat.Ip, heartbeat.DataCenter, heartbeat.Rack)
|
|
|
|
ms.Topo.DataNodeRegistration(dcName, rackName, dn)
|
|
|
|
|
2018-08-24 08:26:56 +00:00
|
|
|
// process heartbeat.Volumes
|
2022-01-24 14:09:43 +00:00
|
|
|
stats.MasterReceivedHeartbeatCounter.WithLabelValues("Volumes").Inc()
|
2020-08-06 16:48:54 +00:00
|
|
|
newVolumes, deletedVolumes := ms.Topo.SyncDataNodeRegistration(heartbeat.Volumes, dn)
|
2018-08-24 08:26:56 +00:00
|
|
|
|
|
|
|
for _, v := range newVolumes {
|
2019-04-30 03:22:19 +00:00
|
|
|
glog.V(0).Infof("master see new volume %d from %s", uint32(v.Id), dn.Url())
|
2018-08-24 08:26:56 +00:00
|
|
|
message.NewVids = append(message.NewVids, uint32(v.Id))
|
|
|
|
}
|
|
|
|
for _, v := range deletedVolumes {
|
2019-04-20 18:35:20 +00:00
|
|
|
glog.V(0).Infof("master see deleted volume %d from %s", uint32(v.Id), dn.Url())
|
2018-08-24 08:26:56 +00:00
|
|
|
message.DeletedVids = append(message.DeletedVids, uint32(v.Id))
|
|
|
|
}
|
2019-05-23 07:42:28 +00:00
|
|
|
}
|
|
|
|
|
2019-05-26 07:21:17 +00:00
|
|
|
if len(heartbeat.NewEcShards) > 0 || len(heartbeat.DeletedEcShards) > 0 {
|
2022-01-24 14:09:43 +00:00
|
|
|
stats.MasterReceivedHeartbeatCounter.WithLabelValues("newEcShards").Inc()
|
2019-05-26 07:21:17 +00:00
|
|
|
// update master internal volume layouts
|
2020-08-06 16:48:54 +00:00
|
|
|
ms.Topo.IncrementalSyncDataNodeEcShards(heartbeat.NewEcShards, heartbeat.DeletedEcShards, dn)
|
2019-05-26 07:49:15 +00:00
|
|
|
|
|
|
|
for _, s := range heartbeat.NewEcShards {
|
2022-04-06 02:03:02 +00:00
|
|
|
message.NewEcVids = append(message.NewEcVids, s.Id)
|
2019-05-26 07:49:15 +00:00
|
|
|
}
|
|
|
|
for _, s := range heartbeat.DeletedEcShards {
|
2022-04-06 02:03:02 +00:00
|
|
|
if dn.HasEcShards(needle.VolumeId(s.Id)) {
|
2019-05-26 07:49:15 +00:00
|
|
|
continue
|
|
|
|
}
|
2022-04-06 02:03:02 +00:00
|
|
|
message.DeletedEcVids = append(message.DeletedEcVids, s.Id)
|
2019-05-26 07:49:15 +00:00
|
|
|
}
|
|
|
|
|
2019-05-26 07:21:17 +00:00
|
|
|
}
|
|
|
|
|
2019-06-05 20:32:33 +00:00
|
|
|
if len(heartbeat.EcShards) > 0 || heartbeat.HasNoEcShards {
|
2022-01-24 14:09:43 +00:00
|
|
|
stats.MasterReceivedHeartbeatCounter.WithLabelValues("ecShards").Inc()
|
|
|
|
glog.V(4).Infof("master received ec shards from %s: %+v", dn.Url(), heartbeat.EcShards)
|
2020-08-06 16:48:54 +00:00
|
|
|
newShards, deletedShards := ms.Topo.SyncDataNodeEcShards(heartbeat.EcShards, dn)
|
2019-05-24 06:47:49 +00:00
|
|
|
|
2019-05-26 07:49:15 +00:00
|
|
|
// broadcast the ec vid changes to master clients
|
|
|
|
for _, s := range newShards {
|
2022-04-06 02:03:02 +00:00
|
|
|
message.NewEcVids = append(message.NewEcVids, uint32(s.VolumeId))
|
2019-05-24 06:47:49 +00:00
|
|
|
}
|
2019-05-26 07:49:15 +00:00
|
|
|
for _, s := range deletedShards {
|
|
|
|
if dn.HasVolumesById(s.VolumeId) {
|
|
|
|
continue
|
|
|
|
}
|
2022-04-06 02:03:02 +00:00
|
|
|
message.DeletedEcVids = append(message.DeletedEcVids, uint32(s.VolumeId))
|
2019-05-24 06:47:49 +00:00
|
|
|
}
|
|
|
|
|
2018-08-24 07:30:03 +00:00
|
|
|
}
|
2022-04-06 02:03:02 +00:00
|
|
|
if len(message.NewVids) > 0 || len(message.DeletedVids) > 0 || len(message.NewEcVids) > 0 || len(message.DeletedEcVids) > 0 {
|
2021-11-06 11:07:38 +00:00
|
|
|
ms.broadcastToClients(&master_pb.KeepConnectedResponse{VolumeLocation: message})
|
2017-01-10 09:01:12 +00:00
|
|
|
}
|
2017-01-18 17:34:27 +00:00
|
|
|
|
2017-01-21 21:58:56 +00:00
|
|
|
// tell the volume servers about the leader
|
2020-08-06 16:48:54 +00:00
|
|
|
newLeader, err := ms.Topo.Leader()
|
2019-03-04 04:43:43 +00:00
|
|
|
if err != nil {
|
2019-10-25 16:35:19 +00:00
|
|
|
glog.Warningf("SendHeartbeat find leader: %v", err)
|
2019-03-04 04:43:43 +00:00
|
|
|
return err
|
|
|
|
}
|
|
|
|
if err := stream.Send(&master_pb.HeartbeatResponse{
|
2021-09-13 05:47:52 +00:00
|
|
|
Leader: string(newLeader),
|
2019-03-04 04:43:43 +00:00
|
|
|
}); err != nil {
|
2019-10-25 16:35:19 +00:00
|
|
|
glog.Warningf("SendHeartbeat.Send response to to %s:%d %v", dn.Ip, dn.Port, err)
|
2019-03-04 04:43:43 +00:00
|
|
|
return err
|
2017-01-18 17:34:27 +00:00
|
|
|
}
|
2017-01-10 09:01:12 +00:00
|
|
|
}
|
|
|
|
}
|
2018-06-01 07:39:39 +00:00
|
|
|
|
2021-11-06 00:52:15 +00:00
|
|
|
// KeepConnected keep a stream gRPC call to the master. Used by clients to know the master is up.
|
2018-07-28 08:30:03 +00:00
|
|
|
// And clients gets the up-to-date list of volume locations
|
2021-11-06 00:52:15 +00:00
|
|
|
func (ms *MasterServer) KeepConnected(stream master_pb.Seaweed_KeepConnectedServer) error {
|
2018-07-28 06:09:55 +00:00
|
|
|
|
2021-08-14 12:03:45 +00:00
|
|
|
req, recvErr := stream.Recv()
|
|
|
|
if recvErr != nil {
|
|
|
|
return recvErr
|
2018-07-28 06:09:55 +00:00
|
|
|
}
|
|
|
|
|
2018-07-28 08:30:03 +00:00
|
|
|
if !ms.Topo.IsLeader() {
|
2019-07-31 08:54:42 +00:00
|
|
|
return ms.informNewLeader(stream)
|
2018-07-28 08:30:03 +00:00
|
|
|
}
|
|
|
|
|
2021-09-13 05:47:52 +00:00
|
|
|
peerAddress := pb.ServerAddress(req.ClientAddress)
|
2018-07-28 06:09:55 +00:00
|
|
|
|
2020-09-22 02:41:38 +00:00
|
|
|
// buffer by 1 so we don't end up getting stuck writing to stopChan forever
|
|
|
|
stopChan := make(chan bool, 1)
|
2018-07-28 06:09:55 +00:00
|
|
|
|
2022-05-02 04:59:16 +00:00
|
|
|
clientName, messageChan := ms.addClient(req.FilerGroup, req.ClientType, peerAddress)
|
2022-07-03 07:29:25 +00:00
|
|
|
for _, update := range ms.Cluster.AddClusterNode(req.FilerGroup, req.ClientType, cluster.DataCenter(req.DataCenter), cluster.Rack(req.Rack), peerAddress, req.Version) {
|
2021-11-06 11:07:38 +00:00
|
|
|
ms.broadcastToClients(update)
|
|
|
|
}
|
2018-07-28 06:09:55 +00:00
|
|
|
|
2021-11-03 06:38:45 +00:00
|
|
|
defer func() {
|
2022-07-10 21:01:53 +00:00
|
|
|
for _, update := range ms.Cluster.RemoveClusterNode(req.FilerGroup, req.ClientType, peerAddress) {
|
2021-11-06 11:07:38 +00:00
|
|
|
ms.broadcastToClients(update)
|
|
|
|
}
|
2021-11-03 06:38:45 +00:00
|
|
|
ms.deleteClient(clientName)
|
|
|
|
}()
|
2022-06-27 16:47:05 +00:00
|
|
|
for i, message := range ms.Topo.ToVolumeLocations() {
|
|
|
|
if i == 0 {
|
|
|
|
if leader, err := ms.Topo.Leader(); err == nil {
|
|
|
|
message.Leader = string(leader)
|
|
|
|
}
|
|
|
|
}
|
2021-11-06 01:11:40 +00:00
|
|
|
if sendErr := stream.Send(&master_pb.KeepConnectedResponse{VolumeLocation: message}); sendErr != nil {
|
2021-08-14 12:03:45 +00:00
|
|
|
return sendErr
|
2018-07-28 08:17:35 +00:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2018-07-28 06:09:55 +00:00
|
|
|
go func() {
|
|
|
|
for {
|
|
|
|
_, err := stream.Recv()
|
|
|
|
if err != nil {
|
|
|
|
glog.V(2).Infof("- client %v: %v", clientName, err)
|
2021-06-12 09:52:41 +00:00
|
|
|
close(stopChan)
|
|
|
|
return
|
2018-07-28 06:09:55 +00:00
|
|
|
}
|
2018-06-01 07:39:39 +00:00
|
|
|
}
|
2018-07-28 06:09:55 +00:00
|
|
|
}()
|
|
|
|
|
2019-01-11 13:47:46 +00:00
|
|
|
ticker := time.NewTicker(5 * time.Second)
|
2018-07-28 06:09:55 +00:00
|
|
|
for {
|
|
|
|
select {
|
|
|
|
case message := <-messageChan:
|
2021-11-06 11:07:38 +00:00
|
|
|
if err := stream.Send(message); err != nil {
|
2018-08-24 08:26:56 +00:00
|
|
|
glog.V(0).Infof("=> client %v: %+v", clientName, message)
|
2018-07-28 06:09:55 +00:00
|
|
|
return err
|
|
|
|
}
|
2019-01-11 13:47:46 +00:00
|
|
|
case <-ticker.C:
|
|
|
|
if !ms.Topo.IsLeader() {
|
2022-01-24 15:13:07 +00:00
|
|
|
stats.MasterRaftIsleader.Set(0)
|
2019-07-31 08:54:42 +00:00
|
|
|
return ms.informNewLeader(stream)
|
2022-01-24 15:13:07 +00:00
|
|
|
} else {
|
|
|
|
stats.MasterRaftIsleader.Set(1)
|
2019-01-11 13:47:46 +00:00
|
|
|
}
|
2018-07-28 06:09:55 +00:00
|
|
|
case <-stopChan:
|
|
|
|
return nil
|
2018-06-01 07:39:39 +00:00
|
|
|
}
|
|
|
|
}
|
2018-07-28 06:09:55 +00:00
|
|
|
|
2018-06-01 07:39:39 +00:00
|
|
|
}
|
2019-07-31 08:54:42 +00:00
|
|
|
|
2021-11-06 11:07:38 +00:00
|
|
|
func (ms *MasterServer) broadcastToClients(message *master_pb.KeepConnectedResponse) {
|
|
|
|
ms.clientChansLock.RLock()
|
|
|
|
for _, ch := range ms.clientChans {
|
|
|
|
ch <- message
|
|
|
|
}
|
|
|
|
ms.clientChansLock.RUnlock()
|
|
|
|
}
|
|
|
|
|
2021-11-06 00:52:15 +00:00
|
|
|
func (ms *MasterServer) informNewLeader(stream master_pb.Seaweed_KeepConnectedServer) error {
|
2019-07-31 08:54:42 +00:00
|
|
|
leader, err := ms.Topo.Leader()
|
|
|
|
if err != nil {
|
2019-07-31 09:09:04 +00:00
|
|
|
glog.Errorf("topo leader: %v", err)
|
2019-07-31 08:54:42 +00:00
|
|
|
return raft.NotLeaderError
|
|
|
|
}
|
2021-11-06 01:11:40 +00:00
|
|
|
if err := stream.Send(&master_pb.KeepConnectedResponse{
|
|
|
|
VolumeLocation: &master_pb.VolumeLocation{
|
|
|
|
Leader: string(leader),
|
|
|
|
},
|
2019-07-31 08:54:42 +00:00
|
|
|
}); err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
return nil
|
|
|
|
}
|
2020-03-02 06:13:47 +00:00
|
|
|
|
2022-05-02 04:59:16 +00:00
|
|
|
func (ms *MasterServer) addClient(filerGroup, clientType string, clientAddress pb.ServerAddress) (clientName string, messageChan chan *master_pb.KeepConnectedResponse) {
|
|
|
|
clientName = filerGroup + "." + clientType + "@" + string(clientAddress)
|
2020-03-02 06:13:47 +00:00
|
|
|
glog.V(0).Infof("+ client %v", clientName)
|
|
|
|
|
2020-09-22 02:41:38 +00:00
|
|
|
// we buffer this because otherwise we end up in a potential deadlock where
|
2021-11-06 00:52:15 +00:00
|
|
|
// the KeepConnected loop is no longer listening on this channel but we're
|
2020-09-22 02:41:38 +00:00
|
|
|
// trying to send to it in SendHeartbeat and so we can't lock the
|
|
|
|
// clientChansLock to remove the channel and we're stuck writing to it
|
|
|
|
// 100 is probably overkill
|
2021-11-06 11:07:38 +00:00
|
|
|
messageChan = make(chan *master_pb.KeepConnectedResponse, 100)
|
2020-03-02 06:13:47 +00:00
|
|
|
|
|
|
|
ms.clientChansLock.Lock()
|
|
|
|
ms.clientChans[clientName] = messageChan
|
|
|
|
ms.clientChansLock.Unlock()
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
func (ms *MasterServer) deleteClient(clientName string) {
|
|
|
|
glog.V(0).Infof("- client %v", clientName)
|
|
|
|
ms.clientChansLock.Lock()
|
|
|
|
delete(ms.clientChans, clientName)
|
|
|
|
ms.clientChansLock.Unlock()
|
|
|
|
}
|
|
|
|
|
|
|
|
func findClientAddress(ctx context.Context, grpcPort uint32) string {
|
|
|
|
// fmt.Printf("FromContext %+v\n", ctx)
|
|
|
|
pr, ok := peer.FromContext(ctx)
|
|
|
|
if !ok {
|
|
|
|
glog.Error("failed to get peer from ctx")
|
|
|
|
return ""
|
|
|
|
}
|
|
|
|
if pr.Addr == net.Addr(nil) {
|
|
|
|
glog.Error("failed to get peer address")
|
|
|
|
return ""
|
|
|
|
}
|
|
|
|
if grpcPort == 0 {
|
|
|
|
return pr.Addr.String()
|
|
|
|
}
|
|
|
|
if tcpAddr, ok := pr.Addr.(*net.TCPAddr); ok {
|
|
|
|
externalIP := tcpAddr.IP
|
2021-09-07 23:43:54 +00:00
|
|
|
return util.JoinHostPort(externalIP.String(), int(grpcPort))
|
2020-03-02 06:13:47 +00:00
|
|
|
}
|
|
|
|
return pr.Addr.String()
|
|
|
|
|
|
|
|
}
|
|
|
|
|
2020-10-07 08:25:39 +00:00
|
|
|
func (ms *MasterServer) GetMasterConfiguration(ctx context.Context, req *master_pb.GetMasterConfigurationRequest) (*master_pb.GetMasterConfigurationResponse, error) {
|
|
|
|
|
|
|
|
// tell the volume servers about the leader
|
|
|
|
leader, _ := ms.Topo.Leader()
|
|
|
|
|
|
|
|
resp := &master_pb.GetMasterConfigurationResponse{
|
|
|
|
MetricsAddress: ms.option.MetricsAddress,
|
|
|
|
MetricsIntervalSeconds: uint32(ms.option.MetricsIntervalSec),
|
|
|
|
StorageBackends: backend.ToPbStorageBackends(),
|
|
|
|
DefaultReplication: ms.option.DefaultReplicaPlacement,
|
2021-08-13 00:54:34 +00:00
|
|
|
VolumeSizeLimitMB: uint32(ms.option.VolumeSizeLimitMB),
|
|
|
|
VolumePreallocate: ms.option.VolumePreallocate,
|
2021-09-13 05:47:52 +00:00
|
|
|
Leader: string(leader),
|
2020-10-07 08:25:39 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
return resp, nil
|
|
|
|
}
|