/third_party/python/Lib/test/ |
H A D | test_sched.py | 46 scheduler = sched.scheduler(time.time, time.sleep) 48 z = scheduler.enter(x, 1, fun, (x,)) 49 scheduler.run() 55 scheduler = sched.scheduler(time.time, time.sleep) 57 z = scheduler.enterabs(x, 1, fun, (x,)) 58 scheduler.run() 66 scheduler = sched.scheduler(time [all...] |
/third_party/skia/third_party/externals/swiftshader/third_party/marl/src/ |
H A D | scheduler_test.cpp | 25 auto scheduler = std::unique_ptr<marl::Scheduler>( in TEST_F() local 30 auto scheduler = std::unique_ptr<marl::Scheduler>( in TEST_F() local 32 scheduler->bind(); in TEST_F() 34 ASSERT_EQ(scheduler.get(), got); in TEST_F() 35 scheduler->unbind(); in TEST_F() 44 auto scheduler = std::unique_ptr<marl::Scheduler>(new marl::Scheduler(cfg)); in TEST_F() local 46 auto gotCfg = scheduler->config(); in TEST_F() 57 auto scheduler = marl::Scheduler::get(); in TEST_P() local 58 scheduler->unbind(); in TEST_P() 59 delete scheduler; in TEST_P() 86 auto scheduler = marl::Scheduler::get(); TEST_P() local 129 auto scheduler = marl::Scheduler::get(); TEST_P() local 163 auto scheduler = std::unique_ptr<marl::Scheduler>(new marl::Scheduler(cfg)); TEST_F() local 189 auto scheduler = std::unique_ptr<marl::Scheduler>(new marl::Scheduler(cfg)); TEST_F() local 219 auto scheduler = std::unique_ptr<marl::Scheduler>(new marl::Scheduler(cfg)); TEST_F() local [all...] |
H A D | marl_test.h | 18 #include "marl/scheduler.h" 31 // WithoutBoundScheduler is a test fixture that does not bind a scheduler. 49 // a bound scheduler using a number of different configurations. 62 auto scheduler = new marl::Scheduler(cfg); variable 63 scheduler->bind(); 67 auto scheduler = marl::Scheduler::get(); variable 68 scheduler->unbind(); 69 delete scheduler;
|
H A D | scheduler.cpp | 17 #include "marl/scheduler.h" 28 // Enable to trace scheduler events. 114 MARL_ASSERT(bound != nullptr, "No scheduler bound"); in unbind() 363 Scheduler::Worker::Worker(Scheduler* scheduler, Mode mode, uint32_t id) in Worker() argument 366 scheduler(scheduler), in Worker() 367 work(scheduler->cfg.allocator), in Worker() 368 idleFibers(scheduler->cfg.allocator) {} in Worker() 373 auto allocator = scheduler->cfg.allocator; in start() 374 auto& affinityPolicy = scheduler in start() [all...] |
H A D | marl_bench.h | 15 #include "marl/scheduler.h" 32 // run() creates a scheduler using the config cfg, sets the number of worker 34 // the scheduler. 42 marl::Scheduler scheduler(cfg); in run() 43 scheduler.bind(); in run() 45 scheduler.unbind(); in run() 48 // run() creates a scheduler, sets the number of worker threads from the 49 // benchmark arguments, calls f, then unbinds and destructs the scheduler.
|
/third_party/skia/third_party/externals/swiftshader/third_party/marl/include/marl/ |
H A D | blockingcall.h | 19 #include "scheduler.h" 36 auto scheduler = Scheduler::get(); in call() local 39 if (scheduler != nullptr) { in call() 40 scheduler->bind(); in call() 43 if (scheduler != nullptr) { in call() 61 auto scheduler = Scheduler::get(); in call() local 64 if (scheduler != nullptr) { in call() 65 scheduler->bind(); in call() 68 if (scheduler != nullptr) { in call()
|
H A D | scheduler.h | 39 // A scheduler can be bound to one or more threads using the bind() method. 52 // Config holds scheduler configuration settings that can be passed to the 59 // Total number of dedicated worker threads to spawn for the scheduler. 72 // Memory allocator to use for the scheduler and internal allocations. 99 // Blocks until the scheduler is unbound from all threads before returning. 103 // get() returns the scheduler bound to the current thread. 107 // bind() binds this scheduler to the current thread. 108 // There must be no existing scheduler bound to the thread prior to calling. 112 // unbind() unbinds the scheduler currently bound to the current thread. 113 // There must be a existing scheduler boun 469 Scheduler* const scheduler; global() member in marl::Scheduler::Worker 584 auto scheduler = Scheduler::get(); schedule() local 593 auto scheduler = Scheduler::get(); schedule() local 603 auto scheduler = Scheduler::get(); schedule() local [all...] |
/third_party/skia/third_party/externals/oboe/apps/OboeTester/app/src/main/cpp/ |
H A D | OboeTesterStreamCallback.cpp | 25 // Print if scheduler changes. 28 int scheduler = sched_getscheduler(gettid()); in printScheduler() local 29 if (scheduler != mPreviousScheduler) { in printScheduler() 30 int schedulerType = scheduler & 0xFFFF; // mask off high flags in printScheduler() 31 LOGD("callback CPU scheduler = 0x%08x = %s", in printScheduler() 32 scheduler, in printScheduler() 37 mPreviousScheduler = scheduler; in printScheduler()
|
/third_party/node/deps/v8/src/compiler/backend/ |
H A D | instruction-scheduler.h | 18 // scheduler is aware of dependencies between instructions. 95 // The scheduler keeps a nominal cycle count to keep track of when the 97 // scheduler to indicate when the value of all the operands of this 108 explicit SchedulingQueueBase(InstructionScheduler* scheduler) in SchedulingQueueBase() argument 109 : scheduler_(scheduler), nodes_(scheduler->zone()) {} in SchedulingQueueBase() 125 explicit CriticalPathFirstQueue(InstructionScheduler* scheduler) in CriticalPathFirstQueue() argument 126 : SchedulingQueueBase(scheduler) {} in CriticalPathFirstQueue() 134 // the scheduler. 137 explicit StressSchedulerQueue(InstructionScheduler* scheduler) in StressSchedulerQueue() argument [all...] |
/third_party/skia/third_party/externals/swiftshader/third_party/marl/examples/ |
H A D | hello_task.cpp | 19 #include "marl/scheduler.h" 25 // Create a marl scheduler using the 4 hardware threads. in main() 26 // Bind this scheduler to the main thread so we can call marl::schedule() in main() 30 marl::Scheduler scheduler(cfg); in main() 31 scheduler.bind(); in main() 32 defer(scheduler.unbind()); // Automatically unbind before returning. in main() 52 // The scheduler will find something else for this thread to do. in main() 65 // All tasks are guaranteed to complete before the scheduler is destructed. in main()
|
H A D | tasks_in_tasks.cpp | 18 #include "marl/scheduler.h" 24 // Create a marl scheduler using the 4 hardware threads. in main() 25 // Bind this scheduler to the main thread so we can call marl::schedule() in main() 29 marl::Scheduler scheduler(cfg); in main() 30 scheduler.bind(); in main() 31 defer(scheduler.unbind()); // Automatically unbind before returning. in main() 33 // marl::schedule() requires the scheduler to be bound to the current thread in main() 34 // (see above). The scheduler ensures that tasks are run on a thread with the in main() 35 // same scheduler automatically bound, so we don't need to call in main()
|
H A D | primes.cpp | 19 #include "marl/scheduler.h" 45 // Create a marl scheduler using the full number of logical cpus. in main() 46 // Bind this scheduler to the main thread so we can call marl::schedule() in main() 47 marl::Scheduler scheduler(marl::Scheduler::Config::allCores()); in main() 48 scheduler.bind(); in main() 49 defer(scheduler.unbind()); // unbind before destructing the scheduler. in main()
|
H A D | fractal.cpp | 19 #include "marl/scheduler.h" 152 // Create a marl scheduler using the full number of logical cpus. in main() 153 // Bind this scheduler to the main thread so we can call marl::schedule() in main() 154 marl::Scheduler scheduler(marl::Scheduler::Config::allCores()); in main() 155 scheduler.bind(); in main() 156 defer(scheduler.unbind()); // unbind before destructing the scheduler. in main()
|
/third_party/skia/third_party/externals/oboe/src/common/ |
H A D | AudioStream.cpp | 42 // Call this from fireDataCallback() if you want to monitor CPU scheduler. 44 int scheduler = sched_getscheduler(0) & ~SCHED_RESET_ON_FORK; // for current thread in checkScheduler() local 45 if (scheduler != mPreviousScheduler) { in checkScheduler() 46 LOGD("AudioStream::%s() scheduler = %s", __func__, in checkScheduler() 47 ((scheduler == SCHED_FIFO) ? "SCHED_FIFO" : in checkScheduler() 48 ((scheduler == SCHED_OTHER) ? "SCHED_OTHER" : in checkScheduler() 49 ((scheduler == SCHED_RR) ? "SCHED_RR" : "UNKNOWN"))) in checkScheduler() 51 mPreviousScheduler = scheduler; in checkScheduler()
|
/third_party/node/src/ |
H A D | node_platform.cc | 100 DelayedTaskScheduler* scheduler = in FlushTasks() local 102 while (std::unique_ptr<Task> task = scheduler->tasks_.Pop()) in FlushTasks() 108 explicit StopTask(DelayedTaskScheduler* scheduler): scheduler_(scheduler) {} in StopTask() argument 126 ScheduleTask(DelayedTaskScheduler* scheduler, in ScheduleTask() argument 129 : scheduler_(scheduler), in ScheduleTask() 149 DelayedTaskScheduler* scheduler = in RunTask() local 151 scheduler->pending_worker_tasks_->Push(scheduler->TakeTimerTask(timer)); in RunTask()
|
/third_party/node/test/sequential/ |
H A D | test-worker-fshandles-error-on-termination.js | 6 const { scheduler } = require('timers/promises'); 41 await scheduler.yield();
|
H A D | test-worker-fshandles-open-close-on-termination.js | 6 const { scheduler } = require('timers/promises'); 36 await scheduler.yield();
|
/third_party/mesa3d/.gitlab-ci/tests/ |
H A D | test_lava_job_submitter.py | 41 proxy_job_state = proxy_mock.scheduler.job_state 255 proxy_logs_mock = proxy_mock.scheduler.jobs.logs 349 proxy.scheduler.jobs.logs.side_effect = load_lines() 351 proxy.scheduler.jobs.submit = reset_logs
|
H A D | conftest.py | 39 proxy_submit_mock = proxy_mock.scheduler.jobs.submit 48 proxy_logs_mock = proxy_mock.scheduler.jobs.logs
|
/third_party/skia/third_party/externals/swiftshader/src/Vulkan/ |
H A D | VkQueue.cpp | 26 #include "marl/scheduler.h" 167 Queue::Queue(Device *device, marl::Scheduler *scheduler) in Queue() argument 170 queueThread = std::thread(&Queue::taskLoop, this, scheduler); in Queue() 272 void Queue::taskLoop(marl::Scheduler *scheduler) in taskLoop() argument 275 scheduler->bind(); in taskLoop() 276 defer(scheduler->unbind()); in taskLoop()
|
H A D | VkQueue.hpp | 45 Queue(Device *device, marl::Scheduler *scheduler); 93 void taskLoop(marl::Scheduler *scheduler);
|
/third_party/node/deps/v8/src/compiler/ |
H A D | scheduler.cc | 5 #include "src/compiler/scheduler.h" 61 Scheduler scheduler(zone, graph, schedule, flags, node_count_hint, in ComputeSchedule() 64 scheduler.BuildCFG(); in ComputeSchedule() 65 scheduler.ComputeSpecialRPONumbering(); in ComputeSchedule() 66 scheduler.GenerateDominatorTree(); in ComputeSchedule() 68 scheduler.PrepareUses(); in ComputeSchedule() 69 scheduler.ScheduleEarly(); in ComputeSchedule() 70 scheduler.ScheduleLate(); in ComputeSchedule() 72 scheduler.SealFinalSchedule(); in ComputeSchedule() 239 CFGBuilder(Zone* zone, Scheduler* scheduler) in CFGBuilder() argument 1317 PrepareUsesVisitor(Scheduler* scheduler, Graph* graph, Zone* zone) PrepareUsesVisitor() argument 1403 ScheduleEarlyNodeVisitor(Zone* zone, Scheduler* scheduler) ScheduleEarlyNodeVisitor() argument 1516 ScheduleLateNodeVisitor(Zone* zone, Scheduler* scheduler) ScheduleLateNodeVisitor() argument [all...] |
/third_party/mesa3d/.gitlab-ci/lava/ |
H A D | lava_job_submitter.py | 252 return _call_proxy(self.proxy.scheduler.jobs.validate, self.definition, True) 256 self.job_id = _call_proxy(self.proxy.scheduler.jobs.submit, self.definition) 263 self.proxy.scheduler.jobs.cancel(self.job_id) 268 self.proxy.scheduler.job_state, self.job_id 283 self.proxy.scheduler.jobs.logs, self.job_id, self.last_log_line 357 show = _call_proxy(job.proxy.scheduler.jobs.show, job.job_id) 394 # Depending on how much payload the RPC scheduler.jobs.logs get, it may
|
/third_party/toybox/toys/other/ |
H A D | chrt.c | 47 #define sched_setscheduler(pid, scheduler, param) \ 48 syscall(SYS_sched_setscheduler, (pid_t)pid, (int)scheduler, (void *)param)
|
/third_party/gn/src/gn/ |
H A D | target_unittest.cc | 13 #include "gn/scheduler.h" 22 // Asserts that the current global scheduler has a single unknown generated 783 scheduler().ClearUnknownGeneratedInputsAndWrittenFiles(); in TEST_F() 799 EXPECT_TRUE(scheduler().GetUnknownGeneratedInputs().empty()); in TEST_F() 812 scheduler().ClearUnknownGeneratedInputsAndWrittenFiles(); in TEST_F() 824 EXPECT_TRUE(scheduler().GetUnknownGeneratedInputs().empty()); in TEST_F() 841 scheduler().ClearUnknownGeneratedInputsAndWrittenFiles(); in TEST_F() 848 scheduler().AddWrittenFile(generated_file); in TEST_F() 851 EXPECT_TRUE(scheduler().GetUnknownGeneratedInputs().empty()); in TEST_F() 873 scheduler() in TEST_F() [all...] |