syncthing/model/model.go

913 lines
23 KiB
Go
Raw Normal View History

2014-07-13 00:45:33 +02:00
// Copyright (C) 2014 Jakob Borg and Contributors (see the CONTRIBUTORS file).
// All rights reserved. Use of this source code is governed by an MIT-style
// license that can be found in the LICENSE file.
2014-06-01 22:50:14 +02:00
2014-05-15 05:26:55 +02:00
package model
2013-12-15 11:43:31 +01:00
import (
"errors"
2013-12-23 18:12:44 +01:00
"fmt"
"io"
2014-01-05 23:54:57 +01:00
"net"
2013-12-15 11:43:31 +01:00
"os"
"path/filepath"
"strconv"
2013-12-15 11:43:31 +01:00
"sync"
"time"
2014-06-21 09:43:12 +02:00
"github.com/syncthing/syncthing/config"
"github.com/syncthing/syncthing/events"
"github.com/syncthing/syncthing/files"
"github.com/syncthing/syncthing/lamport"
"github.com/syncthing/syncthing/protocol"
"github.com/syncthing/syncthing/scanner"
2014-07-06 14:46:48 +02:00
"github.com/syndtr/goleveldb/leveldb"
2013-12-15 11:43:31 +01:00
)
type repoState int
const (
RepoIdle repoState = iota
RepoScanning
RepoSyncing
RepoCleaning
)
2014-07-17 13:38:36 +02:00
func (s repoState) String() string {
switch s {
case RepoIdle:
return "idle"
case RepoScanning:
return "scanning"
case RepoCleaning:
return "cleaning"
case RepoSyncing:
return "syncing"
default:
return "unknown"
}
}
// Somewhat arbitrary amount of bytes that we choose to let represent the size
// of an unsynchronized directory entry or a deleted file. We need it to be
// larger than zero so that it's visible that there is some amount of bytes to
// transfer to bring the systems into synchronization.
const zeroEntrySize = 128
// How many files to send in each Index/IndexUpdate message.
const indexBatchSize = 1000
2013-12-15 11:43:31 +01:00
type Model struct {
2014-05-15 05:26:55 +02:00
indexDir string
cfg *config.Configuration
2014-07-06 14:46:48 +02:00
db *leveldb.DB
2014-05-15 05:26:55 +02:00
clientName string
clientVersion string
2014-05-23 14:31:16 +02:00
repoCfgs map[string]config.RepositoryConfiguration // repo -> cfg
repoFiles map[string]*files.Set // repo -> files
repoNodes map[string][]protocol.NodeID // repo -> nodeIDs
nodeRepos map[protocol.NodeID][]string // nodeID -> repos
2014-05-23 14:31:16 +02:00
suppressor map[string]*suppressor // repo -> suppressor
rmut sync.RWMutex // protects the above
2014-07-17 13:38:36 +02:00
repoState map[string]repoState // repo -> state
repoStateChanged map[string]time.Time // repo -> time when state changed
smut sync.RWMutex
protoConn map[protocol.NodeID]protocol.Connection
rawConn map[protocol.NodeID]io.Closer
nodeVer map[protocol.NodeID]string
2014-01-18 04:06:44 +01:00
pmut sync.RWMutex // protects protoConn and rawConn
2013-12-30 15:30:29 +01:00
sentLocalVer map[protocol.NodeID]map[string]uint64
slMut sync.Mutex
sup suppressor
2014-01-12 16:59:35 +01:00
addedRepo bool
started bool
2013-12-15 11:43:31 +01:00
}
var (
ErrNoSuchFile = errors.New("no such file")
ErrInvalid = errors.New("file is invalid")
)
// NewModel creates and starts a new model. The model starts in read-only mode,
// where it sends index information to connected peers and responds to requests
// for file data without altering the local repository in any way.
2014-07-06 14:46:48 +02:00
func NewModel(indexDir string, cfg *config.Configuration, clientName, clientVersion string, db *leveldb.DB) *Model {
2013-12-15 11:43:31 +01:00
m := &Model{
2014-07-17 13:38:36 +02:00
indexDir: indexDir,
cfg: cfg,
db: db,
clientName: clientName,
clientVersion: clientVersion,
repoCfgs: make(map[string]config.RepositoryConfiguration),
repoFiles: make(map[string]*files.Set),
repoNodes: make(map[string][]protocol.NodeID),
nodeRepos: make(map[protocol.NodeID][]string),
repoState: make(map[string]repoState),
repoStateChanged: make(map[string]time.Time),
suppressor: make(map[string]*suppressor),
protoConn: make(map[protocol.NodeID]protocol.Connection),
rawConn: make(map[protocol.NodeID]io.Closer),
nodeVer: make(map[protocol.NodeID]string),
sentLocalVer: make(map[protocol.NodeID]map[string]uint64),
sup: suppressor{threshold: int64(cfg.Options.MaxChangeKbps)},
2013-12-15 11:43:31 +01:00
}
var timeout = 20 * 60 // seconds
if t := os.Getenv("STDEADLOCKTIMEOUT"); len(t) > 0 {
it, err := strconv.Atoi(t)
if err == nil {
timeout = it
}
}
deadlockDetect(&m.rmut, time.Duration(timeout)*time.Second)
deadlockDetect(&m.smut, time.Duration(timeout)*time.Second)
deadlockDetect(&m.pmut, time.Duration(timeout)*time.Second)
2013-12-15 11:43:31 +01:00
return m
}
// StartRW starts read/write processing on the current model. When in
// read/write mode the model will attempt to keep in sync with the cluster by
// pulling needed files from peer nodes.
func (m *Model) StartRepoRW(repo string, threads int) {
m.rmut.RLock()
defer m.rmut.RUnlock()
2014-05-23 14:31:16 +02:00
if cfg, ok := m.repoCfgs[repo]; !ok {
panic("cannot start without repo")
} else {
2014-05-23 14:31:16 +02:00
newPuller(cfg, m, threads, m.cfg)
}
}
// StartRO starts read only processing on the current model. When in
// read only mode the model will announce files to the cluster but not
// pull in any external changes.
func (m *Model) StartRepoRO(repo string) {
m.StartRepoRW(repo, 0) // zero threads => read only
2014-01-20 22:22:27 +01:00
}
2014-01-05 23:54:57 +01:00
type ConnectionInfo struct {
protocol.Statistics
2014-01-23 13:12:45 +01:00
Address string
ClientVersion string
2014-01-05 23:54:57 +01:00
}
// ConnectionStats returns a map with connection statistics for each connected node.
2014-01-05 23:54:57 +01:00
func (m *Model) ConnectionStats() map[string]ConnectionInfo {
type remoteAddrer interface {
RemoteAddr() net.Addr
}
2014-01-18 04:06:44 +01:00
m.pmut.RLock()
m.rmut.RLock()
2014-01-05 16:16:37 +01:00
2014-01-05 23:54:57 +01:00
var res = make(map[string]ConnectionInfo)
2014-01-09 13:58:35 +01:00
for node, conn := range m.protoConn {
2014-01-05 23:54:57 +01:00
ci := ConnectionInfo{
2014-01-23 13:12:45 +01:00
Statistics: conn.Statistics(),
ClientVersion: m.nodeVer[node],
2014-01-05 23:54:57 +01:00
}
if nc, ok := m.rawConn[node].(remoteAddrer); ok {
ci.Address = nc.RemoteAddr().String()
}
res[node.String()] = ci
2013-12-30 15:30:29 +01:00
}
2014-01-18 04:06:44 +01:00
m.rmut.RUnlock()
2014-01-18 04:06:44 +01:00
m.pmut.RUnlock()
in, out := protocol.TotalInOut()
res["total"] = ConnectionInfo{
Statistics: protocol.Statistics{
At: time.Now(),
InBytesTotal: in,
OutBytesTotal: out,
},
}
2014-01-05 16:16:37 +01:00
return res
2013-12-30 15:30:29 +01:00
}
// Returns the completion status, in percent, for the given node and repo.
func (m *Model) Completion(node protocol.NodeID, repo string) float64 {
var tot int64
m.repoFiles[repo].WithGlobal(func(f protocol.FileInfo) bool {
if !protocol.IsDeleted(f.Flags) {
var size int64
if protocol.IsDirectory(f.Flags) {
size = zeroEntrySize
} else {
size = f.Size()
}
tot += size
}
return true
})
var need int64
m.repoFiles[repo].WithNeed(node, func(f protocol.FileInfo) bool {
if !protocol.IsDeleted(f.Flags) {
var size int64
if protocol.IsDirectory(f.Flags) {
size = zeroEntrySize
} else {
size = f.Size()
}
need += size
}
return true
})
return 100 * (1 - float64(need)/float64(tot))
}
2014-07-12 23:06:48 +02:00
func sizeOf(fs []protocol.FileInfo) (files, deleted int, bytes int64) {
for _, f := range fs {
2014-07-06 14:46:48 +02:00
fs, de, by := sizeOfFile(f)
files += fs
deleted += de
bytes += by
}
return
}
2014-07-12 23:06:48 +02:00
func sizeOfFile(f protocol.FileInfo) (files, deleted int, bytes int64) {
2014-07-06 14:46:48 +02:00
if !protocol.IsDeleted(f.Flags) {
files++
if !protocol.IsDirectory(f.Flags) {
2014-07-12 23:06:48 +02:00
bytes += f.Size()
2014-01-05 23:54:57 +01:00
} else {
bytes += zeroEntrySize
2014-01-05 23:54:57 +01:00
}
2014-07-06 14:46:48 +02:00
} else {
deleted++
bytes += zeroEntrySize
2013-12-30 15:30:29 +01:00
}
2014-01-05 16:16:37 +01:00
return
}
2013-12-30 15:30:29 +01:00
// GlobalSize returns the number of files, deleted files and total bytes for all
// files in the global model.
func (m *Model) GlobalSize(repo string) (files, deleted int, bytes int64) {
m.rmut.RLock()
defer m.rmut.RUnlock()
if rf, ok := m.repoFiles[repo]; ok {
2014-07-12 23:06:48 +02:00
rf.WithGlobal(func(f protocol.FileInfo) bool {
2014-07-06 14:46:48 +02:00
fs, de, by := sizeOfFile(f)
files += fs
deleted += de
bytes += by
return true
})
}
2014-07-06 14:46:48 +02:00
return
}
// LocalSize returns the number of files, deleted files and total bytes for all
// files in the local repository.
func (m *Model) LocalSize(repo string) (files, deleted int, bytes int64) {
m.rmut.RLock()
defer m.rmut.RUnlock()
if rf, ok := m.repoFiles[repo]; ok {
2014-07-12 23:06:48 +02:00
rf.WithHave(protocol.LocalNodeID, func(f protocol.FileInfo) bool {
2014-07-06 14:46:48 +02:00
fs, de, by := sizeOfFile(f)
files += fs
deleted += de
bytes += by
return true
})
}
2014-07-06 23:15:28 +02:00
return
2014-01-06 06:38:01 +01:00
}
// NeedSize returns the number and total size of currently needed files.
func (m *Model) NeedSize(repo string) (files int, bytes int64) {
2014-07-15 17:54:00 +02:00
m.rmut.RLock()
defer m.rmut.RUnlock()
if rf, ok := m.repoFiles[repo]; ok {
rf.WithNeed(protocol.LocalNodeID, func(f protocol.FileInfo) bool {
fs, de, by := sizeOfFile(f)
files += fs + de
bytes += by
return true
})
}
return
2013-12-23 18:12:44 +01:00
}
2014-07-06 14:46:48 +02:00
// NeedFiles returns the list of currently needed files
2014-07-12 23:06:48 +02:00
func (m *Model) NeedFilesRepo(repo string) []protocol.FileInfo {
m.rmut.RLock()
defer m.rmut.RUnlock()
if rf, ok := m.repoFiles[repo]; ok {
2014-07-15 17:54:00 +02:00
fs := make([]protocol.FileInfo, 0, indexBatchSize)
2014-07-12 23:06:48 +02:00
rf.WithNeed(protocol.LocalNodeID, func(f protocol.FileInfo) bool {
2014-07-06 14:46:48 +02:00
fs = append(fs, f)
2014-07-15 17:54:00 +02:00
return len(fs) < indexBatchSize
2014-07-06 14:46:48 +02:00
})
return fs
}
return nil
}
2013-12-30 15:30:29 +01:00
// Index is called when a new node is connected and we receive their full index.
// Implements the protocol.Model interface.
func (m *Model) Index(nodeID protocol.NodeID, repo string, fs []protocol.FileInfo) {
2014-05-15 05:26:55 +02:00
if debug {
l.Debugf("IDX(in): %s %q: %d files", nodeID, repo, len(fs))
}
if !m.repoSharedWith(repo, nodeID) {
l.Warnf("Unexpected repository ID %q sent from node %q; ensure that the repository exists and that this node is selected under \"Share With\" in the repository configuration.", repo, nodeID)
return
}
for i := range fs {
lamport.Default.Tick(fs[i].Version)
}
m.rmut.RLock()
2014-07-17 13:38:36 +02:00
r, ok := m.repoFiles[repo]
m.rmut.RUnlock()
if ok {
2014-07-12 23:06:48 +02:00
r.Replace(nodeID, fs)
} else {
l.Fatalf("Index for nonexistant repo %q", repo)
2013-12-15 11:43:31 +01:00
}
2014-07-13 21:07:24 +02:00
2014-07-17 13:38:36 +02:00
events.Default.Log(events.RemoteIndexUpdated, map[string]interface{}{
"node": nodeID.String(),
"repo": repo,
"items": len(fs),
"version": r.LocalVersion(nodeID),
2014-07-13 21:07:24 +02:00
})
2013-12-28 14:10:36 +01:00
}
2013-12-30 15:30:29 +01:00
// IndexUpdate is called for incremental updates to connected nodes' indexes.
// Implements the protocol.Model interface.
func (m *Model) IndexUpdate(nodeID protocol.NodeID, repo string, fs []protocol.FileInfo) {
2014-05-15 05:26:55 +02:00
if debug {
2014-05-15 02:08:56 +02:00
l.Debugf("IDXUP(in): %s / %q: %d files", nodeID, repo, len(fs))
}
if !m.repoSharedWith(repo, nodeID) {
l.Warnf("Unexpected repository ID %q sent from node %q; ensure that the repository exists and that this node is selected under \"Share With\" in the repository configuration.", repo, nodeID)
return
}
for i := range fs {
lamport.Default.Tick(fs[i].Version)
}
m.rmut.RLock()
2014-07-17 13:38:36 +02:00
r, ok := m.repoFiles[repo]
m.rmut.RUnlock()
if ok {
2014-07-12 23:06:48 +02:00
r.Update(nodeID, fs)
} else {
l.Fatalf("IndexUpdate for nonexistant repo %q", repo)
2013-12-28 14:10:36 +01:00
}
2014-07-13 21:07:24 +02:00
2014-07-17 13:38:36 +02:00
events.Default.Log(events.RemoteIndexUpdated, map[string]interface{}{
"node": nodeID.String(),
"repo": repo,
"items": len(fs),
"version": r.LocalVersion(nodeID),
2014-07-13 21:07:24 +02:00
})
}
func (m *Model) repoSharedWith(repo string, nodeID protocol.NodeID) bool {
m.rmut.RLock()
defer m.rmut.RUnlock()
for _, nrepo := range m.nodeRepos[nodeID] {
if nrepo == repo {
return true
}
}
return false
}
func (m *Model) ClusterConfig(nodeID protocol.NodeID, config protocol.ClusterConfigMessage) {
m.pmut.Lock()
if config.ClientName == "syncthing" {
m.nodeVer[nodeID] = config.ClientVersion
} else {
m.nodeVer[nodeID] = config.ClientName + " " + config.ClientVersion
}
m.pmut.Unlock()
2014-07-02 20:43:16 +02:00
l.Infof(`Node %s client is "%s %s"`, nodeID, config.ClientName, config.ClientVersion)
}
2014-01-20 22:22:27 +01:00
// Close removes the peer from the model and closes the underlying connection if possible.
// Implements the protocol.Model interface.
func (m *Model) Close(node protocol.NodeID, err error) {
2014-06-23 15:06:20 +02:00
l.Infof("Connection to %s closed: %v", node, err)
2014-07-13 21:07:24 +02:00
events.Default.Log(events.NodeDisconnected, map[string]string{
"id": node.String(),
"error": err.Error(),
})
m.pmut.Lock()
m.rmut.RLock()
for _, repo := range m.nodeRepos[node] {
2014-07-06 14:46:48 +02:00
m.repoFiles[repo].Replace(node, nil)
}
m.rmut.RUnlock()
2014-01-20 22:22:27 +01:00
conn, ok := m.rawConn[node]
if ok {
conn.Close()
}
2014-01-09 13:58:35 +01:00
delete(m.protoConn, node)
delete(m.rawConn, node)
delete(m.nodeVer, node)
2014-01-18 04:06:44 +01:00
m.pmut.Unlock()
2013-12-15 11:43:31 +01:00
}
// Request returns the specified data segment by reading it from local disk.
// Implements the protocol.Model interface.
func (m *Model) Request(nodeID protocol.NodeID, repo, name string, offset int64, size int) ([]byte, error) {
// Verify that the requested file exists in the local model.
m.rmut.RLock()
r, ok := m.repoFiles[repo]
m.rmut.RUnlock()
if !ok {
2014-05-15 02:08:56 +02:00
l.Warnf("Request from %s for file %s in nonexistent repo %q", nodeID, name, repo)
return nil, ErrNoSuchFile
}
2014-07-06 14:46:48 +02:00
lf := r.Get(protocol.LocalNodeID, name)
2014-07-12 23:06:48 +02:00
if protocol.IsInvalid(lf.Flags) || protocol.IsDeleted(lf.Flags) {
if debug {
l.Debugf("REQ(in): %s: %q / %q o=%d s=%d; invalid: %v", nodeID, repo, name, offset, size, lf)
}
return nil, ErrInvalid
}
2014-07-12 23:06:48 +02:00
if offset > lf.Size() {
2014-05-15 05:26:55 +02:00
if debug {
2014-05-15 02:08:56 +02:00
l.Debugf("REQ(in; nonexistent): %s: %q o=%d s=%d", nodeID, name, offset, size)
}
return nil, ErrNoSuchFile
}
2014-07-06 14:46:48 +02:00
if debug && nodeID != protocol.LocalNodeID {
2014-05-15 02:08:56 +02:00
l.Debugf("REQ(in): %s: %q / %q o=%d s=%d", nodeID, repo, name, offset, size)
2013-12-15 11:43:31 +01:00
}
m.rmut.RLock()
2014-05-23 14:31:16 +02:00
fn := filepath.Join(m.repoCfgs[repo].Directory, name)
m.rmut.RUnlock()
2013-12-15 11:43:31 +01:00
fd, err := os.Open(fn) // XXX: Inefficient, should cache fd?
if err != nil {
return nil, err
}
defer fd.Close()
2014-06-18 23:57:22 +02:00
buf := make([]byte, size)
_, err = fd.ReadAt(buf, offset)
2013-12-15 11:43:31 +01:00
if err != nil {
return nil, err
}
return buf, nil
}
// ReplaceLocal replaces the local repository index with the given list of files.
2014-07-12 23:06:48 +02:00
func (m *Model) ReplaceLocal(repo string, fs []protocol.FileInfo) {
m.rmut.RLock()
2014-07-06 14:46:48 +02:00
m.repoFiles[repo].ReplaceWithDelete(protocol.LocalNodeID, fs)
m.rmut.RUnlock()
2013-12-15 11:43:31 +01:00
}
2014-07-12 23:06:48 +02:00
func (m *Model) CurrentRepoFile(repo string, file string) protocol.FileInfo {
m.rmut.RLock()
2014-07-06 14:46:48 +02:00
f := m.repoFiles[repo].Get(protocol.LocalNodeID, file)
m.rmut.RUnlock()
return f
}
2014-07-12 23:06:48 +02:00
func (m *Model) CurrentGlobalFile(repo string, file string) protocol.FileInfo {
m.rmut.RLock()
f := m.repoFiles[repo].GetGlobal(file)
m.rmut.RUnlock()
return f
}
type cFiler struct {
m *Model
r string
}
2014-03-16 08:14:55 +01:00
// Implements scanner.CurrentFiler
2014-07-12 23:06:48 +02:00
func (cf cFiler) CurrentFile(file string) protocol.FileInfo {
return cf.m.CurrentRepoFile(cf.r, file)
2014-03-16 08:14:55 +01:00
}
// ConnectedTo returns true if we are connected to the named node.
func (m *Model) ConnectedTo(nodeID protocol.NodeID) bool {
2014-01-18 04:06:44 +01:00
m.pmut.RLock()
2014-01-09 13:58:35 +01:00
_, ok := m.protoConn[nodeID]
2014-01-18 04:06:44 +01:00
m.pmut.RUnlock()
return ok
}
// AddConnection adds a new peer connection to the model. An initial index will
// be sent to the connected peer, thereafter index updates whenever the local
// repository changes.
func (m *Model) AddConnection(rawConn io.Closer, protoConn protocol.Connection) {
2014-01-09 13:58:35 +01:00
nodeID := protoConn.ID()
2014-01-18 04:06:44 +01:00
m.pmut.Lock()
if _, ok := m.protoConn[nodeID]; ok {
panic("add existing node")
}
2014-01-09 13:58:35 +01:00
m.protoConn[nodeID] = protoConn
if _, ok := m.rawConn[nodeID]; ok {
panic("add existing node")
}
2014-01-09 13:58:35 +01:00
m.rawConn[nodeID] = rawConn
cm := m.clusterConfig(nodeID)
protoConn.ClusterConfig(cm)
2014-05-04 17:18:58 +02:00
m.rmut.RLock()
for _, repo := range m.nodeRepos[nodeID] {
fs := m.repoFiles[repo]
go sendIndexes(protoConn, repo, fs)
2014-05-04 17:18:58 +02:00
}
m.rmut.RUnlock()
m.pmut.Unlock()
}
func sendIndexes(conn protocol.Connection, repo string, fs *files.Set) {
nodeID := conn.ID()
name := conn.Name()
var err error
if debug {
l.Debugf("sendIndexes for %s-%s@/%q starting", nodeID, name, repo)
}
2014-05-04 17:18:58 +02:00
defer func() {
if debug {
l.Debugf("sendIndexes for %s-%s@/%q exiting: %v", nodeID, name, repo, err)
}
}()
minLocalVer, err := sendIndexTo(true, 0, conn, repo, fs)
for err == nil {
time.Sleep(5 * time.Second)
if fs.LocalVersion(protocol.LocalNodeID) <= minLocalVer {
continue
}
minLocalVer, err = sendIndexTo(false, minLocalVer, conn, repo, fs)
}
}
func sendIndexTo(initial bool, minLocalVer uint64, conn protocol.Connection, repo string, fs *files.Set) (uint64, error) {
nodeID := conn.ID()
name := conn.Name()
batch := make([]protocol.FileInfo, 0, indexBatchSize)
maxLocalVer := uint64(0)
var err error
fs.WithHave(protocol.LocalNodeID, func(f protocol.FileInfo) bool {
if f.LocalVersion <= minLocalVer {
return true
}
if f.LocalVersion > maxLocalVer {
maxLocalVer = f.LocalVersion
}
if len(batch) == indexBatchSize {
if initial {
if err = conn.Index(repo, batch); err != nil {
return false
}
if debug {
l.Debugf("sendIndexes for %s-%s/%q: %d files (initial index)", nodeID, name, repo, len(batch))
}
initial = false
} else {
if err = conn.IndexUpdate(repo, batch); err != nil {
return false
}
if debug {
l.Debugf("sendIndexes for %s-%s/%q: %d files (batched update)", nodeID, name, repo, len(batch))
}
2014-07-03 12:30:10 +02:00
}
batch = make([]protocol.FileInfo, 0, indexBatchSize)
}
batch = append(batch, f)
return true
})
if initial && err == nil {
err = conn.Index(repo, batch)
if debug && err == nil {
l.Debugf("sendIndexes for %s-%s/%q: %d files (small initial index)", nodeID, name, repo, len(batch))
}
} else if len(batch) > 0 && err == nil {
err = conn.IndexUpdate(repo, batch)
if debug && err == nil {
l.Debugf("sendIndexes for %s-%s/%q: %d files (last batch)", nodeID, name, repo, len(batch))
}
}
return maxLocalVer, err
}
2014-07-12 23:06:48 +02:00
func (m *Model) updateLocal(repo string, f protocol.FileInfo) {
f.LocalVersion = 0
m.rmut.RLock()
2014-07-12 23:06:48 +02:00
m.repoFiles[repo].Update(protocol.LocalNodeID, []protocol.FileInfo{f})
m.rmut.RUnlock()
2014-07-17 13:38:36 +02:00
events.Default.Log(events.LocalIndexUpdated, map[string]interface{}{
"repo": repo,
"name": f.Name,
"modified": time.Unix(f.Modified, 0),
"flags": fmt.Sprintf("0%o", f.Flags),
"size": f.Size(),
})
}
func (m *Model) requestGlobal(nodeID protocol.NodeID, repo, name string, offset int64, size int, hash []byte) ([]byte, error) {
2014-01-18 04:06:44 +01:00
m.pmut.RLock()
2014-01-09 13:58:35 +01:00
nc, ok := m.protoConn[nodeID]
2014-01-18 04:06:44 +01:00
m.pmut.RUnlock()
if !ok {
return nil, fmt.Errorf("requestGlobal: no such node: %s", nodeID)
}
2014-05-15 05:26:55 +02:00
if debug {
2014-05-15 02:08:56 +02:00
l.Debugf("REQ(out): %s: %q / %q o=%d s=%d h=%x", nodeID, repo, name, offset, size, hash)
}
return nc.Request(repo, name, offset, size)
}
2014-05-23 14:31:16 +02:00
func (m *Model) AddRepo(cfg config.RepositoryConfiguration) {
if m.started {
panic("cannot add repo to started model")
}
2014-05-23 14:31:16 +02:00
if len(cfg.ID) == 0 {
panic("cannot add empty repo id")
}
m.rmut.Lock()
2014-05-23 14:31:16 +02:00
m.repoCfgs[cfg.ID] = cfg
2014-07-06 14:46:48 +02:00
m.repoFiles[cfg.ID] = files.NewSet(cfg.ID, m.db)
2014-05-23 14:31:16 +02:00
m.suppressor[cfg.ID] = &suppressor{threshold: int64(m.cfg.Options.MaxChangeKbps)}
2013-12-15 11:43:31 +01:00
m.repoNodes[cfg.ID] = make([]protocol.NodeID, len(cfg.Nodes))
2014-05-23 14:31:16 +02:00
for i, node := range cfg.Nodes {
m.repoNodes[cfg.ID][i] = node.NodeID
m.nodeRepos[node.NodeID] = append(m.nodeRepos[node.NodeID], cfg.ID)
}
2014-01-23 22:20:15 +01:00
m.addedRepo = true
m.rmut.Unlock()
}
2014-01-23 22:20:15 +01:00
func (m *Model) ScanRepos() {
m.rmut.RLock()
2014-05-23 14:31:16 +02:00
var repos = make([]string, 0, len(m.repoCfgs))
for repo := range m.repoCfgs {
repos = append(repos, repo)
}
m.rmut.RUnlock()
var wg sync.WaitGroup
wg.Add(len(repos))
for _, repo := range repos {
repo := repo
go func() {
err := m.ScanRepo(repo)
if err != nil {
invalidateRepo(m.cfg, repo, err)
}
wg.Done()
}()
}
wg.Wait()
}
2013-12-15 11:43:31 +01:00
2014-05-15 05:26:55 +02:00
func (m *Model) CleanRepos() {
m.rmut.RLock()
2014-05-23 14:31:16 +02:00
var dirs = make([]string, 0, len(m.repoCfgs))
for _, cfg := range m.repoCfgs {
dirs = append(dirs, cfg.Directory)
2014-05-15 05:26:55 +02:00
}
m.rmut.RUnlock()
var wg sync.WaitGroup
wg.Add(len(dirs))
for _, dir := range dirs {
w := &scanner.Walker{
Dir: dir,
TempNamer: defTempNamer,
}
go func() {
w.CleanTempFiles()
wg.Done()
}()
}
wg.Wait()
}
func (m *Model) ScanRepo(repo string) error {
m.rmut.RLock()
fs := m.repoFiles[repo]
dir := m.repoCfgs[repo].Directory
w := &scanner.Walker{
Dir: dir,
IgnoreFile: ".stignore",
2014-05-15 05:26:55 +02:00
BlockSize: scanner.StandardBlockSize,
TempNamer: defTempNamer,
2014-05-15 05:26:55 +02:00
Suppressor: m.suppressor[repo],
CurrentFiler: cFiler{m, repo},
2014-05-23 14:31:16 +02:00
IgnorePerms: m.repoCfgs[repo].IgnorePerms,
}
m.rmut.RUnlock()
m.setState(repo, RepoScanning)
fchan, _, err := w.Walk()
if err != nil {
return err
}
2014-07-15 17:54:00 +02:00
batchSize := 100
batch := make([]protocol.FileInfo, 0, 00)
for f := range fchan {
2014-07-29 11:53:45 +02:00
events.Default.Log(events.LocalIndexUpdated, map[string]interface{}{
"repo": repo,
"name": f.Name,
"modified": time.Unix(f.Modified, 0),
"flags": fmt.Sprintf("0%o", f.Flags),
"size": f.Size(),
})
2014-07-15 17:54:00 +02:00
if len(batch) == batchSize {
fs.Update(protocol.LocalNodeID, batch)
batch = batch[:0]
}
batch = append(batch, f)
}
if len(batch) > 0 {
fs.Update(protocol.LocalNodeID, batch)
}
batch = batch[:0]
fs.WithHave(protocol.LocalNodeID, func(f protocol.FileInfo) bool {
if !protocol.IsDeleted(f.Flags) {
2014-07-15 17:54:00 +02:00
if len(batch) == batchSize {
fs.Update(protocol.LocalNodeID, batch)
batch = batch[:0]
}
if _, err := os.Stat(filepath.Join(dir, f.Name)); err != nil && os.IsNotExist(err) {
// File has been deleted
f.Blocks = nil
f.Flags |= protocol.FlagDeleted
f.Version = lamport.Default.Tick(f.Version)
f.LocalVersion = 0
2014-07-29 11:53:45 +02:00
events.Default.Log(events.LocalIndexUpdated, map[string]interface{}{
"repo": repo,
"name": f.Name,
"modified": time.Unix(f.Modified, 0),
"flags": fmt.Sprintf("0%o", f.Flags),
"size": f.Size(),
})
batch = append(batch, f)
}
}
return true
})
if len(batch) > 0 {
fs.Update(protocol.LocalNodeID, batch)
}
m.setState(repo, RepoIdle)
return nil
}
// clusterConfig returns a ClusterConfigMessage that is correct for the given peer node
func (m *Model) clusterConfig(node protocol.NodeID) protocol.ClusterConfigMessage {
cm := protocol.ClusterConfigMessage{
2014-05-15 05:26:55 +02:00
ClientName: m.clientName,
ClientVersion: m.clientVersion,
}
m.rmut.RLock()
for _, repo := range m.nodeRepos[node] {
cr := protocol.Repository{
ID: repo,
2014-01-09 13:58:35 +01:00
}
for _, node := range m.repoNodes[repo] {
// TODO: Set read only bit when relevant
cr.Nodes = append(cr.Nodes, protocol.Node{
ID: node[:],
Flags: protocol.FlagShareTrusted,
})
2014-01-09 13:58:35 +01:00
}
cm.Repositories = append(cm.Repositories, cr)
2013-12-30 02:33:57 +01:00
}
m.rmut.RUnlock()
return cm
2013-12-30 02:33:57 +01:00
}
func (m *Model) setState(repo string, state repoState) {
m.smut.Lock()
2014-07-17 13:38:36 +02:00
oldState := m.repoState[repo]
changed, ok := m.repoStateChanged[repo]
if state != oldState {
m.repoState[repo] = state
m.repoStateChanged[repo] = time.Now()
eventData := map[string]interface{}{
"repo": repo,
"to": state.String(),
}
if ok {
eventData["duration"] = time.Since(changed).Seconds()
eventData["from"] = oldState.String()
}
events.Default.Log(events.StateChanged, eventData)
}
m.smut.Unlock()
}
2014-07-17 13:38:36 +02:00
func (m *Model) State(repo string) (string, time.Time) {
m.smut.RLock()
state := m.repoState[repo]
2014-07-17 13:38:36 +02:00
changed := m.repoStateChanged[repo]
m.smut.RUnlock()
2014-07-17 13:38:36 +02:00
return state.String(), changed
}
func (m *Model) Override(repo string) {
m.rmut.RLock()
2014-07-15 17:54:00 +02:00
fs := m.repoFiles[repo]
m.rmut.RUnlock()
2014-07-15 17:54:00 +02:00
batch := make([]protocol.FileInfo, 0, indexBatchSize)
fs.WithNeed(protocol.LocalNodeID, func(need protocol.FileInfo) bool {
if len(batch) == indexBatchSize {
fs.Update(protocol.LocalNodeID, batch)
batch = batch[:0]
}
have := fs.Get(protocol.LocalNodeID, need.Name)
if have.Name != need.Name {
// We are missing the file
2014-07-15 17:54:00 +02:00
need.Flags |= protocol.FlagDeleted
need.Blocks = nil
} else {
// We have the file, replace with our version
2014-07-15 17:54:00 +02:00
need = have
}
2014-07-15 17:54:00 +02:00
need.Version = lamport.Default.Tick(need.Version)
need.LocalVersion = 0
batch = append(batch, need)
return true
})
if len(batch) > 0 {
fs.Update(protocol.LocalNodeID, batch)
}
}
// Version returns the change version for the given repository. This is
// guaranteed to increment if the contents of the local or global repository
// has changed.
func (m *Model) LocalVersion(repo string) uint64 {
m.rmut.Lock()
2014-07-15 17:54:00 +02:00
defer m.rmut.Unlock()
fs, ok := m.repoFiles[repo]
if !ok {
return 0
}
ver := fs.LocalVersion(protocol.LocalNodeID)
for _, n := range m.repoNodes[repo] {
2014-07-15 17:54:00 +02:00
ver += fs.LocalVersion(n)
}
return ver
}