/aosp_15_r20/hardware/interfaces/audio/aidl/common/tests/ |
H A D | streamworker_tests.cpp | 41 // Use nullptr to test error reporting from the worker thread. 77 worker.stop(); in TearDown() 83 : testing::TestWithParam<bool>(), worker(stream) {} in StreamWorkerInvalidTest() 84 TestWorker worker; member in StreamWorkerInvalidTest 88 EXPECT_FALSE(worker.hasWorkerCycleCalled()); in TEST_P() 89 EXPECT_FALSE(worker.hasError()); in TEST_P() 90 EXPECT_LE(worker.getTid(), 0); in TEST_P() 94 EXPECT_FALSE(worker.hasError()); in TEST_P() 95 worker.pause(); in TEST_P() 96 EXPECT_FALSE(worker.hasError()); in TEST_P() [all …]
|
/aosp_15_r20/external/libvpx/vpx_util/ |
H A D | vpx_thread.c | 10 // Multi-threaded worker 38 static void execute(VPxWorker *const worker); // Forward declaration. 41 VPxWorker *const worker = (VPxWorker *)ptr; in thread_loop() local 43 if (worker->thread_name != NULL) { in thread_loop() 50 strncpy(thread_name, worker->thread_name, sizeof(thread_name) - 1); in thread_loop() 55 if (worker->thread_name != NULL) { in thread_loop() 59 strncpy(thread_name, worker->thread_name, sizeof(thread_name) - 1); in thread_loop() 64 pthread_mutex_lock(&worker->impl_->mutex_); in thread_loop() 66 while (worker->status_ == VPX_WORKER_STATUS_OK) { // wait in idling mode in thread_loop() 67 pthread_cond_wait(&worker->impl_->condition_, &worker->impl_->mutex_); in thread_loop() [all …]
|
/aosp_15_r20/external/libaom/aom_util/ |
H A D | aom_thread.c | 12 // Multi-threaded worker 43 static void execute(AVxWorker *const worker); // Forward declaration. 46 AVxWorker *const worker = (AVxWorker *)ptr; in thread_loop() local 48 if (worker->thread_name != NULL) { in thread_loop() 55 strncpy(thread_name, worker->thread_name, sizeof(thread_name) - 1); in thread_loop() 60 if (worker->thread_name != NULL) { in thread_loop() 64 strncpy(thread_name, worker->thread_name, sizeof(thread_name) - 1); in thread_loop() 69 pthread_mutex_lock(&worker->impl_->mutex_); in thread_loop() 71 while (worker->status_ == AVX_WORKER_STATUS_OK) { // wait in idling mode in thread_loop() 72 pthread_cond_wait(&worker->impl_->condition_, &worker->impl_->mutex_); in thread_loop() [all …]
|
/aosp_15_r20/hardware/interfaces/audio/core/all-versions/vts/functional/tests/ |
H A D | streamworker_tests.cpp | 33 // Use nullptr to test error reporting from the worker thread. 63 worker.stop(); in TearDown() 68 StreamWorkerInvalidTest(TestStream* stream) : testing::TestWithParam<bool>(), worker(stream) {} in StreamWorkerInvalidTest() 69 TestWorker worker; member in StreamWorkerInvalidTest 73 EXPECT_FALSE(worker.hasWorkerCycleCalled()); in TEST_P() 74 EXPECT_FALSE(worker.hasError()); in TEST_P() 78 EXPECT_FALSE(worker.hasError()); in TEST_P() 79 worker.pause(); in TEST_P() 80 EXPECT_FALSE(worker.hasError()); in TEST_P() 84 EXPECT_FALSE(worker.hasError()); in TEST_P() [all …]
|
/aosp_15_r20/external/tensorflow/tensorflow/core/data/service/ |
H A D | auto_shard_rewriter_test.cc | 218 "/worker/task/0", "/worker/task/1", "/worker/task/2"}); in TEST() 219 TF_EXPECT_OK(resolver.ValidateWorker("/worker/task/2:12345")); in TEST() 220 TF_EXPECT_OK(resolver.ValidateWorker("/worker/task/1:23456")); in TEST() 221 TF_EXPECT_OK(resolver.ValidateWorker("/worker/task/0:34567")); in TEST() 222 resolver.AddWorker("/worker/task/2:12345"); in TEST() 223 resolver.AddWorker("/worker/task/1:23456"); in TEST() 224 resolver.AddWorker("/worker/task/0:34567"); in TEST() 225 EXPECT_THAT(resolver.GetWorkerIndex("/worker/task/0:34567"), IsOkAndHolds(0)); in TEST() 226 EXPECT_THAT(resolver.GetWorkerIndex("/worker/task/1:23456"), IsOkAndHolds(1)); in TEST() 227 EXPECT_THAT(resolver.GetWorkerIndex("/worker/task/2:12345"), IsOkAndHolds(2)); in TEST() [all …]
|
/aosp_15_r20/external/rust/android-crates-io/crates/tokio/src/runtime/metrics/ |
D | runtime.rs | 28 /// Returns the number of worker threads used by the runtime. 157 /// Returns the thread id of the given worker thread. 159 /// The returned value is `None` if the worker thread has not yet finished 170 /// `worker` is the index of the worker being queried. The given value must 172 /// worker and will continue to identify the worker throughout the lifetime 177 /// The method panics when `worker` represents an invalid worker, i.e. is 190 /// println!("worker 0 has id {:?}", id); 193 pub fn worker_thread_id(&self, worker: usize) -> Option<ThreadId> { 196 .worker_metrics(worker) 272 /// Returns the total number of times the given worker thread has parked. [all …]
|
/aosp_15_r20/external/rust/android-crates-io/crates/tokio/src/runtime/scheduler/multi_thread/ |
D | worker.rs | 1 //! A scheduler is initialized with a fixed number of workers. Each worker is 2 //! driven by a thread. Each worker has a "core" which contains data such as the 3 //! run queue and other state. When `block_in_place` is called, the worker's 12 //! `OwnedTasks` instance and wakes up all worker threads. 14 //! 2. Each worker thread observes the close signal next time it runs 18 //! 3. The worker thread calls `pre_shutdown` in parallel. Here, the worker 88 /// A scheduler worker 89 pub(super) struct Worker { struct 93 /// Index holding this worker's remote state 96 /// Used to hand-off a worker's core to another thread. [all …]
|
/aosp_15_r20/external/pytorch/torch/distributed/elastic/agent/server/ |
H A D | api.py | 34 "Worker", 49 """Blueprint information about a particular type of worker. 51 For a given role, there must only exist a single worker spec. 52 Worker spec is expected to be homogeneous across all nodes (machine), 59 entrypoint: worker function or command 116 class Worker: class 117 """A worker instance. 120 worker. A ``Worker`` is created from a ``WorkerSpec``. A ``Worker`` is to 123 The ``id`` of the worker is interpreted 125 agent, it could be the ``pid (int)`` of the worker, for a remote [all …]
|
/aosp_15_r20/external/kotlinx.coroutines/kotlinx-coroutines-core/jvm/src/scheduling/ |
H A D | CoroutineScheduler.kt | 14 …* over worker threads, including both CPU-intensive and blocking tasks, in the most efficient mann… in <lambda>() 22 * Scheduler consists of [corePoolSize] worker threads to execute CPU-bound tasks and up to in <lambda>() 24 * Every worker has a local queue in addition to a global scheduler queue in <lambda>() 32 …When a coroutine is dispatched from within a scheduler worker, it's placed into the head of worker… in <lambda>() 44 * To provide even tasks distribution worker tries to steal tasks from other workers queues in <lambda>() 60 * When a worker cannot find any work, they first add themselves to the stack, in <lambda>() 63 …* If a worker finds a task that it cannot yet steal due to time constraints, it stores this fact i… in <lambda>() 67 * either an idle worker is being signalled, or a new worker is attempted to be created. in <lambda>() 72 * When executing or enqueuing blocking tasks, the scheduler notifies or creates one more worker in in <lambda>() 75 …* "CPU permits" -- [corePoolSize] special tokens that permit an arbitrary worker to execute and st… in <lambda>() [all …]
|
/aosp_15_r20/external/libchrome/base/task_scheduler/ |
H A D | scheduler_worker_pool_impl.cc | 56 const SchedulerWorker* worker) { in ContainsWorker() argument 58 [worker](const scoped_refptr<SchedulerWorker>& i) { in ContainsWorker() 59 return i.get() == worker; in ContainsWorker() 70 // |outer| owns the worker for which this delegate is constructed. 77 void OnMainEntry(const SchedulerWorker* worker) override; 78 scoped_refptr<Sequence> GetWork(SchedulerWorker* worker) override; 82 void OnMainExit(SchedulerWorker* worker) override; 92 // Returns true iff this worker has been within a MAY_BLOCK ScopedBlockingCall 103 // Returns true if |worker| is allowed to cleanup and remove itself from the 105 bool CanCleanupLockRequired(const SchedulerWorker* worker) const; [all …]
|
H A D | scheduler_worker_unittest.cc | 62 void OnMainEntry(const SchedulerWorker* worker) override {} in OnMainEntry() argument 63 scoped_refptr<Sequence> GetWork(SchedulerWorker* worker) override { in GetWork() argument 150 void OnMainEntry(const SchedulerWorker* worker) override { in OnMainEntry() argument 152 EXPECT_EQ(outer_->worker_.get(), worker); in OnMainEntry() 162 scoped_refptr<Sequence> GetWork(SchedulerWorker* worker) override { in GetWork() argument 164 EXPECT_EQ(outer_->worker_.get(), worker); in GetWork() 323 // empty after the worker pops Tasks from them and thus should be returned to in TEST_P() 354 // aren't empty after the worker pops Tasks from them and thus should be in TEST_P() 428 scoped_refptr<Sequence> GetWork(SchedulerWorker* worker) in GetWork() argument 435 if (CanCleanup(worker)) { in GetWork() [all …]
|
/aosp_15_r20/external/swiftshader/third_party/marl/docs/ |
H A D | scheduler.md | 10 - [`marl::Scheduler::Worker::run()`](#marlschedulerworkerrun) 11 - [`marl::Scheduler::Worker::runUntilIdle()`](#marlschedulerworkerrununtilidle) 12 - [`marl::Scheduler::Worker::waitForWork()`](#marlschedulerworkerwaitforwork) 13 - [`marl::Scheduler::Worker::spinForWork()`](#marlschedulerworkerspinforwork) 14 - [`marl::Scheduler::Worker::suspend()`](#marlschedulerworkersuspend) 15 - [Worker Types](#worker-types) 35 …Worker](#single-threaded-workers) for the calling thread. This worker is used for scheduling tasks… 45 Each `marl::Scheduler::Fiber` is permanently associated with a `marl::Scheduler::Worker`, and is gu… 74 The scheduler holds a number of `marl::Scheduler::Worker`s. Each worker holds: 83 … call to `marl::schedule()`, a worker is picked, and the task is placed on to the worker's `work.t… [all …]
|
/aosp_15_r20/external/virglrenderer/server/ |
H A D | render_worker.c | 10 * With ENABLE_RENDER_SERVER_WORKER_PROCESS, each worker is a subprocess 13 * With ENABLE_RENDER_SERVER_WORKER_THREAD, each worker is a thread of the 16 * With ENABLE_RENDER_SERVER_WORKER_MINIJAIL, each worker is a subprocess 21 #error "no worker defined" 194 struct render_worker *worker) in render_worker_jail_add_worker() argument 196 list_add(&worker->head, &jail->workers); in render_worker_jail_add_worker() 202 struct render_worker *worker) in render_worker_jail_remove_worker() argument 204 list_del(&worker->head); in render_worker_jail_remove_worker() 207 free(worker); in render_worker_jail_remove_worker() 225 list_for_each_entry (struct render_worker, worker, &jail->workers, head) { in render_worker_jail_reap_any_worker() [all …]
|
/aosp_15_r20/external/cronet/ipc/ |
H A D | ipc_sync_channel_unittest.cc | 43 class Worker : public Listener, public Sender { class 46 Worker(Channel::Mode mode, in Worker() function in IPC::__anon52c3a56f0111::Worker 66 Worker(mojo::ScopedMessagePipeHandle channel_handle, Channel::Mode mode) in Worker() function in IPC::__anon52c3a56f0111::Worker 82 Worker(const Worker&) = delete; 83 Worker& operator=(const Worker&) = delete; 85 ~Worker() override { in ~Worker() 98 FROM_HERE, base::BindOnce(&Worker::OnStart, base::Unretained(this))); in Start() 102 // ~Worker(), since that'll reset the vtable pointer (to Worker's), which in Shutdown() 108 FROM_HERE, base::BindOnce(&Worker::OnListenerThreadShutdown1, in Shutdown() 208 base::BindOnce(&Worker::OnIPCThreadShutdown, base::Unretained(this), in OnListenerThreadShutdown1() [all …]
|
/aosp_15_r20/external/cronet/base/task/thread_pool/ |
H A D | thread_group_impl.cc | 46 for (auto worker : workers_to_wake_up_) { in ~ScopedCommandsExecutor() local 47 worker->WakeUp(); in ~ScopedCommandsExecutor() 51 void ScheduleWakeUp(scoped_refptr<WorkerThreadWaitableEvent> worker) { in ScheduleWakeUp() argument 52 workers_to_wake_up_.emplace_back(std::move(worker)); in ScheduleWakeUp() 64 // |outer| owns the worker for which this delegate is constructed. If 65 // |is_excess| is true, this worker will be eligible for reclaim. 78 void OnMainEntry(WorkerThread* worker) override; 79 void OnMainExit(WorkerThread* worker) override; 80 RegisteredTaskSource GetWork(WorkerThread* worker) override; 82 WorkerThread* worker) override; [all …]
|
/aosp_15_r20/external/ltp/testcases/kernel/fs/read_all/ |
H A D | read_all.c | 17 * The reads are preformed by worker processes which are given file paths by a 24 * number of worker processes is based on the number of available 66 struct worker { struct 90 static struct worker *workers; argument 211 static void worker_heartbeat(const int worker) in worker_heartbeat() argument 213 tst_atomic_store(atomic_timestamp(), &workers[worker].last_seen); in worker_heartbeat() 216 static int worker_elapsed(const int worker) in worker_elapsed() argument 218 struct worker *const w = workers + worker; in worker_elapsed() 223 static int worker_ttl(const int worker) in worker_ttl() argument 225 return MAX(0, worker_timeout - worker_elapsed(worker)); in worker_ttl() [all …]
|
/aosp_15_r20/external/libchrome/ipc/ |
H A D | ipc_sync_channel_unittest.cc | 42 class Worker : public Listener, public Sender { class 45 Worker(Channel::Mode mode, in Worker() function in IPC::__anon2d0729390111::Worker 64 Worker(mojo::ScopedMessagePipeHandle channel_handle, Channel::Mode mode) in Worker() function in IPC::__anon2d0729390111::Worker 80 ~Worker() override { in ~Worker() 93 FROM_HERE, base::Bind(&Worker::OnStart, base::Unretained(this))); in Start() 97 // ~Worker(), since that'll reset the vtable pointer (to Worker's), which in Shutdown() 106 base::Bind(&Worker::OnListenerThreadShutdown1, base::Unretained(this), in Shutdown() 210 base::Bind(&Worker::OnIPCThreadShutdown, base::Unretained(this), in OnListenerThreadShutdown1() 220 FROM_HERE, base::Bind(&Worker::OnListenerThreadShutdown2, in OnIPCThreadShutdown() 230 IPC_BEGIN_MESSAGE_MAP(Worker, message) in OnMessageReceived() [all …]
|
/aosp_15_r20/external/webp/src/utils/ |
H A D | thread_utils.c | 10 // Multi-threaded worker 205 WebPWorker* const worker = (WebPWorker*)ptr; in ThreadLoop() local 206 WebPWorkerImpl* const impl = (WebPWorkerImpl*)worker->impl_; in ThreadLoop() 210 while (worker->status_ == OK) { // wait in idling mode in ThreadLoop() 213 if (worker->status_ == WORK) { in ThreadLoop() 214 WebPGetWorkerInterface()->Execute(worker); in ThreadLoop() 215 worker->status_ = OK; in ThreadLoop() 216 } else if (worker->status_ == NOT_OK) { // finish the worker in ThreadLoop() 231 static void ChangeState(WebPWorker* const worker, WebPWorkerStatus new_status) { in ChangeState() argument 235 WebPWorkerImpl* const impl = (WebPWorkerImpl*)worker->impl_; in ChangeState() [all …]
|
/aosp_15_r20/external/rust/android-crates-io/crates/tower/tests/buffer/ |
D | main.rs | 123 let (service, worker) = Buffer::pair(service, 1); in poll_ready_when_worker_is_dropped_early() 127 drop(worker); in poll_ready_when_worker_is_dropped_early() 140 let (service, worker) = Buffer::pair(service, 1); in response_future_when_worker_is_dropped_early() 144 // keep the request in the worker in response_future_when_worker_is_dropped_early() 149 drop(worker); in response_future_when_worker_is_dropped_early() 162 let (service, worker) = Buffer::pair(service, 3); in waits_for_channel_capacity() 165 let mut worker = task::spawn(worker); in waits_for_channel_capacity() localVariable 167 // keep requests in the worker in waits_for_channel_capacity() 171 assert_pending!(worker.poll()); in waits_for_channel_capacity() 175 assert_pending!(worker.poll()); in waits_for_channel_capacity() [all …]
|
/aosp_15_r20/prebuilts/go/linux-x86/src/internal/fuzz/ |
D | worker.go | 24 // workerFuzzDuration is the amount of time a worker can spend testing random 28 // workerTimeoutDuration is the amount of time a worker can go without 32 // workerExitCode is used as an exit code by fuzz worker processes after an internal error. 42 // worker manages a worker process running a test binary. The worker object 44 // workerClient is used by the coordinator to send RPCs to the worker process, 46 type worker struct { struct 54 memMu chan *sharedMem // mutex guarding shared memory with worker; persists across processes. argument 56 cmd *exec.Cmd // current worker process argument 57 client *workerClient // used to communicate with worker process argument 59 interrupted bool // true after stop interrupts a running worker. argument [all …]
|
/aosp_15_r20/external/rust/android-crates-io/crates/grpcio-sys/grpc/src/core/lib/iomgr/ |
D | ev_epoll1_linux.cc | 196 #define SET_KICK_STATE(worker, kick_state) \ argument 198 (worker)->state = (kick_state); \ 199 (worker)->kick_state_mutator = __LINE__; \ 228 // worker list 487 static bool worker_insert(grpc_pollset* pollset, grpc_pollset_worker* worker) { in worker_insert() argument 489 pollset->root_worker = worker; in worker_insert() 490 worker->next = worker->prev = worker; in worker_insert() 493 worker->next = pollset->root_worker; in worker_insert() 494 worker->prev = worker->next->prev; in worker_insert() 495 worker->next->prev = worker; in worker_insert() [all …]
|
/aosp_15_r20/external/grpc-grpc/src/core/lib/iomgr/ |
H A D | ev_epoll1_linux.cc | 196 #define SET_KICK_STATE(worker, kick_state) \ argument 198 (worker)->state = (kick_state); \ 199 (worker)->kick_state_mutator = __LINE__; \ 228 // worker list 487 static bool worker_insert(grpc_pollset* pollset, grpc_pollset_worker* worker) { in worker_insert() argument 489 pollset->root_worker = worker; in worker_insert() 490 worker->next = worker->prev = worker; in worker_insert() 493 worker->next = pollset->root_worker; in worker_insert() 494 worker->prev = worker->next->prev; in worker_insert() 495 worker->next->prev = worker; in worker_insert() [all …]
|
/aosp_15_r20/external/tensorflow/tensorflow/python/distribute/ |
H A D | distribute_coordinator_test.py | 46 WORKER = distribute_coordinator._TaskType.WORKER variable 122 if task_type in ["chief", "worker"]: 163 WORKER: [ 195 cluster_spec[WORKER] = [ 214 with ops.device("/job:worker/task:%d" % i): 220 with ops.device("/job:worker/task:0"): 349 """Dumps the propoerties of each worker context. 432 # Each finished worker will increment self._result_correct. 443 # Each finished worker will increment self._result_correct. 455 self.assertTrue(WORKER in self._worker_context) [all …]
|
/aosp_15_r20/external/python/google-api-python-client/docs/dyn/ |
D | remotebuildexecution_v1alpha.projects.instances.workerpools.html | 82 …worker pool with a specified size and configuration. Returns a long running operation which contai… 85 …worker pool. Returns a long running operation, which contains a `google.protobuf.Empty` response o… 88 <p class="firstline">Returns the specified worker pool.</p> 91 <p class="firstline">Lists worker pools in an instance.</p> 94 …worker pool with a specified size and/or configuration. Returns a long running operation, which co… 103 …worker pool with a specified size and configuration. Returns a long running operation which contai… 106 …parent: string, Resource name of the instance in which to create the new worker pool. Format: `pro… 111 …String", # Resource name of the instance in which to create the new worker pool. Format: `pro… 112 …"poolId": "A String", # ID of the created worker pool. A valid pool ID must: b… 113 …Pool": { # A worker pool resource in the Remote Build Execution API. # Specifies the worker p… [all …]
|
/aosp_15_r20/external/tensorflow/tensorflow/python/distribute/coordinator/ |
H A D | cluster_coordinator.py | 15 """Module for `ClusterCoordinator` and relevant cluster-worker related library. 47 # Maximum time for failed worker to come back is 1 hour 64 _JOB_WORKER_STRING_IDENTIFIER = "/job:worker" 78 the exception in this class and raises so it can be handled by the worker 168 """Selects the worker slice of each of the items in `structured`.""" 261 def execute_on(self, worker): argument 262 """Executes the closure on the given worker. 265 worker: a `Worker` object. 267 replica_args = _select_worker_slice(worker.worker_index, self._args) 268 replica_kwargs = _select_worker_slice(worker.worker_index, self._kwargs) [all …]
|