Index: third_party/WebKit/Source/platform/scheduler/base/task_queue_manager.cc |
diff --git a/third_party/WebKit/Source/platform/scheduler/base/task_queue_manager.cc b/third_party/WebKit/Source/platform/scheduler/base/task_queue_manager.cc |
index 74a311b176169842a5b18c0f8dc41f83d0819383..3a544e1522d9b7b40c02c2a1a6ab9b469c19c0f1 100644 |
--- a/third_party/WebKit/Source/platform/scheduler/base/task_queue_manager.cc |
+++ b/third_party/WebKit/Source/platform/scheduler/base/task_queue_manager.cc |
@@ -58,7 +58,11 @@ TaskQueueManager::TaskQueueManager( |
: real_time_domain_(new RealTimeDomain(tracing_category)), |
delegate_(delegate), |
task_was_run_on_quiescence_monitored_queue_(false), |
- other_thread_pending_wakeup_(false), |
+ do_work_pending_lock_(), // NOTE this calls the constructor! |
Sami
2016/12/07 16:13:42
Is this gonna work? This[1] says spinlocks can onl
alex clarke (OOO till 29th)
2016/12/08 17:38:48
Acknowledged.
|
+ do_work_running_count_(0), |
+ immediate_do_work_posted_count_(0), |
+ is_nested_(false), |
+ record_task_delay_histograms_(true), |
work_batch_size_(1), |
task_count_(0), |
tracing_category_(tracing_category), |
@@ -75,12 +79,10 @@ TaskQueueManager::TaskQueueManager( |
"TaskQueueManager", this); |
selector_.SetTaskQueueSelectorObserver(this); |
- from_main_thread_immediate_do_work_closure_ = |
- base::Bind(&TaskQueueManager::DoWork, weak_factory_.GetWeakPtr(), |
- base::TimeTicks(), true); |
- from_other_thread_immediate_do_work_closure_ = |
- base::Bind(&TaskQueueManager::DoWork, weak_factory_.GetWeakPtr(), |
- base::TimeTicks(), false); |
+ delayed_do_work_closure_ = |
+ base::Bind(&TaskQueueManager::DoWork, weak_factory_.GetWeakPtr(), true); |
+ immediate_do_work_closure_ = |
+ base::Bind(&TaskQueueManager::DoWork, weak_factory_.GetWeakPtr(), false); |
// TODO(alexclarke): Change this to be a parameter that's passed in. |
RegisterTimeDomain(real_time_domain_.get()); |
@@ -145,45 +147,64 @@ void TaskQueueManager::UnregisterTaskQueue( |
queues_.erase(task_queue); |
selector_.RemoveQueue(task_queue.get()); |
-} |
-void TaskQueueManager::UpdateWorkQueues(LazyNow lazy_now) { |
- TRACE_EVENT0(disabled_by_default_tracing_category_, |
- "TaskQueueManager::UpdateWorkQueues"); |
+ { |
+ SpinLock::Guard guard(do_work_pending_lock_); |
+ has_incomming_immediate_work_.erase(task_queue.get()); |
+ } |
+} |
+void TaskQueueManager::UpdateWorkQueues(LazyNow* lazy_now) { |
for (TimeDomain* time_domain : time_domains_) { |
- LazyNow lazy_now_in_domain = time_domain == real_time_domain_.get() |
- ? lazy_now |
- : time_domain->CreateLazyNow(); |
- time_domain->UpdateWorkQueues(lazy_now_in_domain); |
+ if (time_domain == real_time_domain_.get()) { |
+ time_domain->WakeupReadyDelayedQueues(lazy_now); |
+ continue; |
+ } |
+ LazyNow time_domain_lazy_now = time_domain->CreateLazyNow(); |
+ time_domain->WakeupReadyDelayedQueues(&time_domain_lazy_now); |
} |
} |
void TaskQueueManager::OnBeginNestedMessageLoop() { |
// We just entered a nested message loop, make sure there's a DoWork posted or |
// the system will grind to a halt. |
- delegate_->PostTask(FROM_HERE, from_main_thread_immediate_do_work_closure_); |
+ SpinLock::Guard guard(do_work_pending_lock_); |
Sami
2016/12/07 16:13:42
Seems risky holding to this during the PostTask --
alex clarke (OOO till 29th)
2016/12/08 17:38:48
Done.
|
+ delegate_->PostTask(FROM_HERE, immediate_do_work_closure_); |
+ immediate_do_work_posted_count_++; |
+ is_nested_ = true; |
+} |
+ |
+void TaskQueueManager::OnQueueHasImmediateWork(internal::TaskQueueImpl* queue, |
+ bool ensure_do_work_posted) { |
+ SpinLock::Guard guard(do_work_pending_lock_); |
+ has_incomming_immediate_work_.insert(queue); |
+ if (ensure_do_work_posted) |
+ MaybeScheduleImmediateWorkLocked(FROM_HERE); |
+} |
+ |
+void TaskQueueManager::NotifyQueuesOfIncomingImmediateWorkOnMainThreadLocked() { |
+ for (internal::TaskQueueImpl* queue : has_incomming_immediate_work_) { |
+ queue->ReloadImmediateWorkQueueIfEmpty(); |
+ } |
+ has_incomming_immediate_work_.clear(); |
} |
void TaskQueueManager::MaybeScheduleImmediateWork( |
const tracked_objects::Location& from_here) { |
- bool on_main_thread = delegate_->BelongsToCurrentThread(); |
- // De-duplicate DoWork posts. |
- if (on_main_thread) { |
- if (!main_thread_pending_wakeups_.insert(base::TimeTicks()).second) { |
- return; |
- } |
- delegate_->PostTask(from_here, from_main_thread_immediate_do_work_closure_); |
- } else { |
- { |
- base::AutoLock lock(other_thread_lock_); |
- if (other_thread_pending_wakeup_) |
- return; |
- other_thread_pending_wakeup_ = true; |
- } |
- delegate_->PostTask(from_here, |
- from_other_thread_immediate_do_work_closure_); |
+ SpinLock::Guard guard(do_work_pending_lock_); |
+ MaybeScheduleImmediateWorkLocked(from_here); |
+} |
+ |
+void TaskQueueManager::MaybeScheduleImmediateWorkLocked( |
+ const tracked_objects::Location& from_here) { |
+ // Unlwss we're ensted, try to avoid posting redundant DoWorks. |
Sami
2016/12/07 16:13:42
typo: Unless we're nested
alex clarke (OOO till 29th)
2016/12/08 17:38:48
Done.
|
+ if (!is_nested_ && |
+ (do_work_running_count_ == 1 || immediate_do_work_posted_count_ > 0)) { |
+ return; |
} |
+ |
+ delegate_->PostTask(from_here, immediate_do_work_closure_); |
Sami
2016/12/07 16:13:42
Ditto about the spinlock and the PostTask.
alex clarke (OOO till 29th)
2016/12/08 17:40:28
Done.
|
+ immediate_do_work_posted_count_++; |
} |
void TaskQueueManager::MaybeScheduleDelayedWork( |
@@ -191,51 +212,70 @@ void TaskQueueManager::MaybeScheduleDelayedWork( |
base::TimeTicks now, |
base::TimeDelta delay) { |
DCHECK(main_thread_checker_.CalledOnValidThread()); |
- DCHECK_GE(delay, base::TimeDelta()); |
+ { |
+ SpinLock::Guard guard(do_work_pending_lock_); |
- // If there's a pending immediate DoWork then we rely on |
- // TryAdvanceTimeDomains getting the TimeDomain to call |
- // MaybeScheduleDelayedWork again when the immediate DoWork is complete. |
- if (main_thread_pending_wakeups_.find(base::TimeTicks()) != |
- main_thread_pending_wakeups_.end()) { |
- return; |
+ // If there's a pending immediate DoWork then we rely on the logic in DoWork |
+ // to post a continuation as needed. |
+ if (immediate_do_work_posted_count_ > 0) |
+ return; |
+ |
+ // If a non-nested DoWork is running we can also rely on the logic in DoWork |
+ // to post a continuation as needed. |
+ if (do_work_running_count_ == 1 && !is_nested_) |
+ return; |
} |
+ MaybeScheduleDelayedWorkInternal(from_here, now, delay); |
+} |
+ |
+void TaskQueueManager::MaybeScheduleDelayedWorkInternal( |
+ const tracked_objects::Location& from_here, |
+ base::TimeTicks now, |
+ base::TimeDelta delay) { |
+ DCHECK_GE(delay, base::TimeDelta()); |
// De-duplicate DoWork posts. |
base::TimeTicks run_time = now + delay; |
- if (!main_thread_pending_wakeups_.empty() && |
- *main_thread_pending_wakeups_.begin() <= run_time) { |
+ if (next_delayed_do_work_ <= run_time && !next_delayed_do_work_.is_null()) |
return; |
- } |
- main_thread_pending_wakeups_.insert(run_time); |
+ |
+ cancelable_delayed_do_work_closure_.Reset(delayed_do_work_closure_); |
+ next_delayed_do_work_ = run_time; |
delegate_->PostDelayedTask( |
- from_here, base::Bind(&TaskQueueManager::DoWork, |
- weak_factory_.GetWeakPtr(), run_time, true), |
- delay); |
+ from_here, cancelable_delayed_do_work_closure_.callback(), delay); |
} |
-void TaskQueueManager::DoWork(base::TimeTicks run_time, bool from_main_thread) { |
+void TaskQueueManager::DoWork(bool delayed) { |
DCHECK(main_thread_checker_.CalledOnValidThread()); |
- TRACE_EVENT1(tracing_category_, "TaskQueueManager::DoWork", |
- "from_main_thread", from_main_thread); |
+ TRACE_EVENT1("tracing_category_", "TaskQueueManager::DoWork", "delayed", |
+ delayed); |
+ LazyNow lazy_now(real_time_domain()->CreateLazyNow()); |
- if (from_main_thread) { |
- main_thread_pending_wakeups_.erase(run_time); |
- } else { |
- base::AutoLock lock(other_thread_lock_); |
- other_thread_pending_wakeup_ = false; |
- } |
+ bool is_nested = delegate_->IsNested(); |
+ if (!is_nested) |
+ queues_to_delete_.clear(); |
- // Posting a DoWork while a DoWork is running leads to spurious DoWorks. |
- main_thread_pending_wakeups_.insert(base::TimeTicks()); |
+ for (int i = 0; i < work_batch_size_; i++) { |
+ { |
+ SpinLock::Guard guard(do_work_pending_lock_); |
- if (!delegate_->IsNested()) |
- queues_to_delete_.clear(); |
+ is_nested_ = is_nested; |
+ DCHECK_EQ(is_nested_, delegate_->IsNested()); |
- LazyNow lazy_now(real_time_domain()->CreateLazyNow()); |
- UpdateWorkQueues(lazy_now); |
+ if (i == 0) { |
+ do_work_running_count_++; |
- for (int i = 0; i < work_batch_size_; i++) { |
- internal::WorkQueue* work_queue; |
+ if (!delayed) { |
+ immediate_do_work_posted_count_--; |
+ DCHECK_GE(immediate_do_work_posted_count_, 0); |
+ } |
+ } |
+ |
+ NotifyQueuesOfIncomingImmediateWorkOnMainThreadLocked(); |
+ } |
+ |
+ UpdateWorkQueues(&lazy_now); |
+ |
+ internal::WorkQueue* work_queue = nullptr; |
if (!SelectWorkQueueToService(&work_queue)) |
break; |
@@ -251,29 +291,88 @@ void TaskQueueManager::DoWork(base::TimeTicks run_time, bool from_main_thread) { |
work_queue = nullptr; // The queue may have been unregistered. |
- UpdateWorkQueues(lazy_now); |
- |
// Only run a single task per batch in nested run loops so that we can |
// properly exit the nested loop when someone calls RunLoop::Quit(). |
- if (delegate_->IsNested()) |
+ if (is_nested) |
break; |
} |
- main_thread_pending_wakeups_.erase(base::TimeTicks()); |
- |
// TODO(alexclarke): Consider refactoring the above loop to terminate only |
// when there's no more work left to be done, rather than posting a |
// continuation task. |
- if (!selector_.EnabledWorkQueuesEmpty() || TryAdvanceTimeDomains()) |
- MaybeScheduleImmediateWork(FROM_HERE); |
+ if (delayed) |
+ next_delayed_do_work_ = base::TimeTicks(); |
+ |
+ // If we know we're about to post an immediate do work, then there's no point |
+ // calling UpdateWorkQueues since that'll get done by the next DoWork. |
+ bool work_queues_might_be_empty = selector_.EnabledWorkQueuesEmpty(); |
+ if (work_queues_might_be_empty) |
+ UpdateWorkQueues(&lazy_now); |
+ |
+ SpinLock::Guard guard(do_work_pending_lock_); |
Sami
2016/12/07 16:13:42
Could you also delimit this scope explicitly? Feel
alex clarke (OOO till 29th)
2016/12/08 17:38:48
Done.
|
+ |
+ // Likewise it's only worth calling |
+ // NotifyQueuesOfIncomingImmediateWorkOnMainThreadLocked if it looks like we |
+ // might have run out of immediate work to do. |
+ if (work_queues_might_be_empty) |
+ NotifyQueuesOfIncomingImmediateWorkOnMainThreadLocked(); |
+ |
+ base::Optional<base::TimeDelta> next_delay = DelayTillNextTask(&lazy_now); |
+ DCHECK(work_queues_might_be_empty || |
+ (next_delay && next_delay.value().is_zero())); |
+ |
+ do_work_running_count_--; |
+ DCHECK_GE(do_work_running_count_, 0); |
+ |
+ is_nested_ = is_nested; |
+ DCHECK_EQ(is_nested_, delegate_->IsNested()); |
+ |
+ PostDoWorkContinuation(next_delay, &lazy_now); |
+} |
+ |
+void TaskQueueManager::PostDoWorkContinuation( |
Sami
2016/12/07 16:13:42
...Locked()?
alex clarke (OOO till 29th)
2016/12/08 17:38:48
Done.
|
+ base::Optional<base::TimeDelta> next_delay, |
+ LazyNow* lazy_now) { |
+ // If there are no tasks left then we don't need to post a continuation. |
+ if (!next_delay) |
+ return; |
+ |
+ // If either an immediate DoWork or a delayed DoWork is pending then we don't |
+ // need to post a continuation. |
+ if (immediate_do_work_posted_count_ > 0 || |
+ (!next_delayed_do_work_.is_null() && |
+ next_delayed_do_work_ <= lazy_now->Now())) { |
+ return; |
+ } |
+ |
+ // Post a continuation task based on the delay till the next task. |
+ if (next_delay.value().is_zero()) { |
+ delegate_->PostTask(FROM_HERE, immediate_do_work_closure_); |
Sami
2016/12/07 16:13:42
Ditto about calling into the delegate/selector/tim
alex clarke (OOO till 29th)
2016/12/08 17:38:48
Done.
|
+ immediate_do_work_posted_count_++; |
+ } else { |
+ MaybeScheduleDelayedWorkInternal(FROM_HERE, lazy_now->Now(), |
+ next_delay.value()); |
+ } |
} |
-bool TaskQueueManager::TryAdvanceTimeDomains() { |
- bool can_advance = false; |
+base::Optional<base::TimeDelta> TaskQueueManager::DelayTillNextTask( |
+ LazyNow* lazy_now) { |
+ // If the selector has non-empty queues we trivially know there is immediate |
+ // word to be done. |
+ if (!selector_.EnabledWorkQueuesEmpty()) |
+ return base::TimeDelta(); |
+ |
+ // Otherwise we need to find the shortest delay, if any. |
+ base::Optional<base::TimeDelta> next_continuation; |
for (TimeDomain* time_domain : time_domains_) { |
- can_advance |= time_domain->MaybeAdvanceTime(); |
+ base::Optional<base::TimeDelta> continuation = |
+ time_domain->DelayTillNextTask(lazy_now); |
+ if (!continuation) |
+ continue; |
+ if (!next_continuation || next_continuation.value() < continuation.value()) |
Sami
2016/12/07 16:13:42
Should '<' be '>' or am I missing something?
alex clarke (OOO till 29th)
2016/12/08 17:38:48
Good catch, I added a test.
|
+ next_continuation = continuation; |
} |
- return can_advance; |
+ return next_continuation; |
} |
bool TaskQueueManager::SelectWorkQueueToService( |
Sami
2016/12/07 16:13:42
...Locked()?
alex clarke (OOO till 29th)
2016/12/08 17:38:48
This doesn't need to be locked?
|
@@ -306,7 +405,8 @@ TaskQueueManager::ProcessTaskResult TaskQueueManager::ProcessTaskFromWorkQueue( |
if (queue->GetQuiescenceMonitored()) |
task_was_run_on_quiescence_monitored_queue_ = true; |
- if (!pending_task.nestable && delegate_->IsNested()) { |
+ DCHECK_EQ(is_nested_, delegate_->IsNested()); |
+ if (!pending_task.nestable && is_nested_) { |
// Defer non-nestable work to the main task runner. NOTE these tasks can be |
// arbitrarily delayed so the additional delay should not be a problem. |
// TODO(skyostil): Figure out a way to not forget which task queue the |
@@ -319,7 +419,8 @@ TaskQueueManager::ProcessTaskResult TaskQueueManager::ProcessTaskFromWorkQueue( |
return ProcessTaskResult::DEFERRED; |
} |
- MaybeRecordTaskDelayHistograms(pending_task, queue); |
+ if (record_task_delay_histograms_) |
+ MaybeRecordTaskDelayHistograms(pending_task, queue); |
double task_start_time = 0; |
TRACE_TASK_EXECUTION("TaskQueueManager::ProcessTaskFromWorkQueue", |
@@ -470,6 +571,13 @@ TaskQueueManager::AsValueWithSelectorResult( |
for (auto* time_domain : time_domains_) |
time_domain->AsValueInto(state.get()); |
state->EndArray(); |
+ |
+ state->SetBoolean("is_nested", is_nested_); |
Sami
2016/12/07 16:13:42
Looks like this should be inside the lock.
alex clarke (OOO till 29th)
2016/12/08 17:38:48
Done.
|
+ |
+ SpinLock::Guard guard(do_work_pending_lock_); |
Sami
2016/12/07 16:13:42
nit: explicit scope please.
alex clarke (OOO till 29th)
2016/12/08 17:38:48
Done.
|
+ state->SetInteger("do_work_count", do_work_running_count_); |
+ state->SetInteger("immediate_do_work_posted", |
+ immediate_do_work_posted_count_); |
return std::move(state); |
} |
@@ -494,5 +602,11 @@ bool TaskQueueManager::HasImmediateWorkForTesting() const { |
return !selector_.EnabledWorkQueuesEmpty(); |
} |
+void TaskQueueManager::SetRecordTaskDelayHistograms( |
+ bool record_task_delay_histograms) { |
+ DCHECK(main_thread_checker_.CalledOnValidThread()); |
+ record_task_delay_histograms_ = record_task_delay_histograms; |
+} |
+ |
} // namespace scheduler |
} // namespace blink |