HomeSort by relevance Sort by last modified time
    Searched defs:mutex (Results 101 - 125 of 287) sorted by null

1 2 3 45 6 7 8 91011>>

  /external/brotli/java/org/brotli/wrapper/enc/
BrotliEncoderChannel.java 22 private final Object mutex = new Object(); field in class:BrotliEncoderChannel
47 synchronized (mutex) {
54 synchronized (mutex) {
61 synchronized (mutex) {
  /external/compiler-rt/lib/tsan/rtl/
tsan_debugging.cc 26 if (typ == ReportTypeMutexDestroyLocked) return "locked-mutex-destroy";
27 if (typ == ReportTypeMutexDoubleLock) return "mutex-double-lock";
28 if (typ == ReportTypeMutexInvalidAccess) return "mutex-invalid-access";
29 if (typ == ReportTypeMutexBadUnlock) return "mutex-bad-unlock";
30 if (typ == ReportTypeMutexBadReadLock) return "mutex-bad-read-lock";
31 if (typ == ReportTypeMutexBadReadUnlock) return "mutex-bad-read-unlock";
132 ReportMutex *mutex = rep->mutexes[idx]; local
133 *mutex_id = mutex->id;
134 *addr = (void *)mutex->addr;
135 *destroyed = mutex->destroyed
    [all...]
  /external/harfbuzz_ng/src/
hb-mutex.hh 38 /* mutex */
142 hb_lock_t (hb_mutex_t &mutex_) : mutex (mutex_) { mutex.lock (); }
143 ~hb_lock_t () { mutex.unlock (); }
145 hb_mutex_t &mutex; member in struct:hb_lock_t
  /external/harfbuzz_ng/test/api/
test-multithread.c 43 static pthread_mutex_t mutex = PTHREAD_MUTEX_INITIALIZER; variable
81 pthread_mutex_lock (&mutex);
82 pthread_mutex_unlock (&mutex);
102 pthread_mutex_lock (&mutex);
112 pthread_mutex_unlock (&mutex);
  /external/libvpx/libvpx/vp9/encoder/
vp9_ethread.h 36 pthread_mutex_t *mutex; member in struct:VP9RowMTSyncData
63 // Deallocate row based multi-threading synchronization related mutex and data.
  /external/ltp/testcases/open_posix_testsuite/conformance/interfaces/pthread_cond_signal/
2-2.c 11 * own the mutex with which it called pthread_cond_timedwait().
27 pthread_mutex_t mutex; member in struct:testdata
41 if (pthread_mutex_lock(&td.mutex) != 0) {
42 fprintf(stderr, "[Thread 0x%p] failed to acquire the mutex\n",
46 fprintf(stderr, "[Thread 0x%p] started and locked the mutex\n",
60 rc = pthread_cond_timedwait(&td.cond, &td.mutex, &timeout);
67 if (pthread_mutex_trylock(&td.mutex) != 0) {
69 "[Thread 0x%p] should be able to lock the recursive mutex again\n",
75 "[Thread 0x%p] was wakened and acquired the mutex again\n",
79 if (pthread_mutex_unlock(&td.mutex) != 0)
    [all...]
  /external/mesa3d/src/egl/main/
egllog.c 59 mtx_t mutex; member in struct:__anon33192
64 .mutex = _MTX_INITIALIZER_NP,
150 mtx_lock(&logging.mutex);
160 mtx_unlock(&logging.mutex);
  /external/mesa3d/src/gallium/auxiliary/os/
os_thread.h 31 * Thread, mutex, condition variable, barrier, semaphore and
45 #define pipe_mutex_assert_locked(mutex) \
46 __pipe_mutex_assert_locked(&(mutex))
49 __pipe_mutex_assert_locked(mtx_t *mutex)
55 int ret = mtx_trylock(mutex);
58 mtx_unlock(mutex);
60 (void)mutex;
71 mtx_t mutex; member in struct:__anon33226
80 (void) mtx_init(&sema->mutex, mtx_plain);
88 mtx_destroy(&sema->mutex);
    [all...]
  /external/mesa3d/src/gallium/auxiliary/pipebuffer/
pb_cache.h 55 mtx_t mutex; member in struct:pb_cache
pb_bufmgr_mm.c 56 mtx_t mutex; member in struct:mm_pb_manager
102 mtx_lock(&mm->mutex);
105 mtx_unlock(&mm->mutex);
187 mtx_lock(&mm->mutex);
191 mtx_unlock(&mm->mutex);
211 mtx_unlock(&mm->mutex);
219 mtx_unlock(&mm->mutex);
236 mtx_lock(&mm->mutex);
243 mtx_unlock(&mm->mutex);
269 (void) mtx_init(&mm->mutex, mtx_plain)
    [all...]
  /external/mesa3d/src/gallium/auxiliary/util/
u_ringbuffer.c 20 mtx_t mutex; member in struct:util_ringbuffer
39 (void) mtx_init(&ring->mutex, mtx_plain);
51 mtx_destroy(&ring->mutex);
79 mtx_lock(&ring->mutex);
88 cnd_wait(&ring->change, &ring->mutex);
106 mtx_unlock(&ring->mutex);
120 mtx_lock(&ring->mutex);
126 cnd_wait(&ring->change, &ring->mutex);
158 mtx_unlock(&ring->mutex);
  /external/mesa3d/src/gallium/winsys/svga/drm/
vmw_surface.h 60 mtx_t mutex; member in struct:vmw_svga_winsys_surface
  /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);
  /external/perfetto/src/base/
watchdog_unittest.cc 31 #include <mutex>
137 std::mutex mutex; local
143 auto thread_fn = [&mutex, &cv, &quit, &expected_tid](size_t thread_num) {
150 std::unique_lock<std::mutex> lock(mutex);
154 std::unique_lock<std::mutex> lock(mutex);
  /external/tensorflow/tensorflow/core/kernels/boosted_trees/quantiles/
quantile_stream_resource.h 22 #include "tensorflow/core/platform/mutex.h"
50 tensorflow::mutex* mutex() { return &mu_; } function in class:tensorflow::BoostedTreesQuantileStreamResource
73 // Mutex for the whole resource.
74 tensorflow::mutex mu_;
  /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 64 mutex;
88 % ActivateSemaphoreInfo() activates a semaphore under protection of a mutex
213 omp_init_lock((omp_lock_t *) &semaphore_info->mutex);
226 perror("unable to initialize mutex attributes");
235 perror("unable to set mutex type");
240 status=pthread_mutex_init(&semaphore_info->mutex,&mutex_info);
244 perror("unable to initialize mutex");
251 perror("unable to destroy mutex attributes");
260 status=InitializeCriticalSectionAndSpinCount(&semaphore_info->mutex,0x0400);
311 omp_set_lock((omp_lock_t *) &semaphore_info->mutex);
62 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/libcxx/src/
mutex.cpp 1 //===------------------------- mutex.cpp ----------------------------------===//
10 #include "mutex"
23 mutex::~mutex()
29 mutex::lock()
33 __throw_system_error(ec, "mutex lock failed");
37 mutex::try_lock() _NOEXCEPT
43 mutex::unlock() _NOEXCEPT
47 _LIBCPP_ASSERT(ec == 0, "call to mutex::unlock failed");
97 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));

Completed in 768 milliseconds

1 2 3 45 6 7 8 91011>>