/external/trusty/lk/kernel/ |
D | thread.c | 315 thread_t *current_thread = get_current_thread(); in thread_create_etc() local 318 t->tls[i] = current_thread->tls[i]; in thread_create_etc() 397 static mp_cpu_mask_t thread_get_mp_reschedule_target(thread_t *current_thread, thread_t *t) in thread_get_mp_reschedule_target() argument 403 if (t->pinned_cpu != -1 && current_thread->pinned_cpu == t->pinned_cpu) in thread_get_mp_reschedule_target() 420 … __func__, cpu, target_cpu, cpu_priority[target_cpu], t->priority, current_thread->priority); in thread_get_mp_reschedule_target() 427 __func__, cpu, target_cpu, cpu_priority[target_cpu], t->priority, current_thread->priority); in thread_get_mp_reschedule_target() 443 static void thread_mp_reschedule(thread_t *current_thread, thread_t *t) in thread_mp_reschedule() argument 445 mp_reschedule(thread_get_mp_reschedule_target(current_thread, t), 0); in thread_mp_reschedule() 647 thread_t *current_thread = get_current_thread(); in thread_exit() local 649 DEBUG_ASSERT(current_thread->magic == THREAD_MAGIC); in thread_exit() [all …]
|
/external/pigweed/pw_kernel/kernel/ |
D | scheduler.rs | 149 let id = if let Some(mut current_thread) = sched_state.current_thread.take() { in start() 150 let id = current_thread.id(); in start() 151 current_thread.state = State::Ready; in start() 152 sched_state.insert_in_run_queue_head(current_thread); in start() 207 current_thread: Option<ForeignBox<Thread>>, field 222 current_thread: None, in new() 235 let Some(mut current_thread) = self.current_thread.take() else { in move_current_thread_to_back() 238 let current_thread_id = current_thread.id(); in move_current_thread_to_back() 239 current_thread.state = State::Ready; in move_current_thread_to_back() 240 self.insert_in_run_queue_tail(current_thread); in move_current_thread_to_back() [all …]
|
/external/pigweed/pw_thread_freertos/ |
D | thread_iteration.cc | 31 bool StackInfoCollector(TaskHandle_t current_thread, in StackInfoCollector() argument 33 const tskTCB& tcb = *reinterpret_cast<tskTCB*>(current_thread); in StackInfoCollector() 53 (sizeof(StackType_t) * uxTaskGetStackHighWaterMark(current_thread))); in StackInfoCollector() 57 (sizeof(StackType_t) * uxTaskGetStackHighWaterMark(current_thread))); in StackInfoCollector() 70 [&cb](TaskHandle_t current_thread, eTaskState) -> bool { in ForEachThread() argument 71 return freertos::StackInfoCollector(current_thread, cb); in ForEachThread()
|
D | util.cc | 70 void* current_thread; in ForEachThreadInList() local 74 listGET_OWNER_OF_NEXT_ENTRY(current_thread, list); in ForEachThreadInList() 81 reinterpret_cast<TaskHandle_t>(current_thread); in ForEachThreadInList() 88 } while (current_thread != first_thread_in_list); in ForEachThreadInList()
|
/external/webrtc/rtc_base/synchronization/ |
D | sequence_checker_internal.cc | 44 const rtc::PlatformThreadRef current_thread = rtc::CurrentThreadRef(); in IsCurrent() local 49 valid_thread_ = current_thread; in IsCurrent() 60 return rtc::IsThreadRefEqual(valid_thread_, current_thread); in IsCurrent() 73 const rtc::PlatformThreadRef current_thread = rtc::CurrentThreadRef(); in ExpectationToString() local 92 current_system_queue, reinterpret_cast<const void*>(current_thread)); in ExpectationToString() 99 } else if (!rtc::IsThreadRefEqual(valid_thread_, current_thread)) { in ExpectationToString()
|
/external/rust/android-crates-io/crates/tokio/tests/ |
D | sync_panic.rs | 31 let rt = current_thread(); in mutex_blocking_lock_panic_caller() 47 let rt = current_thread(); in oneshot_blocking_recv_panic_caller() 75 let rt = current_thread(); in rwlock_blocking_read_panic_caller() 91 let rt = current_thread(); in rwlock_blocking_write_panic_caller() 119 let rt = current_thread(); in mpsc_bounded_receiver_blocking_recv_panic_caller() 135 let rt = current_thread(); in mpsc_bounded_receiver_blocking_recv_many_panic_caller() 151 let rt = current_thread(); in mpsc_bounded_sender_blocking_send_panic_caller() 167 let rt = current_thread(); in mpsc_unbounded_receiver_blocking_recv_panic_caller() 183 let rt = current_thread(); in mpsc_unbounded_receiver_blocking_recv_many_panic_caller() 229 fn current_thread() -> Runtime { in current_thread() function
|
D | rt_unstable_metrics.rs | 22 let rt = current_thread(); in num_workers() 31 let rt = current_thread(); in num_blocking_threads() 44 let rt = current_thread(); in num_idle_blocking_threads() 98 let rt = current_thread(); in spawned_tasks_count() 125 let rt = current_thread(); in remote_schedule_count() 156 let rt = current_thread(); in worker_thread_id_current_thread() 218 let rt = current_thread(); in worker_park_count() 238 let rt = current_thread(); in worker_park_unpark_count() 279 let rt = current_thread(); in worker_noop_count() 337 let rt = current_thread(); in worker_poll_count_and_time() [all …]
|
D | rt_metrics.rs | 11 let rt = current_thread(); in num_workers() 20 let rt = current_thread(); in num_alive_tasks() 54 let rt = current_thread(); in global_queue_depth_current_thread() 119 fn current_thread() -> Runtime { in current_thread() function
|
D | time_panic.rs | 19 let rt = current_thread(); in pause_panic_caller() 36 let rt = current_thread(); in resume_panic_caller() 89 fn current_thread() -> Runtime { in current_thread() function
|
/external/trusty/lk/arch/arm64/ |
D | thread.c | 62 thread_t *current_thread = get_current_thread(); in initial_thread_func() local 64 …thread_func: thread %p calling %p with arg %p\n", current_thread, current_thread->entry, current_t… in initial_thread_func() 70 ret = current_thread->entry(current_thread->arg); in initial_thread_func() 72 LTRACEF("initial_thread_func: thread %p exiting with %d\n", current_thread, ret); in initial_thread_func()
|
/external/coreboot/src/lib/ |
D | thread.c | 40 static inline struct thread *current_thread(void) in current_thread() function 115 struct thread *current = current_thread(); in schedule() 148 struct thread *current = current_thread(); in call_wrapper() 165 struct thread *current = current_thread(); in call_wrapper_block_state() 221 tocb->priv = current_thread(); in thread_yield_timed_callback() 280 current = current_thread(); in thread_run() 314 current = current_thread(); in thread_run_until() 347 current = current_thread(); in thread_yield_microseconds() 362 current = current_thread(); in thread_coop_enable() 376 current = current_thread(); in thread_coop_disable() [all …]
|
/external/pigweed/pw_sync_threadx/ |
D | interrupt_spin_lock.cc | 38 TX_THREAD* current_thread = tx_thread_identify(); in lock() local 40 if (current_thread != nullptr) { in lock() 75 TX_THREAD* current_thread = tx_thread_identify(); in unlock() local 77 if (current_thread != nullptr) { in unlock()
|
/external/webrtc/rtc_base/ |
D | race_checker.cc | 26 const PlatformThreadRef current_thread = CurrentThreadRef(); in Acquire() local 31 accessing_thread_ = current_thread; in Acquire() 36 return IsThreadRefEqual(accessing_thread, current_thread); in Acquire()
|
D | thread.cc | 769 Thread* current_thread = Thread::Current(); in PreRun() local 772 if (current_thread) { in PreRun() 773 RTC_DCHECK_RUN_ON(current_thread); in PreRun() 774 current_thread->blocking_call_count_++; in PreRun() 775 RTC_DCHECK(current_thread->IsInvokeToThreadAllowed(this)); in PreRun() 776 ThreadManager::Instance()->RegisterSendAndCheckForCycles(current_thread, in PreRun() 784 if (!current_thread) in PreRun() 788 absl::Cleanup cleanup = [this, &ready, current_thread, in PreRun() 790 if (current_thread) { in PreRun() 795 current_thread->socketserver()->WakeUp(); in PreRun() [all …]
|
/external/rust/android-crates-io/crates/tokio/src/runtime/scheduler/ |
D | mod.rs | 2 pub(crate) mod current_thread; 3 pub(crate) use current_thread::CurrentThread; 35 CurrentThread(Arc<current_thread::Handle>), 52 CurrentThread(current_thread::Context), 147 Handle::CurrentThread(h) => current_thread::Handle::spawn(h, future, id), 169 current_thread::Handle::spawn_local(h, future, id) 191 pub(crate) fn as_current_thread(&self) -> &Arc<current_thread::Handle> { 279 pub(crate) fn expect_current_thread(&self) -> ¤t_thread::Context {
|
/external/autotest/client/cros/bluetooth/floss/ |
D | utils.py | 67 threading.current_thread().name, str(method)) 103 current_thread_name = threading.current_thread().name 120 threading.current_thread().name, str(method)) 143 current_thread_name = threading.current_thread().name
|
/external/chromium-trace/catapult/devil/devil/utils/ |
D | reraiser_thread.py | 223 current_thread = threading.current_thread() 224 if isinstance(current_thread, ReraiserThread): 225 return current_thread._thread_group # pylint: disable=no-member
|
/external/cronet/tot/base/allocator/partition_allocator/src/partition_alloc/ |
D | partition_lock.h | 40 base::PlatformThreadRef current_thread = base::PlatformThread::CurrentRef(); in Acquire() local 54 if (owning_thread_ref_.load(std::memory_order_acquire) == current_thread) in Acquire() 62 owning_thread_ref_.store(current_thread, std::memory_order_release); in Acquire()
|
/external/cronet/stable/base/allocator/partition_allocator/src/partition_alloc/ |
D | partition_lock.h | 40 base::PlatformThreadRef current_thread = base::PlatformThread::CurrentRef(); in Acquire() local 54 if (owning_thread_ref_.load(std::memory_order_acquire) == current_thread) in Acquire() 62 owning_thread_ref_.store(current_thread, std::memory_order_release); in Acquire()
|
/external/trusty/lk/arch/x86/ |
D | thread.c | 39 thread_t *current_thread = get_current_thread(); in initial_thread_func() local 45 ret = current_thread->entry(current_thread->arg); in initial_thread_func()
|
/external/python/cpython3/Lib/ |
D | _threading_local.py | 161 thread = current_thread() 168 thread = current_thread() 242 from threading import current_thread, RLock
|
/external/rust/android-crates-io/crates/rayon-core/src/thread_pool/ |
D | mod.rs | 239 let curr = self.registry.current_thread()?; in current_thread_index() 266 let curr = self.registry.current_thread()?; in current_thread_has_pending_tasks() 388 let curr = self.registry.current_thread()?; in yield_now() 400 let curr = self.registry.current_thread()?; in yield_local()
|
/external/rust/android-crates-io/crates/rayon-core/src/broadcast/ |
D | mod.rs | 108 let current_thread = WorkerThread::current().as_ref(); in broadcast_in() localVariable 109 let latch = CountLatch::with_count(n_threads, current_thread); in broadcast_in() 118 latch.wait(current_thread); in broadcast_in()
|
/external/trusty/lk/arch/arm/arm/ |
D | faults.c | 101 struct thread *current_thread = get_current_thread(); in dump_thread_info() local 104 current_thread, current_thread ? current_thread->name : ""); in dump_thread_info()
|
/external/chromium-trace/catapult/common/py_trace_event/py_trace_event/trace_event_impl/ |
D | log.py | 112 tid = threading.current_thread().ident 145 "tid": threading.current_thread().ident, 226 tid=threading.current_thread().ident, 286 tid = threading.current_thread().ident
|