/external/v8/src/heap/ |
D | incremental-marking.cc | 24 : heap_(heap), in IncrementalMarking() 59 heap_->mark_compact_collector()->RecordSlot(obj, slot, value); in RecordWriteSlow() 84 RelocInfo rinfo(heap_->isolate(), pc, RelocInfo::CODE_TARGET, 0, host); in RecordCodeTargetPatch() 92 Code* host = heap_->isolate() in RecordCodeTargetPatch() 95 RelocInfo rinfo(heap_->isolate(), pc, RelocInfo::CODE_TARGET, 0, host); in RecordCodeTargetPatch() 106 heap_->mark_compact_collector()->RecordCodeEntrySlot( in RecordWriteOfCodeEntrySlow() 115 heap_->mark_compact_collector()->RecordRelocSlot(host, rinfo, value); in RecordWriteIntoCodeSlow() 121 heap_->mark_compact_collector()->marking_deque()->Push(obj); in WhiteToGreyAndPush() 279 MarkGrey(heap_, map); in IterateBlackObject() 288 : heap_(incremental_marking->heap()) {} in IncrementalMarkingRootMarkingVisitor() [all …]
|
D | gc-tracer.cc | 30 start_time_ = tracer_->heap_->MonotonicallyIncreasingTimeInMs(); in Scope() 34 tracer_->heap_->isolate()->counters()->runtime_call_stats(), &timer_, in Scope() 41 scope_, tracer_->heap_->MonotonicallyIncreasingTimeInMs() - start_time_); in ~Scope() 45 tracer_->heap_->isolate()->counters()->runtime_call_stats(), &timer_); in ~Scope() 101 : heap_(heap), in GCTracer() 116 current_.end_time = heap_->MonotonicallyIncreasingTimeInMs(); in GCTracer() 121 current_.end_time = heap_->MonotonicallyIncreasingTimeInMs(); in ResetForTesting() 146 heap_->isolate()->counters()->young_generation_handling()->AddSample( in NotifyYoungGenerationHandling() 157 double start_time = heap_->MonotonicallyIncreasingTimeInMs(); in Start() 158 SampleAllocation(start_time, heap_->NewSpaceAllocationCounter(), in Start() [all …]
|
D | object-stats.cc | 281 if (obj->IsUndefined(parent_->heap_->isolate())) continue; in VisitPointers() 294 RecordFixedArrayHelper(nullptr, heap_->weak_new_space_object_to_code_list(), in CollectGlobalStatistics() 296 RecordFixedArrayHelper(nullptr, heap_->serialized_templates(), in CollectGlobalStatistics() 298 RecordFixedArrayHelper(nullptr, heap_->number_string_cache(), in CollectGlobalStatistics() 300 RecordFixedArrayHelper(nullptr, heap_->single_character_string_cache(), in CollectGlobalStatistics() 302 RecordFixedArrayHelper(nullptr, heap_->string_split_cache(), in CollectGlobalStatistics() 304 RecordFixedArrayHelper(nullptr, heap_->regexp_multiple_cache(), in CollectGlobalStatistics() 306 RecordFixedArrayHelper(nullptr, heap_->retained_maps(), in CollectGlobalStatistics() 311 nullptr, WeakFixedArray::cast(heap_->noscript_shared_function_infos()), in CollectGlobalStatistics() 313 RecordFixedArrayHelper(nullptr, WeakFixedArray::cast(heap_->script_list()), in CollectGlobalStatistics() [all …]
|
D | scavenger.h | 19 explicit Scavenger(Heap* heap) : heap_(heap) {} in Scavenger() 40 Heap* heap() { return heap_; } in heap() 43 Heap* heap_; 52 explicit ScavengeVisitor(Heap* heap) : heap_(heap) {} in ScavengeVisitor() 60 Heap* heap_; variable
|
D | page-parallel-job.h | 44 : heap_(heap), in PageParallelJob() 91 Task* task = new Task(heap_, items_, num_items_, start_index, in Run() 115 JobTraits::FinalizePageSequentially(heap_, item->chunk, success, in Run() 141 heap_(heap), in Task() 162 heap_, data_, current->chunk, current->data); in RunInternal() 174 Heap* heap_; variable 183 Heap* heap_; variable
|
D | mark-compact.cc | 52 heap_(heap), in MarkCompactCollector() 303 DCHECK(heap_->incremental_marking()->IsStopped()); in CollectGarbage() 311 VerifyMarking(heap_); in CollectGarbage() 340 VerifyMarkbitsAreClean(heap_->old_space()); in VerifyMarkbitsAreClean() 341 VerifyMarkbitsAreClean(heap_->code_space()); in VerifyMarkbitsAreClean() 342 VerifyMarkbitsAreClean(heap_->map_space()); in VerifyMarkbitsAreClean() 343 VerifyMarkbitsAreClean(heap_->new_space()); in VerifyMarkbitsAreClean() 345 LargeObjectIterator it(heap_->lo_space()); in VerifyMarkbitsAreClean() 389 ClearMarkbitsInPagedSpace(heap_->code_space()); in ClearMarkbits() 390 ClearMarkbitsInPagedSpace(heap_->map_space()); in ClearMarkbits() [all …]
|
D | object-stats.h | 20 explicit ObjectStats(Heap* heap) : heap_(heap) { ClearObjectStats(); } in ObjectStats() 94 Heap* heap() { return heap_; } in heap() 118 Heap* heap_; variable 136 : heap_(heap), stats_(stats) {} in ObjectStatsCollector() 162 Heap* heap_; variable
|
D | memory-reducer.h | 114 : heap_(heap), in MemoryReducer() 139 Heap* heap() { return heap_; } in heap() 161 Heap* heap_; variable
|
D | store-buffer.h | 97 StoreBufferOverflow(heap_->isolate()); in InsertDeletionIntoStoreBuffer() 118 StoreBufferOverflow(heap_->isolate()); in InsertIntoStoreBuffer() 155 Heap* heap() { return heap_; } in heap() 185 Heap* heap_; variable
|
D | array-buffer-tracker.cc | 24 heap_->isolate()->array_buffer_allocator()->Free(buffer->backing_store(), in Free() 33 heap_->update_external_memory_concurrently_freed( in Free() 64 heap_->isolate()->array_buffer_allocator()->Free( in Process() 73 heap_->update_external_memory_concurrently_freed( in Process()
|
D | heap.cc | 64 : AllocationObserver(step_size), heap_(heap) {} in IdleScavengeObserver() 67 heap_.ScheduleIdleScavengeIfNeeded(bytes_allocated); in Step() 71 Heap& heap_; member in v8::internal::IdleScavengeObserver 538 explicit PretenuringScope(Heap* heap) : heap_(heap) { in PretenuringScope() 539 heap_->global_pretenuring_feedback_ = in PretenuringScope() 544 delete heap_->global_pretenuring_feedback_; in ~PretenuringScope() 545 heap_->global_pretenuring_feedback_ = nullptr; in ~PretenuringScope() 549 Heap* heap_; member in v8::internal::Heap::PretenuringScope 775 explicit GCCallbacksScope(Heap* heap) : heap_(heap) { in GCCallbacksScope() 776 heap_->gc_callbacks_depth_++; in GCCallbacksScope() [all …]
|
D | store-buffer.cc | 19 : heap_(heap), in StoreBuffer() 96 Task* task = new Task(heap_->isolate(), this); in FlipStoreBuffers() 109 Page* page = Page::FromAnyPointerAddress(heap_, addr); in MoveEntriesToRememberedSet()
|
D | array-buffer-tracker.h | 68 explicit LocalArrayBufferTracker(Heap* heap) : heap_(heap) {} in LocalArrayBufferTracker() 95 Heap* heap_; variable
|
D | heap-inl.h | 702 if (heap_->InNewSpace(string)) { in AddString() 731 DCHECK(heap_->InNewSpace(obj)); in Verify() 732 DCHECK(!obj->IsTheHole(heap_->isolate())); in Verify() 736 DCHECK(!heap_->InNewSpace(obj)); in Verify() 737 DCHECK(!obj->IsTheHole(heap_->isolate())); in Verify() 745 DCHECK(!heap_->InNewSpace(string)); in AddOldString() 849 : heap_(isolate->heap()) { in AlwaysAllocateScope() 850 heap_->always_allocate_scope_count_.Increment(1); in AlwaysAllocateScope() 855 heap_->always_allocate_scope_count_.Increment(-1); in ~AlwaysAllocateScope()
|
D | heap.h | 403 heap_(heap) {} in PromotionQueue() 440 Heap* heap_; variable 574 explicit RelocationLock(Heap* heap) : heap_(heap) { in RelocationLock() 575 heap_->relocation_mutex_.Lock(); in RelocationLock() 578 ~RelocationLock() { heap_->relocation_mutex_.Unlock(); } in ~RelocationLock() 581 Heap* heap_; 1553 explicit ExternalStringTable(Heap* heap) : heap_(heap) {} in ExternalStringTable() 1567 Heap* heap_; variable 2445 Heap* heap_; 2471 explicit AllSpaces(Heap* heap) : heap_(heap), counter_(FIRST_SPACE) {} in AllSpaces() [all …]
|
D | mark-compact.h | 137 heap_(heap) {} in MarkingDeque() 250 Heap* heap_; variable 429 : heap_(heap), in Sweeper() 473 Heap* heap_; variable 521 inline Heap* heap() const { return heap_; } in heap() 787 Heap* heap_; variable
|
D | spaces-inl.h | 320 : heap_(heap), in MemoryChunkIterator() 330 if (old_iterator_ != heap_->old_space()->end()) return *(old_iterator_++); in next() 335 if (map_iterator_ != heap_->map_space()->end()) return *(map_iterator_++); in next() 340 if (code_iterator_ != heap_->code_space()->end()) in next() 346 if (lo_iterator_ != heap_->lo_space()->end()) return *(lo_iterator_++); in next() 397 return heap_->PrecedeWithFiller(HeapObject::FromAddress(current_top), in AllocateRawAligned()
|
/external/libmojo/mojo/edk/system/ports/ |
D | message_queue.cc | 37 for (const auto& message : heap_) in ~MessageQueue() 45 return !heap_.empty() && GetSequenceNum(heap_[0]) == next_sequence_num_; in HasNextMessage() 50 if (!HasNextMessage() || (filter && !filter->Match(*heap_[0].get()))) { in GetNextMessage() 55 std::pop_heap(heap_.begin(), heap_.end()); in GetNextMessage() 56 *message = std::move(heap_.back()); in GetNextMessage() 57 heap_.pop_back(); in GetNextMessage() 68 heap_.emplace_back(std::move(message)); in AcceptMessage() 69 std::push_heap(heap_.begin(), heap_.end()); in AcceptMessage() 74 *has_next_message = (GetSequenceNum(heap_[0]) == next_sequence_num_); in AcceptMessage() 79 for (const auto& message : heap_) { in GetReferencedPorts()
|
/external/v8/src/ |
D | identity-map.cc | 25 heap_->UnregisterStrongRoots(keys_); in Clear() 53 Object* not_mapped = heap_->not_mapped_symbol(); in ScanKeysFor() 66 Object* not_mapped = heap_->not_mapped_symbol(); in InsertKey() 87 Object* not_mapped = heap_->not_mapped_symbol(); in DeleteIndex() 125 if (index < 0 && gc_counter_ != heap_->gc_count()) { in Lookup() 138 if (gc_counter_ != heap_->gc_count()) Rehash(); in LookupOrInsert() 148 CHECK_NE(address, heap_->not_mapped_symbol()); in Hash() 163 gc_counter_ = heap_->gc_count(); in GetEntry() 166 Object* not_mapped = heap_->not_mapped_symbol(); in GetEntry() 171 heap_->RegisterStrongRoots(keys_, keys_ + capacity_); in GetEntry() [all …]
|
D | isolate-inl.h | 41 thread_local_top_.pending_exception_ = heap_.the_hole_value(); in clear_pending_exception() 52 thread_local_top_.pending_message_obj_ = heap_.the_hole_value(); in clear_pending_message() 65 return thread_local_top_.scheduled_exception_ != heap_.the_hole_value(); in has_scheduled_exception() 71 thread_local_top_.scheduled_exception_ = heap_.the_hole_value(); in clear_scheduled_exception()
|
D | isolate.cc | 969 return Throw(heap_.termination_exception(), nullptr); in TerminateExecution() 978 pending_exception() == heap_.termination_exception()) { in CancelTerminateExecution() 983 scheduled_exception() == heap_.termination_exception()) { in CancelTerminateExecution() 1768 pending_exception() == heap_.termination_exception(); in Throw() 2134 : heap_(heap), in Throw() 2173 double time = heap_->isolate()->time_millis_since_init(); in Throw() 2182 reinterpret_cast<void*>(heap_->isolate()), time, in Throw() 2190 double time = heap_->isolate()->time_millis_since_init(); in Throw() 2201 reinterpret_cast<void*>(heap_->isolate()), time, in Throw() 2210 double time = heap_->isolate()->time_millis_since_init(); in Throw() [all …]
|
/external/tensorflow/tensorflow/contrib/nearest_neighbor/kernels/ |
D | hyperplane_lsh_probes.h | 108 heap_.Resize(2 * num_probes_); in SetupProbing() 110 heap_.Reset(); in SetupProbing() 118 heap_.InsertUnsorted(score, ProbeCandidate(ii, hash_mask, 0)); in SetupProbing() 120 heap_.Heapify(); in SetupProbing() 150 if (heap_.IsEmpty()) { in GetNextProbe() 156 heap_.ExtractMin(&cur_score, &cur_candidate); in GetNextProbe() 180 heap_.Insert(next_score, ProbeCandidate(*cur_table, next_mask, in GetNextProbe() 189 heap_.Insert(next_score, ProbeCandidate(*cur_table, next_mask, in GetNextProbe() 228 SimpleHeap<CoordinateType, ProbeCandidate> heap_; variable
|
/external/v8/src/profiler/ |
D | sampling-heap-profiler.h | 123 Heap* heap() const { return heap_; } in heap() 144 Heap* const heap_; variable 166 heap_(heap), in SamplingAllocationObserver() 173 USE(heap_); in Step() 174 DCHECK(heap_->gc_state() == Heap::NOT_IN_GC); in Step() 184 Heap* const heap_; variable
|
D | sampling-heap-profiler.cc | 55 heap_(heap), in SamplingHeapProfiler() 57 heap_, static_cast<intptr_t>(rate), rate, this, in SamplingHeapProfiler() 60 heap_, static_cast<intptr_t>(rate), rate, this, in SamplingHeapProfiler() 80 heap_->new_space()->RemoveAllocationObserver(new_space_observer_.get()); in ~SamplingHeapProfiler() 81 AllSpaces spaces(heap_); in ~SamplingHeapProfiler() 83 if (space != heap_->new_space()) { in ~SamplingHeapProfiler()
|
D | heap-snapshot-generator.cc | 362 : next_id_(kFirstAvailableObjectId), heap_(heap) { in HeapObjectsMap() 473 heap_->CollectAllGarbage(Heap::kMakeHeapIterableMask, in UpdateHeapObjectsMap() 475 HeapIterator iterator(heap_); in UpdateHeapObjectsMap() 539 HeapIterator iterator(heap_); in FindUntrackedObjects() 687 heap_->HashSeed()); in GenerateId() 762 : heap_(snapshot->profiler()->heap_object_map()->heap()), in V8HeapExplorer() 1078 PrototypeIterator iter(heap_->isolate(), js_obj); in ExtractJSObjectReferences() 1079 SetPropertyReference(obj, entry, heap_->proto_string(), iter.GetCurrent()); in ExtractJSObjectReferences() 1098 if (!proto_or_map->IsTheHole(heap_->isolate())) { in ExtractJSObjectReferences() 1102 heap_->prototype_string(), proto_or_map, in ExtractJSObjectReferences() [all …]
|