HomeSort by relevance Sort by last modified time
    Searched refs:mu_ (Results 51 - 75 of 279) sorted by null

1 23 4 5 6 7 8 91011>>

  /external/tensorflow/tensorflow/core/kernels/
conditional_accumulator_base.h 65 mutex_lock lock(mu_);
84 EXCLUSIVE_LOCKS_REQUIRED(mu_) = 0; member in class:tensorflow::ConditionalAccumulatorBase
94 DoneCallback done_callback; // must be run outside mu_
98 RunCallback run_callback; // must be run while holding mu_
128 mutex mu_; member in class:tensorflow::ConditionalAccumulatorBase
129 int counter_ GUARDED_BY(mu_);
130 int64 current_global_step_ GUARDED_BY(mu_);
132 std::deque<Attempt> takegrad_attempts_ GUARDED_BY(mu_);
151 EXCLUSIVE_LOCKS_REQUIRED(mu_);
156 EXCLUSIVE_LOCKS_REQUIRED(mu_);
    [all...]
tensor_array.h 190 mutex_lock l(mu_);
198 mutex_lock l(mu_);
226 mutex_lock l(mu_);
233 mutex_lock l(mu_);
248 mutex_lock l(mu_);
253 mutex_lock l(mu_);
264 mutex_lock l(mu_);
270 mutex_lock l(mu_);
276 mutex_lock l(mu_);
284 mutex_lock l(mu_);
376 mutex mu_; member in class:tensorflow::TensorArray
    [all...]
  /external/tensorflow/tensorflow/core/util/
guarded_philox_random.h 71 mutex mu_; member in class:tensorflow::GuardedPhiloxRandom
72 random::PhiloxRandom generator_ GUARDED_BY(mu_);
tensor_slice_reader_cache.h 48 mutable mutex mu_; member in class:tensorflow::checkpoint::TensorSliceReaderCacheWrapper
71 mutex mu_; member in class:tensorflow::checkpoint::TensorSliceReaderCache
  /external/clang/test/Sema/
