Skip to content

Commit 6ef46ce

Browse files
committedMay 19, 2021
8231672: Simplify the reference processing parallelization framework
Reviewed-by: tschatzl, ayang
1 parent 392f962 commit 6ef46ce

20 files changed

+380
-724
lines changed
 

‎src/hotspot/share/gc/g1/g1CollectedHeap.cpp

+32-122
Original file line numberDiff line numberDiff line change
@@ -3051,7 +3051,7 @@ bool G1ParEvacuateFollowersClosure::offer_termination() {
30513051
EventGCPhaseParallel event;
30523052
G1ParScanThreadState* const pss = par_scan_state();
30533053
start_term_time();
3054-
const bool res = terminator()->offer_termination();
3054+
const bool res = (terminator() == nullptr) ? true : terminator()->offer_termination();
30553055
end_term_time();
30563056
event.commit(GCId::current(), pss->worker_id(), G1GCPhaseTimes::phase_name(G1GCPhaseTimes::Termination));
30573057
return res;
@@ -3182,99 +3182,35 @@ class G1STWDrainQueueClosure: public VoidClosure {
31823182
}
31833183
};
31843184

3185-
// Parallel Reference Processing closures
3186-
3187-
// Implementation of AbstractRefProcTaskExecutor for parallel reference
3188-
// processing during G1 evacuation pauses.
3189-
3190-
class G1STWRefProcTaskExecutor: public AbstractRefProcTaskExecutor {
3191-
private:
3192-
G1CollectedHeap* _g1h;
3193-
G1ParScanThreadStateSet* _pss;
3194-
G1ScannerTasksQueueSet* _queues;
3195-
WorkGang* _workers;
3196-
3197-
public:
3198-
G1STWRefProcTaskExecutor(G1CollectedHeap* g1h,
3199-
G1ParScanThreadStateSet* per_thread_states,
3200-
WorkGang* workers,
3201-
G1ScannerTasksQueueSet *task_queues) :
3202-
_g1h(g1h),
3203-
_pss(per_thread_states),
3204-
_queues(task_queues),
3205-
_workers(workers)
3206-
{
3207-
g1h->ref_processor_stw()->set_active_mt_degree(workers->active_workers());
3208-
}
3209-
3210-
// Executes the given task using concurrent marking worker threads.
3211-
virtual void execute(ProcessTask& task, uint ergo_workers);
3212-
};
3213-
3214-
// Gang task for possibly parallel reference processing
3215-
3216-
class G1STWRefProcTaskProxy: public AbstractGangTask {
3217-
typedef AbstractRefProcTaskExecutor::ProcessTask ProcessTask;
3218-
ProcessTask& _proc_task;
3219-
G1CollectedHeap* _g1h;
3220-
G1ParScanThreadStateSet* _pss;
3221-
G1ScannerTasksQueueSet* _task_queues;
3222-
TaskTerminator* _terminator;
3185+
class G1STWRefProcProxyTask : public RefProcProxyTask {
3186+
G1CollectedHeap& _g1h;
3187+
G1ParScanThreadStateSet& _pss;
3188+
TaskTerminator _terminator;
3189+
G1ScannerTasksQueueSet& _task_queues;
32233190

32243191
public:
3225-
G1STWRefProcTaskProxy(ProcessTask& proc_task,
3226-
G1CollectedHeap* g1h,
3227-
G1ParScanThreadStateSet* per_thread_states,
3228-
G1ScannerTasksQueueSet *task_queues,
3229-
TaskTerminator* terminator) :
3230-
AbstractGangTask("Process reference objects in parallel"),
3231-
_proc_task(proc_task),
3232-
_g1h(g1h),
3233-
_pss(per_thread_states),
3234-
_task_queues(task_queues),
3235-
_terminator(terminator)
3236-
{}
3237-
3238-
virtual void work(uint worker_id) {
3239-
// The reference processing task executed by a single worker.
3240-
ResourceMark rm;
3241-
3242-
G1STWIsAliveClosure is_alive(_g1h);
3243-
3244-
G1ParScanThreadState* pss = _pss->state_for_worker(worker_id);
3245-
pss->set_ref_discoverer(NULL);
3246-
3247-
// Keep alive closure.
3248-
G1CopyingKeepAliveClosure keep_alive(_g1h, pss);
3249-
3250-
// Complete GC closure
3251-
G1ParEvacuateFollowersClosure drain_queue(_g1h, pss, _task_queues, _terminator, G1GCPhaseTimes::ObjCopy);
3192+
G1STWRefProcProxyTask(uint max_workers, G1CollectedHeap& g1h, G1ParScanThreadStateSet& pss, G1ScannerTasksQueueSet& task_queues)
3193+
: RefProcProxyTask("G1STWRefProcProxyTask", max_workers),
3194+
_g1h(g1h),
3195+
_pss(pss),
3196+
_terminator(max_workers, &task_queues),
3197+
_task_queues(task_queues) {}
32523198

3253-
// Call the reference processing task's work routine.
3254-
_proc_task.work(worker_id, is_alive, keep_alive, drain_queue);
3199+
void work(uint worker_id) override {
3200+
assert(worker_id < _max_workers, "sanity");
3201+
uint index = (_tm == RefProcThreadModel::Single) ? 0 : worker_id;
3202+
_pss.state_for_worker(index)->set_ref_discoverer(nullptr);
3203+
G1STWIsAliveClosure is_alive(&_g1h);
3204+
G1CopyingKeepAliveClosure keep_alive(&_g1h, _pss.state_for_worker(index));
3205+
G1ParEvacuateFollowersClosure complete_gc(&_g1h, _pss.state_for_worker(index), &_task_queues, _tm == RefProcThreadModel::Single ? nullptr : &_terminator, G1GCPhaseTimes::ObjCopy);
3206+
_rp_task->rp_work(worker_id, &is_alive, &keep_alive, &complete_gc);
3207+
}
32553208

3256-
// Note we cannot assert that the refs array is empty here as not all
3257-
// of the processing tasks (specifically phase2 - pp2_work) execute
3258-
// the complete_gc closure (which ordinarily would drain the queue) so
3259-
// the queue may not be empty.
3209+
void prepare_run_task_hook() override {
3210+
_terminator.reset_for_reuse(_queue_count);
32603211
}
32613212
};
32623213

3263-
// Driver routine for parallel reference processing.
3264-
// Creates an instance of the ref processing gang
3265-
// task and has the worker threads execute it.
3266-
void G1STWRefProcTaskExecutor::execute(ProcessTask& proc_task, uint ergo_workers) {
3267-
assert(_workers != NULL, "Need parallel worker threads.");
3268-
3269-
assert(_workers->active_workers() >= ergo_workers,
3270-
"Ergonomically chosen workers (%u) should be less than or equal to active workers (%u)",
3271-
ergo_workers, _workers->active_workers());
3272-
TaskTerminator terminator(ergo_workers, _queues);
3273-
G1STWRefProcTaskProxy proc_task_proxy(proc_task, _g1h, _pss, _queues, &terminator);
3274-
3275-
_workers->run_task(&proc_task_proxy, ergo_workers);
3276-
}
3277-
32783214
// End of weak reference support closures
32793215

32803216
void G1CollectedHeap::process_discovered_references(G1ParScanThreadStateSet* per_thread_states) {
@@ -3283,53 +3219,27 @@ void G1CollectedHeap::process_discovered_references(G1ParScanThreadStateSet* per
32833219
ReferenceProcessor* rp = _ref_processor_stw;
32843220
assert(rp->discovery_enabled(), "should have been enabled");
32853221

3286-
// Closure to test whether a referent is alive.
3287-
G1STWIsAliveClosure is_alive(this);
3288-
3289-
// Even when parallel reference processing is enabled, the processing
3290-
// of JNI refs is serial and performed serially by the current thread
3291-
// rather than by a worker. The following PSS will be used for processing
3292-
// JNI refs.
3293-
32943222
// Use only a single queue for this PSS.
32953223
G1ParScanThreadState* pss = per_thread_states->state_for_worker(0);
32963224
pss->set_ref_discoverer(NULL);
32973225
assert(pss->queue_is_empty(), "pre-condition");
32983226

3299-
// Keep alive closure.
3300-
G1CopyingKeepAliveClosure keep_alive(this, pss);
3301-
3302-
// Serial Complete GC closure
3303-
G1STWDrainQueueClosure drain_queue(this, pss);
3304-
33053227
// Setup the soft refs policy...
33063228
rp->setup_policy(false);
33073229

3308-
ReferenceProcessorPhaseTimes* pt = phase_times()->ref_phase_times();
3230+
ReferenceProcessorPhaseTimes& pt = *phase_times()->ref_phase_times();
33093231

33103232
ReferenceProcessorStats stats;
3311-
if (!rp->processing_is_mt()) {
3312-
// Serial reference processing...
3313-
stats = rp->process_discovered_references(&is_alive,
3314-
&keep_alive,
3315-
&drain_queue,
3316-
NULL,
3317-
pt);
3318-
} else {
3319-
uint no_of_gc_workers = workers()->active_workers();
3233+
uint no_of_gc_workers = workers()->active_workers();
33203234

3321-
// Parallel reference processing
3322-
assert(no_of_gc_workers <= rp->max_num_queues(),
3323-
"Mismatch between the number of GC workers %u and the maximum number of Reference process queues %u",
3324-
no_of_gc_workers, rp->max_num_queues());
3235+
// Parallel reference processing
3236+
assert(no_of_gc_workers <= rp->max_num_queues(),
3237+
"Mismatch between the number of GC workers %u and the maximum number of Reference process queues %u",
3238+
no_of_gc_workers, rp->max_num_queues());
33253239

3326-
G1STWRefProcTaskExecutor par_task_executor(this, per_thread_states, workers(), _task_queues);
3327-
stats = rp->process_discovered_references(&is_alive,
3328-
&keep_alive,
3329-
&drain_queue,
3330-
&par_task_executor,
3331-
pt);
3332-
}
3240+
rp->set_active_mt_degree(no_of_gc_workers);
3241+
G1STWRefProcProxyTask task(rp->max_num_queues(), *this, *per_thread_states, *_task_queues);
3242+
stats = rp->process_discovered_references(task, pt);
33333243

33343244
_gc_tracer_stw->report_gc_reference_stats(stats);
33353245

‎src/hotspot/share/gc/g1/g1ConcurrentMark.cpp

+22-84
Original file line numberDiff line numberDiff line change
@@ -1458,71 +1458,34 @@ class G1CMDrainMarkingStackClosure : public VoidClosure {
14581458
}
14591459
};
14601460

1461-
// Implementation of AbstractRefProcTaskExecutor for parallel
1462-
// reference processing at the end of G1 concurrent marking
1463-
1464-
class G1CMRefProcTaskExecutor : public AbstractRefProcTaskExecutor {
1465-
private:
1466-
G1CollectedHeap* _g1h;
1467-
G1ConcurrentMark* _cm;
1468-
WorkGang* _workers;
1469-
uint _active_workers;
1461+
class G1CMRefProcProxyTask : public RefProcProxyTask {
1462+
G1CollectedHeap& _g1h;
1463+
G1ConcurrentMark& _cm;
14701464

14711465
public:
1472-
G1CMRefProcTaskExecutor(G1CollectedHeap* g1h,
1473-
G1ConcurrentMark* cm,
1474-
WorkGang* workers,
1475-
uint n_workers) :
1476-
_g1h(g1h), _cm(cm),
1477-
_workers(workers), _active_workers(n_workers) { }
1478-
1479-
virtual void execute(ProcessTask& task, uint ergo_workers);
1480-
};
1481-
1482-
class G1CMRefProcTaskProxy : public AbstractGangTask {
1483-
typedef AbstractRefProcTaskExecutor::ProcessTask ProcessTask;
1484-
ProcessTask& _proc_task;
1485-
G1CollectedHeap* _g1h;
1486-
G1ConcurrentMark* _cm;
1466+
G1CMRefProcProxyTask(uint max_workers, G1CollectedHeap& g1h, G1ConcurrentMark &cm)
1467+
: RefProcProxyTask("G1CMRefProcProxyTask", max_workers),
1468+
_g1h(g1h),
1469+
_cm(cm) {}
14871470

1488-
public:
1489-
G1CMRefProcTaskProxy(ProcessTask& proc_task,
1490-
G1CollectedHeap* g1h,
1491-
G1ConcurrentMark* cm) :
1492-
AbstractGangTask("Process reference objects in parallel"),
1493-
_proc_task(proc_task), _g1h(g1h), _cm(cm) {
1494-
ReferenceProcessor* rp = _g1h->ref_processor_cm();
1495-
assert(rp->processing_is_mt(), "shouldn't be here otherwise");
1471+
void work(uint worker_id) override {
1472+
assert(worker_id < _max_workers, "sanity");
1473+
G1CMIsAliveClosure is_alive(&_g1h);
1474+
uint index = (_tm == RefProcThreadModel::Single) ? 0 : worker_id;
1475+
G1CMKeepAliveAndDrainClosure keep_alive(&_cm, _cm.task(index), _tm == RefProcThreadModel::Single);
1476+
G1CMDrainMarkingStackClosure complete_gc(&_cm, _cm.task(index), _tm == RefProcThreadModel::Single);
1477+
_rp_task->rp_work(worker_id, &is_alive, &keep_alive, &complete_gc);
14961478
}
14971479

1498-
virtual void work(uint worker_id) {
1499-
ResourceMark rm;
1500-
G1CMTask* task = _cm->task(worker_id);
1501-
G1CMIsAliveClosure g1_is_alive(_g1h);
1502-
G1CMKeepAliveAndDrainClosure g1_par_keep_alive(_cm, task, false /* is_serial */);
1503-
G1CMDrainMarkingStackClosure g1_par_drain(_cm, task, false /* is_serial */);
1504-
1505-
_proc_task.work(worker_id, g1_is_alive, g1_par_keep_alive, g1_par_drain);
1480+
void prepare_run_task_hook() override {
1481+
// We need to reset the concurrency level before each
1482+
// proxy task execution, so that the termination protocol
1483+
// and overflow handling in G1CMTask::do_marking_step() knows
1484+
// how many workers to wait for.
1485+
_cm.set_concurrency(_queue_count);
15061486
}
15071487
};
15081488

1509-
void G1CMRefProcTaskExecutor::execute(ProcessTask& proc_task, uint ergo_workers) {
1510-
assert(_workers != NULL, "Need parallel worker threads.");
1511-
assert(_g1h->ref_processor_cm()->processing_is_mt(), "processing is not MT");
1512-
assert(_workers->active_workers() >= ergo_workers,
1513-
"Ergonomically chosen workers(%u) should be less than or equal to active workers(%u)",
1514-
ergo_workers, _workers->active_workers());
1515-
1516-
G1CMRefProcTaskProxy proc_task_proxy(proc_task, _g1h, _cm);
1517-
1518-
// We need to reset the concurrency level before each
1519-
// proxy task execution, so that the termination protocol
1520-
// and overflow handling in G1CMTask::do_marking_step() knows
1521-
// how many workers to wait for.
1522-
_cm->set_concurrency(ergo_workers);
1523-
_workers->run_task(&proc_task_proxy, ergo_workers);
1524-
}
1525-
15261489
void G1ConcurrentMark::weak_refs_work(bool clear_all_soft_refs) {
15271490
ResourceMark rm;
15281491

@@ -1541,23 +1504,6 @@ void G1ConcurrentMark::weak_refs_work(bool clear_all_soft_refs) {
15411504
rp->setup_policy(clear_all_soft_refs);
15421505
assert(_global_mark_stack.is_empty(), "mark stack should be empty");
15431506

1544-
// Instances of the 'Keep Alive' and 'Complete GC' closures used
1545-
// in serial reference processing. Note these closures are also
1546-
// used for serially processing (by the the current thread) the
1547-
// JNI references during parallel reference processing.
1548-
//
1549-
// These closures do not need to synchronize with the worker
1550-
// threads involved in parallel reference processing as these
1551-
// instances are executed serially by the current thread (e.g.
1552-
// reference processing is not multi-threaded and is thus
1553-
// performed by the current thread instead of a gang worker).
1554-
//
1555-
// The gang tasks involved in parallel reference processing create
1556-
// their own instances of these closures, which do their own
1557-
// synchronization among themselves.
1558-
G1CMKeepAliveAndDrainClosure g1_keep_alive(this, task(0), true /* is_serial */);
1559-
G1CMDrainMarkingStackClosure g1_drain_mark_stack(this, task(0), true /* is_serial */);
1560-
15611507
// We need at least one active thread. If reference processing
15621508
// is not multi-threaded we use the current (VMThread) thread,
15631509
// otherwise we use the work gang from the G1CollectedHeap and
@@ -1576,19 +1522,11 @@ void G1ConcurrentMark::weak_refs_work(bool clear_all_soft_refs) {
15761522
rp->set_active_mt_degree(active_workers);
15771523

15781524
// Parallel processing task executor.
1579-
G1CMRefProcTaskExecutor par_task_executor(_g1h, this,
1580-
_g1h->workers(), active_workers);
1581-
AbstractRefProcTaskExecutor* executor = (rp->processing_is_mt() ? &par_task_executor : NULL);
1582-
1525+
G1CMRefProcProxyTask task(rp->max_num_queues(), *_g1h, *this);
15831526
ReferenceProcessorPhaseTimes pt(_gc_timer_cm, rp->max_num_queues());
15841527

15851528
// Process the weak references.
1586-
const ReferenceProcessorStats& stats =
1587-
rp->process_discovered_references(&g1_is_alive,
1588-
&g1_keep_alive,
1589-
&g1_drain_mark_stack,
1590-
executor,
1591-
&pt);
1529+
const ReferenceProcessorStats& stats = rp->process_discovered_references(task, pt);
15921530
_gc_tracer_cm->report_gc_reference_stats(stats);
15931531
pt.print_all_references();
15941532

‎src/hotspot/share/gc/g1/g1ConcurrentMark.hpp

+4-5
Original file line numberDiff line numberDiff line change
@@ -278,15 +278,14 @@ class G1CMRootMemRegions {
278278
// This class manages data structures and methods for doing liveness analysis in
279279
// G1's concurrent cycle.
280280
class G1ConcurrentMark : public CHeapObj<mtGC> {
281-
friend class G1ConcurrentMarkThread;
282-
friend class G1CMRefProcTaskProxy;
283-
friend class G1CMRefProcTaskExecutor;
284-
friend class G1CMKeepAliveAndDrainClosure;
285-
friend class G1CMDrainMarkingStackClosure;
286281
friend class G1CMBitMapClosure;
287282
friend class G1CMConcurrentMarkingTask;
283+
friend class G1CMDrainMarkingStackClosure;
284+
friend class G1CMKeepAliveAndDrainClosure;
285+
friend class G1CMRefProcProxyTask;
288286
friend class G1CMRemarkTask;
289287
friend class G1CMTask;
288+
friend class G1ConcurrentMarkThread;
290289

291290
G1ConcurrentMarkThread* _cm_thread; // The thread doing the work
292291
G1CollectedHeap* _g1h; // The heap

0 commit comments

Comments
 (0)
Please sign in to comment.