123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341 |
- /* -*- Mode: C++; tab-width: 2; indent-tabs-mode: nil; c-basic-offset: 2 -*- */
- /* This Source Code Form is subject to the terms of the Mozilla Public
- * License, v. 2.0. If a copy of the MPL was not distributed with this
- * file, You can obtain one at http://mozilla.org/MPL/2.0/. */
- #include "DecodePool.h"
- #include <algorithm>
- #include "mozilla/ClearOnShutdown.h"
- #include "mozilla/Monitor.h"
- #include "nsCOMPtr.h"
- #include "nsIObserverService.h"
- #include "nsIThreadPool.h"
- #include "nsThreadManager.h"
- #include "nsThreadUtils.h"
- #include "nsXPCOMCIDInternal.h"
- #include "prsystem.h"
- #include "gfxPrefs.h"
- #include "Decoder.h"
- #include "IDecodingTask.h"
- #include "RasterImage.h"
- using std::max;
- using std::min;
- namespace mozilla {
- namespace image {
- ///////////////////////////////////////////////////////////////////////////////
- // DecodePool implementation.
- ///////////////////////////////////////////////////////////////////////////////
- /* static */ StaticRefPtr<DecodePool> DecodePool::sSingleton;
- /* static */ uint32_t DecodePool::sNumCores = 0;
- NS_IMPL_ISUPPORTS(DecodePool, nsIObserver)
- struct Work
- {
- enum class Type {
- TASK,
- SHUTDOWN
- } mType;
- RefPtr<IDecodingTask> mTask;
- };
- class DecodePoolImpl
- {
- public:
- MOZ_DECLARE_REFCOUNTED_TYPENAME(DecodePoolImpl)
- NS_INLINE_DECL_THREADSAFE_REFCOUNTING(DecodePoolImpl)
- DecodePoolImpl()
- : mMonitor("DecodePoolImpl")
- , mShuttingDown(false)
- { }
- /// Initialize the current thread for use by the decode pool.
- void InitCurrentThread()
- {
- MOZ_ASSERT(!NS_IsMainThread());
- mThreadNaming.SetThreadPoolName(NS_LITERAL_CSTRING("ImgDecoder"));
- }
- /// Shut down the provided decode pool thread.
- static void ShutdownThread(nsIThread* aThisThread)
- {
- // Threads have to be shut down from another thread, so we'll ask the
- // main thread to do it for us.
- NS_DispatchToMainThread(NewRunnableMethod(aThisThread, &nsIThread::Shutdown));
- }
- /**
- * Requests shutdown. New work items will be dropped on the floor, and all
- * decode pool threads will be shut down once existing work items have been
- * processed.
- */
- void RequestShutdown()
- {
- MonitorAutoLock lock(mMonitor);
- mShuttingDown = true;
- mMonitor.NotifyAll();
- }
- /// Pushes a new decode work item.
- void PushWork(IDecodingTask* aTask)
- {
- MOZ_ASSERT(aTask);
- RefPtr<IDecodingTask> task(aTask);
- MonitorAutoLock lock(mMonitor);
- if (mShuttingDown) {
- // Drop any new work on the floor if we're shutting down.
- return;
- }
- if (task->Priority() == TaskPriority::eHigh) {
- mHighPriorityQueue.AppendElement(Move(task));
- } else {
- mLowPriorityQueue.AppendElement(Move(task));
- }
- mMonitor.Notify();
- }
- /// Pops a new work item, blocking if necessary.
- Work PopWork()
- {
- MonitorAutoLock lock(mMonitor);
- do {
- if (!mHighPriorityQueue.IsEmpty()) {
- return PopWorkFromQueue(mHighPriorityQueue);
- }
- if (!mLowPriorityQueue.IsEmpty()) {
- return PopWorkFromQueue(mLowPriorityQueue);
- }
- if (mShuttingDown) {
- Work work;
- work.mType = Work::Type::SHUTDOWN;
- return work;
- }
- // Nothing to do; block until some work is available.
- mMonitor.Wait();
- } while (true);
- }
- private:
- ~DecodePoolImpl() { }
- Work PopWorkFromQueue(nsTArray<RefPtr<IDecodingTask>>& aQueue)
- {
- Work work;
- work.mType = Work::Type::TASK;
- work.mTask = aQueue.LastElement().forget();
- aQueue.RemoveElementAt(aQueue.Length() - 1);
- return work;
- }
- nsThreadPoolNaming mThreadNaming;
- // mMonitor guards the queues and mShuttingDown.
- Monitor mMonitor;
- nsTArray<RefPtr<IDecodingTask>> mHighPriorityQueue;
- nsTArray<RefPtr<IDecodingTask>> mLowPriorityQueue;
- bool mShuttingDown;
- };
- class DecodePoolWorker : public Runnable
- {
- public:
- explicit DecodePoolWorker(DecodePoolImpl* aImpl) : mImpl(aImpl) { }
- NS_IMETHOD Run() override
- {
- MOZ_ASSERT(!NS_IsMainThread());
- mImpl->InitCurrentThread();
- nsCOMPtr<nsIThread> thisThread;
- nsThreadManager::get().GetCurrentThread(getter_AddRefs(thisThread));
- do {
- Work work = mImpl->PopWork();
- switch (work.mType) {
- case Work::Type::TASK:
- work.mTask->Run();
- break;
- case Work::Type::SHUTDOWN:
- DecodePoolImpl::ShutdownThread(thisThread);
- return NS_OK;
- default:
- MOZ_ASSERT_UNREACHABLE("Unknown work type");
- }
- } while (true);
- MOZ_ASSERT_UNREACHABLE("Exiting thread without Work::Type::SHUTDOWN");
- return NS_OK;
- }
- private:
- RefPtr<DecodePoolImpl> mImpl;
- };
- /* static */ void
- DecodePool::Initialize()
- {
- MOZ_ASSERT(NS_IsMainThread());
- sNumCores = max<int32_t>(PR_GetNumberOfProcessors(), 1);
- DecodePool::Singleton();
- }
- /* static */ DecodePool*
- DecodePool::Singleton()
- {
- if (!sSingleton) {
- MOZ_ASSERT(NS_IsMainThread());
- sSingleton = new DecodePool();
- ClearOnShutdown(&sSingleton);
- }
- return sSingleton;
- }
- /* static */ uint32_t
- DecodePool::NumberOfCores()
- {
- return sNumCores;
- }
- DecodePool::DecodePool()
- : mImpl(new DecodePoolImpl)
- , mMutex("image::DecodePool")
- {
- // Determine the number of threads we want.
- int32_t prefLimit = gfxPrefs::ImageMTDecodingLimit();
- uint32_t limit;
- if (prefLimit <= 0) {
- int32_t numCores = NumberOfCores();
- if (numCores <= 1) {
- limit = 1;
- } else if (numCores == 2) {
- // On an otherwise mostly idle system, having two image decoding threads
- // doubles decoding performance, so it's worth doing on dual-core devices,
- // even if under load we can't actually get that level of parallelism.
- limit = 2;
- } else {
- limit = numCores - 1;
- }
- } else {
- limit = static_cast<uint32_t>(prefLimit);
- }
- if (limit > 32) {
- limit = 32;
- }
- // Initialize the thread pool.
- for (uint32_t i = 0 ; i < limit ; ++i) {
- nsCOMPtr<nsIRunnable> worker = new DecodePoolWorker(mImpl);
- nsCOMPtr<nsIThread> thread;
- nsresult rv = NS_NewThread(getter_AddRefs(thread), worker);
- MOZ_RELEASE_ASSERT(NS_SUCCEEDED(rv) && thread,
- "Should successfully create image decoding threads");
- mThreads.AppendElement(Move(thread));
- }
- // Initialize the I/O thread.
- nsresult rv = NS_NewNamedThread("ImageIO", getter_AddRefs(mIOThread));
- MOZ_RELEASE_ASSERT(NS_SUCCEEDED(rv) && mIOThread,
- "Should successfully create image I/O thread");
- nsCOMPtr<nsIObserverService> obsSvc = services::GetObserverService();
- if (obsSvc) {
- obsSvc->AddObserver(this, "xpcom-shutdown-threads", false);
- }
- }
- DecodePool::~DecodePool()
- {
- MOZ_ASSERT(NS_IsMainThread(), "Must shut down DecodePool on main thread!");
- }
- NS_IMETHODIMP
- DecodePool::Observe(nsISupports*, const char* aTopic, const char16_t*)
- {
- MOZ_ASSERT(strcmp(aTopic, "xpcom-shutdown-threads") == 0, "Unexpected topic");
- nsTArray<nsCOMPtr<nsIThread>> threads;
- nsCOMPtr<nsIThread> ioThread;
- {
- MutexAutoLock lock(mMutex);
- threads.SwapElements(mThreads);
- ioThread.swap(mIOThread);
- }
- mImpl->RequestShutdown();
- for (uint32_t i = 0 ; i < threads.Length() ; ++i) {
- threads[i]->Shutdown();
- }
- if (ioThread) {
- ioThread->Shutdown();
- }
- return NS_OK;
- }
- void
- DecodePool::AsyncRun(IDecodingTask* aTask)
- {
- MOZ_ASSERT(aTask);
- mImpl->PushWork(aTask);
- }
- void
- DecodePool::SyncRunIfPreferred(IDecodingTask* aTask)
- {
- MOZ_ASSERT(NS_IsMainThread());
- MOZ_ASSERT(aTask);
- if (aTask->ShouldPreferSyncRun()) {
- aTask->Run();
- return;
- }
- AsyncRun(aTask);
- }
- void
- DecodePool::SyncRunIfPossible(IDecodingTask* aTask)
- {
- MOZ_ASSERT(NS_IsMainThread());
- MOZ_ASSERT(aTask);
- aTask->Run();
- }
- already_AddRefed<nsIEventTarget>
- DecodePool::GetIOEventTarget()
- {
- MutexAutoLock threadPoolLock(mMutex);
- nsCOMPtr<nsIEventTarget> target = do_QueryInterface(mIOThread);
- return target.forget();
- }
- } // namespace image
- } // namespace mozilla
|