/arkcompiler/ets_frontend/test/scripts/sdk_test/ |
H A D | execution.py | 41 def prepare_full_task(task, test_name): 42 if test_name in task.full_compilation_info: 43 full_task = task.full_compilation_info[test_name] 47 task.full_compilation_info[test_name] = full_task 51 def full_compile(task, is_debug): 53 logging.info(f"==========> Running {test_name} for task: {task.name}") 54 clean_compile(task) 56 full_task = FullTest.prepare_full_task(task, test_name) 57 [stdout, stderr] = compile_project(task, is_debu [all...] |
H A D | options.py | 198 task = TestTask() 199 task.name = hap['name'] 200 task.path = hap['path'] 201 task.bundle_name = hap['bundle_name'] 202 task.ability_name = hap['ability_name'] 203 task.type = hap['type'] 204 task.hap_module = hap['hap_module'] 205 task.hap_module_path = hap['hap_module_path'] 207 task.hsp_module = hap.get('hsp_module', '') 208 task [all...] |
H A D | result.py | 109 for task in test_tasks: 110 logging.info("task index: %d", idx) 112 logging.info("task name: %s", task.name) 113 logging.info("task type: %s", task.type) 116 for full_task in task.full_compilation_info.values(): 131 for inc_task in task.incre_compilation_info.values(): 146 for byte_task in task.bytecode_har_compilation_info.values(): 161 for external_task in task [all...] |
H A D | utils.py | 144 def move_picture(task, image_name): 149 pic_save_path = os.path.join(os.path.dirname(os.path.abspath(__file__)), f'pictures/{task.name}') 160 def get_running_screenshot(task, image_name, is_debug, module=''): 161 logging.debug(f'Getting runtime screenshot of {task.name}') 166 module_path = get_module_path(task, module) 167 output_path_signed = get_output_path(task, module, options.OutputType.signed) 168 build_path = os.path.join(task.path, *module_path, *task.build_path) 175 hsp_output_path = task.backup_info.hsp_signed_output_debug if is_debug \ 176 else task [all...] |
/arkcompiler/ets_runtime/ecmascript/taskpool/ |
H A D | task_queue.cpp | 19 void TaskQueue::PostTask(std::unique_ptr<Task> task) in PostTask() argument 23 tasks_.push_back(std::move(task)); in PostTask() 32 std::unique_ptr<Task> task = std::move(tasks_.front()); in PopTask() local 34 return task; in PopTask() 47 for (auto &task : tasks_) { in TerminateTask() 48 if (id != ALL_TASK_ID && id != task->GetId()) { in TerminateTask() 51 if (type != TaskType::ALL && type != task->GetTaskType()) { in TerminateTask() 54 task->Terminated(); in TerminateTask() 68 for (auto &task : tasks_) { in ForEachTask() 69 if (task in ForEachTask() [all...] |
/arkcompiler/runtime_core/static_core/libpandabase/taskmanager/ |
H A D | task_queue.h | 27 * tasks on workers. Also, queues can notify other threads when a new task is pushed. 46 * @param priority: A number from 1 to 10 that determines the weight of the queue during the task selection process 69 * @brief Adds task in task queue. Operation is thread-safe. 70 * @param task - task that will be added 71 * @return the size of queue after @arg task was added to it. 73 PANDA_PUBLIC_API size_t AddTask(Task &&task) override 75 auto properties = task.GetTaskProperties(); 78 // Send info about new added task 93 EventOnTaskAdding(&task); global() variable 128 auto task = queue->Pop(); global() variable 242 PushTaskToInternalQueues(Task &&task) PushTaskToInternalQueues() argument 255 auto task = foregroundTaskQueue_.Pop(); PopTaskFromInternalQueues() local 262 EventOnTaskAdding(Task *task) EventOnTaskAdding() argument [all...] |
H A D | worker_thread.cpp | 17 #include "libpandabase/taskmanager/task.h" 32 void WorkerThread::AddTask(Task &&task) in AddTask() argument 34 localQueue_.Push(std::move(task)); in AddTask() 89 // Start popping task from local queue and executing them in ExecuteTasksFromLocalQueue() 92 auto task = localQueue_.Pop(perWorkerPopId_[this]); in ExecuteTasksFromLocalQueue() local 93 // If pop task returned nullopt need to finish execution in ExecuteTasksFromLocalQueue() 94 if (UNLIKELY(!task.has_value())) { in ExecuteTasksFromLocalQueue() 97 task->RunTask(); in ExecuteTasksFromLocalQueue() 98 finishedTasksCounterMap_[task->GetTaskProperties()]++; in ExecuteTasksFromLocalQueue() 108 void WorkerThread::ExecuteTask(Task *task) in ExecuteTask() argument [all...] |
H A D | task_scheduler.cpp | 64 LOG(DEBUG, TASK_MANAGER) << "TaskScheduler: Register task queue with {" << queue->GetTaskType() << ", " in RegisterQueue() 75 // init countOfTasksIsSystem_ for possible task from registered queue in RegisterQueue() 114 // If worker was successfully found, steals task from its local queue in StealTaskFromOtherWorker() 116 [taskReceiver](Task &&task) { taskReceiver->SetStolenTask(std::move(task)); }, 1UL, in StealTaskFromOtherWorker() 133 // Use selector to choose next queue to pop task in FillWithTasks() 136 // Getting task from selected queue in FillWithTasks() 140 // Wait list have task that should be added in queues. So worker firstly should add this task in local queue in FillWithTasks() 163 auto addTaskFunc = [worker](Task &&task) { worke in PutTasksInWorker() 378 AddTaskToWaitListWithTimeout(Task &&task, uint64_t time) AddTaskToWaitListWithTimeout() argument 385 AddTaskToWaitList(Task &&task) AddTaskToWaitList() argument 401 Task task = std::move(queue.front()); PutTaskInTaskQueues() local 411 std::optional<Task> task; SignalWaitList() local [all...] |
/arkcompiler/runtime_core/static_core/runtime/scheduler/ |
H A D | task.cpp | 16 #include "runtime/scheduler/task.h" 23 // NOTE(xuliang): task id 33 auto *task = allocator->New<Task>(vm, obj); in Create() local 34 task->Initialize(); in Create() 35 return task; in Create() 64 auto task = Task::GetCurrent(); in SuspendCurrent() local 65 auto wt = task->workerThread_; in SuspendCurrent() 73 auto task = Task::GetCurrent(); in EndCurrent() local 74 auto wt = task->workerThread_; in EndCurrent() 76 task in EndCurrent() [all...] |
/arkcompiler/runtime_core/static_core/plugins/ets/tests/debugger/src/arkdb/ |
H A D | trio_tracer.py | 59 def task_spawned(self, task: trio.lowlevel.Task): 60 self._task_log("+++ SPAWNED ", task) 63 def task_scheduled(self, task: trio.lowlevel.Task): 64 self._task_log(" SCHEDULED ", task) 67 def before_task_step(self, task: trio.lowlevel.Task): 68 self._task_log("* { BEFORE STEP ", task) 71 def after_task_step(self, task: trio.lowlevel.Task): 72 self._task_log(" } AFTER STEP ", task) 75 def task_exited(self, task: trio.lowlevel.Task): 76 self._task_log("--- EXITED ", task) [all...] |
/arkcompiler/runtime_core/static_core/runtime/mem/gc/ |
H A D | gc_queue.cpp | 41 GCTask *task = queue_.top().get(); in GetTask() local 43 while (gc_->IsGCRunning() && (task->GetTargetTime() >= currentTime)) { in GetTask() 44 auto delta = task->GetTargetTime() - currentTime; in GetTask() 49 task = queue_.top().get(); in GetTask() 54 LOG(DEBUG, GC) << "Extract a task from a " << queueName_; in GetTask() 58 bool GCQueueWithTime::AddTask(PandaUniquePtr<GCTask> task) in AddTask() argument 60 if (task == nullptr) { in AddTask() 66 if (lastElem->reason == task->reason) { in AddTask() 67 // do not duplicate GC task with the same reason. in AddTask() 71 LOG(DEBUG, GC) << "Add task t in AddTask() [all...] |
H A D | gc.cpp | 59 // Create gc task queue for task manager in GC() 155 auto task = MakePandaUnique<GCTask>(GCTaskCause::NATIVE_ALLOC_CAUSE, time::GetCurrentTimeInNanos()); in TriggerGCForNative() local 156 AddGCTask(false, std::move(task)); in TriggerGCForNative() 283 bool GC::NeedRunGCAfterWaiting(size_t counterBeforeWaiting, const GCTask &task) const in NeedRunGCAfterWaiting() 291 return (newCounter == counterBeforeWaiting || lastCause_.load(std::memory_order_acquire) < task.reason); in NeedRunGCAfterWaiting() 294 bool GC::GCPhasesPreparation(const GCTask &task) in GCPhasesPreparation() argument 300 if (!this->NeedRunGCAfterWaiting(oldCounter, task)) { in GCPhasesPreparation() 308 lastCause_.store(task.reason, std::memory_order_release); in GCPhasesPreparation() 328 void GC::GCPhasesFinish(const GCTask &task) in GCPhasesFinish() argument 354 RunPhases(GCTask &task) RunPhases() argument 470 ProcessReferences(GCPhase gcPhase, const GCTask &task, const ReferenceClearPredicateT &pred) ProcessReferences() argument 613 auto task = MakePandaUnique<PostForkGCTask>(GCTaskCause::STARTUP_COMPLETE_CAUSE, PreStartup() local 621 AddGCTask(bool isManaged, PandaUniquePtr<GCTask> task) AddGCTask() argument 729 WaitForGC(GCTask task) WaitForGC() argument 761 WaitForGCInManaged(const GCTask &task) WaitForGCInManaged() argument 822 WaitForGCOnPygoteFork(const GCTask &task) WaitForGCOnPygoteFork() argument 1007 FireGCStarted(const GCTask &task, size_t bytesInHeapBeforeGc) FireGCStarted() argument 1014 FireGCFinished(const GCTask &task, size_t bytesInHeapBeforeGc, size_t bytesInHeapAfterGc) FireGCFinished() argument [all...] |
H A D | gc_trigger.cpp | 87 void GCTriggerHeap::ComputeNewTargetFootprint(const GCTask &task, size_t heapSizeBeforeGc, size_t heapSize) in ComputeNewTargetFootprint() argument 90 if (gc->IsGenerational() && task.reason == GCTaskCause::YOUNG_GC_CAUSE && in ComputeNewTargetFootprint() 91 task.collectionType != GCCollectionType::MIXED) { in ComputeNewTargetFootprint() 133 auto task = MakePandaUnique<GCTask>(GCTaskCause::HEAP_USAGE_THRESHOLD_CAUSE, time::GetCurrentTimeInNanos()); in TriggerGcIfNeeded() local 134 gc->Trigger(std::move(task)); in TriggerGcIfNeeded() 249 void GCTriggerHeap::GCStarted([[maybe_unused]] const GCTask &task, [[maybe_unused]] size_t heapSize) in GCStarted() argument 254 void GCTriggerHeap::GCFinished(const GCTask &task, size_t heapSizeBeforeGc, size_t heapSize) in GCFinished() argument 256 this->ComputeNewTargetFootprint(task, heapSizeBeforeGc, heapSize); in GCFinished() 272 auto task = MakePandaUnique<GCTask>(GCTaskCause::HEAP_USAGE_THRESHOLD_CAUSE, time::GetCurrentTimeInNanos()); in TriggerGcIfNeeded() local 273 gc->Trigger(std::move(task)); in TriggerGcIfNeeded() 278 GCStarted([[maybe_unused]] const GCTask &task, [[maybe_unused]] size_t heapSize) GCStarted() argument 283 GCFinished([[maybe_unused]] const GCTask &task, [[maybe_unused]] size_t heapSizeBeforeGc, [[maybe_unused]] size_t heapSize) GCFinished() argument 295 GCStarted([[maybe_unused]] const GCTask &task, [[maybe_unused]] size_t heapSize) GCStarted() argument 300 GCFinished([[maybe_unused]] const GCTask &task, [[maybe_unused]] size_t heapSizeBeforeGc, [[maybe_unused]] size_t heapSize) GCFinished() argument 315 auto task = MakePandaUnique<GCTask>(GCTaskCause::HEAP_USAGE_THRESHOLD_CAUSE, time::GetCurrentTimeInNanos()); TriggerGcIfNeeded() local 342 auto task = MakePandaUnique<GCTask>(cause_); TriggerGcIfNeeded() local 388 GCFinished(const GCTask &task, size_t heapSizeBeforeGc, size_t heapSize) GCFinished() argument [all...] |
/arkcompiler/runtime_core/static_core/runtime/include/ |
H A D | compiler_interface.h | 44 CompilerTask(CompilerTask &&task) in CompilerTask() argument 46 method_ = task.method_; in CompilerTask() 47 isOsr_ = task.isOsr_; in CompilerTask() 48 vm_ = task.vm_; in CompilerTask() 49 task.vm_ = nullptr; in CompilerTask() 50 task.method_ = nullptr; in CompilerTask() 53 CompilerTask &operator=(CompilerTask &&task) in operator =() argument 55 method_ = task.method_; in operator =() 56 isOsr_ = task.isOsr_; in operator =() 57 vm_ = task in operator =() [all...] |
/arkcompiler/runtime_core/static_core/libpandabase/taskmanager/utils/ |
H A D | worker_thread_local_queue.h | 19 #include "libpandabase/taskmanager/task.h" 62 void Push(Task &&task) in Push() argument 64 auto properties = task.GetTaskProperties(); in Push() 65 ASSERT(!task.IsInvalid()); in Push() 66 perPropertiesQueue_.at(properties).Push(std::move(task)); in Push() 85 auto task = Pop(id, prop); in Pop() local 86 if (task.has_value()) { in Pop() 87 return task; in Pop() 97 auto task = queue.Pop(id); in Pop() local 98 if (task in Pop() [all...] |
/arkcompiler/runtime_core/static_core/runtime/mem/gc/workers/ |
H A D | gc_worker.cpp | 50 // Get gc task from local gc tasks queue in GCThreadLoop() 51 auto task = gcWorker->GetTask(); in GCThreadLoop() local 56 gcWorker->RunGC(std::move(task)); in GCThreadLoop() 81 // Signal that no need to delay task running in FinalizeAndDestroyWorker() 100 ASSERT_PRINT(gcRunner_ != nullptr, "Need to create task only for TaskManager case"); in CreateAndAddTaskToTaskManager() 107 // only one task can get gc task from queue and run it in GCTaskRunner() 109 // If any task is executed in TaskManager then current task should do nothing and just return in GCTaskRunner() 110 // According task fo in GCTaskRunner() 137 AddTask(PandaUniquePtr<GCTask> task) AddTask() argument 163 RunGC(PandaUniquePtr<GCTask> task) RunGC() argument [all...] |
H A D | gc_workers_task_pool.cpp | 36 bool GCWorkersTaskPool::AddTask(GCWorkersTask &&task) in AddTask() argument 39 [[maybe_unused]] GCWorkersTaskTypes type = task.GetType(); in AddTask() 40 if (this->TryAddTask(std::forward<GCWorkersTask &&>(task))) { in AddTask() 41 LOG(DEBUG, GC) << "Added a new " << GCWorkersTaskTypesToString(type) << " to gc task pool"; in AddTask() 44 // Couldn't add gc workers task to pool in AddTask() 49 void GCWorkersTaskPool::RunGCWorkersTask(GCWorkersTask *task, void *workerData) in RunGCWorkersTask() argument 51 gc_->WorkerTaskProcessing(task, workerData); in RunGCWorkersTask() 58 // Current thread can to help workers with gc task processing. in WaitUntilTasksEnd() 59 // Try to get gc workers task from pool if it's possible and run the task immediatel in WaitUntilTasksEnd() [all...] |
/arkcompiler/runtime_core/static_core/runtime/mem/gc/gen-gc/ |
H A D | gen-gc.h | 71 void RunPhasesImpl(GCTask &task) override; 77 * @param task gc task for current GC 79 void RunYoungGC(GCTask &task); 83 * @param task gc task for current GC 85 void RunTenuredGC(GCTask &task); 89 * @param task gc task for current GC 91 void RunFullGC(GCTask &task); [all...] |
/arkcompiler/ets_runtime/ecmascript/pgo_profiler/ |
H A D | pgo_profiler_encoder.cpp | 161 const SaveTask *task) in MergeWithExistProfile() 182 if (task && task->IsTerminate()) { in MergeWithExistProfile() 183 LOG_ECMA(DEBUG) << "ProcessProfile: task is already terminate"; in MergeWithExistProfile() 187 if (task && task->IsTerminate()) { in MergeWithExistProfile() 188 LOG_ECMA(DEBUG) << "ProcessProfile: task is already terminate"; in MergeWithExistProfile() 194 bool PGOProfilerEncoder::SaveAndRename(const SaveTask *task) in SaveAndRename() argument 210 globalRecordInfos_->ProcessToBinary(task, fileStream, header_); in SaveAndRename() 223 if (task in SaveAndRename() 160 MergeWithExistProfile(PGOProfilerEncoder &runtimeEncoder, PGOProfilerDecoder &decoder, const SaveTask *task) MergeWithExistProfile() argument 255 InternalSave(const SaveTask *task) InternalSave() argument 334 StartSaveTask(const SaveTask *task) StartSaveTask() argument [all...] |
/arkcompiler/runtime_core/static_core/runtime/tests/ |
H A D | mock_queue_thread_pool.cpp | 102 auto task = queue_.front(); variable 104 LOG(DEBUG, RUNTIME) << "Extract task " << task.GetId(); 105 return task; 109 void AddTask(MockTask &&task, [[maybe_unused]] size_t priority = 0) override 111 task.SetStatus(MockTask::IN_QUEUE); 112 queue_.push_front(task); 134 void SolveTask(MockTask task) in SolveTask() argument 136 task.SetStatus(MockTask::PROCESSING); in SolveTask() 140 task in SolveTask() [all...] |
H A D | gc_log_test.cpp | 93 GCTask task(GCTaskCause::YOUNG_GC_CAUSE); in CounterLogTest() 100 task.Run(*gc); in CounterLogTest() 107 task.reason = static_cast<GCTaskCause>(i % numberOfGcCauses_ == 0 ? i % numberOfGcCauses_ + 1 in CounterLogTest() 121 GCTask task(GCTaskCause::YOUNG_GC_CAUSE); in FullLogTest() 124 task.reason = GCTaskCause::YOUNG_GC_CAUSE; in FullLogTest() 125 task.Run(*gc); in FullLogTest() 131 task.reason = GCTaskCause::HEAP_USAGE_THRESHOLD_CAUSE; in FullLogTest() 132 task.Run(*gc); in FullLogTest() 138 task.reason = GCTaskCause::OOM_CAUSE; in FullLogTest() 139 task in FullLogTest() [all...] |
/arkcompiler/runtime_core/static_core/libpandabase/tests/taskmanager/ |
H A D | task_test.cpp | 51 std::string message = "task:"; in TEST_F() 52 Task task = Task::Create({TaskType::GC, VMType::DYNAMIC_VM, TaskExecutionMode::BACKGROUND}, in TEST_F() local 54 EXPECT_EQ(message, "task:"); in TEST_F() 55 EXPECT_EQ(task.GetTaskProperties().GetTaskType(), TaskType::GC); in TEST_F() 56 EXPECT_EQ(task.GetTaskProperties().GetVMType(), VMType::DYNAMIC_VM); in TEST_F() 57 EXPECT_EQ(task.GetTaskProperties().GetTaskExecutionMode(), TaskExecutionMode::BACKGROUND); in TEST_F() 58 task.RunTask(); in TEST_F() 59 EXPECT_EQ(message, "task:done"); in TEST_F() 60 EXPECT_EQ(task.GetTaskProperties().GetTaskType(), TaskType::GC); in TEST_F() 61 EXPECT_EQ(task in TEST_F() 251 auto task = queue->PopTask(); global() local 289 auto task = queue->PopTask(TaskExecutionMode::FOREGROUND); global() local [all...] |
/arkcompiler/runtime_core/static_core/runtime/mem/gc/g1/ |
H A D | g1-gc.h | 32 #include "runtime/mem/gc/g1/g1-evacuate-regions-task.h" 105 void WorkerTaskProcessing(GCWorkersTask *task, void *workerData) override; 149 bool Trigger(PandaUniquePtr<GCTask> task) override; 184 void CollectEmptyRegions(GCTask &task, PandaVector<Region *> *emptyTenuredRegions); 206 bool NeedFullGC(const ark::GCTask &task); 208 bool NeedToRunGC(const ark::GCTask &task); 210 void RunPhasesImpl(GCTask &task) override; 212 void RunFullGC(ark::GCTask &task); 213 void TryRunMixedGC(ark::GCTask &task); 217 void RunMixedGC(ark::GCTask &task, cons [all...] |
/arkcompiler/ets_runtime/ecmascript/daemon/ |
H A D | daemon_thread.cpp | 90 bool DaemonThread::CheckAndPostTask(DaemonTask task) in CheckAndPostTask() argument 93 LOG_GC(FATAL) << "Try to post task to terminated daemon thread, taskType = " in CheckAndPostTask() 94 << static_cast<uint32_t>(task.GetTaskType()); in CheckAndPostTask() 98 if (AddTaskGroup(task.GetTaskGroup())) { in CheckAndPostTask() 99 tasks_.emplace_back(task); in CheckAndPostTask() 119 DaemonTask task = PopTask(); in Run() local 120 runningGroup_ = task.GetTaskGroup(); in Run() 121 task.Run(); in Run() 153 DaemonTask task = tasks_.front(); in PopTask() local 155 return task; in PopTask() [all...] |
/arkcompiler/runtime_core/static_core/runtime/mem/gc/stw-gc/ |
H A D | stw-gc.cpp | 62 void StwGC<LanguageConfig>::RunPhasesImpl(GCTask &task) in RunPhasesImpl() argument 69 Mark(task); in RunPhasesImpl() 74 task.collectionType = GCCollectionType::FULL; in RunPhasesImpl() 78 void StwGC<LanguageConfig>::Mark(const GCTask &task) in Mark() argument 116 this->GetPandaVm()->HandleReferences(task, refClearPred); in Mark() 191 bool StwGC<LanguageConfig>::Trigger(PandaUniquePtr<GCTask> task) in Trigger() argument 193 return this->AddGCTask(true, std::move(task)); in Trigger() 197 void StwGC<LanguageConfig>::WorkerTaskProcessing(GCWorkersTask *task, [[maybe_unused]] void *workerData) in WorkerTaskProcessing() argument 199 switch (task->GetType()) { in WorkerTaskProcessing() 201 auto *stack = task in WorkerTaskProcessing() [all...] |