HomeSort by relevance Sort by last modified time
    Searched defs:mutex (Results 151 - 175 of 511) sorted by null

1 2 3 4 5 67 8 91011>>

  /external/mesa3d/src/vulkan/wsi/
wsi_common_queue.h 33 pthread_mutex_t mutex; member in struct:wsi_queue
64 ret = pthread_mutex_init(&queue->mutex, NULL);
85 pthread_mutex_destroy(&queue->mutex);
94 pthread_mutex_lock(&queue->mutex);
102 pthread_mutex_unlock(&queue->mutex);
114 pthread_mutex_lock(&queue->mutex);
132 ret = pthread_cond_timedwait(&queue->cond, &queue->mutex, &abstime);
150 pthread_mutex_unlock(&queue->mutex);
  /hardware/qcom/display/msm8960/libgralloc/
gr.h 65 pthread_mutex_t mutex; member in class:Locker
73 inline Locker() { pthread_mutex_init(&mutex, 0); }
74 inline ~Locker() { pthread_mutex_destroy(&mutex); }
75 inline void lock() { pthread_mutex_lock(&mutex); }
76 inline void unlock() { pthread_mutex_unlock(&mutex); }
  /external/mockito/src/main/java/org/mockito/internal/creation/bytebuddy/
ByteBuddyCrossClassLoaderSerializationSupport.java 59 private final Lock mutex = new ReentrantLock(); field in class:ByteBuddyCrossClassLoaderSerializationSupport
106 mutex.lock();
127 mutex.unlock();
  /external/ImageMagick/MagickCore/
semaphore.c 63 mutex;
87 % ActivateSemaphoreInfo() activates a semaphore under protection of a mutex
212 omp_init_lock((omp_lock_t *) &semaphore_info->mutex);
225 perror("unable to initialize mutex attributes");
234 perror("unable to set mutex type");
239 status=pthread_mutex_init(&semaphore_info->mutex,&mutex_info);
243 perror("unable to initialize mutex");
250 perror("unable to destroy mutex attributes");
259 status=InitializeCriticalSectionAndSpinCount(&semaphore_info->mutex,0x0400);
310 omp_set_lock((omp_lock_t *) &semaphore_info->mutex);
61 mutex; member in struct:SemaphoreInfo
    [all...]
  /external/brotli/java/org/brotli/wrapper/common/
