lib/watchaggregator: Speedup propagation of removals (fixes #4953) (#4955)

This commit is contained in:
Simon Frei 2018-05-26 11:08:23 +02:00 committed by Audrius Butkevicius
parent eb31be0432
commit a83176c77a
3 changed files with 170 additions and 105 deletions

View File

@ -107,6 +107,11 @@ const (
Mixed // Should probably not be necessary to be used in filesystem interface implementation Mixed // Should probably not be necessary to be used in filesystem interface implementation
) )
// Merge returns Mixed, except if evType and other are the same and not Mixed.
func (evType EventType) Merge(other EventType) EventType {
return evType | other
}
func (evType EventType) String() string { func (evType EventType) String() string {
switch { switch {
case evType == NonRemove: case evType == NonRemove:

View File

@ -26,6 +26,8 @@ var (
// aggregatedEvent represents potentially multiple events at and/or recursively // aggregatedEvent represents potentially multiple events at and/or recursively
// below one path until it times out and a scan is scheduled. // below one path until it times out and a scan is scheduled.
// If it represents multiple events and there are events of both Remove and
// NonRemove types, the evType attribute is Mixed (as returned by fs.Event.Merge).
type aggregatedEvent struct { type aggregatedEvent struct {
firstModTime time.Time firstModTime time.Time
lastModTime time.Time lastModTime time.Time
@ -46,14 +48,6 @@ func newEventDir() *eventDir {
} }
} }
func (dir *eventDir) eventCount() int {
count := len(dir.events)
for _, dir := range dir.dirs {
count += dir.eventCount()
}
return count
}
func (dir *eventDir) childCount() int { func (dir *eventDir) childCount() int {
return len(dir.events) + len(dir.dirs) return len(dir.events) + len(dir.dirs)
} }
@ -110,6 +104,8 @@ type aggregator struct {
notifyTimer *time.Timer notifyTimer *time.Timer
notifyTimerNeedsReset bool notifyTimerNeedsReset bool
notifyTimerResetChan chan time.Duration notifyTimerResetChan chan time.Duration
counts map[fs.EventType]int
root *eventDir
ctx context.Context ctx context.Context
} }
@ -119,6 +115,8 @@ func newAggregator(folderCfg config.FolderConfiguration, ctx context.Context) *a
folderCfgUpdate: make(chan config.FolderConfiguration), folderCfgUpdate: make(chan config.FolderConfiguration),
notifyTimerNeedsReset: false, notifyTimerNeedsReset: false,
notifyTimerResetChan: make(chan time.Duration), notifyTimerResetChan: make(chan time.Duration),
counts: make(map[fs.EventType]int),
root: newEventDir(),
ctx: ctx, ctx: ctx,
} }
@ -143,16 +141,14 @@ func (a *aggregator) mainLoop(in <-chan fs.Event, out chan<- []string, cfg *conf
cfg.Subscribe(a) cfg.Subscribe(a)
rootEventDir := newEventDir()
for { for {
select { select {
case event := <-in: case event := <-in:
a.newEvent(event, rootEventDir, inProgress) a.newEvent(event, inProgress)
case event := <-inProgressItemSubscription.C(): case event := <-inProgressItemSubscription.C():
updateInProgressSet(event, inProgress) updateInProgressSet(event, inProgress)
case <-a.notifyTimer.C: case <-a.notifyTimer.C:
a.actOnTimer(rootEventDir, out) a.actOnTimer(out)
case interval := <-a.notifyTimerResetChan: case interval := <-a.notifyTimerResetChan:
a.resetNotifyTimer(interval) a.resetNotifyTimer(interval)
case folderCfg := <-a.folderCfgUpdate: case folderCfg := <-a.folderCfgUpdate:
@ -165,8 +161,8 @@ func (a *aggregator) mainLoop(in <-chan fs.Event, out chan<- []string, cfg *conf
} }
} }
func (a *aggregator) newEvent(event fs.Event, rootEventDir *eventDir, inProgress map[string]struct{}) { func (a *aggregator) newEvent(event fs.Event, inProgress map[string]struct{}) {
if _, ok := rootEventDir.events["."]; ok { if _, ok := a.root.events["."]; ok {
l.Debugln(a, "Will scan entire folder anyway; dropping:", event.Name) l.Debugln(a, "Will scan entire folder anyway; dropping:", event.Name)
return return
} }
@ -174,29 +170,31 @@ func (a *aggregator) newEvent(event fs.Event, rootEventDir *eventDir, inProgress
l.Debugln(a, "Skipping path we modified:", event.Name) l.Debugln(a, "Skipping path we modified:", event.Name)
return return
} }
a.aggregateEvent(event, time.Now(), rootEventDir) a.aggregateEvent(event, time.Now())
} }
func (a *aggregator) aggregateEvent(event fs.Event, evTime time.Time, rootEventDir *eventDir) { func (a *aggregator) aggregateEvent(event fs.Event, evTime time.Time) {
if event.Name == "." || rootEventDir.eventCount() == maxFiles { if event.Name == "." || a.eventCount() == maxFiles {
l.Debugln(a, "Scan entire folder") l.Debugln(a, "Scan entire folder")
firstModTime := evTime firstModTime := evTime
if rootEventDir.childCount() != 0 { if a.root.childCount() != 0 {
event.Type |= rootEventDir.eventType() event.Type = event.Type.Merge(a.root.eventType())
firstModTime = rootEventDir.firstModTime() firstModTime = a.root.firstModTime()
} }
rootEventDir.dirs = make(map[string]*eventDir) a.root.dirs = make(map[string]*eventDir)
rootEventDir.events = make(map[string]*aggregatedEvent) a.root.events = make(map[string]*aggregatedEvent)
rootEventDir.events["."] = &aggregatedEvent{ a.root.events["."] = &aggregatedEvent{
firstModTime: firstModTime, firstModTime: firstModTime,
lastModTime: evTime, lastModTime: evTime,
evType: event.Type, evType: event.Type,
} }
a.counts = make(map[fs.EventType]int)
a.counts[event.Type]++
a.resetNotifyTimerIfNeeded() a.resetNotifyTimerIfNeeded()
return return
} }
parentDir := rootEventDir parentDir := a.root
// Check if any parent directory is already tracked or will exceed // Check if any parent directory is already tracked or will exceed
// events per directory limit bottom up // events per directory limit bottom up
@ -211,7 +209,11 @@ func (a *aggregator) aggregateEvent(event fs.Event, evTime time.Time, rootEventD
if ev, ok := parentDir.events[name]; ok { if ev, ok := parentDir.events[name]; ok {
ev.lastModTime = evTime ev.lastModTime = evTime
ev.evType |= event.Type if merged := event.Type.Merge(ev.evType); ev.evType != merged {
a.counts[ev.evType]--
ev.evType = merged
a.counts[ev.evType]++
}
l.Debugf("%v Parent %s (type %s) already tracked: %s", a, currPath, ev.evType, event.Name) l.Debugf("%v Parent %s (type %s) already tracked: %s", a, currPath, ev.evType, event.Name)
return return
} }
@ -219,7 +221,7 @@ func (a *aggregator) aggregateEvent(event fs.Event, evTime time.Time, rootEventD
if parentDir.childCount() == localMaxFilesPerDir { if parentDir.childCount() == localMaxFilesPerDir {
l.Debugf("%v Parent dir %s already has %d children, tracking it instead: %s", a, currPath, localMaxFilesPerDir, event.Name) l.Debugf("%v Parent dir %s already has %d children, tracking it instead: %s", a, currPath, localMaxFilesPerDir, event.Name)
event.Name = filepath.Dir(currPath) event.Name = filepath.Dir(currPath)
a.aggregateEvent(event, evTime, rootEventDir) a.aggregateEvent(event, evTime)
return return
} }
@ -244,7 +246,11 @@ func (a *aggregator) aggregateEvent(event fs.Event, evTime time.Time, rootEventD
if ev, ok := parentDir.events[name]; ok { if ev, ok := parentDir.events[name]; ok {
ev.lastModTime = evTime ev.lastModTime = evTime
ev.evType |= event.Type if merged := event.Type.Merge(ev.evType); ev.evType != merged {
a.counts[ev.evType]--
ev.evType = merged
a.counts[ev.evType]++
}
l.Debugf("%v Already tracked (type %v): %s", a, ev.evType, event.Name) l.Debugf("%v Already tracked (type %v): %s", a, ev.evType, event.Name)
return return
} }
@ -256,14 +262,17 @@ func (a *aggregator) aggregateEvent(event fs.Event, evTime time.Time, rootEventD
if !ok && parentDir.childCount() == localMaxFilesPerDir { if !ok && parentDir.childCount() == localMaxFilesPerDir {
l.Debugf("%v Parent dir already has %d children, tracking it instead: %s", a, localMaxFilesPerDir, event.Name) l.Debugf("%v Parent dir already has %d children, tracking it instead: %s", a, localMaxFilesPerDir, event.Name)
event.Name = filepath.Dir(event.Name) event.Name = filepath.Dir(event.Name)
a.aggregateEvent(event, evTime, rootEventDir) a.aggregateEvent(event, evTime)
return return
} }
firstModTime := evTime firstModTime := evTime
if ok { if ok {
firstModTime = childDir.firstModTime() firstModTime = childDir.firstModTime()
event.Type |= childDir.eventType() if merged := event.Type.Merge(childDir.eventType()); event.Type != merged {
a.counts[event.Type]--
event.Type = merged
}
delete(parentDir.dirs, name) delete(parentDir.dirs, name)
} }
l.Debugf("%v Tracking (type %v): %s", a, event.Type, event.Name) l.Debugf("%v Tracking (type %v): %s", a, event.Type, event.Name)
@ -272,6 +281,7 @@ func (a *aggregator) aggregateEvent(event fs.Event, evTime time.Time, rootEventD
lastModTime: evTime, lastModTime: evTime,
evType: event.Type, evType: event.Type,
} }
a.counts[event.Type]++
a.resetNotifyTimerIfNeeded() a.resetNotifyTimerIfNeeded()
} }
@ -289,22 +299,27 @@ func (a *aggregator) resetNotifyTimer(duration time.Duration) {
a.notifyTimer.Reset(duration) a.notifyTimer.Reset(duration)
} }
func (a *aggregator) actOnTimer(rootEventDir *eventDir, out chan<- []string) { func (a *aggregator) actOnTimer(out chan<- []string) {
eventCount := rootEventDir.eventCount() c := a.eventCount()
if eventCount == 0 { if c == 0 {
l.Debugln(a, "No tracked events, waiting for new event.") l.Debugln(a, "No tracked events, waiting for new event.")
a.notifyTimerNeedsReset = true a.notifyTimerNeedsReset = true
return return
} }
oldevents := a.popOldEvents(rootEventDir, ".", time.Now()) oldEvents := make(map[string]*aggregatedEvent, c)
if len(oldevents) == 0 { a.popOldEventsTo(oldEvents, a.root, ".", time.Now(), true)
if a.notifyDelay != a.notifyTimeout && a.counts[fs.NonRemove]+a.counts[fs.Mixed] == 0 && a.counts[fs.Remove] != 0 {
// Only deletion events remaining, no need to delay them additionally
a.popOldEventsTo(oldEvents, a.root, ".", time.Now(), false)
}
if len(oldEvents) == 0 {
l.Debugln(a, "No old fs events") l.Debugln(a, "No old fs events")
a.resetNotifyTimer(a.notifyDelay) a.resetNotifyTimer(a.notifyDelay)
return return
} }
// Sending to channel might block for a long time, but we need to keep // Sending to channel might block for a long time, but we need to keep
// reading from notify backend channel to avoid overflow // reading from notify backend channel to avoid overflow
go a.notify(oldevents, out) go a.notify(oldEvents, out)
} }
// Schedule scan for given events dispatching deletes last and reset notification // Schedule scan for given events dispatching deletes last and reset notification
@ -348,42 +363,50 @@ func (a *aggregator) notify(oldEvents map[string]*aggregatedEvent, out chan<- []
// popOldEvents finds events that should be scheduled for scanning recursively in dirs, // popOldEvents finds events that should be scheduled for scanning recursively in dirs,
// removes those events and empty eventDirs and returns a map with all the removed // removes those events and empty eventDirs and returns a map with all the removed
// events referenced by their filesystem path // events referenced by their filesystem path
func (a *aggregator) popOldEvents(dir *eventDir, dirPath string, currTime time.Time) map[string]*aggregatedEvent { func (a *aggregator) popOldEventsTo(to map[string]*aggregatedEvent, dir *eventDir, dirPath string, currTime time.Time, delayRem bool) {
oldEvents := make(map[string]*aggregatedEvent)
for childName, childDir := range dir.dirs { for childName, childDir := range dir.dirs {
for evPath, event := range a.popOldEvents(childDir, filepath.Join(dirPath, childName), currTime) { a.popOldEventsTo(to, childDir, filepath.Join(dirPath, childName), currTime, delayRem)
oldEvents[evPath] = event
}
if childDir.childCount() == 0 { if childDir.childCount() == 0 {
delete(dir.dirs, childName) delete(dir.dirs, childName)
} }
} }
for name, event := range dir.events { for name, event := range dir.events {
if a.isOld(event, currTime) { if a.isOld(event, currTime, delayRem) {
oldEvents[filepath.Join(dirPath, name)] = event to[filepath.Join(dirPath, name)] = event
delete(dir.events, name) delete(dir.events, name)
a.counts[event.evType]--
} }
} }
return oldEvents
} }
func (a *aggregator) isOld(ev *aggregatedEvent, currTime time.Time) bool { func (a *aggregator) isOld(ev *aggregatedEvent, currTime time.Time, delayRem bool) bool {
// Deletes should always be scanned last, therefore they are always // Deletes should in general be scanned last, therefore they are delayed by
// delayed by letting them time out (see below). // letting them time out. This behaviour is overriden by delayRem == false.
// Refer to following comments as to why.
// An event that has not registered any new modifications recently is scanned. // An event that has not registered any new modifications recently is scanned.
// a.notifyDelay is the user facing value signifying the normal delay between // a.notifyDelay is the user facing value signifying the normal delay between
// a picking up a modification and scanning it. As scheduling scans happens at // picking up a modification and scanning it. As scheduling scans happens at
// regular intervals of a.notifyDelay the delay of a single event is not exactly // regular intervals of a.notifyDelay the delay of a single event is not exactly
// a.notifyDelay, but lies in in the range of 0.5 to 1.5 times a.notifyDelay. // a.notifyDelay, but lies in the range of 0.5 to 1.5 times a.notifyDelay.
if ev.evType == fs.NonRemove && 2*currTime.Sub(ev.lastModTime) > a.notifyDelay { if (!delayRem || ev.evType == fs.NonRemove) && 2*currTime.Sub(ev.lastModTime) > a.notifyDelay {
return true return true
} }
// When an event registers repeat modifications or involves removals it // When an event registers repeat modifications or involves removals it
// is delayed to reduce resource usage, but after a certain time (notifyTimeout) // is delayed to reduce resource usage, but after a certain time (notifyTimeout)
// passed it is scanned anyway. // passed it is scanned anyway.
// If only removals are remaining to be scanned, there is no point to delay
// removals further, so this behaviour is overriden by delayRem == false.
return currTime.Sub(ev.firstModTime) > a.notifyTimeout return currTime.Sub(ev.firstModTime) > a.notifyTimeout
} }
func (a *aggregator) eventCount() int {
c := 0
for _, v := range a.counts {
c += v
}
return c
}
func (a *aggregator) String() string { func (a *aggregator) String() string {
return fmt.Sprintf("aggregator/%s:", a.folderCfg.Description()) return fmt.Sprintf("aggregator/%s:", a.folderCfg.Description())
} }

View File

@ -23,17 +23,19 @@ import (
func TestMain(m *testing.M) { func TestMain(m *testing.M) {
maxFiles = 32 maxFiles = 32
maxFilesPerDir = 8 maxFilesPerDir = 8
defer func() {
ret := m.Run()
maxFiles = 512 maxFiles = 512
maxFilesPerDir = 128 maxFilesPerDir = 128
}()
os.Exit(m.Run()) os.Exit(ret)
} }
const ( const (
testNotifyDelayS = 1 testNotifyDelayS = 1
testNotifyTimeout = 2 * time.Second testNotifyTimeout = 2 * time.Second
timeoutWithinBatch = time.Second
) )
var ( var (
@ -48,8 +50,10 @@ var (
}) })
) )
// Represents possibly multiple (different event types) expected paths from
// aggregation, that should be received back to back.
type expectedBatch struct { type expectedBatch struct {
paths []string paths [][]string
afterMs int afterMs int
beforeMs int beforeMs int
} }
@ -57,7 +61,6 @@ type expectedBatch struct {
// TestAggregate checks whether maxFilesPerDir+1 events in one dir are // TestAggregate checks whether maxFilesPerDir+1 events in one dir are
// aggregated to parent dir // aggregated to parent dir
func TestAggregate(t *testing.T) { func TestAggregate(t *testing.T) {
evDir := newEventDir()
inProgress := make(map[string]struct{}) inProgress := make(map[string]struct{})
folderCfg := defaultFolderCfg.Copy() folderCfg := defaultFolderCfg.Copy()
@ -67,45 +70,44 @@ func TestAggregate(t *testing.T) {
// checks whether maxFilesPerDir events in one dir are kept as is // checks whether maxFilesPerDir events in one dir are kept as is
for i := 0; i < maxFilesPerDir; i++ { for i := 0; i < maxFilesPerDir; i++ {
a.newEvent(fs.Event{filepath.Join("parent", strconv.Itoa(i)), fs.NonRemove}, evDir, inProgress) a.newEvent(fs.Event{filepath.Join("parent", strconv.Itoa(i)), fs.NonRemove}, inProgress)
} }
if len(getEventPaths(evDir, ".", a)) != maxFilesPerDir { if l := len(getEventPaths(a.root, ".", a)); l != maxFilesPerDir {
t.Errorf("Unexpected number of events stored") t.Errorf("Unexpected number of events stored, got %v, expected %v", l, maxFilesPerDir)
} }
// checks whether maxFilesPerDir+1 events in one dir are aggregated to parent dir // checks whether maxFilesPerDir+1 events in one dir are aggregated to parent dir
a.newEvent(fs.Event{filepath.Join("parent", "new"), fs.NonRemove}, evDir, inProgress) a.newEvent(fs.Event{filepath.Join("parent", "new"), fs.NonRemove}, inProgress)
compareBatchToExpected(t, getEventPaths(evDir, ".", a), []string{"parent"}) compareBatchToExpectedDirect(t, getEventPaths(a.root, ".", a), []string{"parent"})
// checks that adding an event below "parent" does not change anything // checks that adding an event below "parent" does not change anything
a.newEvent(fs.Event{filepath.Join("parent", "extra"), fs.NonRemove}, evDir, inProgress) a.newEvent(fs.Event{filepath.Join("parent", "extra"), fs.NonRemove}, inProgress)
compareBatchToExpected(t, getEventPaths(evDir, ".", a), []string{"parent"}) compareBatchToExpectedDirect(t, getEventPaths(a.root, ".", a), []string{"parent"})
// again test aggregation in "parent" but with event in subdirs // again test aggregation in "parent" but with event in subdirs
evDir = newEventDir() a = newAggregator(folderCfg, ctx)
for i := 0; i < maxFilesPerDir; i++ { for i := 0; i < maxFilesPerDir; i++ {
a.newEvent(fs.Event{filepath.Join("parent", strconv.Itoa(i)), fs.NonRemove}, evDir, inProgress) a.newEvent(fs.Event{filepath.Join("parent", strconv.Itoa(i)), fs.NonRemove}, inProgress)
} }
a.newEvent(fs.Event{filepath.Join("parent", "sub", "new"), fs.NonRemove}, evDir, inProgress) a.newEvent(fs.Event{filepath.Join("parent", "sub", "new"), fs.NonRemove}, inProgress)
compareBatchToExpected(t, getEventPaths(evDir, ".", a), []string{"parent"}) compareBatchToExpectedDirect(t, getEventPaths(a.root, ".", a), []string{"parent"})
// test aggregation in root // test aggregation in root
evDir = newEventDir() a = newAggregator(folderCfg, ctx)
for i := 0; i < maxFiles; i++ { for i := 0; i < maxFiles; i++ {
a.newEvent(fs.Event{strconv.Itoa(i), fs.NonRemove}, evDir, inProgress) a.newEvent(fs.Event{strconv.Itoa(i), fs.NonRemove}, inProgress)
} }
if len(getEventPaths(evDir, ".", a)) != maxFiles { if len(getEventPaths(a.root, ".", a)) != maxFiles {
t.Errorf("Unexpected number of events stored in root") t.Errorf("Unexpected number of events stored in root")
} }
a.newEvent(fs.Event{filepath.Join("parent", "sub", "new"), fs.NonRemove}, evDir, inProgress) a.newEvent(fs.Event{filepath.Join("parent", "sub", "new"), fs.NonRemove}, inProgress)
compareBatchToExpected(t, getEventPaths(evDir, ".", a), []string{"."}) compareBatchToExpectedDirect(t, getEventPaths(a.root, ".", a), []string{"."})
// checks that adding an event when "." is already stored is a noop // checks that adding an event when "." is already stored is a noop
a.newEvent(fs.Event{"anythingelse", fs.NonRemove}, evDir, inProgress) a.newEvent(fs.Event{"anythingelse", fs.NonRemove}, inProgress)
compareBatchToExpected(t, getEventPaths(evDir, ".", a), []string{"."}) compareBatchToExpectedDirect(t, getEventPaths(a.root, ".", a), []string{"."})
// TestOverflow checks that the entire folder is scanned when maxFiles is reached a = newAggregator(folderCfg, ctx)
evDir = newEventDir()
filesPerDir := maxFilesPerDir / 2 filesPerDir := maxFilesPerDir / 2
dirs := make([]string, maxFiles/filesPerDir+1) dirs := make([]string, maxFiles/filesPerDir+1)
for i := 0; i < maxFiles/filesPerDir+1; i++ { for i := 0; i < maxFiles/filesPerDir+1; i++ {
@ -113,10 +115,10 @@ func TestAggregate(t *testing.T) {
} }
for _, dir := range dirs { for _, dir := range dirs {
for i := 0; i < filesPerDir; i++ { for i := 0; i < filesPerDir; i++ {
a.newEvent(fs.Event{filepath.Join(dir, strconv.Itoa(i)), fs.NonRemove}, evDir, inProgress) a.newEvent(fs.Event{filepath.Join(dir, strconv.Itoa(i)), fs.NonRemove}, inProgress)
} }
} }
compareBatchToExpected(t, getEventPaths(evDir, ".", a), []string{"."}) compareBatchToExpectedDirect(t, getEventPaths(a.root, ".", a), []string{"."})
} }
// TestInProgress checks that ignoring files currently edited by Syncthing works // TestInProgress checks that ignoring files currently edited by Syncthing works
@ -137,7 +139,7 @@ func TestInProgress(t *testing.T) {
} }
expectedBatches := []expectedBatch{ expectedBatches := []expectedBatch{
{[]string{"notinprogress"}, 2000, 3500}, {[][]string{{"notinprogress"}}, 2000, 3500},
} }
testScenario(t, "InProgress", testCase, expectedBatches) testScenario(t, "InProgress", testCase, expectedBatches)
@ -149,6 +151,7 @@ func TestDelay(t *testing.T) {
file := filepath.Join("parent", "file") file := filepath.Join("parent", "file")
delayed := "delayed" delayed := "delayed"
del := "deleted" del := "deleted"
delAfter := "deletedAfter"
both := filepath.Join("parent", "sub", "both") both := filepath.Join("parent", "sub", "both")
testCase := func(c chan<- fs.Event) { testCase := func(c chan<- fs.Event) {
sleepMs(200) sleepMs(200)
@ -166,16 +169,15 @@ func TestDelay(t *testing.T) {
timer.Reset(delay) timer.Reset(delay)
c <- fs.Event{Name: delayed, Type: fs.NonRemove} c <- fs.Event{Name: delayed, Type: fs.NonRemove}
} }
c <- fs.Event{Name: delAfter, Type: fs.Remove}
<-timer.C <-timer.C
} }
// batches that we expect to receive with time interval in milliseconds // batches that we expect to receive with time interval in milliseconds
expectedBatches := []expectedBatch{ expectedBatches := []expectedBatch{
{[]string{file}, 500, 2500}, {[][]string{{file}}, 500, 2500},
{[]string{delayed}, 2500, 4500}, {[][]string{{delayed}, {both}, {del}}, 2500, 4500},
{[]string{both}, 2500, 4500}, {[][]string{{delayed}, {delAfter}}, 3600, 7000},
{[]string{del}, 2500, 4500},
{[]string{delayed}, 3600, 7000},
} }
testScenario(t, "Delay", testCase, expectedBatches) testScenario(t, "Delay", testCase, expectedBatches)
@ -202,7 +204,7 @@ func durationMs(ms int) time.Duration {
return time.Duration(ms) * time.Millisecond return time.Duration(ms) * time.Millisecond
} }
func compareBatchToExpected(t *testing.T, batch []string, expectedPaths []string) { func compareBatchToExpected(batch []string, expectedPaths []string) (missing []string, unexpected []string) {
for _, expected := range expectedPaths { for _, expected := range expectedPaths {
expected = filepath.Clean(expected) expected = filepath.Clean(expected)
found := false found := false
@ -214,15 +216,28 @@ func compareBatchToExpected(t *testing.T, batch []string, expectedPaths []string
} }
} }
if !found { if !found {
t.Errorf("Did not receive event %s", expected) missing = append(missing, expected)
} }
} }
for _, received := range batch { for _, received := range batch {
t.Errorf("Received unexpected event %s", received) unexpected = append(unexpected, received)
}
return missing, unexpected
}
func compareBatchToExpectedDirect(t *testing.T, batch []string, expectedPaths []string) {
t.Helper()
missing, unexpected := compareBatchToExpected(batch, expectedPaths)
for _, p := range missing {
t.Errorf("Did not receive event %s", p)
}
for _, p := range unexpected {
t.Errorf("Received unexpected event %s", p)
} }
} }
func testScenario(t *testing.T, name string, testCase func(c chan<- fs.Event), expectedBatches []expectedBatch) { func testScenario(t *testing.T, name string, testCase func(c chan<- fs.Event), expectedBatches []expectedBatch) {
t.Helper()
ctx, cancel := context.WithCancel(context.Background()) ctx, cancel := context.WithCancel(context.Background())
eventChan := make(chan fs.Event) eventChan := make(chan fs.Event)
watchChan := make(chan []string) watchChan := make(chan []string)
@ -245,9 +260,10 @@ func testScenario(t *testing.T, name string, testCase func(c chan<- fs.Event), e
} }
func testAggregatorOutput(t *testing.T, fsWatchChan <-chan []string, expectedBatches []expectedBatch, startTime time.Time) { func testAggregatorOutput(t *testing.T, fsWatchChan <-chan []string, expectedBatches []expectedBatch, startTime time.Time) {
t.Helper()
var received []string var received []string
var elapsedTime time.Duration var elapsedTime time.Duration
batchIndex := 0 var batchIndex, innerIndex int
timeout := time.NewTimer(10 * time.Second) timeout := time.NewTimer(10 * time.Second)
for { for {
select { select {
@ -257,28 +273,49 @@ func testAggregatorOutput(t *testing.T, fsWatchChan <-chan []string, expectedBat
case received = <-fsWatchChan: case received = <-fsWatchChan:
} }
elapsedTime = time.Since(startTime) if batchIndex >= len(expectedBatches) {
expected := expectedBatches[batchIndex] t.Errorf("Received batch %d, expected only %d", batchIndex+1, len(expectedBatches))
continue
}
if runtime.GOOS != "darwin" { if runtime.GOOS != "darwin" {
now := time.Since(startTime)
if innerIndex == 0 {
switch { switch {
case elapsedTime < durationMs(expected.afterMs): case now < durationMs(expectedBatches[batchIndex].afterMs):
t.Errorf("Received batch %d after %v (too soon)", batchIndex+1, elapsedTime) t.Errorf("Received batch %d after %v (too soon)", batchIndex+1, elapsedTime)
case elapsedTime > durationMs(expected.beforeMs): case now > durationMs(expectedBatches[batchIndex].beforeMs):
t.Errorf("Received batch %d after %v (too late)", batchIndex+1, elapsedTime) t.Errorf("Received batch %d after %v (too late)", batchIndex+1, elapsedTime)
} }
} else if innerTime := now - elapsedTime; innerTime > timeoutWithinBatch {
t.Errorf("Receive part %d of batch %d after %v (too late)", innerIndex+1, batchIndex+1, innerTime)
}
elapsedTime = now
} }
if len(received) != len(expected.paths) { expected := expectedBatches[batchIndex].paths[innerIndex]
t.Errorf("Received %v events instead of %v for batch %v", len(received), len(expected.paths), batchIndex+1)
}
compareBatchToExpected(t, received, expected.paths)
batchIndex++ if len(received) != len(expected) {
if batchIndex == len(expectedBatches) { t.Errorf("Received %v events instead of %v for batch %v", len(received), len(expected), batchIndex+1)
}
missing, unexpected := compareBatchToExpected(received, expected)
for _, p := range missing {
t.Errorf("Did not receive event %s in batch %d (%d)", p, batchIndex+1, innerIndex+1)
}
for _, p := range unexpected {
t.Errorf("Received unexpected event %s in batch %d (%d)", p, batchIndex+1, innerIndex+1)
}
if innerIndex == len(expectedBatches[batchIndex].paths)-1 {
if batchIndex == len(expectedBatches)-1 {
// received everything we expected to // received everything we expected to
return return
} }
innerIndex = 0
batchIndex++
} else {
innerIndex++
}
} }
} }