diff --git a/base/CMakeLists.txt b/base/CMakeLists.txt index 7744b6c475..ef270f33ce 100644 --- a/base/CMakeLists.txt +++ b/base/CMakeLists.txt @@ -51,7 +51,6 @@ set( observer_list.hpp pprof.cpp pprof.hpp - primitive_thread_pool.hpp random.cpp random.hpp range_iterator.hpp @@ -84,6 +83,9 @@ set( thread_checker.hpp thread_pool.cpp thread_pool.hpp + thread_pool_computational.hpp + thread_pool_delayed.cpp + thread_pool_delayed.hpp thread_utils.hpp threaded_container.cpp threaded_container.hpp @@ -97,8 +99,6 @@ set( url_helpers.cpp url_helpers.hpp visitor.hpp - worker_thread.cpp - worker_thread.hpp ) omim_add_library(${PROJECT_NAME} ${SRC}) diff --git a/base/base_tests/CMakeLists.txt b/base/base_tests/CMakeLists.txt index 90c92f694f..f09c3239a4 100644 --- a/base/base_tests/CMakeLists.txt +++ b/base/base_tests/CMakeLists.txt @@ -25,7 +25,6 @@ set( move_to_front_tests.cpp newtype_test.cpp observer_list_test.cpp - primitive_thread_pool_tests.cpp range_iterator_test.cpp ref_counted_tests.cpp regexp_test.cpp @@ -38,13 +37,14 @@ set( suffix_array_tests.cpp sunrise_sunset_test.cpp thread_pool_tests.cpp + thread_pool_computational_tests.cpp + thread_pool_delayed_tests.cpp threaded_list_test.cpp threads_test.cpp timegm_test.cpp timer_test.cpp uni_string_dfa_test.cpp visitor_tests.cpp - worker_thread_tests.cpp ) omim_add_test(${PROJECT_NAME} ${SRC}) diff --git a/base/base_tests/primitive_thread_pool_tests.cpp b/base/base_tests/thread_pool_computational_tests.cpp similarity index 77% rename from base/base_tests/primitive_thread_pool_tests.cpp rename to base/base_tests/thread_pool_computational_tests.cpp index 6ca1e5420f..630bab57ee 100644 --- a/base/base_tests/primitive_thread_pool_tests.cpp +++ b/base/base_tests/thread_pool_computational_tests.cpp @@ -1,6 +1,6 @@ #include "testing/testing.hpp" -#include "base/primitive_thread_pool.hpp" +#include "base/thread_pool_computational.hpp" #include #include @@ -14,14 +14,14 @@ namespace size_t const kTimes = 500; } // namespace -UNIT_TEST(PrimitiveThreadPool_SomeThreads) +UNIT_TEST(ThreadPoolComputational_SomeThreads) { for (size_t t = 0; t < kTimes; ++t) { size_t const threadCount = 4; std::atomic counter{0}; { - threads::PrimitiveThreadPool threadPool(threadCount); + base::thread_pool::computational::ThreadPool threadPool(threadCount); for (size_t i = 0; i < threadCount; ++i) { threadPool.Submit([&]() { @@ -35,14 +35,14 @@ UNIT_TEST(PrimitiveThreadPool_SomeThreads) } } -UNIT_TEST(PrimitiveThreadPool_OneThread) +UNIT_TEST(ThreadPoolComputational_OneThread) { for (size_t t = 0; t < kTimes; ++t) { size_t const threadCount = 1; std::atomic counter{0}; { - threads::PrimitiveThreadPool threadPool(threadCount); + base::thread_pool::computational::ThreadPool threadPool(threadCount); for (size_t i = 0; i < threadCount; ++i) { threadPool.Submit([&]() { @@ -56,7 +56,7 @@ UNIT_TEST(PrimitiveThreadPool_OneThread) } } -UNIT_TEST(PrimitiveThreadPool_ManyThread) +UNIT_TEST(ThreadPoolComputational_ManyThread) { for (size_t t = 0; t < kTimes; ++t) { @@ -65,7 +65,7 @@ UNIT_TEST(PrimitiveThreadPool_ManyThread) threadCount *= 2; std::atomic counter{0}; { - threads::PrimitiveThreadPool threadPool(threadCount); + base::thread_pool::computational::ThreadPool threadPool(threadCount); for (size_t i = 0; i < threadCount; ++i) { threadPool.Submit([&]() { @@ -79,12 +79,12 @@ UNIT_TEST(PrimitiveThreadPool_ManyThread) } } -UNIT_TEST(PrimitiveThreadPool_ReturnValue) +UNIT_TEST(ThreadPoolComputational_ReturnValue) { for (size_t t = 0; t < kTimes; ++t) { size_t const threadCount = 4; - threads::PrimitiveThreadPool threadPool(threadCount); + base::thread_pool::computational::ThreadPool threadPool(threadCount); std::vector> futures; for (size_t i = 0; i < threadCount; ++i) { @@ -101,14 +101,14 @@ UNIT_TEST(PrimitiveThreadPool_ReturnValue) } } -UNIT_TEST(PrimitiveThreadPool_ManyTasks) +UNIT_TEST(ThreadPoolComputational_ManyTasks) { for (size_t t = 0; t < kTimes; ++t) { size_t taskCount = 11; std::atomic counter{0}; { - threads::PrimitiveThreadPool threadPool(4); + base::thread_pool::computational::ThreadPool threadPool(4); for (size_t i = 0; i < taskCount; ++i) { threadPool.Submit([&]() { diff --git a/base/base_tests/worker_thread_tests.cpp b/base/base_tests/thread_pool_delayed_tests.cpp similarity index 64% rename from base/base_tests/worker_thread_tests.cpp rename to base/base_tests/thread_pool_delayed_tests.cpp index 6b07cb6b88..7726cd83b8 100644 --- a/base/base_tests/worker_thread_tests.cpp +++ b/base/base_tests/thread_pool_delayed_tests.cpp @@ -1,6 +1,6 @@ #include "testing/testing.hpp" -#include "base/worker_thread.hpp" +#include "base/thread_pool_delayed.hpp" #include #include @@ -13,24 +13,24 @@ using namespace std; namespace { -UNIT_TEST(WorkerThread_Smoke) +UNIT_TEST(ThreadPoolDelayed_Smoke) { { - WorkerThread thread; + thread_pool::delayed::ThreadPool thread; } { - WorkerThread thread; - TEST(thread.Shutdown(WorkerThread::Exit::SkipPending), ()); + thread_pool::delayed::ThreadPool thread; + TEST(thread.Shutdown(thread_pool::delayed::ThreadPool::Exit::SkipPending), ()); } { - WorkerThread thread; - TEST(thread.Shutdown(WorkerThread::Exit::ExecPending), ()); + thread_pool::delayed::ThreadPool thread; + TEST(thread.Shutdown(thread_pool::delayed::ThreadPool::Exit::ExecPending), ()); } } -UNIT_TEST(WorkerThread_SimpleSync) +UNIT_TEST(ThreadPoolDelayed_SimpleSync) { int value = 0; @@ -38,7 +38,7 @@ UNIT_TEST(WorkerThread_SimpleSync) condition_variable cv; bool done = false; - WorkerThread thread; + thread_pool::delayed::ThreadPool thread; TEST(thread.Push([&value]() { ++value; }), ()); TEST(thread.Push([&value]() { value *= 2; }), ()); TEST(thread.Push([&value]() { value = value * value * value; }), ()); @@ -56,55 +56,55 @@ UNIT_TEST(WorkerThread_SimpleSync) TEST_EQUAL(value, 8, ()); } -UNIT_TEST(WorkerThread_SimpleFlush) +UNIT_TEST(ThreadPoolDelayed_SimpleFlush) { int value = 0; { - WorkerThread thread; + thread_pool::delayed::ThreadPool thread; TEST(thread.Push([&value]() { ++value; }), ()); TEST(thread.Push([&value]() { for (int i = 0; i < 10; ++i) value *= 2; }), ()); - TEST(thread.Shutdown(WorkerThread::Exit::ExecPending), ()); + TEST(thread.Shutdown(thread_pool::delayed::ThreadPool::Exit::ExecPending), ()); } TEST_EQUAL(value, 1024, ()); } -UNIT_TEST(WorkerThread_PushFromPendingTask) +UNIT_TEST(ThreadPoolDelayed_PushFromPendingTask) { // promise - future pair is used as a socketpair here to pass a // signal from the main thread to the worker thread. promise p; auto f = p.get_future(); - WorkerThread thread; + thread_pool::delayed::ThreadPool thread; bool const rv = thread.Push([&f, &thread]() { f.get(); bool const rv = thread.Push([]() { TEST(false, ("This task should not be executed")); }); TEST(!rv, ()); }); TEST(rv, ()); - thread.Shutdown(WorkerThread::Exit::ExecPending); + thread.Shutdown(thread_pool::delayed::ThreadPool::Exit::ExecPending); p.set_value(); } -UNIT_TEST(WorkerThread_DelayedAndImmediateTasks) +UNIT_TEST(ThreadPoolDelayed_DelayedAndImmediateTasks) { int const kNumTasks = 100; struct DelayedTaskEntry { - WorkerThread::TimePoint m_start = {}; - WorkerThread::Duration m_delay = {}; - WorkerThread::TimePoint m_end = {}; + thread_pool::delayed::ThreadPool::TimePoint m_start = {}; + thread_pool::delayed::ThreadPool::Duration m_delay = {}; + thread_pool::delayed::ThreadPool::TimePoint m_end = {}; }; vector delayedEntries(kNumTasks); - vector immediateEntries(kNumTasks); + vector immediateEntries(kNumTasks); { - WorkerThread thread; + thread_pool::delayed::ThreadPool thread; for (int i = kNumTasks - 1; i >= 0; --i) { @@ -122,7 +122,7 @@ UNIT_TEST(WorkerThread_DelayedAndImmediateTasks) TEST(rv, ()); } - thread.Shutdown(WorkerThread::Exit::ExecPending); + thread.Shutdown(thread_pool::delayed::ThreadPool::Exit::ExecPending); } for (int i = 0; i < kNumTasks; ++i) diff --git a/base/base_tests/thread_pool_tests.cpp b/base/base_tests/thread_pool_tests.cpp index ac1544a1c6..07152758bf 100644 --- a/base/base_tests/thread_pool_tests.cpp +++ b/base/base_tests/thread_pool_tests.cpp @@ -43,7 +43,7 @@ UNIT_TEST(ThreadPool_CanceledTaskTest) { int finishCounter = 0; threads::Condition cond; - threads::ThreadPool pool(4, std::bind(&JoinFinishFunction, std::placeholders::_1, + base::thread_pool::routine::ThreadPool pool(4, std::bind(&JoinFinishFunction, std::placeholders::_1, std::ref(finishCounter), std::ref(cond))); for (int i = 0; i < TASK_COUNT; ++i) @@ -76,7 +76,7 @@ UNIT_TEST(ThreadPool_StopOperationTest) int finishCounter = 0; threads::Condition cond; // in this case we have empty pool, and all tasks must be finish only on Stop method call - threads::ThreadPool pool(0, std::bind(&JoinFinishFunction, std::placeholders::_1, + base::thread_pool::routine::ThreadPool pool(0, std::bind(&JoinFinishFunction, std::placeholders::_1, std::ref(finishCounter), std::ref(cond))); for (int i = 0; i < TASK_COUNT; ++i) @@ -126,7 +126,7 @@ UNIT_TEST(ThreadPool_ExecutionTaskTest) int finishCounter = 0; threads::Condition cond; - threads::ThreadPool pool(4, std::bind(&JoinFinishFunction, std::placeholders::_1, + base::thread_pool::routine::ThreadPool pool(4, std::bind(&JoinFinishFunction, std::placeholders::_1, std::ref(finishCounter), std::ref(cond))); for (size_t i = 0; i < tasks.size(); ++i) @@ -149,7 +149,7 @@ UNIT_TEST(ThreadPool_EmptyTest) { int finishCouter = 0; threads::Condition cond; - threads::ThreadPool pool(4, std::bind(&JoinFinishFunction, std::placeholders::_1, + base::thread_pool::routine::ThreadPool pool(4, std::bind(&JoinFinishFunction, std::placeholders::_1, std::ref(finishCouter), std::ref(cond))); threads::Sleep(100); diff --git a/base/thread.cpp b/base/thread.cpp index 6b94df4ce5..5cc65a2d92 100644 --- a/base/thread.cpp +++ b/base/thread.cpp @@ -83,25 +83,6 @@ void Thread::Join() IRoutine * Thread::GetRoutine() { return m_routine.get(); } -///////////////////////////////////////////////////////////////////// -// SimpleThreadPool implementation - -SimpleThreadPool::SimpleThreadPool(size_t reserve) { m_pool.reserve(reserve); } - -void SimpleThreadPool::Add(std::unique_ptr && routine) -{ - m_pool.emplace_back(new Thread()); - m_pool.back()->Create(move(routine)); -} - -void SimpleThreadPool::Join() -{ - for (auto & thread : m_pool) - thread->Join(); -} - -IRoutine * SimpleThreadPool::GetRoutine(size_t i) const { return m_pool[i]->GetRoutine(); } - void Sleep(size_t ms) { std::this_thread::sleep_for(std::chrono::milliseconds(ms)); } ThreadID GetCurrentThreadID() { return std::this_thread::get_id(); } diff --git a/base/thread.hpp b/base/thread.hpp index e66bbf35a1..157426b1b6 100644 --- a/base/thread.hpp +++ b/base/thread.hpp @@ -77,20 +77,6 @@ public: } }; -/// Simple threads container. Takes ownership for every added IRoutine. -class SimpleThreadPool : public boost::noncopyable -{ - std::vector> m_pool; - -public: - SimpleThreadPool(size_t reserve = 0); - - void Add(std::unique_ptr && routine); - void Join(); - - IRoutine * GetRoutine(size_t i) const; -}; - /// Suspends the execution of the current thread until the time-out interval elapses. /// @param[in] ms time-out interval in milliseconds void Sleep(size_t ms); diff --git a/base/thread_pool.cpp b/base/thread_pool.cpp index 1b20c78a8e..a2d3d868b7 100644 --- a/base/thread_pool.cpp +++ b/base/thread_pool.cpp @@ -8,129 +8,155 @@ #include #include -namespace threads +namespace base { - namespace - { - typedef std::function TPopRoutineFn; +namespace thread_pool +{ +namespace routine +{ +using namespace threads; +namespace +{ +typedef std::function TPopRoutineFn; - class PoolRoutine : public IRoutine +class PoolRoutine : public IRoutine +{ +public: + PoolRoutine(const TPopRoutineFn & popFn, const TFinishRoutineFn & finishFn) + : m_popFn(popFn) + , m_finishFn(finishFn) + { + } + + virtual void Do() + { + while (!IsCancelled()) { - public: - PoolRoutine(const TPopRoutineFn & popFn, const TFinishRoutineFn & finishFn) - : m_popFn(popFn) - , m_finishFn(finishFn) + threads::IRoutine * task = m_popFn(); + if (task == NULL) { + Cancel(); + continue; } - virtual void Do() - { - while (!IsCancelled()) - { - threads::IRoutine * task = m_popFn(); - if (task == NULL) - { - Cancel(); - continue; - } - - if (!task->IsCancelled()) - task->Do(); - m_finishFn(task); - } - } - - private: - TPopRoutineFn m_popFn; - TFinishRoutineFn m_finishFn; - }; + if (!task->IsCancelled()) + task->Do(); + m_finishFn(task); + } } - class ThreadPool::Impl - { - public: - Impl(size_t size, const TFinishRoutineFn & finishFn) : m_finishFn(finishFn), m_threads(size) - { - for (auto & thread : m_threads) - { - thread.reset(new threads::Thread()); - thread->Create(std::make_unique(std::bind(&ThreadPool::Impl::PopFront, this), m_finishFn)); - } - } - - ~Impl() - { - Stop(); - } - - void PushBack(threads::IRoutine * routine) - { - m_tasks.PushBack(routine); - } - - void PushFront(threads::IRoutine * routine) - { - m_tasks.PushFront(routine); - } - - threads::IRoutine * PopFront() - { - return m_tasks.Front(true); - } - - void Stop() - { - m_tasks.Cancel(); - - for (auto & thread : m_threads) - thread->Cancel(); - m_threads.clear(); - - m_tasks.ProcessList([this](std::list & tasks) - { - FinishTasksOnStop(tasks); - }); - m_tasks.Clear(); - } - - private: - void FinishTasksOnStop(std::list & tasks) - { - typedef std::list::iterator task_iter; - for (task_iter it = tasks.begin(); it != tasks.end(); ++it) - { - (*it)->Cancel(); - m_finishFn(*it); - } - } - - private: - ThreadedList m_tasks; - TFinishRoutineFn m_finishFn; - - std::vector> m_threads; - }; - - ThreadPool::ThreadPool(size_t size, const TFinishRoutineFn & finishFn) - : m_impl(new Impl(size, finishFn)) {} - - ThreadPool::~ThreadPool() - { - delete m_impl; - } - - void ThreadPool::PushBack(threads::IRoutine * routine) - { - m_impl->PushBack(routine); - } - - void ThreadPool::PushFront(IRoutine * routine) - { - m_impl->PushFront(routine); - } - - void ThreadPool::Stop() - { - m_impl->Stop(); - } +private: + TPopRoutineFn m_popFn; + TFinishRoutineFn m_finishFn; +}; } + +class ThreadPool::Impl +{ +public: + Impl(size_t size, const TFinishRoutineFn & finishFn) : m_finishFn(finishFn), m_threads(size) + { + for (auto & thread : m_threads) + { + thread.reset(new threads::Thread()); + thread->Create(std::make_unique(std::bind(&ThreadPool::Impl::PopFront, this), m_finishFn)); + } + } + + ~Impl() + { + Stop(); + } + + void PushBack(threads::IRoutine * routine) + { + m_tasks.PushBack(routine); + } + + void PushFront(threads::IRoutine * routine) + { + m_tasks.PushFront(routine); + } + + threads::IRoutine * PopFront() + { + return m_tasks.Front(true); + } + + void Stop() + { + m_tasks.Cancel(); + + for (auto & thread : m_threads) + thread->Cancel(); + m_threads.clear(); + + m_tasks.ProcessList([this](std::list & tasks) + { + FinishTasksOnStop(tasks); + }); + m_tasks.Clear(); + } + +private: + void FinishTasksOnStop(std::list & tasks) + { + typedef std::list::iterator task_iter; + for (task_iter it = tasks.begin(); it != tasks.end(); ++it) + { + (*it)->Cancel(); + m_finishFn(*it); + } + } + +private: + ThreadedList m_tasks; + TFinishRoutineFn m_finishFn; + + std::vector> m_threads; +}; + +ThreadPool::ThreadPool(size_t size, const TFinishRoutineFn & finishFn) + : m_impl(new Impl(size, finishFn)) {} + +ThreadPool::~ThreadPool() +{ + delete m_impl; +} + +void ThreadPool::PushBack(threads::IRoutine * routine) +{ + m_impl->PushBack(routine); +} + +void ThreadPool::PushFront(IRoutine * routine) +{ + m_impl->PushFront(routine); +} + +void ThreadPool::Stop() +{ + m_impl->Stop(); +} +} // namespace routine + +namespace routine_simple +{ +ThreadPool::ThreadPool(size_t reserve) { m_pool.reserve(reserve); } + +void ThreadPool::Add(std::unique_ptr && routine) +{ + m_pool.emplace_back(new threads::Thread()); + m_pool.back()->Create(move(routine)); +} + +void ThreadPool::Join() +{ + for (auto & thread : m_pool) + thread->Join(); +} + +threads::IRoutine * ThreadPool::GetRoutine(size_t i) const { return m_pool[i]->GetRoutine(); } +} // namespace routine_simple +} // namespace thread_pool +} // namespace base diff --git a/base/thread_pool.hpp b/base/thread_pool.hpp index ddd664ae28..cf71ff357a 100644 --- a/base/thread_pool.hpp +++ b/base/thread_pool.hpp @@ -1,28 +1,60 @@ #pragma once #include "base/base.hpp" +#include "base/macros.hpp" #include +#include namespace threads { - class IRoutine; +class IRoutine; +class Thread; +} // namespace threads - typedef std::function TFinishRoutineFn; +namespace base +{ +namespace thread_pool +{ +namespace routine +{ +typedef std::function TFinishRoutineFn; - class ThreadPool - { - public: - ThreadPool(size_t size, const TFinishRoutineFn & finishFn); - ~ThreadPool(); +class ThreadPool +{ +public: + ThreadPool(size_t size, const TFinishRoutineFn & finishFn); + ~ThreadPool(); - // ThreadPool will not delete routine. You can delete it in finish_routine_fn if need - void PushBack(threads::IRoutine * routine); - void PushFront(threads::IRoutine * routine); - void Stop(); + // ThreadPool will not delete routine. You can delete it in finish_routine_fn if need + void PushBack(threads::IRoutine * routine); + void PushFront(threads::IRoutine * routine); + void Stop(); - private: - class Impl; - Impl * m_impl; - }; -} +private: + class Impl; + Impl * m_impl; +}; +} // namespace routine + +namespace routine_simple +{ +/// Simple threads container. Takes ownership for every added IRoutine. +class ThreadPool +{ +public: + ThreadPool(size_t reserve = 0); + + void Add(std::unique_ptr && routine); + void Join(); + + threads::IRoutine * GetRoutine(size_t i) const; + +private: + std::vector> m_pool; + + DISALLOW_COPY(ThreadPool); +}; +} // namespace routine_simple +} // namespace thread_pool +} // namespace base diff --git a/base/primitive_thread_pool.hpp b/base/thread_pool_computational.hpp similarity index 86% rename from base/primitive_thread_pool.hpp rename to base/thread_pool_computational.hpp index 33dd9696a9..63bd40d5d0 100644 --- a/base/primitive_thread_pool.hpp +++ b/base/thread_pool_computational.hpp @@ -1,4 +1,4 @@ -// This file contains PrimitiveThreadPool class. +// This file contains ThreadPool class. #pragma once #include "base/assert.hpp" @@ -11,14 +11,19 @@ #include #include -namespace threads +namespace base { -// PrimitiveThreadPool is needed for easy parallelization of tasks. -// PrimitiveThreadPool can accept tasks that return result as std::future. +using namespace threads; +namespace thread_pool +{ +namespace computational +{ +// ThreadPool is needed for easy parallelization of tasks. +// ThreadPool can accept tasks that return result as std::future. // When the destructor is called, all threads will join. // Warning: ThreadPool works with std::thread instead of SimpleThread and therefore // should not be used when the JVM is needed. -class PrimitiveThreadPool +class ThreadPool { public: using FunctionType = FunctionWrapper; @@ -27,7 +32,7 @@ public: // Constructs a ThreadPool. // threadCount - number of threads used by the thread pool. // Warning: The constructor may throw exceptions. - PrimitiveThreadPool(size_t threadCount) : m_done(false), m_joiner(m_threads) + ThreadPool(size_t threadCount) : m_done(false), m_joiner(m_threads) { CHECK_GREATER(threadCount, 0, ()); @@ -35,7 +40,7 @@ public: try { for (size_t i = 0; i < threadCount; i++) - m_threads.emplace_back(&PrimitiveThreadPool::Worker, this); + m_threads.emplace_back(&ThreadPool::Worker, this); } catch (...) // std::system_error etc. { @@ -46,7 +51,7 @@ public: // Destroys the ThreadPool. // This function will block until all runnables have been completed. - ~PrimitiveThreadPool() + ~ThreadPool() { { std::unique_lock lock(m_mutex); @@ -127,6 +132,6 @@ private: Threads m_threads; ThreadsJoiner<> m_joiner; }; - - -} // namespace threads +} // namespace computational +} // namespace thread_pool +} // namespace base diff --git a/base/worker_thread.cpp b/base/thread_pool_delayed.cpp similarity index 81% rename from base/worker_thread.cpp rename to base/thread_pool_delayed.cpp index 85da0a1d96..4f74a4b265 100644 --- a/base/worker_thread.cpp +++ b/base/thread_pool_delayed.cpp @@ -1,4 +1,4 @@ -#include "base/worker_thread.hpp" +#include "base/thread_pool_delayed.hpp" #include @@ -6,41 +6,45 @@ using namespace std; namespace base { -WorkerThread::WorkerThread(size_t threadsCount /* = 1 */, Exit e /* = Exit::SkipPending */) +namespace thread_pool +{ +namespace delayed +{ +ThreadPool::ThreadPool(size_t threadsCount /* = 1 */, Exit e /* = Exit::SkipPending */) : m_exit(e) { for (size_t i = 0; i < threadsCount; ++i) - m_threads.emplace_back(threads::SimpleThread(&WorkerThread::ProcessTasks, this)); + m_threads.emplace_back(threads::SimpleThread(&ThreadPool::ProcessTasks, this)); } -WorkerThread::~WorkerThread() +ThreadPool::~ThreadPool() { ShutdownAndJoin(); } -bool WorkerThread::Push(Task && t) +bool ThreadPool::Push(Task && t) { return TouchQueues([&]() { m_immediate.emplace(move(t)); }); } -bool WorkerThread::Push(Task const & t) +bool ThreadPool::Push(Task const & t) { return TouchQueues([&]() { m_immediate.emplace(t); }); } -bool WorkerThread::PushDelayed(Duration const & delay, Task && t) +bool ThreadPool::PushDelayed(Duration const & delay, Task && t) { auto const when = Now() + delay; return TouchQueues([&]() { m_delayed.emplace(when, move(t)); }); } -bool WorkerThread::PushDelayed(Duration const & delay, Task const & t) +bool ThreadPool::PushDelayed(Duration const & delay, Task const & t) { auto const when = Now() + delay; return TouchQueues([&]() { m_delayed.emplace(when, t); }); } -void WorkerThread::ProcessTasks() +void ThreadPool::ProcessTasks() { ImmediateQueue pendingImmediate; DelayedQueue pendingDelayed; @@ -60,7 +64,7 @@ void WorkerThread::ProcessTasks() auto const when = m_delayed.top().m_when; m_cv.wait_until(lk, when, [this, when]() { return m_shutdown || !m_immediate.empty() || m_delayed.empty() || - (!m_delayed.empty() && m_delayed.top().m_when < when); + (!m_delayed.empty() && m_delayed.top().m_when < when); }); } else @@ -130,7 +134,7 @@ void WorkerThread::ProcessTasks() } } -bool WorkerThread::Shutdown(Exit e) +bool ThreadPool::Shutdown(Exit e) { lock_guard lk(m_mu); if (m_shutdown) @@ -141,7 +145,7 @@ bool WorkerThread::Shutdown(Exit e) return true; } -void WorkerThread::ShutdownAndJoin() +void ThreadPool::ShutdownAndJoin() { ASSERT(m_checker.CalledOnOriginalThread(), ()); Shutdown(m_exit); @@ -152,4 +156,6 @@ void WorkerThread::ShutdownAndJoin() } m_threads.clear(); } +} // namespace delayed +} // namespace thread_pool } // namespace base diff --git a/base/worker_thread.hpp b/base/thread_pool_delayed.hpp similarity index 90% rename from base/worker_thread.hpp rename to base/thread_pool_delayed.hpp index 05e4032bb3..bd5bc481c7 100644 --- a/base/worker_thread.hpp +++ b/base/thread_pool_delayed.hpp @@ -14,11 +14,15 @@ namespace base { +namespace thread_pool +{ +namespace delayed +{ // This class represents a simple worker thread with a queue of tasks. // // *NOTE* This class IS NOT thread-safe, it must be destroyed on the // same thread it was created, but Push* methods are thread-safe. -class WorkerThread : public TaskLoop +class ThreadPool : public TaskLoop { public: using Clock = std::chrono::steady_clock; @@ -31,8 +35,8 @@ public: SkipPending }; - explicit WorkerThread(size_t threadsCount = 1, Exit e = Exit::SkipPending); - ~WorkerThread() override; + explicit ThreadPool(size_t threadsCount = 1, Exit e = Exit::SkipPending); + ~ThreadPool() override; // Pushes task to the end of the thread's queue of immediate tasks. // Returns false when the thread is shut down. @@ -92,7 +96,7 @@ private: using ImmediateQueue = std::queue; using DelayedQueue = - std::priority_queue, std::greater>; + std::priority_queue, std::greater>; template bool TouchQueues(Fn && fn) @@ -119,4 +123,6 @@ private: ThreadChecker m_checker; }; +} // namespace delayed +} // namespace thread_pool } // namespace base diff --git a/base/thread_utils.hpp b/base/thread_utils.hpp index 8253b44e29..69ac2c7cd9 100644 --- a/base/thread_utils.hpp +++ b/base/thread_utils.hpp @@ -5,6 +5,8 @@ #include "base/macros.hpp" +namespace base +{ namespace threads { template > @@ -70,3 +72,4 @@ private: DISALLOW_COPY(FunctionWrapper); }; } // namespace threads +} // namespace base diff --git a/drape/drape_routine.hpp b/drape/drape_routine.hpp index b51257ec7d..210ce26df3 100644 --- a/drape/drape_routine.hpp +++ b/drape/drape_routine.hpp @@ -2,7 +2,7 @@ #include "base/assert.hpp" #include "base/macros.hpp" -#include "base/worker_thread.hpp" +#include "base/thread_pool_delayed.hpp" #include #include @@ -77,7 +77,7 @@ public: } template - static ResultPtr RunDelayed(base::WorkerThread::Duration const & duration, Task && t) + static ResultPtr RunDelayed(base::thread_pool::delayed::ThreadPool::Duration const & duration, Task && t) { ResultPtr result(new Result(Instance().GetNextId())); bool const success = Instance().m_workerThread.PushDelayed(duration, [result, t]() mutable @@ -140,7 +140,7 @@ private: bool m_finished = false; std::condition_variable m_condition; std::mutex m_mutex; - base::WorkerThread m_workerThread; + base::thread_pool::delayed::ThreadPool m_workerThread; }; // This is a helper class, which aggregates logic of waiting for active diff --git a/drape_frontend/drape_notifier.cpp b/drape_frontend/drape_notifier.cpp index 2973ac2403..183dc35202 100644 --- a/drape_frontend/drape_notifier.cpp +++ b/drape_frontend/drape_notifier.cpp @@ -11,7 +11,7 @@ DrapeNotifier::DrapeNotifier(ref_ptr commutator) {} uint64_t DrapeNotifier::Notify(ThreadsCommutator::ThreadName threadName, - base::WorkerThread::Duration const & duration, bool repeating, + base::thread_pool::delayed::ThreadPool::Duration const & duration, bool repeating, Functor && functor) { uint64_t const notifyId = m_counter++; @@ -20,7 +20,7 @@ uint64_t DrapeNotifier::Notify(ThreadsCommutator::ThreadName threadName, } void DrapeNotifier::NotifyImpl(ThreadsCommutator::ThreadName threadName, - base::WorkerThread::Duration const & duration, bool repeating, + base::thread_pool::delayed::ThreadPool::Duration const & duration, bool repeating, uint64_t notifyId, Functor && functor) { dp::DrapeRoutine::RunDelayed(duration, diff --git a/drape_frontend/drape_notifier.hpp b/drape_frontend/drape_notifier.hpp index bf319c3ee3..8e505f54e4 100644 --- a/drape_frontend/drape_notifier.hpp +++ b/drape_frontend/drape_notifier.hpp @@ -4,7 +4,7 @@ #include "drape/pointers.hpp" -#include "base/worker_thread.hpp" +#include "base/thread_pool_delayed.hpp" #include #include @@ -21,12 +21,12 @@ public: explicit DrapeNotifier(ref_ptr commutator); uint64_t Notify(ThreadsCommutator::ThreadName threadName, - base::WorkerThread::Duration const & duration, + base::thread_pool::delayed::ThreadPool::Duration const & duration, bool repeating, Functor && functor); private: void NotifyImpl(ThreadsCommutator::ThreadName threadName, - base::WorkerThread::Duration const & duration, bool repeating, + base::thread_pool::delayed::ThreadPool::Duration const & duration, bool repeating, uint64_t notifyId, Functor && functor); ref_ptr m_commutator; diff --git a/drape_frontend/read_manager.cpp b/drape_frontend/read_manager.cpp index 3a336b1705..ca2a9f51be 100755 --- a/drape_frontend/read_manager.cpp +++ b/drape_frontend/read_manager.cpp @@ -68,7 +68,7 @@ void ReadManager::Start() return; using namespace std::placeholders; - m_pool = make_unique_dp(kReadingThreadsCount, + m_pool = make_unique_dp(kReadingThreadsCount, std::bind(&ReadManager::OnTaskFinished, this, _1)); } diff --git a/drape_frontend/read_manager.hpp b/drape_frontend/read_manager.hpp index 8a177b29da..116d9e58f6 100755 --- a/drape_frontend/read_manager.hpp +++ b/drape_frontend/read_manager.hpp @@ -73,7 +73,7 @@ private: MapDataProvider & m_model; - drape_ptr m_pool; + drape_ptr m_pool; ScreenBase m_currentViewport; bool m_have3dBuildings; diff --git a/generator/popularity.cpp b/generator/popularity.cpp index 2fafd53376..ad6467b54c 100644 --- a/generator/popularity.cpp +++ b/generator/popularity.cpp @@ -11,7 +11,7 @@ #include "base/assert.hpp" #include "base/geo_object_id.hpp" -#include "base/primitive_thread_pool.hpp" +#include "base/thread_pool_computational.hpp" #include #include @@ -268,7 +268,7 @@ std::vector BuildPopularitySrcFromAllData(std::vector>> futures; for (auto const & filename : dataFilenames) { diff --git a/generator/regions/regions_builder.cpp b/generator/regions/regions_builder.cpp index 8715002102..6eab84dd1b 100644 --- a/generator/regions/regions_builder.cpp +++ b/generator/regions/regions_builder.cpp @@ -1,7 +1,7 @@ #include "generator/regions/regions_builder.hpp" #include "base/assert.hpp" -#include "base/primitive_thread_pool.hpp" +#include "base/thread_pool_computational.hpp" #include "base/stl_helpers.hpp" #include diff --git a/map/mwm_tests/multithread_mwm_test.cpp b/map/mwm_tests/multithread_mwm_test.cpp index 6fe176fe18..4b1899a1d2 100644 --- a/map/mwm_tests/multithread_mwm_test.cpp +++ b/map/mwm_tests/multithread_mwm_test.cpp @@ -6,6 +6,7 @@ #include "base/macros.hpp" #include "base/thread.hpp" +#include "base/thread_pool.hpp" namespace { @@ -74,7 +75,7 @@ namespace srand(666); size_t const count = 20; - threads::SimpleThreadPool pool(count); + base::thread_pool::routine_simple::ThreadPool pool(count); for (size_t i = 0; i < count; ++i) pool.Add(make_unique(src)); diff --git a/map/transit/transit_reader.cpp b/map/transit/transit_reader.cpp index fbd04ffd4b..75f493b83c 100644 --- a/map/transit/transit_reader.cpp +++ b/map/transit/transit_reader.cpp @@ -158,7 +158,7 @@ void TransitReadManager::Start() using namespace placeholders; uint8_t constexpr kThreadsCount = 1; - m_threadsPool = make_unique( + m_threadsPool = make_unique( kThreadsCount, bind(&TransitReadManager::OnTaskCompleted, this, _1)); } diff --git a/map/transit/transit_reader.hpp b/map/transit/transit_reader.hpp index 0161b5b2dd..32e82674c3 100644 --- a/map/transit/transit_reader.hpp +++ b/map/transit/transit_reader.hpp @@ -114,7 +114,7 @@ private: void ShrinkCacheToAllowableSize(); void ClearCache(MwmSet::MwmId const & mwmId); - std::unique_ptr m_threadsPool; + std::unique_ptr m_threadsPool; std::mutex m_mutex; std::condition_variable m_event; diff --git a/partners_api/partners_api_tests/taxi_engine_tests.cpp b/partners_api/partners_api_tests/taxi_engine_tests.cpp index a704423b5e..98e89d1d3b 100644 --- a/partners_api/partners_api_tests/taxi_engine_tests.cpp +++ b/partners_api/partners_api_tests/taxi_engine_tests.cpp @@ -14,7 +14,7 @@ #include "geometry/mercator.hpp" #include "base/scope_guard.hpp" -#include "base/worker_thread.hpp" +#include "base/thread_pool_delayed.hpp" #include diff --git a/platform/platform.cpp b/platform/platform.cpp index 9303d4ad86..1ef6edaf48 100644 --- a/platform/platform.cpp +++ b/platform/platform.cpp @@ -344,9 +344,9 @@ void Platform::ShutdownThreads() void Platform::RunThreads() { ASSERT(!m_networkThread && !m_fileThread && !m_backgroundThread, ()); - m_networkThread = make_unique(); - m_fileThread = make_unique(); - m_backgroundThread = make_unique(); + m_networkThread = make_unique(); + m_fileThread = make_unique(); + m_backgroundThread = make_unique(); } string DebugPrint(Platform::EError err) diff --git a/platform/platform.hpp b/platform/platform.hpp index 3f832bcd07..4b18ff46f7 100644 --- a/platform/platform.hpp +++ b/platform/platform.hpp @@ -12,7 +12,7 @@ #include "base/exception.hpp" #include "base/macros.hpp" #include "base/task_loop.hpp" -#include "base/worker_thread.hpp" +#include "base/thread_pool_delayed.hpp" #include #include @@ -128,9 +128,9 @@ protected: std::unique_ptr m_guiThread; - std::unique_ptr m_networkThread; - std::unique_ptr m_fileThread; - std::unique_ptr m_backgroundThread; + std::unique_ptr m_networkThread; + std::unique_ptr m_fileThread; + std::unique_ptr m_backgroundThread; platform::BatteryLevelTracker m_batteryTracker; @@ -330,7 +330,7 @@ public: } template - void RunDelayedTask(Thread thread, base::WorkerThread::Duration const & delay, Task && task) + void RunDelayedTask(Thread thread, base::thread_pool::delayed::ThreadPool::Duration const & delay, Task && task) { ASSERT(m_networkThread && m_fileThread && m_backgroundThread, ()); switch (thread) diff --git a/platform/platform_tests/apk_test.cpp b/platform/platform_tests/apk_test.cpp index 6305aa9dba..83760b4e24 100644 --- a/platform/platform_tests/apk_test.cpp +++ b/platform/platform_tests/apk_test.cpp @@ -6,11 +6,11 @@ #include "coding/internal/file_data.hpp" #include "base/thread.hpp" +#include "base/thread_pool.hpp" #include "base/logging.hpp" #include "std/numeric.hpp" - namespace { char const * arrFiles[] = { @@ -103,7 +103,7 @@ UNIT_TEST(ApkReader_Multithreaded) srand(static_cast(size)); size_t const count = 20; - threads::SimpleThreadPool pool(count); + base::thread_pool::routine_simple::ThreadPool pool(count); for (size_t i = 0; i < count; ++i) pool.Add(make_unique(path)); diff --git a/platform/platform_tests_support/async_gui_thread.hpp b/platform/platform_tests_support/async_gui_thread.hpp index c77f95f58c..43b8a3bc6e 100644 --- a/platform/platform_tests_support/async_gui_thread.hpp +++ b/platform/platform_tests_support/async_gui_thread.hpp @@ -3,7 +3,7 @@ #include "platform/gui_thread.hpp" #include "platform/platform.hpp" -#include "base/worker_thread.hpp" +#include "base/thread_pool_delayed.hpp" #include @@ -16,8 +16,8 @@ class AsyncGuiThread public: AsyncGuiThread() { - GetPlatform().SetGuiThread(std::make_unique( - 1 /* threadsCount */, base::WorkerThread::Exit::ExecPending)); + GetPlatform().SetGuiThread(std::make_unique( + 1 /* threadsCount */, base::thread_pool::delayed::ThreadPool::Exit::ExecPending)); } virtual ~AsyncGuiThread() diff --git a/shaders/shaders_tests/gl_shaders_mobile_compile_test.cpp b/shaders/shaders_tests/gl_shaders_mobile_compile_test.cpp index a3d06af0b6..b74a2d709f 100644 --- a/shaders/shaders_tests/gl_shaders_mobile_compile_test.cpp +++ b/shaders/shaders_tests/gl_shaders_mobile_compile_test.cpp @@ -7,7 +7,7 @@ #include "coding/file_name_utils.hpp" #include "base/logging.hpp" -#include "base/worker_thread.hpp" +#include "base/thread_pool_delayed.hpp" #include #include @@ -217,7 +217,7 @@ void CompileShadersSamsungGoogleNexus(CompilerData const & compiler) UNIT_TEST(MobileCompileShaders_Test) { - base::WorkerThread workerThread(6 /* threadsCount */); + base::thread_pool::delayed::ThreadPool workerThread(6 /* threadsCount */); workerThread.Push([] { CompileShaders({dp::ApiVersion::OpenGLES2, GetCompilerPath(kCompilerOpenGLES2)}); @@ -243,7 +243,7 @@ UNIT_TEST(MobileCompileShaders_Test) CompileShadersSamsungGoogleNexus({dp::ApiVersion::OpenGLES3, GetCompilerPath(kCompilerOpenGLES3)}); }); - workerThread.Shutdown(base::WorkerThread::Exit::ExecPending); + workerThread.Shutdown(base::thread_pool::delayed::ThreadPool::Exit::ExecPending); } #endif @@ -540,7 +540,7 @@ UNIT_TEST(MALI_MobileCompileShaders_Test) driversES3new} }; - base::WorkerThread workerThread(16 /* threadsCount */); + base::thread_pool::delayed::ThreadPool workerThread(16 /* threadsCount */); uint32_t counter = 0; std::atomic progressCounter(0); for (auto const & compiler : compilers) @@ -562,10 +562,10 @@ UNIT_TEST(MALI_MobileCompileShaders_Test) } } - // Here we are in active waiting, because WorkerThread stops dispatching tasks + // Here we are in active waiting, because thread_pool::delayed::ThreadPool stops dispatching tasks // to different threads in case of shutting down. while (progressCounter < counter) std::this_thread::sleep_for(std::chrono::milliseconds(100)); - workerThread.Shutdown(base::WorkerThread::Exit::ExecPending); + workerThread.Shutdown(base::thread_pool::delayed::ThreadPool::Exit::ExecPending); } diff --git a/storage/diff_scheme/diff_manager.hpp b/storage/diff_scheme/diff_manager.hpp index 170a6e9b4b..3f028b2ef6 100644 --- a/storage/diff_scheme/diff_manager.hpp +++ b/storage/diff_scheme/diff_manager.hpp @@ -5,7 +5,7 @@ #include "base/observer_list.hpp" #include "base/thread_checker.hpp" -#include "base/worker_thread.hpp" +#include "base/thread_pool_delayed.hpp" #include #include @@ -69,7 +69,7 @@ private: NameDiffInfoMap m_diffs; LocalMapsInfo m_localMapsInfo; base::ObserverListUnsafe m_observers; - base::WorkerThread m_workerThread; + base::thread_pool::delayed::ThreadPool m_workerThread; }; } // namespace diffs } // namespace storage diff --git a/storage/pinger.cpp b/storage/pinger.cpp index bb66cd6c80..7089f1f7eb 100644 --- a/storage/pinger.cpp +++ b/storage/pinger.cpp @@ -6,7 +6,7 @@ #include "base/assert.hpp" #include "base/logging.hpp" #include "base/stl_helpers.hpp" -#include "base/worker_thread.hpp" +#include "base/thread_pool_delayed.hpp" #include "3party/Alohalytics/src/alohalytics.h" @@ -61,11 +61,11 @@ void Pinger::Ping(vector const & urls, Pinger::Pong const & pong) vector readyUrls(size); { - base::WorkerThread t(size); + base::thread_pool::delayed::ThreadPool t(size); for (size_t i = 0; i < size; ++i) t.Push([url = urls[i], &readyUrls, i] { DoPing(url, i, readyUrls); }); - t.Shutdown(base::WorkerThread::Exit::ExecPending); + t.Shutdown(base::thread_pool::delayed::ThreadPool::Exit::ExecPending); } base::EraseIf(readyUrls, [](auto const & url) { return url.empty(); }); diff --git a/storage/storage.hpp b/storage/storage.hpp index 7361f80101..9dfbff78c6 100644 --- a/storage/storage.hpp +++ b/storage/storage.hpp @@ -15,7 +15,7 @@ #include "base/deferred_task.hpp" #include "base/thread_checker.hpp" -#include "base/worker_thread.hpp" +#include "base/thread_pool_delayed.hpp" #include "std/function.hpp" #include "std/list.hpp" diff --git a/ugc/api.hpp b/ugc/api.hpp index 2f58d236d4..17bab94a10 100644 --- a/ugc/api.hpp +++ b/ugc/api.hpp @@ -8,7 +8,7 @@ #include "geometry/point2d.hpp" -#include "base/worker_thread.hpp" +#include "base/thread_pool_delayed.hpp" #include @@ -54,7 +54,7 @@ private: void SendingCompletedImpl(); void SaveUGCOnDiskImpl(); - base::WorkerThread m_thread; + base::thread_pool::delayed::ThreadPool m_thread; Storage m_storage; Loader m_loader; }; diff --git a/xcode/base/base.xcodeproj/project.pbxproj b/xcode/base/base.xcodeproj/project.pbxproj index 14fd5351f9..5f08733490 100644 --- a/xcode/base/base.xcodeproj/project.pbxproj +++ b/xcode/base/base.xcodeproj/project.pbxproj @@ -27,7 +27,6 @@ 3917FA63211E010400937DF4 /* move_to_front_tests.cpp in Sources */ = {isa = PBXBuildFile; fileRef = 39F995DF20F55B8A0034F977 /* move_to_front_tests.cpp */; }; 3917FA64211E010400937DF4 /* suffix_array_tests.cpp in Sources */ = {isa = PBXBuildFile; fileRef = 39F995E120F55B8A0034F977 /* suffix_array_tests.cpp */; }; 3917FA65211E010400937DF4 /* visitor_tests.cpp in Sources */ = {isa = PBXBuildFile; fileRef = 39F995E220F55B8A0034F977 /* visitor_tests.cpp */; }; - 3917FA66211E010400937DF4 /* worker_thread_tests.cpp in Sources */ = {isa = PBXBuildFile; fileRef = 39F995DE20F55B8A0034F977 /* worker_thread_tests.cpp */; }; 3917FA67211E010400937DF4 /* bwt_tests.cpp in Sources */ = {isa = PBXBuildFile; fileRef = 39BC707520F55B6700A6EC20 /* bwt_tests.cpp */; }; 3917FA68211E010400937DF4 /* clustering_map_tests.cpp in Sources */ = {isa = PBXBuildFile; fileRef = 39BC707420F55B6700A6EC20 /* clustering_map_tests.cpp */; }; 3917FA69211E010400937DF4 /* fifo_cache_test.cpp in Sources */ = {isa = PBXBuildFile; fileRef = 564BB446206E8A4D00BDD211 /* fifo_cache_test.cpp */; }; @@ -143,8 +142,12 @@ 67A609AF1C88642E001E641A /* deferred_task.hpp in Headers */ = {isa = PBXBuildFile; fileRef = 67A609AD1C88642E001E641A /* deferred_task.hpp */; }; 67B52B601AD3C84E00664C17 /* thread_checker.cpp in Sources */ = {isa = PBXBuildFile; fileRef = 67B52B5E1AD3C84E00664C17 /* thread_checker.cpp */; }; 67B52B611AD3C84E00664C17 /* thread_checker.hpp in Headers */ = {isa = PBXBuildFile; fileRef = 67B52B5F1AD3C84E00664C17 /* thread_checker.hpp */; }; - F6F8E3C81EF846CE00F2DE8F /* worker_thread.cpp in Sources */ = {isa = PBXBuildFile; fileRef = F6F8E3C61EF846CE00F2DE8F /* worker_thread.cpp */; }; - F6F8E3C91EF846CE00F2DE8F /* worker_thread.hpp in Headers */ = {isa = PBXBuildFile; fileRef = F6F8E3C71EF846CE00F2DE8F /* worker_thread.hpp */; }; + E1B7FFC121FA19FE00F094DC /* thread_pool_computational.hpp in Headers */ = {isa = PBXBuildFile; fileRef = E1B7FFBD21FA19FD00F094DC /* thread_pool_computational.hpp */; }; + E1B7FFC221FA19FE00F094DC /* thread_pool_delayed.hpp in Headers */ = {isa = PBXBuildFile; fileRef = E1B7FFBE21FA19FD00F094DC /* thread_pool_delayed.hpp */; }; + E1B7FFC321FA19FE00F094DC /* thread_utils.hpp in Headers */ = {isa = PBXBuildFile; fileRef = E1B7FFBF21FA19FD00F094DC /* thread_utils.hpp */; }; + E1B7FFC421FA19FE00F094DC /* thread_pool_delayed.cpp in Sources */ = {isa = PBXBuildFile; fileRef = E1B7FFC021FA19FE00F094DC /* thread_pool_delayed.cpp */; }; + E1B7FFC721FA1A2200F094DC /* thread_pool_computational_tests.cpp in Sources */ = {isa = PBXBuildFile; fileRef = E1B7FFC521FA1A2100F094DC /* thread_pool_computational_tests.cpp */; }; + E1B7FFC821FA1A2200F094DC /* thread_pool_delayed_tests.cpp in Sources */ = {isa = PBXBuildFile; fileRef = E1B7FFC621FA1A2200F094DC /* thread_pool_delayed_tests.cpp */; }; /* End PBXBuildFile section */ /* Begin PBXFileReference section */ @@ -174,7 +177,6 @@ 39BC707520F55B6700A6EC20 /* bwt_tests.cpp */ = {isa = PBXFileReference; fileEncoding = 4; lastKnownFileType = sourcecode.cpp.cpp; path = bwt_tests.cpp; sourceTree = ""; }; 39F1E52E21C961A800D961DC /* beam.hpp */ = {isa = PBXFileReference; fileEncoding = 4; lastKnownFileType = sourcecode.cpp.h; path = beam.hpp; sourceTree = ""; }; 39F1E53021C961B800D961DC /* beam_tests.cpp */ = {isa = PBXFileReference; fileEncoding = 4; lastKnownFileType = sourcecode.cpp.cpp; path = beam_tests.cpp; sourceTree = ""; }; - 39F995DE20F55B8A0034F977 /* worker_thread_tests.cpp */ = {isa = PBXFileReference; fileEncoding = 4; lastKnownFileType = sourcecode.cpp.cpp; path = worker_thread_tests.cpp; sourceTree = ""; }; 39F995DF20F55B8A0034F977 /* move_to_front_tests.cpp */ = {isa = PBXFileReference; fileEncoding = 4; lastKnownFileType = sourcecode.cpp.cpp; path = move_to_front_tests.cpp; sourceTree = ""; }; 39F995E120F55B8A0034F977 /* suffix_array_tests.cpp */ = {isa = PBXFileReference; fileEncoding = 4; lastKnownFileType = sourcecode.cpp.cpp; path = suffix_array_tests.cpp; sourceTree = ""; }; 39F995E220F55B8A0034F977 /* visitor_tests.cpp */ = {isa = PBXFileReference; fileEncoding = 4; lastKnownFileType = sourcecode.cpp.cpp; path = visitor_tests.cpp; sourceTree = ""; }; @@ -292,8 +294,12 @@ 67B52B5F1AD3C84E00664C17 /* thread_checker.hpp */ = {isa = PBXFileReference; fileEncoding = 4; lastKnownFileType = sourcecode.cpp.h; path = thread_checker.hpp; sourceTree = ""; }; 67C79B9E1E2929DB00C40034 /* checked_cast.hpp */ = {isa = PBXFileReference; lastKnownFileType = sourcecode.cpp.h; path = checked_cast.hpp; sourceTree = ""; }; 67E40EC71E4DC0D500A6D200 /* small_set_test.cpp */ = {isa = PBXFileReference; fileEncoding = 4; lastKnownFileType = sourcecode.cpp.cpp; path = small_set_test.cpp; sourceTree = ""; }; - F6F8E3C61EF846CE00F2DE8F /* worker_thread.cpp */ = {isa = PBXFileReference; fileEncoding = 4; lastKnownFileType = sourcecode.cpp.cpp; path = worker_thread.cpp; sourceTree = ""; }; - F6F8E3C71EF846CE00F2DE8F /* worker_thread.hpp */ = {isa = PBXFileReference; fileEncoding = 4; lastKnownFileType = sourcecode.cpp.h; path = worker_thread.hpp; sourceTree = ""; }; + E1B7FFBD21FA19FD00F094DC /* thread_pool_computational.hpp */ = {isa = PBXFileReference; fileEncoding = 4; lastKnownFileType = sourcecode.cpp.h; path = thread_pool_computational.hpp; sourceTree = ""; }; + E1B7FFBE21FA19FD00F094DC /* thread_pool_delayed.hpp */ = {isa = PBXFileReference; fileEncoding = 4; lastKnownFileType = sourcecode.cpp.h; path = thread_pool_delayed.hpp; sourceTree = ""; }; + E1B7FFBF21FA19FD00F094DC /* thread_utils.hpp */ = {isa = PBXFileReference; fileEncoding = 4; lastKnownFileType = sourcecode.cpp.h; path = thread_utils.hpp; sourceTree = ""; }; + E1B7FFC021FA19FE00F094DC /* thread_pool_delayed.cpp */ = {isa = PBXFileReference; fileEncoding = 4; lastKnownFileType = sourcecode.cpp.cpp; path = thread_pool_delayed.cpp; sourceTree = ""; }; + E1B7FFC521FA1A2100F094DC /* thread_pool_computational_tests.cpp */ = {isa = PBXFileReference; fileEncoding = 4; lastKnownFileType = sourcecode.cpp.cpp; path = thread_pool_computational_tests.cpp; sourceTree = ""; }; + E1B7FFC621FA1A2200F094DC /* thread_pool_delayed_tests.cpp */ = {isa = PBXFileReference; fileEncoding = 4; lastKnownFileType = sourcecode.cpp.cpp; path = thread_pool_delayed_tests.cpp; sourceTree = ""; }; /* End PBXFileReference section */ /* Begin PBXFrameworksBuildPhase section */ @@ -318,13 +324,14 @@ 39FD26C71CC659D200AFF551 /* base_tests */ = { isa = PBXGroup; children = ( + E1B7FFC521FA1A2100F094DC /* thread_pool_computational_tests.cpp */, + E1B7FFC621FA1A2200F094DC /* thread_pool_delayed_tests.cpp */, 39F1E53021C961B800D961DC /* beam_tests.cpp */, 395FEB3321492F320036395C /* stl_helpers_tests.cpp */, 3917FA60211E00F100937DF4 /* geo_object_id_tests.cpp */, 39F995DF20F55B8A0034F977 /* move_to_front_tests.cpp */, 39F995E120F55B8A0034F977 /* suffix_array_tests.cpp */, 39F995E220F55B8A0034F977 /* visitor_tests.cpp */, - 39F995DE20F55B8A0034F977 /* worker_thread_tests.cpp */, 39BC707520F55B6700A6EC20 /* bwt_tests.cpp */, 39BC707420F55B6700A6EC20 /* clustering_map_tests.cpp */, 564BB446206E8A4D00BDD211 /* fifo_cache_test.cpp */, @@ -388,6 +395,10 @@ 675341791A3F57BF00A0A8C3 /* base */ = { isa = PBXGroup; children = ( + E1B7FFBD21FA19FD00F094DC /* thread_pool_computational.hpp */, + E1B7FFC021FA19FE00F094DC /* thread_pool_delayed.cpp */, + E1B7FFBE21FA19FD00F094DC /* thread_pool_delayed.hpp */, + E1B7FFBF21FA19FD00F094DC /* thread_utils.hpp */, 39F1E52E21C961A800D961DC /* beam.hpp */, 3D1BE645212D775500ACD94A /* atomic_shared_ptr.hpp */, 3917FA5E211E00C300937DF4 /* suffix_array.hpp */, @@ -482,8 +493,6 @@ 3D3731FD1F9A445500D2121B /* url_helpers.hpp */, 3D74EF0C1F8B902B0081202C /* visitor.hpp */, 3D78157A1F3D89EC0068B6AC /* waiter.hpp */, - F6F8E3C61EF846CE00F2DE8F /* worker_thread.cpp */, - F6F8E3C71EF846CE00F2DE8F /* worker_thread.hpp */, ); name = base; path = ../../base; @@ -545,6 +554,7 @@ 3917FA5F211E00C400937DF4 /* suffix_array.hpp in Headers */, 3917FA53211E008C00937DF4 /* clustering_map.hpp in Headers */, 3D3731FF1F9A445500D2121B /* url_helpers.hpp in Headers */, + E1B7FFC121FA19FE00F094DC /* thread_pool_computational.hpp in Headers */, 675342071A3F57E400A0A8C3 /* thread_pool.hpp in Headers */, 3446C6711DDCA96300146687 /* dfa_helpers.hpp in Headers */, 6753420C1A3F57E400A0A8C3 /* threaded_list.hpp in Headers */, @@ -568,19 +578,20 @@ 3D74EF151F8B902C0081202C /* bwt.hpp in Headers */, 675341F71A3F57E400A0A8C3 /* shared_buffer_manager.hpp in Headers */, 56B1A0761E69DE4D00395022 /* small_set.hpp in Headers */, + E1B7FFC221FA19FE00F094DC /* thread_pool_delayed.hpp in Headers */, 67B52B611AD3C84E00664C17 /* thread_checker.hpp in Headers */, 3917FA5D211E00BB00937DF4 /* pprof.hpp in Headers */, 672DD4BE1E0425600078E13C /* cancellable.hpp in Headers */, 675341CB1A3F57E400A0A8C3 /* array_adapters.hpp in Headers */, 3446C6751DDCA96300146687 /* uni_string_dfa.hpp in Headers */, 6753420B1A3F57E400A0A8C3 /* threaded_container.hpp in Headers */, + E1B7FFC321FA19FE00F094DC /* thread_utils.hpp in Headers */, 672DD4C21E0425600078E13C /* condition.hpp in Headers */, 672DD4C41E0425600078E13C /* newtype.hpp in Headers */, 564BB445206E89ED00BDD211 /* fifo_cache.hpp in Headers */, 672DD4C31E0425600078E13C /* mem_trie.hpp in Headers */, 672DD4C61E0425600078E13C /* range_iterator.hpp in Headers */, 3917FA58211E009700937DF4 /* geo_object_id.hpp in Headers */, - F6F8E3C91EF846CE00F2DE8F /* worker_thread.hpp in Headers */, ); runOnlyForDeploymentPostprocessing = 0; }; @@ -683,7 +694,6 @@ 3917FA68211E010400937DF4 /* clustering_map_tests.cpp in Sources */, 3917FA65211E010400937DF4 /* visitor_tests.cpp in Sources */, 39F1E53121C961B800D961DC /* beam_tests.cpp in Sources */, - 3917FA66211E010400937DF4 /* worker_thread_tests.cpp in Sources */, 3917FA6A211E010400937DF4 /* control_flow_tests.cpp in Sources */, 39FD27321CC65AD000AFF551 /* string_format_test.cpp in Sources */, 39FD272A1CC65AD000AFF551 /* mem_trie_test.cpp in Sources */, @@ -725,15 +735,16 @@ 3446C6721DDCA96300146687 /* levenshtein_dfa.cpp in Sources */, 6753453D1A3F6F6A00A0A8C3 /* message.cpp in Sources */, 675342081A3F57E400A0A8C3 /* thread.cpp in Sources */, + E1B7FFC821FA1A2200F094DC /* thread_pool_delayed_tests.cpp in Sources */, 675342061A3F57E400A0A8C3 /* thread_pool.cpp in Sources */, 670E39441C46C76900E9C0A6 /* sunrise_sunset.cpp in Sources */, + E1B7FFC721FA1A2200F094DC /* thread_pool_computational_tests.cpp in Sources */, 6753420E1A3F57E400A0A8C3 /* timer.cpp in Sources */, 675341F61A3F57E400A0A8C3 /* shared_buffer_manager.cpp in Sources */, 56B1A0741E69DE4D00395022 /* random.cpp in Sources */, 675341DA1A3F57E400A0A8C3 /* exception.cpp in Sources */, 3D74EF111F8B902C0081202C /* suffix_array.cpp in Sources */, 3917FA57211E009700937DF4 /* geo_object_id.cpp in Sources */, - F6F8E3C81EF846CE00F2DE8F /* worker_thread.cpp in Sources */, 3D3731FE1F9A445500D2121B /* url_helpers.cpp in Sources */, 675341F91A3F57E400A0A8C3 /* src_point.cpp in Sources */, 675342031A3F57E400A0A8C3 /* strings_bundle.cpp in Sources */, @@ -742,6 +753,7 @@ 675341CD1A3F57E400A0A8C3 /* base.cpp in Sources */, 675342011A3F57E400A0A8C3 /* string_utils.cpp in Sources */, 674A7E2E1C0DB03D003D48E1 /* timegm.cpp in Sources */, + E1B7FFC421FA19FE00F094DC /* thread_pool_delayed.cpp in Sources */, 6753420A1A3F57E400A0A8C3 /* threaded_container.cpp in Sources */, 3917FA5C211E00BB00937DF4 /* pprof.cpp in Sources */, 675341FF1A3F57E400A0A8C3 /* string_format.cpp in Sources */,