/external/cronet/stable/base/task/thread_pool/ |
D | thread_pool_impl_unittest.cc | 288 : thread_pool_(std::make_unique<ThreadPoolImpl>("Test")), in ThreadPoolImplTestBase() 315 thread_pool_->Start(init_params, worker_thread_observer_.get()); in StartThreadPool() 322 if (thread_pool_) { in TearDown() 323 thread_pool_->FlushForTesting(); in TearDown() 324 thread_pool_->JoinForTesting(); in TearDown() 325 thread_pool_.reset(); in TearDown() 330 std::unique_ptr<ThreadPoolImpl> thread_pool_; member in base::internal::__anone67c5aec0111::ThreadPoolImplTestBase 392 thread_pool_->PostDelayedTask( in TEST_P() 407 thread_pool_->PostDelayedTask( in TEST_P() 449 CreateSequencedTaskRunnerAndExecutionMode(thread_pool_.get(), GetTraits(), in TEST_P() [all …]
|
/external/cronet/tot/base/task/thread_pool/ |
D | thread_pool_impl_unittest.cc | 288 : thread_pool_(std::make_unique<ThreadPoolImpl>("Test")), in ThreadPoolImplTestBase() 315 thread_pool_->Start(init_params, worker_thread_observer_.get()); in StartThreadPool() 322 if (thread_pool_) { in TearDown() 323 thread_pool_->FlushForTesting(); in TearDown() 324 thread_pool_->JoinForTesting(); in TearDown() 325 thread_pool_.reset(); in TearDown() 330 std::unique_ptr<ThreadPoolImpl> thread_pool_; member in base::internal::__anon7b9602880111::ThreadPoolImplTestBase 392 thread_pool_->PostDelayedTask( in TEST_P() 407 thread_pool_->PostDelayedTask( in TEST_P() 449 CreateSequencedTaskRunnerAndExecutionMode(thread_pool_.get(), GetTraits(), in TEST_P() [all …]
|
/external/libgav1/src/ |
D | threading_strategy.cc | 76 thread_pool_.reset(nullptr); in Reset() 86 if (thread_pool_ == nullptr || thread_pool_->num_threads() != thread_count) { in Reset() 87 thread_pool_ = ThreadPool::Create("libgav1", thread_count); in Reset() 88 if (thread_pool_ == nullptr) { in Reset() 164 if (thread_pool_ == nullptr || thread_pool_->num_threads() != thread_count) { in Reset() 165 thread_pool_ = ThreadPool::Create("libgav1-fp", thread_count); in Reset() 166 if (thread_pool_ == nullptr) { in Reset()
|
D | threading_strategy.h | 66 return (tile_thread_count_ != 0) ? thread_pool_.get() : nullptr; in tile_thread_pool() 74 ThreadPool* thread_pool() const { return thread_pool_.get(); } in thread_pool() 80 return tile_index < max_tile_index_for_row_threads_ ? thread_pool_.get() in row_thread_pool() 88 return frame_parallel_ ? nullptr : thread_pool_.get(); in post_filter_thread_pool() 94 ThreadPool* film_grain_thread_pool() const { return thread_pool_.get(); } in film_grain_thread_pool() 97 std::unique_ptr<ThreadPool> thread_pool_;
|
/external/rust/android-crates-io/crates/grpcio-sys/grpc/src/core/lib/event_engine/windows/ |
D | windows_engine.cc | 54 : thread_pool_(thread_pool), iocp_(iocp) { in IOCPWorkClosure() 55 thread_pool_->Run(this); in IOCPWorkClosure() 61 thread_pool_->Run(this); in Run() 66 thread_pool_->Run(this); in Run() 101 : thread_pool_( in WindowsEventEngine() 103 iocp_(thread_pool_.get()), in WindowsEventEngine() 104 timer_manager_(thread_pool_), in WindowsEventEngine() 105 iocp_worker_(thread_pool_.get(), &iocp_) { in WindowsEventEngine() 145 thread_pool_->Quiesce(); in ~WindowsEventEngine() 172 thread_pool_->Run(std::move(closure)); in Run() [all …]
|
D | windows_endpoint.cc | 58 thread_pool_(thread_pool), in WindowsEndpoint() 104 thread_pool_->Run(&io_state_->handle_read_event); in DoTcpRead() 130 thread_pool_->Run([on_read = std::move(on_read)]() mutable { in Read() 147 io_state_->endpoint->thread_pool_->Run([this, status]() { in Read() 158 thread_pool_->Run([on_writable = std::move(on_writable)]() mutable { in Write() 186 thread_pool_->Run( in Write() 207 thread_pool_->Run([cb = std::move(on_writable), wsa_error]() mutable { in Write() 221 thread_pool_->Run([cb = std::move(on_writable), wsa_error]() mutable { in Write() 323 io_state_->endpoint->thread_pool_->Run( in MaybeFinishIfDataHasAlreadyBeenRead()
|
D | win_socket.cc | 43 thread_pool_(thread_pool), in WinSocket() 93 thread_pool_->Run(closure); in NotifyOnReady() 97 thread_pool_->Run(closure); in NotifyOnReady() 123 win_socket_->thread_pool_->Run(closure); in SetReady()
|
D | windows_engine.h | 95 ThreadPool* thread_pool() { return thread_pool_.get(); } in thread_pool() 126 ThreadPool* thread_pool_; variable 153 std::shared_ptr<ThreadPool> thread_pool_; variable
|
/external/grpc-grpc/test/core/event_engine/windows/ |
D | win_socket_test.cc | 45 : thread_pool_(grpc_event_engine::experimental::MakeThreadPool(8)) { in WinSocketTest() 48 std::make_unique<WinSocket>(sockpair_[0], thread_pool_.get()); in WinSocketTest() 50 std::make_unique<WinSocket>(sockpair_[1], thread_pool_.get()); in WinSocketTest() 56 thread_pool_->Quiesce(); in ~WinSocketTest() 60 std::shared_ptr<ThreadPool> thread_pool_; member in WinSocketTest
|
/external/grpc-grpc/src/core/lib/event_engine/windows/ |
D | windows_engine.cc | 63 : thread_pool_(thread_pool), iocp_(iocp) { in IOCPWorkClosure() 64 thread_pool_->Run(this); in IOCPWorkClosure() 70 thread_pool_->Run(this); in Run() 75 thread_pool_->Run(this); in Run() 110 : thread_pool_( in WindowsEventEngine() 112 iocp_(thread_pool_.get()), in WindowsEventEngine() 113 timer_manager_(thread_pool_), in WindowsEventEngine() 114 iocp_worker_(thread_pool_.get(), &iocp_) { in WindowsEventEngine() 154 thread_pool_->Quiesce(); in ~WindowsEventEngine() 181 thread_pool_->Run(std::move(closure)); in Run() [all …]
|
/external/grpc-grpc/src/core/lib/event_engine/posix_engine/ |
D | timer_manager.cc | 44 thread_pool_->Run(timer); in RunSomeTimers() 78 thread_pool_->Run([this, next, timers_found]() { in MainLoop() 91 : host_(this), thread_pool_(std::move(thread_pool)) { in TimerManager() 94 thread_pool_->Run([this]() { MainLoop(); }); in TimerManager() 155 thread_pool_->Run([this]() { MainLoop(); }); in RestartPostFork()
|
/external/tensorflow/tensorflow/core/tfrt/eager/ |
D | tfrt_context.h | 46 : thread_pool_{thread_pool} { in ThreadPoolInterfaceWrapper() 68 DCHECK(thread_pool_); in thread_pool() 69 return *thread_pool_; in thread_pool() 73 Eigen::ThreadPoolInterface* thread_pool_ = nullptr; variable
|
/external/libgav1/src/post_filter/ |
D | cdef.cc | 177 (thread_pool_ == nullptr) in PrepareCdefBlock() 200 (thread_pool_ == nullptr) ? src_buffer : cdef_border; in PrepareCdefBlock() 202 (thread_pool_ == nullptr) ? src_stride : cdef_border_stride; in PrepareCdefBlock() 222 (thread_pool_ == nullptr || is_frame_bottom) ? 0 : kCdefBorder; in PrepareCdefBlock() 224 (thread_pool_ == nullptr || !use_border_columns) in PrepareCdefBlock() 264 (thread_pool_ == nullptr) ? src_buffer : cdef_border; in PrepareCdefBlock() 266 (thread_pool_ == nullptr) ? src_stride : cdef_border_stride; in PrepareCdefBlock() 327 if (thread_pool_ == nullptr) { in ApplyCdefForOneUnit() 344 if (!is_frame_right && thread_pool_ != nullptr) { in ApplyCdefForOneUnit() 395 if (thread_pool_ == nullptr) { in ApplyCdefForOneUnit() [all …]
|
/external/federated-compute/fcp/client/ |
D | interruptible_runner.h | 67 thread_pool_ = fcp::CreateThreadPoolScheduler(1); in InterruptibleRunner() 70 ~InterruptibleRunner() { thread_pool_->WaitUntilIdle(); } in ~InterruptibleRunner() 84 std::unique_ptr<Scheduler> thread_pool_; variable
|
/external/rust/android-crates-io/crates/grpcio-sys/grpc/src/core/lib/event_engine/cf_engine/ |
D | cf_engine.cc | 54 : thread_pool_( in CFEventEngine() 56 timer_manager_(thread_pool_) {} in CFEventEngine() 71 thread_pool_->Quiesce(); in ~CFEventEngine() 164 thread_pool_->Run(closure); in Run() 168 thread_pool_->Run(std::move(closure)); in Run()
|
/external/grpc-grpc/src/core/lib/event_engine/cf_engine/ |
D | cf_engine.cc | 57 : thread_pool_( in CFEventEngine() 59 timer_manager_(thread_pool_) {} in CFEventEngine() 74 thread_pool_->Quiesce(); in ~CFEventEngine() 173 thread_pool_->Run(closure); in Run() 177 thread_pool_->Run(std::move(closure)); in Run()
|
/external/tensorflow/tensorflow/core/grappler/clusters/ |
D | single_machine.cc | 45 thread_pool_.reset(new thread::ThreadPool( in SingleMachine() 68 thread_pool_.reset(); in ~SingleMachine() 265 timeout_s * 1000, thread_pool_.get()); in RunWithTimeout() 276 if (!session_ || !thread_pool_) { in CloseSession() 308 use_timeout ? timeout_s_ * 1000 : -1, thread_pool_.get()); in CloseSession() 331 thread_pool_.reset(); in ShutdownSession() 361 thread_pool_.reset(new thread::ThreadPool( in ResetSession()
|
/external/cronet/stable/base/test/ |
D | task_environment.cc | 225 if (thread_pool_) { in AdvanceClock() 226 thread_pool_->ProcessRipeDelayedTasksForTesting(); in AdvanceClock() 237 if (thread_pool_) { in SuspendedAdvanceClock() 238 thread_pool_->ProcessRipeDelayedTasksForTesting(); in SuspendedAdvanceClock() 244 DCHECK(!thread_pool_); in SetThreadPool() 246 thread_pool_ = thread_pool; in SetThreadPool() 319 if (thread_pool_ && thread_pool_task_tracker_->TasksAllowedToRun()) { in FastForwardToNextTaskOrCap() 321 thread_pool_->NextScheduledRunTimeForTesting(); in FastForwardToNextTaskOrCap() 357 thread_pool_->ProcessRipeDelayedTasksForTesting(); in FastForwardToNextTaskOrCap() 373 thread_pool_->FlushAsyncForTesting(BindOnce( in FastForwardToNextTaskOrCap() [all …]
|
/external/cronet/tot/base/test/ |
D | task_environment.cc | 225 if (thread_pool_) { in AdvanceClock() 226 thread_pool_->ProcessRipeDelayedTasksForTesting(); in AdvanceClock() 237 if (thread_pool_) { in SuspendedAdvanceClock() 238 thread_pool_->ProcessRipeDelayedTasksForTesting(); in SuspendedAdvanceClock() 244 DCHECK(!thread_pool_); in SetThreadPool() 246 thread_pool_ = thread_pool; in SetThreadPool() 319 if (thread_pool_ && thread_pool_task_tracker_->TasksAllowedToRun()) { in FastForwardToNextTaskOrCap() 321 thread_pool_->NextScheduledRunTimeForTesting(); in FastForwardToNextTaskOrCap() 357 thread_pool_->ProcessRipeDelayedTasksForTesting(); in FastForwardToNextTaskOrCap() 373 thread_pool_->FlushAsyncForTesting(BindOnce( in FastForwardToNextTaskOrCap() [all …]
|
/external/tensorflow/tensorflow/cc/training/ |
D | coordinator_test.cc | 61 thread_pool_.reset(new thread::ThreadPool(Env::Default(), "test-pool", 10)); in MockQueueRunner() 72 thread_pool_->Schedule( in StartCounting() 78 thread_pool_->Schedule(std::bind(&MockQueueRunner::SetStatusThread, this, in StartSettingStatus() 86 thread_pool_.reset(); in Join() 113 std::unique_ptr<thread::ThreadPool> thread_pool_; member in tensorflow::__anonf00792e20111::MockQueueRunner
|
D | queue_runner.cc | 76 thread_pool_.reset(new thread::ThreadPool( in Init() 99 thread_pool_->Schedule( in Start() 103 thread_pool_->Schedule(std::bind(&QueueRunner::Stop, this, sess)); in Start() 140 thread_pool_.reset(); in Join()
|
/external/grpc-grpc/src/cpp/server/ |
D | secure_server_credentials.h | 44 thread_pool_.reset(CreateDefaultThreadPool()); in AuthMetadataProcessorAsyncWrapper() 52 std::unique_ptr<ThreadPoolInterface> thread_pool_; variable
|
/external/tensorflow/tensorflow/tsl/platform/default/ |
D | unbounded_work_queue.cc | 51 thread_pool_.clear(); in ~UnboundedWorkQueue() 71 thread_pool_.emplace_back(new_thread); in Schedule()
|
/external/tensorflow/tensorflow/core/kernels/data/experimental/ |
D | threadpool_dataset_op.cc | 63 : thread_pool_(env, thread_options, name, num_threads, low_latency_hint), in ThreadPoolResource() 69 thread_pool_.Schedule(std::move(fn)); in Schedule() 71 thread_pool_.Schedule(std::bind( in Schedule() 82 int32 NumThreads() { return thread_pool_.NumThreads(); } in NumThreads() 87 thread::ThreadPool thread_pool_; member in tensorflow::data::experimental::ThreadPoolResource 438 thread_pool_ = std::make_unique<thread::ThreadPool>( 500 thread::ThreadPool* pool = dataset()->thread_pool_.get(); in GetNextInternal() 540 std::unique_ptr<thread::ThreadPool> thread_pool_; member in tensorflow::data::experimental::PrivateThreadPoolDatasetOp::Dataset
|
/external/rust/android-crates-io/crates/grpcio-sys/grpc/src/cpp/server/ |
D | secure_server_credentials.h | 50 thread_pool_.reset(CreateDefaultThreadPool()); in AuthMetadataProcessorAyncWrapper() 58 std::unique_ptr<ThreadPoolInterface> thread_pool_; variable
|