Searched defs:thread (Results 276 - 300 of 379) sorted by relevance

<<111213141516

/openjdk7/hotspot/src/os/solaris/vm/
H A DattachListener_solaris.cpp46 // listener thread to startup. This thread creats a door that is
90 // semaphore to wakeup listener thread
533 JavaThread* thread = JavaThread::current(); local
534 ThreadBlockInVM tbivm(thread);
536 thread->set_suspend_equivalent();
555 thread->check_and_wait_while_suspended();
564 JavaThread* thread = JavaThread::current(); local
565 ThreadBlockInVM tbivm(thread);
567 thread
580 JavaThread* thread = JavaThread::current(); local
[all...]
/openjdk7/hotspot/src/os_cpu/bsd_x86/vm/
H A Dos_bsd_x86.cpp310 // For Forte Analyzer AsyncGetCallTrace profiling support - thread
315 ExtendedPC os::Bsd::fetch_frame_from_ucontext(Thread* thread, argument
318 assert(thread != NULL, "just checking");
428 JavaThread* thread = NULL; local
433 thread = (JavaThread*)t;
455 if (info != NULL && uc != NULL && thread != NULL) {
473 // check if fault address is within thread stack
474 if (addr < thread->stack_base() &&
475 addr >= thread->stack_base() - thread
[all...]
/openjdk7/hotspot/src/os_cpu/linux_sparc/vm/
H A Dos_linux_sparc.cpp93 // For Forte Analyzer AsyncGetCallTrace profiling support - thread is
98 ExtendedPC os::Linux::fetch_frame_from_ucontext(Thread* thread, argument
102 assert(thread != NULL, "just checking");
169 // initial thread needs special handling because pthread_getattr_np()
389 JavaThread* thread,
391 // check if fault address is within thread stack
392 if (addr < thread->stack_base() &&
393 addr >= thread->stack_base() - thread->stack_size()) {
395 if (thread
386 checkOverflow(sigcontext* uc, address pc, address addr, JavaThread* thread, address* stub) argument
470 checkFPFault(address pc, int code, JavaThread* thread, address* stub) argument
483 checkNullPointer(address pc, intptr_t fault, JavaThread* thread, address* stub) argument
506 checkSerializePage(JavaThread* thread, address addr) argument
579 JavaThread* thread = NULL; local
[all...]
/openjdk7/hotspot/src/os_cpu/solaris_sparc/vm/
H A Dos_solaris_sparc.cpp67 # include <thread.h>
122 bool os::Solaris::valid_ucontext(Thread* thread, ucontext_t* valid, ucontext_t* suspect) { argument
131 if (thread->is_Java_thread()) {
132 if (!valid_stack_address(thread, (address)suspect)) {
133 DEBUG_ONLY(tty->print_cr("valid_ucontext: uc_link not in thread stack");)
137 if (!valid_stack_address(thread, _sp) ||
138 !frame::is_valid_stack_pointer(((JavaThread*)thread)->base_of_stack_pointer(), (intptr_t*)_sp)) {
139 DEBUG_ONLY(tty->print_cr("valid_ucontext: stackpointer not in thread stack");)
149 ucontext_t* os::Solaris::get_valid_uc_in_signal_handler(Thread *thread, argument
164 } else if (os::Solaris::valid_ucontext(thread, u
209 fetch_frame_from_ucontext(Thread* thread, ucontext_t* uc, intptr_t** ret_sp, intptr_t** ret_fp) argument
334 JavaThread* thread = NULL; local
[all...]
/openjdk7/hotspot/src/os_cpu/solaris_x86/vm/
H A Dos_solaris_x86.cpp67 # include <thread.h>
123 bool os::Solaris::valid_ucontext(Thread* thread, ucontext_t* valid, ucontext_t* suspect) { argument
132 if (thread->is_Java_thread()) {
133 if (!valid_stack_address(thread, (address)suspect)) {
134 DEBUG_ONLY(tty->print_cr("valid_ucontext: uc_link not in thread stack");)
137 if (!valid_stack_address(thread, (address) suspect->uc_mcontext.gregs[REG_SP])) {
138 DEBUG_ONLY(tty->print_cr("valid_ucontext: stackpointer not in thread stack");)
148 ucontext_t* os::Solaris::get_valid_uc_in_signal_handler(Thread *thread, argument
157 } else if (os::Solaris::valid_ucontext(thread, uc, uc->uc_link)) {
163 } else if (os::Solaris::valid_ucontext(thread, u
196 fetch_frame_from_ucontext(Thread* thread, ucontext_t* uc, intptr_t** ret_sp, intptr_t** ret_fp) argument
394 JavaThread* thread = NULL; local
[all...]
/openjdk7/hotspot/src/os_cpu/windows_x86/vm/
H A Dos_windows_x86.cpp72 // Install a win32 structured exception handler around thread.
73 void os::os_exception_wrapper(java_call_t f, JavaValue* value, methodHandle* method, JavaCallArguments* args, Thread* thread) { argument
77 // We store the current thread in this wrapperthread location
80 // code can then get the thread pointer via FS.
85 volatile Thread* wrapperthread = thread;
108 "thread pointer offset from SEH changed");
113 f(value, method, args, thread);
/openjdk7/hotspot/src/share/vm/prims/
H A DjvmtiThreadState.hpp32 #include "runtime/thread.hpp"
73 // The Jvmti state for each thread (across all JvmtiEnv):
99 // doubly-linked linear list of active thread state
111 JvmtiThreadState(JavaThread *thread);
120 // is event_type enabled and usable for this thread in any enviroments?
129 // Must only be called in situations where the state is for the current thread and
143 // access to the linked list of all JVMTI thread states
154 // These functions should only be called at a safepoint - usually called from same thread.
256 // Note again, that this redirection happens only for the verifier thread.
278 JavaThread *thread) {
277 class_to_verify_considering_redefinition(klassOop klass, JavaThread *thread) argument
329 state_for_while_locked(JavaThread *thread) argument
346 state_for(JavaThread *thread) argument
[all...]
/openjdk7/hotspot/src/share/vm/runtime/
H A DbiasedLocking.cpp76 // Use async VM operation to avoid blocking the Watcher thread.
111 // Returns MonitorInfos for all objects locked on this thread in youngest to oldest order
112 static GrowableArray<MonitorInfo*>* get_or_compute_monitor_info(JavaThread* thread) { argument
113 GrowableArray<MonitorInfo*>* info = thread->cached_monitor_info();
120 // It's possible for the thread to not have any Java frames on it,
121 // i.e., if it's the main thread and it's already returned from main()
122 if (thread->has_last_Java_frame()) {
123 RegisterMap rm(thread);
124 for (javaVFrame* vf = thread->last_java_vframe(&rm); vf != NULL; vf = vf->java_sender()) {
141 thread
[all...]
H A Dmutex.cpp57 // * A thread acquires ownership of a Monitor/Mutex by CASing the LockByte
59 // is advisory and is used only to verify that the thread calling unlock()
60 // is indeed the last thread to have acquired the lock.
96 // -- Invariant: a thread appears on at most one list -- cxq, EntryList
98 // -- For a given monitor there can be at most one "OnDeck" thread at any
108 // As necessary, the unlock()ing thread identifies, unlinks, and unparks
109 // an "heir presumptive" tentative successor thread from the EntryList.
110 // This becomes the so-called "OnDeck" thread, of which there can be only
115 // The exiting thread does _not_ grant or pass ownership to the
116 // successor thread
1365 check_prelock_state(Thread *thread) argument
1378 check_block_state(Thread *thread) argument
[all...]
H A Dos.hpp78 CriticalPriority = 11 // Critical thread priority
86 typedef void (*java_call_t)(JavaValue* value, methodHandle* method, JavaCallArguments* args, Thread* thread);
169 // The "virtual time" of a thread is the amount of time a thread has
171 // this functionality for the current thread, and if so:
175 // thread.
223 // Give a name to the current thread.
232 static bool stack_shadow_pages_available(Thread *thread, methodHandle method);
345 // Routines used to serialize the thread state without using membars
348 // Since we write to the serialize page from every thread, w
371 write_memory_serialize_page(JavaThread *thread) argument
378 is_memory_serialize_page(JavaThread *thread, address addr) argument
808 SuspendedThreadTaskContext(Thread* thread, void *ucontext) argument
809 Thread* thread() const { return _thread; } function in class:os::SuspendedThreadTaskContext
818 SuspendedThreadTask(Thread* thread) argument
[all...]
H A Dsafepoint.cpp110 assert(myThread->is_VM_thread(), "Only VM thread may execute a safepoint");
172 // When returning from the native code, a Java thread must check
174 // VM thread sees a Java thread in native, it does
175 // not wait for this thread to block. The order of the memory
179 // the VM thread issues a memory barrier instruction
181 // a memory barrier for each Java thread making native calls, each Java
182 // thread performs a write to a single memory page after changing
183 // the thread state. The VM thread perform
557 safepoint_safe(JavaThread *thread, JavaThreadState state) argument
578 check_for_lazy_critical_native(JavaThread *thread, JavaThreadState state) argument
613 block(JavaThread *thread) argument
803 handle_polling_page_exception(JavaThread *thread) argument
881 ThreadSafepointState(JavaThread *thread) argument
888 create(JavaThread *thread) argument
893 destroy(JavaThread *thread) argument
[all...]
H A Dsweeper.cpp238 // Only one thread at a time will sweep
291 assert(Thread::current()->is_Java_thread(), "should be java thread");
292 JavaThread* thread = (JavaThread*)Thread::current(); local
293 ThreadBlockInVM tbivm(thread);
294 thread->java_suspend_self();
H A Dvframe.cpp49 vframe::vframe(const frame* fr, const RegisterMap* reg_map, JavaThread* thread) argument
50 : _reg_map(reg_map), _thread(thread) {
55 vframe::vframe(const frame* fr, JavaThread* thread) argument
56 : _reg_map(thread), _thread(thread) {
61 vframe* vframe::new_vframe(const frame* f, const RegisterMap* reg_map, JavaThread* thread) { argument
64 return new interpretedVFrame(f, reg_map, thread);
72 return new compiledVFrame(f, reg_map, thread, nm);
79 return new_vframe(&s, &temp_map, thread);
84 return new externalVFrame(f, reg_map, thread);
366 entryVFrame(const frame* fr, const RegisterMap* reg_map, JavaThread* thread) argument
379 vframeStream(JavaThread* thread, frame top_frame, bool stop_at_java_call_stub) argument
[all...]
H A Dvm_operations.hpp31 #include "runtime/thread.hpp"
35 // initiated by a Java thread but that must
128 // VM operation support (used by VM thread)
131 void set_calling_thread(Thread* thread, ThreadPriority priority);
136 // Called by VM thread - does in turn invoke doit(). Do not override this
140 // If the thread invoking VMThread::execute((VM_Operation*) is a JavaThread,
141 // doit_prologue() is called in that thread before transferring control to
170 // vm thread, either concurrently with mutators or with the mutators
203 VM_ThreadStop(oop thread, oop throwable) { argument
204 _thread = thread;
[all...]
/openjdk7/hotspot/src/share/vm/services/
H A DmemTracker.cpp44 void SyncThreadRecorderClosure::do_thread(Thread* thread) { argument
46 if (thread->is_Java_thread()) {
47 JavaThread* javaThread = (JavaThread*)thread;
117 // create nmt lock for multi-thread execution
118 assert(_main_thread_tid == os::current_thread_id(), "wrong thread");
129 assert(_main_thread_tid == os::current_thread_id(), "wrong thread");
156 * 2. Worker thread calls MemTracker::final_shutdown(), which transites
165 // we still in single thread mode, there is not contention
200 // can not delete worker inside the thread critical
239 * retrieve per-thread recorde
242 get_thread_recorder(JavaThread* thread) argument
336 write_tracking_record(address addr, MEMFLAGS flags, size_t size, jint seq, address pc, JavaThread* thread) argument
493 thread_exiting(JavaThread* thread) argument
[all...]
H A DmemoryService.cpp74 void do_thread(Thread* thread);
78 void GcThreadCountClosure::do_thread(Thread* thread) { argument
104 // set the GC thread count
/openjdk7/jdk/src/windows/classes/sun/nio/ch/
H A DWindowsSelectorImpl.java70 // Number of helper threads needed for select. We need one thread per
115 // SubSelector for the main thread
154 // do polling in the main thread. Main thread is responsible for
163 // Main thread is out of poll(). Wakeup others and wait for them
191 // This function is called by a helper thread to wait for the
192 // next round of poll(). It also checks, if this thread became
193 // redundant. If yes, it returns true, notifying the thread
195 private synchronized boolean waitForStart(SelectThread thread) { argument
197 while (runsCounter == thread
[all...]
/openjdk7/jdk/test/com/sun/jdi/
H A DTestScaffold.java184 Thread thread = new Thread(this);
185 thread.setDaemon(true);
186 thread.start();
492 * This is normally called in the main thread of the test case.
493 * It starts up an EventHandler thread that gets events coming in
494 * from the debuggee and distributes them to listeners. That thread
549 vmStartThread = event.thread();
584 * This code is commented out because it needs a thread
589 * mainThread = bpe.thread();
744 private StepEvent doStep(ThreadReference thread, in argument
758 stepIntoInstruction(ThreadReference thread) argument
762 stepIntoLine(ThreadReference thread) argument
766 stepOverInstruction(ThreadReference thread) argument
770 stepOverLine(ThreadReference thread) argument
774 stepOut(ThreadReference thread) argument
[all...]
/openjdk7/jdk/src/share/demo/jvmti/hprof/
H A Dhprof_trace.c44 * A trace is an optional thread serial number plus N frames.
46 * The thread serial number is added to the key only if the user asks for
53 * It is important that the thread serial number is used and not the
55 * but the thread serial number is unique per thread.
527 /* Get the trace for the supplied thread */
529 trace_get_current(jthread thread, SerialNumber thread_serial_num, argument
539 HPROF_ASSERT(thread!=NULL);
546 /* Get the stack trace for this one thread */
549 getStackTrace(thread, jframes_buffe
[all...]
/openjdk7/jdk/src/share/demo/jvmti/mtrace/
H A Dmtrace.c153 get_thread_name(jvmtiEnv *jvmti, jthread thread, char *tname, int maxlen) argument
164 /* Get the thread information, which includes the name */
165 error = (*jvmti)->GetThreadInfo(jvmti, thread, &info);
166 check_jvmti_error(jvmti, error, "Cannot get thread info");
168 /* The thread might not have a name, be careful here. */
172 /* Copy the thread name into tname if it will fit */
244 MTRACE_native_entry(JNIEnv *env, jclass klass, jobject thread, jint cnum, jint mnum) argument
271 MTRACE_native_exit(JNIEnv *env, jclass klass, jobject thread, jint cnum, jint mnum) argument
343 cbVMInit(jvmtiEnv *jvmti, JNIEnv *env, jthread thread) argument
352 get_thread_name(jvmti, thread, tnam
452 cbThreadStart(jvmtiEnv *jvmti, JNIEnv *env, jthread thread) argument
467 cbThreadEnd(jvmtiEnv *jvmti, JNIEnv *env, jthread thread) argument
[all...]
/openjdk7/hotspot/agent/src/share/classes/sun/jvm/hotspot/debugger/proc/
H A DProcDebuggerLocal.java453 public synchronized CFrame topFrameForThread(ThreadProxy thread) argument
457 if (isCore && ((res = (CFrame) topFrameCache.get(thread)) != null)) {
460 ThreadContext context = thread.getContext();
468 topFrameCache.put(thread, res);
686 // libthread.so's dlopen handle, thread agent
705 // for core files, we cache load object list, thread list, top frames etc.
/openjdk7/jdk/src/share/classes/java/util/concurrent/
H A DThreadPoolExecutor.java60 * Executors#newCachedThreadPool} (unbounded thread pool, with
61 * automatic thread reclamation), {@link Executors#newFixedThreadPool}
62 * (fixed size thread pool) and {@link
63 * Executors#newSingleThreadExecutor} (single background thread), that
79 * than corePoolSize threads are running, a new thread is created to
82 * threads running, a new thread will be created only if the queue is
84 * create a fixed-size thread pool. By setting maximumPoolSize to an
106 * alter the thread's name, thread group, priority, daemon status,
107 * etc. If a {@code ThreadFactory} fails to create a thread whe
597 final Thread thread; field in class:ThreadPoolExecutor.Worker
[all...]
/openjdk7/jdk/src/share/classes/java/util/concurrent/locks/
H A DAbstractQueuedLongSynchronizer.java85 * information about a thread in the predecessor of its node. A
86 * "status" field in each node keeps track of whether a thread
90 * thread. The status field does NOT control whether threads are
91 * granted locks etc though. A thread may try to acquire if it is
94 * contender thread may need to rewait.
120 * The thread id for each node is kept in its own node, so a
122 * next link to determine which thread it is. Determination of
163 /** waitStatus value to indicate thread has cancelled */
165 /** waitStatus value to indicate successor's thread needs unparking */
167 /** waitStatus value to indicate thread i
243 volatile Thread thread; field in class:AbstractQueuedLongSynchronizer.Node
282 Node(Thread thread, Node mode) argument
287 Node(Thread thread, int waitStatus) argument
1219 isQueued(Thread thread) argument
[all...]
H A DAbstractQueuedSynchronizer.java72 * waiting thread (if one exists) must also determine whether it can
83 * held with respect to the current thread, method {@link #release}
100 * thread queues. Typical subclasses requiring serializability will
121 * must be internally thread-safe, and should in general be short and
127 * AbstractOwnableSynchronizer} useful to keep track of the thread
139 * <em>enqueue thread if it is not already queued</em>;
140 * <em>possibly block current thread</em>;
145 * <em>unblock the first queued thread</em>;
151 * enqueuing, a newly acquiring thread may <em>barge</em> ahead of
193 * thread, thi
466 volatile Thread thread; field in class:AbstractQueuedSynchronizer.Node
505 Node(Thread thread, Node mode) argument
510 Node(Thread thread, int waitStatus) argument
1442 isQueued(Thread thread) argument
[all...]
/openjdk7/hotspot/src/share/vm/memory/
H A Dallocation.cpp701 Thread *thread = ThreadLocalStorage::get_thread_slow(); local
702 _nesting = thread->resource_area()->nesting();

Completed in 95 milliseconds

<<111213141516