BrotliCommon.java 37 private static final Object mutex = new Object(); field in class:BrotliCommon
78 synchronized (mutex) {
90 synchronized (mutex) {
120 synchronized (mutex) {
  /external/conscrypt/common/src/jni/main/include/conscrypt/
app_data.h 28 #include <mutex> // NOLINT(build/c++11)
78 * (4) Finally, a mutex is needed to make sure that at most one thread is in
80 * requirement. We use the same mutex to guard the field for counting the
114 std::mutex mutex; member in class:conscrypt::AppData
  /external/drm_gralloc/
gralloc_drm_priv.h 46 pthread_mutex_t mutex; member in struct:drm_module_t
  /external/fio/
mutex.c 14 #include "mutex.h"
21 void __fio_mutex_remove(struct fio_mutex *mutex)
23 assert(mutex->magic == FIO_MUTEX_MAGIC);
24 pthread_cond_destroy(&mutex->cond);
27 * Ensure any subsequent attempt to grab this mutex will fail
30 memset(mutex, 0, sizeof(*mutex));
33 void fio_mutex_remove(struct fio_mutex *mutex)
35 __fio_mutex_remove(mutex);
36 munmap((void *) mutex, sizeof(*mutex))
127 struct fio_mutex *mutex = NULL; local
    [all...]
  /external/libcxx/src/
mutex.cpp 1 //===------------------------- mutex.cpp ----------------------------------===//
11 #include "mutex"
24 mutex::~mutex()
30 mutex::lock()
34 __throw_system_error(ec, "mutex lock failed");
38 mutex::try_lock() _NOEXCEPT
44 mutex::unlock() _NOEXCEPT
48 _LIBCPP_ASSERT(ec == 0, "call to mutex::unlock failed");
98 lock_guard<mutex> _(__m_)
    [all...]
  /external/llvm/include/llvm/Support/
RWMutex.h 86 /// SmartMutex - An R/W mutex with a compile time constant parameter that
87 /// indicates whether this mutex should become a no-op when we're not
148 SmartRWMutex<mt_only>& mutex; member in struct:llvm::sys::SmartScopedReader
150 explicit SmartScopedReader(SmartRWMutex<mt_only>& m) : mutex(m) {
151 mutex.lock_shared();
155 mutex.unlock_shared();
163 SmartRWMutex<mt_only>& mutex; member in struct:llvm::sys::SmartScopedWriter
165 explicit SmartScopedWriter(SmartRWMutex<mt_only>& m) : mutex(m) {
166 mutex.lock();
170 mutex.unlock()
    [all...]
  /external/ltp/testcases/open_posix_testsuite/conformance/interfaces/pthread_attr_setschedpolicy/
2-1.c 41 static pthread_mutex_t mutex = PTHREAD_MUTEX_INITIALIZER; variable
73 rc = pthread_mutex_lock(&mutex);
85 rc = pthread_mutex_unlock(&mutex);
162 rc = pthread_mutex_lock(&mutex);
178 rc = pthread_mutex_unlock(&mutex);
  /external/ltp/testcases/open_posix_testsuite/functional/threads/condvar/
pthread_cond_wait_1.c 39 pthread_mutex_t mutex = PTHREAD_MUTEX_INITIALIZER; variable
67 SAFE_PFUNC(pthread_mutex_lock(&mutex));
70 SAFE_PFUNC(pthread_cond_wait(&cond, &mutex));
78 SAFE_PFUNC(pthread_mutex_unlock(&mutex));
pthread_cond_wait_2.c 39 pthread_mutex_t mutex = PTHREAD_MUTEX_INITIALIZER; variable
67 SAFE_PFUNC(pthread_mutex_lock(&mutex));
70 SAFE_PFUNC(pthread_cond_wait(&cond, &mutex));
78 SAFE_PFUNC(pthread_mutex_unlock(&mutex));
  /external/ltp/testcases/open_posix_testsuite/functional/threads/schedule/
1-2.c 13 * 1. Create a mutex and lock
14 * 2. Create a high priority thread and make it wait on the mutex
17 * 5. Unlock the mutex and make sure that the higher priority thread
39 pthread_mutex_t mutex = PTHREAD_MUTEX_INITIALIZER; variable
69 SAFE_PFUNC(pthread_mutex_lock(&mutex));
77 SAFE_PFUNC(pthread_mutex_unlock(&mutex));
129 SAFE_PFUNC(pthread_mutex_lock(&mutex));
150 SAFE_PFUNC(pthread_mutex_unlock(&mutex));
  /external/mesa3d/src/gallium/auxiliary/pipebuffer/
pb_bufmgr_mm.c 56 pipe_mutex mutex; member in struct:mm_pb_manager
102 pipe_mutex_lock(mm->mutex);
105 pipe_mutex_unlock(mm->mutex);
187 pipe_mutex_lock(mm->mutex);
191 pipe_mutex_unlock(mm->mutex);
211 pipe_mutex_unlock(mm->mutex);
219 pipe_mutex_unlock(mm->mutex);
236 pipe_mutex_lock(mm->mutex);
243 pipe_mutex_unlock(mm->mutex);
269 pipe_mutex_init(mm->mutex);
    [all...]
pb_slab.h 99 * the pb_slab functions, or a deadlock (recursive mutex lock) may occur.
113 pipe_mutex mutex; member in struct:pb_slabs
  /external/mesa3d/src/gallium/auxiliary/util/
u_queue.h 43 pipe_mutex mutex; member in struct:util_queue_fence
  /external/mesa3d/src/gallium/state_trackers/clover/core/
event.hpp 95 mutable std::mutex mutex; member in class:clover::event
  /external/mesa3d/src/gallium/state_trackers/wgl/
stw_framebuffer.h 50 * This mutex has two purposes:
54 * Note: if both this mutex and the stw_device::fb_mutex need to be locked,
57 CRITICAL_SECTION mutex; member in struct:stw_framebuffer
62 * Note that even access to immutable members implies acquiring the mutex
112 * This is protected by stw_device::fb_mutex, not the mutex above.
115 * acquiring the stw_framebuffer::mutex of the framebuffer to be deleted.
118 * It is not necessary to acquire the mutex above to navigate the linked list
129 * This function will acquire stw_framebuffer::mutex. stw_framebuffer_unlock
145 assert(stw_own_mutex(&fb->mutex));
157 * This function will acquire stw_framebuffer::mutex. stw_framebuffer_unloc
    [all...]
  /external/swiftshader/third_party/LLVM/include/llvm/Support/
RWMutex.h 83 /// SmartMutex - An R/W mutex with a compile time constant parameter that
84 /// indicates whether this mutex should become a no-op when we're not
144 SmartRWMutex<mt_only>& mutex; member in struct:llvm::sys::SmartScopedReader
146 explicit SmartScopedReader(SmartRWMutex<mt_only>& m) : mutex(m) {
147 mutex.reader_acquire();
151 mutex.reader_release();
159 SmartRWMutex<mt_only>& mutex; member in struct:llvm::sys::SmartScopedWriter
161 explicit SmartScopedWriter(SmartRWMutex<mt_only>& m) : mutex(m) {
162 mutex.writer_acquire();
166 mutex.writer_release()
    [all...]
  /external/tensorflow/tensorflow/contrib/boosted_trees/resources/
quantile_stream_resource.h 23 #include "tensorflow/core/platform/mutex.h"
48 tensorflow::mutex* mutex() { return &mu_; } function in class:tensorflow::boosted_trees::QuantileStreamResource
87 // Mutex for the whole resource.
88 tensorflow::mutex mu_;
  /external/tensorflow/tensorflow/core/platform/default/
mutex.h 19 // IWYU pragma: private, include "third_party/tensorflow/core/platform/mutex.h"
20 // IWYU pragma: friend third_party/tensorflow/core/platform/mutex.h
24 #include <mutex>
36 // Mimic std::mutex + C++17's shared_mutex, adding a LinkerInitialized
37 // constructor interface. This type is as fast as mutex, but is also a shared
39 class LOCKABLE mutex { class in namespace:tensorflow
41 mutex() { nsync::nsync_mu_init(&mu_); } function in class:tensorflow::mutex
44 explicit mutex(LinkerInitialized x) {} function in class:tensorflow::mutex
63 // Mimic a subset of the std::unique_lock<tensorflow::mutex> functionality.
66 typedef ::tensorflow::mutex mutex_type
89 mutex_type* mutex() { return mu_; } function in class:tensorflow::mutex_lock
127 mutex_type* mutex() { return mu_; } function in class:tensorflow::tf_shared_lock
    [all...]
  /frameworks/base/libs/usb/tests/accessorytest/
audio.c 47 static pthread_mutex_t mutex = PTHREAD_MUTEX_INITIALIZER; variable
58 pthread_mutex_lock(&mutex);
61 pthread_cond_wait(&empty_cond, &mutex);
71 pthread_mutex_unlock(&mutex);
77 pthread_mutex_lock(&mutex);
85 pthread_mutex_unlock(&mutex);
92 pthread_mutex_lock(&mutex);
95 pthread_cond_wait(&full_cond, &mutex);
105 pthread_mutex_unlock(&mutex);
111 pthread_mutex_lock(&mutex);
    [all...]
hid.c 37 static pthread_mutex_t mutex = PTHREAD_MUTEX_INITIALIZER; variable
84 pthread_mutex_lock(&mutex);
106 pthread_mutex_unlock(&mutex);
  /frameworks/native/services/vr/performanced/
performance_service_tests.cpp 10 #include <mutex>
75 std::mutex mutex; local
79 std::unique_lock<std::mutex> lock(mutex);
88 std::unique_lock<std::mutex> lock(mutex);
97 std::lock_guard<std::mutex> lock(mutex);

Completed in 388 milliseconds

1 2 3 4 5 67 8 91011>>