warn-thread-safety-analysis.c 31 struct Mutex *mu_; member in struct:Foo
45 int a_ GUARDED_BY(foo_.mu_);
46 int *b_ PT_GUARDED_BY(foo_.mu_) = &a_;
67 void set_value(int *a, int value) EXCLUSIVE_LOCKS_REQUIRED(foo_.mu_) {
71 int get_value(int *p) SHARED_LOCKS_REQUIRED(foo_.mu_){
104 set_value(&a_, 0); // expected-warning{{calling function 'set_value' requires holding mutex 'foo_.mu_' exclusively}}
105 get_value(b_); // expected-warning{{calling function 'get_value' requires holding mutex 'foo_.mu_'}}
106 mutex_exclusive_lock(foo_.mu_);
108 mutex_unlock(foo_.mu_);
109 mutex_shared_lock(foo_.mu_);
    [all...]
  /external/tensorflow/tensorflow/core/distributed_runtime/
master_session.h 130 mutex mu_; member in class:tensorflow::MasterSession
131 std::unique_ptr<GraphExecutionState> execution_state_ GUARDED_BY(mu_);
141 RCGMap run_graphs_ GUARDED_BY(mu_);
142 RCGMap partial_run_graphs_ GUARDED_BY(mu_);
176 GUARDED_BY(mu_);
180 int32 num_running_ GUARDED_BY(mu_) = 0; member in class:tensorflow::MasterSession
182 bool closed_ GUARDED_BY(mu_) = false; member in class:tensorflow::MasterSession
183 bool garbage_collected_ GUARDED_BY(mu_) = false; member in class:tensorflow::MasterSession
185 std::unordered_map<uint64, int64> subgraph_execution_counts_ GUARDED_BY(mu_);
189 int64 next_node_id_ GUARDED_BY(mu_) = 0 member in class:tensorflow::MasterSession
    [all...]
partial_run_mgr.cc 31 mutex_lock l(mu_);
49 mutex_lock l(mu_);
67 mutex_lock l(mu_);
76 mutex_lock l(mu_);
92 mutex_lock l(mu_);
  /external/tensorflow/tensorflow/core/framework/
tracking_allocator.cc 44 mutex_lock lock(mu_);
57 mutex_lock lock(mu_);
67 mutex_lock lock(mu_);
88 mutex_lock lock(mu_);
98 mutex_lock lock(mu_);
118 mutex_lock lock(mu_);
131 mutex_lock lock(mu_);
144 mutex_lock lock(mu_);
166 mutex_lock lock(mu_);
178 mutex_lock lock(mu_);
    [all...]
reader_op_kernel.h 44 LOCKS_EXCLUDED(mu_) {
45 mutex_lock l(mu_);
73 EXCLUSIVE_LOCKS_REQUIRED(mu_) override {
83 std::function<ReaderInterface*()> factory_ GUARDED_BY(mu_);
allocator.cc 83 mutex_lock l(mu_);
98 mutex_lock l(mu_);
105 mutex_lock l(mu_);
110 mutex_lock l(mu_);
121 mutex mu_; member in class:tensorflow::CPUAllocator
122 AllocatorStats stats_ GUARDED_BY(mu_);
  /build/kati/
thread_pool.cc 40 unique_lock<mutex> lock(mu_);
47 unique_lock<mutex> lock(mu_);
64 unique_lock<mutex> lock(mu_);
82 mutex mu_; member in class:ThreadPoolImpl
  /external/tensorflow/tensorflow/compiler/xla/service/cpu/
xfeed_manager.cc 31 tensorflow::mutex_lock l(mu_);
41 tensorflow::mutex_lock l(mu_);
50 // immediately trying and failing to acquire mu_, but seems
58 tensorflow::mutex_lock l(mu_);
75 tensorflow::mutex_lock l(mu_);
  /external/tensorflow/tensorflow/compiler/xla/service/gpu/
infeed_manager.cc 30 tensorflow::mutex_lock l(mu_);
39 tensorflow::mutex_lock l(mu_);
46 // immediately trying and failing to acquire mu_, but seems
54 tensorflow::mutex_lock l(mu_);
66 tensorflow::mutex_lock l(mu_);
  /external/tensorflow/tensorflow/cc/training/
coordinator.cc 40 mutex_lock l(mu_);
62 mutex_lock l(mu_);
73 mutex_lock l(mu_);
80 mutex_lock l(mu_);
112 mutex_lock l(mu_);
coordinator.h 116 mutex mu_; member in class:tensorflow::Coordinator
117 bool should_stop_ GUARDED_BY(mu_);
  /external/tensorflow/tensorflow/core/common_runtime/sycl/
sycl_allocator.cc 39 mutex_lock lock(mu_);
60 mutex_lock lock(mu_);
70 mutex_lock lock(mu_);
75 mutex_lock l(mu_);
82 mutex_lock lock(mu_);
  /external/tensorflow/tensorflow/core/distributed_runtime/rpc/
grpc_server_lib.h 113 mutex mu_; member in class:tensorflow::GrpcServer
125 State state_ GUARDED_BY(mu_);
131 std::unique_ptr<Thread> master_thread_ GUARDED_BY(mu_);
137 std::unique_ptr<Thread> worker_thread_ GUARDED_BY(mu_);
139 std::unique_ptr<::grpc::Server> server_ GUARDED_BY(mu_);
  /external/tensorflow/tensorflow/core/kernels/data/
stats_aggregator_ops.cc 34 mutex_lock l(mu_);
42 mutex_lock l(mu_);
55 mutex mu_; member in class:tensorflow::__anon39760::StatsAggregatorImpl
56 std::unordered_map<string, histogram::Histogram> histograms_ GUARDED_BY(mu_);
68 EXCLUSIVE_LOCKS_REQUIRED(mu_) {
cache_dataset_ops.cc 118 mutex_lock l(mu_);
158 Status EnsureLockFileExists() EXCLUSIVE_LOCKS_REQUIRED(mu_) {
194 Status Finish() EXCLUSIVE_LOCKS_REQUIRED(mu_) {
201 mutex mu_; member in class:tensorflow::__anon39736::CacheDatasetOp::FileDataset::FileWriterIterator
202 size_t cur_index_ GUARDED_BY(mu_);
203 std::unique_ptr<IteratorBase> input_impl_ GUARDED_BY(mu_);
204 BundleWriter writer_ GUARDED_BY(mu_);
206 bool lockfile_created_ GUARDED_BY(mu_);
207 bool iteration_completed_ GUARDED_BY(mu_);
220 mutex_lock l(mu_);
248 mutex mu_; member in class:tensorflow::__anon39736::CacheDatasetOp::FileDataset::FileReaderIterator
333 mutex mu_; member in class:tensorflow::__anon39736::CacheDatasetOp::MemoryDataset::MemoryWriterIterator
364 mutex mu_; member in class:tensorflow::__anon39736::CacheDatasetOp::MemoryDataset::MemoryReaderIterator
383 mutable mutex mu_; member in class:tensorflow::__anon39736::CacheDatasetOp::MemoryDataset
386 mutable bool writer_iterator_created_ GUARDED_BY(mu_) = false; member in class:tensorflow::__anon39736::CacheDatasetOp::MemoryDataset
    [all...]
  /external/tensorflow/tensorflow/core/kernels/batching_util/
adaptive_shared_batch_scheduler.h 164 mutex_lock l(mu_);
185 void MaybeScheduleNextBatch() EXCLUSIVE_LOCKS_REQUIRED(mu_);
207 batches_ GUARDED_BY(mu_);
211 queues_and_callbacks_ GUARDED_BY(mu_);
213 mutex mu_; member in class:tensorflow::serving::AdaptiveSharedBatchScheduler
237 double in_flight_batches_limit_ GUARDED_BY(mu_);
241 int64 in_flight_batches_ GUARDED_BY(mu_) = 0; member in class:tensorflow::serving::AdaptiveSharedBatchScheduler
251 int64 batch_count_ GUARDED_BY(mu_) = 0; member in class:tensorflow::serving::AdaptiveSharedBatchScheduler
253 int64 batch_latency_sum_ GUARDED_BY(mu_) = 0; member in class:tensorflow::serving::AdaptiveSharedBatchScheduler
255 double last_avg_latency_ms_ GUARDED_BY(mu_) = 0 member in class:tensorflow::serving::AdaptiveSharedBatchScheduler
257 bool last_latency_decreased_ GUARDED_BY(mu_) = false; member in class:tensorflow::serving::AdaptiveSharedBatchScheduler
259 int step_direction_ GUARDED_BY(mu_) = 1; member in class:tensorflow::serving::AdaptiveSharedBatchScheduler
265 double step_size_multiplier_ GUARDED_BY(mu_) = kMaxStepSizeMultiplier; member in class:tensorflow::serving::AdaptiveSharedBatchScheduler
308 ASBSBatch<TaskType>* current_batch_ GUARDED_BY(mu_) = nullptr; member in class:tensorflow::serving::internal::ASBSQueue
309 int64 num_enqueued_batches_ GUARDED_BY(mu_) = 0; member in class:tensorflow::serving::internal::ASBSQueue
310 int64 num_enqueued_tasks_ GUARDED_BY(mu_) = 0; member in class:tensorflow::serving::internal::ASBSQueue
311 mutable mutex mu_; member in class:tensorflow::serving::internal::ASBSQueue
    [all...]
shared_batch_scheduler.h 177 mutex mu_; member in class:tensorflow::serving::SharedBatchScheduler
187 QueueList queues_ GUARDED_BY(mu_);
191 typename QueueList::iterator next_queue_to_schedule_ GUARDED_BY(mu_);
271 mutex_lock l(mu_);
276 // Same as IsEmpty(), but assumes the caller already holds a lock on 'mu_'.
277 bool IsEmptyInternal() const EXCLUSIVE_LOCKS_REQUIRED(mu_);
281 void StartNewBatch() EXCLUSIVE_LOCKS_REQUIRED(mu_);
285 bool IsOpenBatchSchedulable() const EXCLUSIVE_LOCKS_REQUIRED(mu_);
300 mutable mutex mu_; member in class:tensorflow::serving::internal::Queue
305 bool closed_ GUARDED_BY(mu_) = false member in class:tensorflow::serving::internal::Queue
316 bool schedulable_batch_ GUARDED_BY(mu_) = false; member in class:tensorflow::serving::internal::Queue
320 int num_batches_being_processed_ GUARDED_BY(mu_) = 0; member in class:tensorflow::serving::internal::Queue
326 Notification* empty_notification_ GUARDED_BY(mu_) = nullptr; member in class:tensorflow::serving::internal::Queue
    [all...]
  /external/tensorflow/tensorflow/contrib/data/kernels/
prefetching_kernels.cc 64 mutex_lock l(mu_);
79 Status Instantiate() LOCKS_EXCLUDED(mu_) {
80 mutex_lock l(mu_);
94 bool Finished() LOCKS_EXCLUDED(mu_) {
95 mutex_lock l(mu_);
100 void Cancel() LOCKS_EXCLUDED(mu_) {
101 mutex_lock l(mu_);
108 void MaybeGet(FunctionBufferCallback callback) LOCKS_EXCLUDED(mu_) {
113 mutex_lock l(mu_);
135 void FillBuffer() LOCKS_EXCLUDED(mu_) {
223 mutex mu_; member in class:tensorflow::FunctionBufferingResource
    [all...]
ignore_errors_dataset_op.cc 82 tf_shared_lock l(mu_);
94 mutex_lock l(mu_);
102 mutex_lock l(mu_);
113 mutex_lock l(mu_);
122 mutex mu_; member in class:tensorflow::__anon39165::IgnoreErrorsDatasetOp::Dataset::Iterator
123 std::unique_ptr<IteratorBase> input_impl_ GUARDED_BY(mu_);
  /external/tensorflow/tensorflow/core/lib/monitoring/
counter.h 98 CounterCell* GetCell(const Labels&... labels) LOCKS_EXCLUDED(mu_);
108 mutex_lock l(mu_);
114 mutable mutex mu_; member in class:tensorflow::monitoring::Counter
123 std::map<LabelArray, CounterCell> cells_ GUARDED_BY(mu_);
151 LOCKS_EXCLUDED(mu_) {
159 mutex_lock l(mu_);
sampler.h 129 SamplerCell* GetCell(const Labels&... labels) LOCKS_EXCLUDED(mu_);
143 mutex_lock l(mu_);
149 mutable mutex mu_; member in class:tensorflow::monitoring::Sampler
166 std::map<LabelArray, SamplerCell> cells_ GUARDED_BY(mu_);
194 LOCKS_EXCLUDED(mu_) {
202 mutex_lock l(mu_);

Completed in 245 milliseconds

1 23 4 5 6 7 8 91011>>