< prev index next >

src/hotspot/share/gc/shenandoah/shenandoahFreeSet.cpp

Print this page
@@ -23,14 +23,19 @@
   *
   */
  
  #include "precompiled.hpp"
  #include "gc/shared/tlab_globals.hpp"
+ #include "gc/shenandoah/shenandoahAffiliation.hpp"
+ #include "gc/shenandoah/shenandoahBarrierSet.hpp"
  #include "gc/shenandoah/shenandoahFreeSet.hpp"
  #include "gc/shenandoah/shenandoahHeap.inline.hpp"
  #include "gc/shenandoah/shenandoahHeapRegionSet.hpp"
  #include "gc/shenandoah/shenandoahMarkingContext.inline.hpp"
+ #include "gc/shenandoah/shenandoahOldGeneration.hpp"
+ #include "gc/shenandoah/shenandoahScanRemembered.inline.hpp"
+ #include "gc/shenandoah/shenandoahYoungGeneration.hpp"
  #include "gc/shenandoah/shenandoahSimpleBitMap.hpp"
  #include "gc/shenandoah/shenandoahSimpleBitMap.inline.hpp"
  #include "logging/logStream.hpp"
  #include "memory/resourceArea.hpp"
  #include "runtime/orderAccess.hpp"

@@ -38,31 +43,38 @@
  static const char* partition_name(ShenandoahFreeSetPartitionId t) {
    switch (t) {
      case ShenandoahFreeSetPartitionId::NotFree: return "NotFree";
      case ShenandoahFreeSetPartitionId::Mutator: return "Mutator";
      case ShenandoahFreeSetPartitionId::Collector: return "Collector";
+     case ShenandoahFreeSetPartitionId::OldCollector: return "OldCollector";
      default:
        ShouldNotReachHere();
        return "Unrecognized";
    }
  }
  
  #ifndef PRODUCT
  void ShenandoahRegionPartitions::dump_bitmap() const {
-   log_info(gc)("Mutator range [" SSIZE_FORMAT ", " SSIZE_FORMAT "], Collector range [" SSIZE_FORMAT ", " SSIZE_FORMAT "]",
+   log_info(gc)("Mutator range [" SSIZE_FORMAT ", " SSIZE_FORMAT "], Collector range [" SSIZE_FORMAT ", " SSIZE_FORMAT
+                "], Old Collector range [" SSIZE_FORMAT ", " SSIZE_FORMAT "]",
                 _leftmosts[int(ShenandoahFreeSetPartitionId::Mutator)],
                 _rightmosts[int(ShenandoahFreeSetPartitionId::Mutator)],
                 _leftmosts[int(ShenandoahFreeSetPartitionId::Collector)],
-                _rightmosts[int(ShenandoahFreeSetPartitionId::Collector)]);
+                _rightmosts[int(ShenandoahFreeSetPartitionId::Collector)],
+                _leftmosts[int(ShenandoahFreeSetPartitionId::OldCollector)],
+                _rightmosts[int(ShenandoahFreeSetPartitionId::OldCollector)]);
    log_info(gc)("Empty Mutator range [" SSIZE_FORMAT ", " SSIZE_FORMAT
-                "], Empty Collector range [" SSIZE_FORMAT ", " SSIZE_FORMAT "]",
+                "], Empty Collector range [" SSIZE_FORMAT ", " SSIZE_FORMAT
+                "], Empty Old Collecto range [" SSIZE_FORMAT ", " SSIZE_FORMAT "]",
                 _leftmosts_empty[int(ShenandoahFreeSetPartitionId::Mutator)],
                 _rightmosts_empty[int(ShenandoahFreeSetPartitionId::Mutator)],
                 _leftmosts_empty[int(ShenandoahFreeSetPartitionId::Collector)],
-                _rightmosts_empty[int(ShenandoahFreeSetPartitionId::Collector)]);
+                _rightmosts_empty[int(ShenandoahFreeSetPartitionId::Collector)],
+                _leftmosts_empty[int(ShenandoahFreeSetPartitionId::OldCollector)],
+                _rightmosts_empty[int(ShenandoahFreeSetPartitionId::OldCollector)]);
  
-   log_info(gc)("%6s: %18s %18s %18s", "index", "Mutator Bits", "Collector Bits", "NotFree Bits");
+   log_info(gc)("%6s: %18s %18s %18s %18s", "index", "Mutator Bits", "Collector Bits", "Old Collector Bits", "NotFree Bits");
    dump_bitmap_range(0, _max-1);
  }
  
  void ShenandoahRegionPartitions::dump_bitmap_range(idx_t start_region_idx, idx_t end_region_idx) const {
    assert((start_region_idx >= 0) && (start_region_idx < (idx_t) _max), "precondition");

@@ -79,22 +91,23 @@
  void ShenandoahRegionPartitions::dump_bitmap_row(idx_t region_idx) const {
    assert((region_idx >= 0) && (region_idx < (idx_t) _max), "precondition");
    idx_t aligned_idx = _membership[int(ShenandoahFreeSetPartitionId::Mutator)].aligned_index(region_idx);
    uintx mutator_bits = _membership[int(ShenandoahFreeSetPartitionId::Mutator)].bits_at(aligned_idx);
    uintx collector_bits = _membership[int(ShenandoahFreeSetPartitionId::Collector)].bits_at(aligned_idx);
-   uintx free_bits = mutator_bits | collector_bits;
+   uintx old_collector_bits = _membership[int(ShenandoahFreeSetPartitionId::OldCollector)].bits_at(aligned_idx);
+   uintx free_bits = mutator_bits | collector_bits | old_collector_bits;
    uintx notfree_bits =  ~free_bits;
-   log_info(gc)(SSIZE_FORMAT_W(6) ": " SIZE_FORMAT_X_0 " 0x" SIZE_FORMAT_X_0 " 0x" SIZE_FORMAT_X_0,
-                aligned_idx, mutator_bits, collector_bits, notfree_bits);
+   log_info(gc)(SSIZE_FORMAT_W(6) ": " SIZE_FORMAT_X_0 " 0x" SIZE_FORMAT_X_0 " 0x" SIZE_FORMAT_X_0 " 0x" SIZE_FORMAT_X_0,
+                aligned_idx, mutator_bits, collector_bits, old_collector_bits, notfree_bits);
  }
  #endif
  
  ShenandoahRegionPartitions::ShenandoahRegionPartitions(size_t max_regions, ShenandoahFreeSet* free_set) :
      _max(max_regions),
      _region_size_bytes(ShenandoahHeapRegion::region_size_bytes()),
      _free_set(free_set),
-     _membership{ ShenandoahSimpleBitMap(max_regions), ShenandoahSimpleBitMap(max_regions) }
+     _membership{ ShenandoahSimpleBitMap(max_regions), ShenandoahSimpleBitMap(max_regions) , ShenandoahSimpleBitMap(max_regions) }
  {
    make_all_regions_unavailable();
  }
  
  inline bool ShenandoahFreeSet::can_allocate_from(ShenandoahHeapRegion *r) const {

@@ -160,11 +173,10 @@
  }
  
  void ShenandoahRegionPartitions::establish_mutator_intervals(idx_t mutator_leftmost, idx_t mutator_rightmost,
                                                               idx_t mutator_leftmost_empty, idx_t mutator_rightmost_empty,
                                                               size_t mutator_region_count, size_t mutator_used) {
-   _region_counts[int(ShenandoahFreeSetPartitionId::Mutator)] = mutator_region_count;
    _leftmosts[int(ShenandoahFreeSetPartitionId::Mutator)] = mutator_leftmost;
    _rightmosts[int(ShenandoahFreeSetPartitionId::Mutator)] = mutator_rightmost;
    _leftmosts_empty[int(ShenandoahFreeSetPartitionId::Mutator)] = mutator_leftmost_empty;
    _rightmosts_empty[int(ShenandoahFreeSetPartitionId::Mutator)] = mutator_rightmost_empty;
  

@@ -180,10 +192,24 @@
    _region_counts[int(ShenandoahFreeSetPartitionId::Collector)] = 0;
    _used[int(ShenandoahFreeSetPartitionId::Collector)] = 0;
    _capacity[int(ShenandoahFreeSetPartitionId::Collector)] = 0;
  }
  
+ void ShenandoahRegionPartitions::establish_old_collector_intervals(idx_t old_collector_leftmost, idx_t old_collector_rightmost,
+                                                                    idx_t old_collector_leftmost_empty,
+                                                                    idx_t old_collector_rightmost_empty,
+                                                                    size_t old_collector_region_count, size_t old_collector_used) {
+   _leftmosts[int(ShenandoahFreeSetPartitionId::OldCollector)] = old_collector_leftmost;
+   _rightmosts[int(ShenandoahFreeSetPartitionId::OldCollector)] = old_collector_rightmost;
+   _leftmosts_empty[int(ShenandoahFreeSetPartitionId::OldCollector)] = old_collector_leftmost_empty;
+   _rightmosts_empty[int(ShenandoahFreeSetPartitionId::OldCollector)] = old_collector_rightmost_empty;
+ 
+   _region_counts[int(ShenandoahFreeSetPartitionId::OldCollector)] = old_collector_region_count;
+   _used[int(ShenandoahFreeSetPartitionId::OldCollector)] = old_collector_used;
+   _capacity[int(ShenandoahFreeSetPartitionId::OldCollector)] = old_collector_region_count * _region_size_bytes;
+ }
+ 
  void ShenandoahRegionPartitions::increase_used(ShenandoahFreeSetPartitionId which_partition, size_t bytes) {
    assert (which_partition < NumPartitions, "Partition must be valid");
    _used[int(which_partition)] += bytes;
    assert (_used[int(which_partition)] <= _capacity[int(which_partition)],
            "Must not use (" SIZE_FORMAT ") more than capacity (" SIZE_FORMAT ") after increase by " SIZE_FORMAT,

@@ -200,11 +226,11 @@
      } else {
        _leftmosts[int(partition)] = find_index_of_next_available_region(partition, high_idx + 1);
      }
      if (_leftmosts_empty[int(partition)] < _leftmosts[int(partition)]) {
        // This gets us closer to where we need to be; we'll scan further when leftmosts_empty is requested.
-       _leftmosts_empty[int(partition)] = leftmost(partition);
+       _leftmosts_empty[int(partition)] = _leftmosts[int(partition)];
      }
    }
    if (high_idx == _rightmosts[int(partition)]) {
      assert (!_membership[int(partition)].is_set(high_idx), "Do not shrink interval if region not removed");
      if (low_idx == 0) {

@@ -287,35 +313,65 @@
  
    _membership[int(which_partition)].set_bit(idx);
    _capacity[int(which_partition)] += _region_size_bytes;
    _used[int(which_partition)] += _region_size_bytes - available;
    expand_interval_if_boundary_modified(which_partition, idx, available);
- 
    _region_counts[int(which_partition)]++;
  }
  
+ bool ShenandoahRegionPartitions::is_mutator_partition(ShenandoahFreeSetPartitionId p) {
+   return (p == ShenandoahFreeSetPartitionId::Mutator);
+ }
+ 
+ bool ShenandoahRegionPartitions::is_young_collector_partition(ShenandoahFreeSetPartitionId p) {
+   return (p == ShenandoahFreeSetPartitionId::Collector);
+ }
+ 
+ bool ShenandoahRegionPartitions::is_old_collector_partition(ShenandoahFreeSetPartitionId p) {
+   return (p == ShenandoahFreeSetPartitionId::OldCollector);
+ }
+ 
+ bool ShenandoahRegionPartitions::available_implies_empty(size_t available_in_region) {
+   return (available_in_region == _region_size_bytes);
+ }
+ 
+ 
  void ShenandoahRegionPartitions::move_from_partition_to_partition(idx_t idx, ShenandoahFreeSetPartitionId orig_partition,
                                                                    ShenandoahFreeSetPartitionId new_partition, size_t available) {
+   ShenandoahHeapRegion* r = ShenandoahHeap::heap()->get_region(idx);
    assert (idx < _max, "index is sane: " SIZE_FORMAT " < " SIZE_FORMAT, idx, _max);
    assert (orig_partition < NumPartitions, "Original partition must be valid");
    assert (new_partition < NumPartitions, "New partition must be valid");
    assert (available <= _region_size_bytes, "Available cannot exceed region size");
+   assert (_membership[int(orig_partition)].is_set(idx), "Cannot move from partition unless in partition");
+   assert ((r != nullptr) && ((r->is_trash() && (available == _region_size_bytes)) ||
+                              (r->used() + available == _region_size_bytes)),
+           "Used: " SIZE_FORMAT " + available: " SIZE_FORMAT " should equal region size: " SIZE_FORMAT,
+           ShenandoahHeap::heap()->get_region(idx)->used(), available, _region_size_bytes);
  
    // Expected transitions:
    //  During rebuild:         Mutator => Collector
+   //                          Mutator empty => Collector
+   //                          Mutator empty => OldCollector
    //  During flip_to_gc:      Mutator empty => Collector
+   //                          Mutator empty => OldCollector
    // At start of update refs: Collector => Mutator
-   assert (((available <= _region_size_bytes) &&
-            (((orig_partition == ShenandoahFreeSetPartitionId::Mutator)
-              && (new_partition == ShenandoahFreeSetPartitionId::Collector)) ||
-             ((orig_partition == ShenandoahFreeSetPartitionId::Collector)
-              && (new_partition == ShenandoahFreeSetPartitionId::Mutator)))) ||
-           ((available == _region_size_bytes) &&
-            ((orig_partition == ShenandoahFreeSetPartitionId::Mutator)
-             && (new_partition == ShenandoahFreeSetPartitionId::Collector))), "Unexpected movement between partitions");
+   //                          OldCollector Empty => Mutator
+   assert ((is_mutator_partition(orig_partition) && is_young_collector_partition(new_partition)) ||
+           (is_mutator_partition(orig_partition) &&
+            available_implies_empty(available) && is_old_collector_partition(new_partition)) ||
+           (is_young_collector_partition(orig_partition) && is_mutator_partition(new_partition)) ||
+           (is_old_collector_partition(orig_partition)
+            && available_implies_empty(available) && is_mutator_partition(new_partition)),
+           "Unexpected movement between partitions, available: " SIZE_FORMAT ", _region_size_bytes: " SIZE_FORMAT
+           ", orig_partition: %s, new_partition: %s",
+           available, _region_size_bytes, partition_name(orig_partition), partition_name(new_partition));
  
    size_t used = _region_size_bytes - available;
+   assert (_used[int(orig_partition)] >= used,
+           "Orig partition used: " SIZE_FORMAT " must exceed moved used: " SIZE_FORMAT " within region " SSIZE_FORMAT,
+           _used[int(orig_partition)], used, idx);
  
    _membership[int(orig_partition)].clear_bit(idx);
    _membership[int(new_partition)].set_bit(idx);
  
    _capacity[int(orig_partition)] -= _region_size_bytes;

@@ -480,10 +536,11 @@
        case ShenandoahFreeSetPartitionId::NotFree:
          break;
  
        case ShenandoahFreeSetPartitionId::Mutator:
        case ShenandoahFreeSetPartitionId::Collector:
+       case ShenandoahFreeSetPartitionId::OldCollector:
        {
          size_t capacity = _free_set->alloc_capacity(i);
          bool is_empty = (capacity == _region_size_bytes);
          assert(capacity > 0, "free regions must have allocation capacity");
          if (i < leftmosts[int(partition)]) {

@@ -569,37 +626,149 @@
            "free empty regions before the leftmost: " SSIZE_FORMAT ", bound " SSIZE_FORMAT,
            beg_off, leftmost_empty(ShenandoahFreeSetPartitionId::Collector));
    assert (end_off <= _rightmosts_empty[int(ShenandoahFreeSetPartitionId::Collector)],
            "free empty regions past the rightmost: " SSIZE_FORMAT ", bound " SSIZE_FORMAT,
            end_off, rightmost_empty(ShenandoahFreeSetPartitionId::Collector));
+ 
+   // Performance invariants. Failing these would not break the free partition, but performance would suffer.
+   assert (leftmost(ShenandoahFreeSetPartitionId::OldCollector) <= _max, "leftmost in bounds: "  SSIZE_FORMAT " < " SSIZE_FORMAT,
+           leftmost(ShenandoahFreeSetPartitionId::OldCollector),  _max);
+   assert (rightmost(ShenandoahFreeSetPartitionId::OldCollector) < _max, "rightmost in bounds: "  SSIZE_FORMAT " < " SSIZE_FORMAT,
+           rightmost(ShenandoahFreeSetPartitionId::OldCollector),  _max);
+ 
+   assert (leftmost(ShenandoahFreeSetPartitionId::OldCollector) == _max
+           || partition_id_matches(leftmost(ShenandoahFreeSetPartitionId::OldCollector),
+                                   ShenandoahFreeSetPartitionId::OldCollector),
+           "leftmost region should be free: " SSIZE_FORMAT,  leftmost(ShenandoahFreeSetPartitionId::OldCollector));
+   assert (leftmost(ShenandoahFreeSetPartitionId::OldCollector) == _max
+           || partition_id_matches(rightmost(ShenandoahFreeSetPartitionId::OldCollector),
+                                   ShenandoahFreeSetPartitionId::OldCollector),
+           "rightmost region should be free: " SSIZE_FORMAT, rightmost(ShenandoahFreeSetPartitionId::OldCollector));
+ 
+   // If OldCollector partition is empty, leftmosts will both equal max, rightmosts will both equal zero.
+   // Likewise for empty region partitions.
+   beg_off = leftmosts[int(ShenandoahFreeSetPartitionId::OldCollector)];
+   end_off = rightmosts[int(ShenandoahFreeSetPartitionId::OldCollector)];
+   assert (beg_off >= leftmost(ShenandoahFreeSetPartitionId::OldCollector),
+           "free regions before the leftmost: " SSIZE_FORMAT ", bound " SSIZE_FORMAT,
+           beg_off, leftmost(ShenandoahFreeSetPartitionId::OldCollector));
+   assert (end_off <= rightmost(ShenandoahFreeSetPartitionId::OldCollector),
+           "free regions past the rightmost: " SSIZE_FORMAT ", bound " SSIZE_FORMAT,
+           end_off, rightmost(ShenandoahFreeSetPartitionId::OldCollector));
+ 
+   beg_off = empty_leftmosts[int(ShenandoahFreeSetPartitionId::OldCollector)];
+   end_off = empty_rightmosts[int(ShenandoahFreeSetPartitionId::OldCollector)];
+   assert (beg_off >= _leftmosts_empty[int(ShenandoahFreeSetPartitionId::OldCollector)],
+           "free empty regions before the leftmost: " SSIZE_FORMAT ", bound " SSIZE_FORMAT,
+           beg_off, leftmost_empty(ShenandoahFreeSetPartitionId::OldCollector));
+   assert (end_off <= _rightmosts_empty[int(ShenandoahFreeSetPartitionId::OldCollector)],
+           "free empty regions past the rightmost: " SSIZE_FORMAT ", bound " SSIZE_FORMAT,
+           end_off, rightmost_empty(ShenandoahFreeSetPartitionId::OldCollector));
  }
  #endif
  
  ShenandoahFreeSet::ShenandoahFreeSet(ShenandoahHeap* heap, size_t max_regions) :
    _heap(heap),
    _partitions(max_regions, this),
-   _right_to_left_bias(false),
    _alloc_bias_weight(0)
  {
    clear_internal();
  }
  
+ void ShenandoahFreeSet::add_promoted_in_place_region_to_old_collector(ShenandoahHeapRegion* region) {
+   shenandoah_assert_heaplocked();
+   size_t plab_min_size_in_bytes = ShenandoahGenerationalHeap::heap()->plab_min_size() * HeapWordSize;
+   size_t idx = region->index();
+   size_t capacity = alloc_capacity(region);
+   assert(_partitions.membership(idx) == ShenandoahFreeSetPartitionId::NotFree,
+          "Regions promoted in place should have been excluded from Mutator partition");
+   if (capacity >= plab_min_size_in_bytes) {
+     _partitions.make_free(idx, ShenandoahFreeSetPartitionId::OldCollector, capacity);
+     _heap->old_generation()->augment_promoted_reserve(capacity);
+   }
+ }
+ 
+ HeapWord* ShenandoahFreeSet::allocate_from_partition_with_affiliation(ShenandoahFreeSetPartitionId which_partition,
+                                                                       ShenandoahAffiliation affiliation,
+                                                                       ShenandoahAllocRequest& req, bool& in_new_region) {
+   shenandoah_assert_heaplocked();
+   idx_t rightmost_collector = ((affiliation == ShenandoahAffiliation::FREE)?
+                                _partitions.rightmost_empty(which_partition): _partitions.rightmost(which_partition));
+   idx_t leftmost_collector = ((affiliation == ShenandoahAffiliation::FREE)?
+                               _partitions.leftmost_empty(which_partition): _partitions.leftmost(which_partition));
+   if (_partitions.alloc_from_left_bias(which_partition)) {
+     for (idx_t idx = leftmost_collector; idx <= rightmost_collector; ) {
+       assert(_partitions.in_free_set(which_partition, idx), "Boundaries or find_prev_last_bit failed: " SSIZE_FORMAT, idx);
+       ShenandoahHeapRegion* r = _heap->get_region(idx);
+       if (r->affiliation() == affiliation) {
+         HeapWord* result = try_allocate_in(r, req, in_new_region);
+         if (result != nullptr) {
+           return result;
+         }
+       }
+       idx = _partitions.find_index_of_next_available_region(which_partition, idx + 1);
+     }
+   } else {
+     for (idx_t idx = rightmost_collector; idx >= leftmost_collector; ) {
+       assert(_partitions.in_free_set(which_partition, idx),
+              "Boundaries or find_prev_last_bit failed: " SSIZE_FORMAT, idx);
+       ShenandoahHeapRegion* r = _heap->get_region(idx);
+       if (r->affiliation() == affiliation) {
+         HeapWord* result = try_allocate_in(r, req, in_new_region);
+         if (result != nullptr) {
+           return result;
+         }
+       }
+       idx = _partitions.find_index_of_previous_available_region(which_partition, idx - 1);
+     }
+   }
+   log_debug(gc, free)("Could not allocate collector region with affiliation: %s for request " PTR_FORMAT,
+                       shenandoah_affiliation_name(affiliation), p2i(&req));
+   return nullptr;
+ }
+ 
  HeapWord* ShenandoahFreeSet::allocate_single(ShenandoahAllocRequest& req, bool& in_new_region) {
    shenandoah_assert_heaplocked();
  
    // Scan the bitmap looking for a first fit.
    //
-   // Leftmost and rightmost bounds provide enough caching to quickly find a region from which to allocate.
+   // Leftmost and rightmost bounds provide enough caching to walk bitmap efficiently. Normally,
+   // we would find the region to allocate at right away.
    //
    // Allocations are biased: GC allocations are taken from the high end of the heap.  Regular (and TLAB)
    // mutator allocations are taken from the middle of heap, below the memory reserved for Collector.
    // Humongous mutator allocations are taken from the bottom of the heap.
    //
-   // Free set maintains mutator and collector partitions.  Mutator can only allocate from the
-   // Mutator partition.  Collector prefers to allocate from the Collector partition, but may steal
-   // regions from the Mutator partition if the Collector partition has been depleted.
+   // Free set maintains mutator and collector partitions.  Normally, each allocates only from its partition,
+   // except in special cases when the collector steals regions from the mutator partition.
+ 
+   // Overwrite with non-zero (non-NULL) values only if necessary for allocation bookkeeping.
+   bool allow_new_region = true;
+   if (_heap->mode()->is_generational()) {
+     switch (req.affiliation()) {
+       case ShenandoahAffiliation::OLD_GENERATION:
+         // Note: unsigned result from free_unaffiliated_regions() will never be less than zero, but it may equal zero.
+         if (_heap->old_generation()->free_unaffiliated_regions() <= 0) {
+           allow_new_region = false;
+         }
+         break;
+ 
+       case ShenandoahAffiliation::YOUNG_GENERATION:
+         // Note: unsigned result from free_unaffiliated_regions() will never be less than zero, but it may equal zero.
+         if (_heap->young_generation()->free_unaffiliated_regions() <= 0) {
+           allow_new_region = false;
+         }
+         break;
+ 
+       case ShenandoahAffiliation::FREE:
+         fatal("Should request affiliation");
  
+       default:
+         ShouldNotReachHere();
+         break;
+     }
+   }
    switch (req.type()) {
      case ShenandoahAllocRequest::_alloc_tlab:
      case ShenandoahAllocRequest::_alloc_shared: {
        // Try to allocate in the mutator view
        if (_alloc_bias_weight-- <= 0) {

@@ -620,14 +789,14 @@
          //     late in the GC cycle.
          idx_t non_empty_on_left = (_partitions.leftmost_empty(ShenandoahFreeSetPartitionId::Mutator)
                                       - _partitions.leftmost(ShenandoahFreeSetPartitionId::Mutator));
          idx_t non_empty_on_right = (_partitions.rightmost(ShenandoahFreeSetPartitionId::Mutator)
                                        - _partitions.rightmost_empty(ShenandoahFreeSetPartitionId::Mutator));
-         _right_to_left_bias = (non_empty_on_right > non_empty_on_left);
+         _partitions.set_bias_from_left_to_right(ShenandoahFreeSetPartitionId::Mutator, (non_empty_on_right < non_empty_on_left));
          _alloc_bias_weight = _InitialAllocBiasWeight;
        }
-       if (_right_to_left_bias) {
+       if (!_partitions.alloc_from_left_bias(ShenandoahFreeSetPartitionId::Mutator)) {
          // Allocate within mutator free from high memory to low so as to preserve low memory for humongous allocations
          if (!_partitions.is_empty(ShenandoahFreeSetPartitionId::Mutator)) {
            // Use signed idx.  Otherwise, loop will never terminate.
            idx_t leftmost = _partitions.leftmost(ShenandoahFreeSetPartitionId::Mutator);
            for (idx_t idx = _partitions.rightmost(ShenandoahFreeSetPartitionId::Mutator); idx >= leftmost; ) {

@@ -668,113 +837,253 @@
        break;
      }
      case ShenandoahAllocRequest::_alloc_gclab:
        // GCLABs are for evacuation so we must be in evacuation phase.
  
+     case ShenandoahAllocRequest::_alloc_plab: {
+       // PLABs always reside in old-gen and are only allocated during
+       // evacuation phase.
+ 
      case ShenandoahAllocRequest::_alloc_shared_gc: {
        // Fast-path: try to allocate in the collector view first
-       idx_t leftmost_collector = _partitions.leftmost(ShenandoahFreeSetPartitionId::Collector);
-       for (idx_t idx = _partitions.rightmost(ShenandoahFreeSetPartitionId::Collector); idx >= leftmost_collector; ) {
-         assert(_partitions.in_free_set(ShenandoahFreeSetPartitionId::Collector, idx),
-                "Boundaries or find_prev_last_bit failed: " SSIZE_FORMAT, idx);
-         HeapWord* result = try_allocate_in(_heap->get_region(idx), req, in_new_region);
+       HeapWord* result;
+       result = allocate_from_partition_with_affiliation(req.is_old()? ShenandoahFreeSetPartitionId::OldCollector:
+                                                         ShenandoahFreeSetPartitionId::Collector,
+                                                         req.affiliation(), req, in_new_region);
+       if (result != nullptr) {
+         return result;
+       } else if (allow_new_region) {
+         // Try a free region that is dedicated to GC allocations.
+         result = allocate_from_partition_with_affiliation(req.is_old()? ShenandoahFreeSetPartitionId::OldCollector:
+                                                           ShenandoahFreeSetPartitionId::Collector,
+                                                           ShenandoahAffiliation::FREE, req, in_new_region);
          if (result != nullptr) {
            return result;
          }
-         idx = _partitions.find_index_of_previous_available_region(ShenandoahFreeSetPartitionId::Collector, idx - 1);
        }
  
        // No dice. Can we borrow space from mutator view?
        if (!ShenandoahEvacReserveOverflow) {
          return nullptr;
        }
+       if (!allow_new_region && req.is_old() && (_heap->young_generation()->free_unaffiliated_regions() > 0)) {
+         // This allows us to flip a mutator region to old_collector
+         allow_new_region = true;
+       }
  
-       // Try to steal an empty region from the mutator view.
-       idx_t leftmost_mutator_empty = _partitions.leftmost_empty(ShenandoahFreeSetPartitionId::Mutator);
-       for (idx_t idx = _partitions.rightmost_empty(ShenandoahFreeSetPartitionId::Mutator); idx >= leftmost_mutator_empty; ) {
-         assert(_partitions.in_free_set(ShenandoahFreeSetPartitionId::Mutator, idx),
-                "Boundaries or find_prev_last_bit failed: " SSIZE_FORMAT, idx);
-         ShenandoahHeapRegion* r = _heap->get_region(idx);
-         if (can_allocate_from(r)) {
-           flip_to_gc(r);
-           HeapWord *result = try_allocate_in(r, req, in_new_region);
-           if (result != nullptr) {
-             log_debug(gc)("Flipped region " SIZE_FORMAT " to gc for request: " PTR_FORMAT, idx, p2i(&req));
-             return result;
+       // We should expand old-gen if this can prevent an old-gen evacuation failure.  We don't care so much about
+       // promotion failures since they can be mitigated in a subsequent GC pass.  Would be nice to know if this
+       // allocation request is for evacuation or promotion.  Individual threads limit their use of PLAB memory for
+       // promotions, so we already have an assurance that any additional memory set aside for old-gen will be used
+       // only for old-gen evacuations.
+ 
+       // TODO:
+       // if (GC is idle (out of cycle) and mutator allocation fails and there is memory reserved in Collector
+       // or OldCollector sets, transfer a region of memory so that we can satisfy the allocation request, and
+       // immediately trigger the start of GC.  Is better to satisfy the allocation than to trigger out-of-cycle
+       // allocation failure (even if this means we have a little less memory to handle evacuations during the
+       // subsequent GC pass).
+ 
+       if (allow_new_region) {
+         // Try to steal an empty region from the mutator view.
+         idx_t rightmost_mutator = _partitions.rightmost_empty(ShenandoahFreeSetPartitionId::Mutator);
+         idx_t leftmost_mutator =  _partitions.leftmost_empty(ShenandoahFreeSetPartitionId::Mutator);
+         for (idx_t idx = rightmost_mutator; idx >= leftmost_mutator; ) {
+           assert(_partitions.in_free_set(ShenandoahFreeSetPartitionId::Mutator, idx),
+                  "Boundaries or find_prev_last_bit failed: " SSIZE_FORMAT, idx);
+           ShenandoahHeapRegion* r = _heap->get_region(idx);
+           if (can_allocate_from(r)) {
+             if (req.is_old()) {
+               flip_to_old_gc(r);
+             } else {
+               flip_to_gc(r);
+             }
+             // Region r is entirely empty.  If try_allocat_in fails on region r, something else is really wrong.
+             // Don't bother to retry with other regions.
+             log_debug(gc, free)("Flipped region " SIZE_FORMAT " to gc for request: " PTR_FORMAT, idx, p2i(&req));
+             return try_allocate_in(r, req, in_new_region);
            }
+           idx = _partitions.find_index_of_previous_available_region(ShenandoahFreeSetPartitionId::Mutator, idx - 1);
          }
-         idx = _partitions.find_index_of_previous_available_region(ShenandoahFreeSetPartitionId::Mutator, idx - 1);
        }
- 
        // No dice. Do not try to mix mutator and GC allocations, because adjusting region UWM
        // due to GC allocations would expose unparsable mutator allocations.
        break;
      }
+     }
      default:
        ShouldNotReachHere();
    }
    return nullptr;
  }
  
+ // This work method takes an argument corresponding to the number of bytes
+ // free in a region, and returns the largest amount in heapwords that can be allocated
+ // such that both of the following conditions are satisfied:
+ //
+ // 1. it is a multiple of card size
+ // 2. any remaining shard may be filled with a filler object
+ //
+ // The idea is that the allocation starts and ends at card boundaries. Because
+ // a region ('s end) is card-aligned, the remainder shard that must be filled is
+ // at the start of the free space.
+ //
+ // This is merely a helper method to use for the purpose of such a calculation.
+ size_t ShenandoahFreeSet::get_usable_free_words(size_t free_bytes) const {
+   // e.g. card_size is 512, card_shift is 9, min_fill_size() is 8
+   //      free is 514
+   //      usable_free is 512, which is decreased to 0
+   size_t usable_free = (free_bytes / CardTable::card_size()) << CardTable::card_shift();
+   assert(usable_free <= free_bytes, "Sanity check");
+   if ((free_bytes != usable_free) && (free_bytes - usable_free < ShenandoahHeap::min_fill_size() * HeapWordSize)) {
+     // After aligning to card multiples, the remainder would be smaller than
+     // the minimum filler object, so we'll need to take away another card's
+     // worth to construct a filler object.
+     if (usable_free >= CardTable::card_size()) {
+       usable_free -= CardTable::card_size();
+     } else {
+       assert(usable_free == 0, "usable_free is a multiple of card_size and card_size > min_fill_size");
+     }
+   }
+ 
+   return usable_free / HeapWordSize;
+ }
+ 
+ // Given a size argument, which is a multiple of card size, a request struct
+ // for a PLAB, and an old region, return a pointer to the allocated space for
+ // a PLAB which is card-aligned and where any remaining shard in the region
+ // has been suitably filled by a filler object.
+ // It is assumed (and assertion-checked) that such an allocation is always possible.
+ HeapWord* ShenandoahFreeSet::allocate_aligned_plab(size_t size, ShenandoahAllocRequest& req, ShenandoahHeapRegion* r) {
+   assert(_heap->mode()->is_generational(), "PLABs are only for generational mode");
+   assert(r->is_old(), "All PLABs reside in old-gen");
+   assert(!req.is_mutator_alloc(), "PLABs should not be allocated by mutators.");
+   assert(is_aligned(size, CardTable::card_size_in_words()), "Align by design");
+ 
+   HeapWord* result = r->allocate_aligned(size, req, CardTable::card_size());
+   assert(result != nullptr, "Allocation cannot fail");
+   assert(r->top() <= r->end(), "Allocation cannot span end of region");
+   assert(is_aligned(result, CardTable::card_size_in_words()), "Align by design");
+   return result;
+ }
+ 
  HeapWord* ShenandoahFreeSet::try_allocate_in(ShenandoahHeapRegion* r, ShenandoahAllocRequest& req, bool& in_new_region) {
    assert (has_alloc_capacity(r), "Performance: should avoid full regions on this path: " SIZE_FORMAT, r->index());
    if (_heap->is_concurrent_weak_root_in_progress() && r->is_trash()) {
      return nullptr;
    }
- 
    HeapWord* result = nullptr;
    try_recycle_trashed(r);
    in_new_region = r->is_empty();
  
    if (in_new_region) {
      log_debug(gc)("Using new region (" SIZE_FORMAT ") for %s (" PTR_FORMAT ").",
                         r->index(), ShenandoahAllocRequest::alloc_type_to_string(req.type()), p2i(&req));
+     assert(!r->is_affiliated(), "New region " SIZE_FORMAT " should be unaffiliated", r->index());
+     r->set_affiliation(req.affiliation());
+     if (r->is_old()) {
+       // Any OLD region allocated during concurrent coalesce-and-fill does not need to be coalesced and filled because
+       // all objects allocated within this region are above TAMS (and thus are implicitly marked).  In case this is an
+       // OLD region and concurrent preparation for mixed evacuations visits this region before the start of the next
+       // old-gen concurrent mark (i.e. this region is allocated following the start of old-gen concurrent mark but before
+       // concurrent preparations for mixed evacuations are completed), we mark this region as not requiring any
+       // coalesce-and-fill processing.
+       r->end_preemptible_coalesce_and_fill();
+       _heap->old_generation()->clear_cards_for(r);
+     }
+     _heap->generation_for(r->affiliation())->increment_affiliated_region_count();
+ 
+ #ifdef ASSERT
+     ShenandoahMarkingContext* const ctx = _heap->complete_marking_context();
+     assert(ctx->top_at_mark_start(r) == r->bottom(), "Newly established allocation region starts with TAMS equal to bottom");
+     assert(ctx->is_bitmap_clear_range(ctx->top_bitmap(r), r->end()), "Bitmap above top_bitmap() must be clear");
+ #endif
+     log_debug(gc)("Using new region (" SIZE_FORMAT ") for %s (" PTR_FORMAT ").",
+                        r->index(), ShenandoahAllocRequest::alloc_type_to_string(req.type()), p2i(&req));
+   } else {
+     assert(r->is_affiliated(), "Region " SIZE_FORMAT " that is not new should be affiliated", r->index());
+     if (r->affiliation() != req.affiliation()) {
+       assert(_heap->mode()->is_generational(), "Request for %s from %s region should only happen in generational mode.",
+              req.affiliation_name(), r->affiliation_name());
+       return nullptr;
+     }
    }
  
    // req.size() is in words, r->free() is in bytes.
    if (req.is_lab_alloc()) {
-     // This is a GCLAB or a TLAB allocation
      size_t adjusted_size = req.size();
-     size_t free = align_down(r->free() >> LogHeapWordSize, MinObjAlignment);
-     if (adjusted_size > free) {
-       adjusted_size = free;
-     }
-     if (adjusted_size >= req.min_size()) {
-       result = r->allocate(adjusted_size, req.type());
-       log_debug(gc)("Allocated " SIZE_FORMAT " words (adjusted from " SIZE_FORMAT ") for %s @" PTR_FORMAT
-                           " from %s region " SIZE_FORMAT ", free bytes remaining: " SIZE_FORMAT,
-                           adjusted_size, req.size(), ShenandoahAllocRequest::alloc_type_to_string(req.type()), p2i(result),
-                           _partitions.partition_membership_name(r->index()), r->index(), r->free());
-       assert (result != nullptr, "Allocation must succeed: free " SIZE_FORMAT ", actual " SIZE_FORMAT, free, adjusted_size);
-       req.set_actual_size(adjusted_size);
+     size_t free = r->free();    // free represents bytes available within region r
+     if (req.type() == ShenandoahAllocRequest::_alloc_plab) {
+       // This is a PLAB allocation
+       assert(_heap->mode()->is_generational(), "PLABs are only for generational mode");
+       assert(_partitions.in_free_set(ShenandoahFreeSetPartitionId::OldCollector, r->index()),
+              "PLABS must be allocated in old_collector_free regions");
+ 
+       // Need to assure that plabs are aligned on multiple of card region
+       // Convert free from unaligned bytes to aligned number of words
+       size_t usable_free = get_usable_free_words(free);
+       if (adjusted_size > usable_free) {
+         adjusted_size = usable_free;
+       }
+       adjusted_size = align_down(adjusted_size, CardTable::card_size_in_words());
+       if (adjusted_size >= req.min_size()) {
+         result = allocate_aligned_plab(adjusted_size, req, r);
+         assert(result != nullptr, "allocate must succeed");
+         req.set_actual_size(adjusted_size);
+       } else {
+         // Otherwise, leave result == nullptr because the adjusted size is smaller than min size.
+         log_trace(gc, free)("Failed to shrink PLAB request (" SIZE_FORMAT ") in region " SIZE_FORMAT " to " SIZE_FORMAT
+                             " because min_size() is " SIZE_FORMAT, req.size(), r->index(), adjusted_size, req.min_size());
+       }
      } else {
-       log_trace(gc, free)("Failed to shrink TLAB or GCLAB request (" SIZE_FORMAT ") in region " SIZE_FORMAT " to " SIZE_FORMAT
-                           " because min_size() is " SIZE_FORMAT, req.size(), r->index(), adjusted_size, req.min_size());
+       // This is a GCLAB or a TLAB allocation
+       // Convert free from unaligned bytes to aligned number of words
+       free = align_down(free >> LogHeapWordSize, MinObjAlignment);
+       if (adjusted_size > free) {
+         adjusted_size = free;
+       }
+       if (adjusted_size >= req.min_size()) {
+         result = r->allocate(adjusted_size, req);
+         assert (result != nullptr, "Allocation must succeed: free " SIZE_FORMAT ", actual " SIZE_FORMAT, free, adjusted_size);
+         req.set_actual_size(adjusted_size);
+       } else {
+         log_trace(gc, free)("Failed to shrink TLAB or GCLAB request (" SIZE_FORMAT ") in region " SIZE_FORMAT " to " SIZE_FORMAT
+                             " because min_size() is " SIZE_FORMAT, req.size(), r->index(), adjusted_size, req.min_size());
+       }
      }
    } else {
      size_t size = req.size();
-     result = r->allocate(size, req.type());
+     result = r->allocate(size, req);
      if (result != nullptr) {
        // Record actual allocation size
-       log_debug(gc)("Allocated " SIZE_FORMAT " words for %s @" PTR_FORMAT
-                           " from %s region " SIZE_FORMAT ", free bytes remaining: " SIZE_FORMAT,
-                           size, ShenandoahAllocRequest::alloc_type_to_string(req.type()), p2i(result),
-                           _partitions.partition_membership_name(r->index()),  r->index(), r->free());
        req.set_actual_size(size);
      }
    }
  
    if (result != nullptr) {
      // Allocation successful, bump stats:
      if (req.is_mutator_alloc()) {
+       assert(req.is_young(), "Mutator allocations always come from young generation.");
        _partitions.increase_used(ShenandoahFreeSetPartitionId::Mutator, req.actual_size() * HeapWordSize);
      } else {
        assert(req.is_gc_alloc(), "Should be gc_alloc since req wasn't mutator alloc");
  
        // For GC allocations, we advance update_watermark because the objects relocated into this memory during
-       // evacuation are not updated during evacuation.
+       // evacuation are not updated during evacuation.  For both young and old regions r, it is essential that all
+       // PLABs be made parsable at the end of evacuation.  This is enabled by retiring all plabs at end of evacuation.
+       // TODO: Making a PLAB parsable involves placing a filler object in its remnant memory but does not require
+       // that the PLAB be disabled for all future purposes.  We may want to introduce a new service to make the
+       // PLABs parsable while still allowing the PLAB to serve future allocation requests that arise during the
+       // next evacuation pass.
        r->set_update_watermark(r->top());
+       if (r->is_old()) {
+         _partitions.increase_used(ShenandoahFreeSetPartitionId::OldCollector, req.actual_size() * HeapWordSize);
+         assert(req.type() != ShenandoahAllocRequest::_alloc_gclab, "old-gen allocations use PLAB or shared allocation");
+         // for plabs, we'll sort the difference between evac and promotion usage when we retire the plab
+       } else {
+         _partitions.increase_used(ShenandoahFreeSetPartitionId::Collector, req.actual_size() * HeapWordSize);
+       }
      }
    }
  
    static const size_t min_capacity = (size_t) (ShenandoahHeapRegion::region_size_bytes() * (1.0 - 1.0 / ShenandoahEvacWaste));
    size_t ac = alloc_capacity(r);

@@ -785,13 +1094,26 @@
  
      // Also, if this allocation request failed and the consumed within this region * ShenandoahEvacWaste > region size,
      // then retire the region so that subsequent searches can find available memory more quickly.
  
      size_t idx = r->index();
-     _partitions.retire_from_partition(req.is_mutator_alloc()?
-                                       ShenandoahFreeSetPartitionId::Mutator: ShenandoahFreeSetPartitionId::Collector,
-                                       idx, r->used());
+     ShenandoahFreeSetPartitionId orig_partition;
+     if (req.is_mutator_alloc()) {
+       orig_partition = ShenandoahFreeSetPartitionId::Mutator;
+     } else if (req.type() == ShenandoahAllocRequest::_alloc_gclab) {
+       orig_partition = ShenandoahFreeSetPartitionId::Collector;
+     } else if (req.type() == ShenandoahAllocRequest::_alloc_plab) {
+       orig_partition = ShenandoahFreeSetPartitionId::OldCollector;
+     } else {
+       assert(req.type() == ShenandoahAllocRequest::_alloc_shared_gc, "Unexpected allocation type");
+       if (req.is_old()) {
+         orig_partition = ShenandoahFreeSetPartitionId::OldCollector;
+       } else {
+         orig_partition = ShenandoahFreeSetPartitionId::Collector;
+       }
+     }
+     _partitions.retire_from_partition(orig_partition, idx, r->used());
      _partitions.assert_bounds();
    }
    return result;
  }
  

@@ -800,10 +1122,13 @@
    shenandoah_assert_heaplocked();
  
    size_t words_size = req.size();
    idx_t num = ShenandoahHeapRegion::required_regions(words_size * HeapWordSize);
  
+   assert(req.is_young(), "Humongous regions always allocated in YOUNG");
+   ShenandoahGeneration* generation = _heap->generation_for(req.affiliation());
+ 
    // Check if there are enough regions left to satisfy allocation.
    if (num > (idx_t) _partitions.count(ShenandoahFreeSetPartitionId::Mutator)) {
      return nullptr;
    }
  

@@ -812,11 +1137,11 @@
    idx_t last_possible_start = end_range - num;
  
    // Find the continuous interval of $num regions, starting from $beg and ending in $end,
    // inclusive. Contiguous allocations are biased to the beginning.
    idx_t beg = _partitions.find_index_of_next_available_cluster_of_regions(ShenandoahFreeSetPartitionId::Mutator,
-                                                                             start_range, num);
+                                                                           start_range, num);
    if (beg > last_possible_start) {
      // Hit the end, goodbye
      return nullptr;
    }
    idx_t end = beg;

@@ -857,10 +1182,11 @@
  
      end++;
    }
  
    size_t remainder = words_size & ShenandoahHeapRegion::region_size_words_mask();
+   bool is_generational = _heap->mode()->is_generational();
    // Initialize regions:
    for (idx_t i = beg; i <= end; i++) {
      ShenandoahHeapRegion* r = _heap->get_region(i);
      try_recycle_trashed(r);
  

@@ -879,13 +1205,15 @@
        used_words = remainder;
      } else {
        used_words = ShenandoahHeapRegion::region_size_words();
      }
  
+     r->set_affiliation(req.affiliation());
+     r->set_update_watermark(r->bottom());
      r->set_top(r->bottom() + used_words);
    }
- 
+   generation->increase_affiliated_region_count(num);
    if (remainder != 0) {
      // Record this remainder as allocation waste
      _heap->notify_mutator_alloc_words(ShenandoahHeapRegion::region_size_words() - remainder, true);
    }
  

@@ -894,34 +1222,56 @@
  
    size_t total_humongous_size = ShenandoahHeapRegion::region_size_bytes() * num;
    _partitions.increase_used(ShenandoahFreeSetPartitionId::Mutator, total_humongous_size);
    _partitions.assert_bounds();
    req.set_actual_size(words_size);
+   if (remainder != 0) {
+     req.set_waste(ShenandoahHeapRegion::region_size_words() - remainder);
+   }
    return _heap->get_region(beg)->bottom();
  }
  
  void ShenandoahFreeSet::try_recycle_trashed(ShenandoahHeapRegion *r) {
    if (r->is_trash()) {
-     _heap->decrease_used(r->used());
      r->recycle();
    }
  }
  
  void ShenandoahFreeSet::recycle_trash() {
    // lock is not reentrable, check we don't have it
    shenandoah_assert_not_heaplocked();
- 
    for (size_t i = 0; i < _heap->num_regions(); i++) {
      ShenandoahHeapRegion* r = _heap->get_region(i);
      if (r->is_trash()) {
        ShenandoahHeapLocker locker(_heap->lock());
        try_recycle_trashed(r);
      }
      SpinPause(); // allow allocators to take the lock
    }
  }
  
+ void ShenandoahFreeSet::flip_to_old_gc(ShenandoahHeapRegion* r) {
+   size_t idx = r->index();
+ 
+   assert(_partitions.partition_id_matches(idx, ShenandoahFreeSetPartitionId::Mutator), "Should be in mutator view");
+   assert(can_allocate_from(r), "Should not be allocated");
+ 
+   ShenandoahGenerationalHeap* gen_heap = ShenandoahGenerationalHeap::heap();
+   size_t region_capacity = alloc_capacity(r);
+   _partitions.move_from_partition_to_partition(idx, ShenandoahFreeSetPartitionId::Mutator,
+                                                ShenandoahFreeSetPartitionId::OldCollector, region_capacity);
+   _partitions.assert_bounds();
+   _heap->old_generation()->augment_evacuation_reserve(region_capacity);
+   bool transferred = gen_heap->generation_sizer()->transfer_to_old(1);
+   if (!transferred) {
+     log_warning(gc, free)("Forcing transfer of " SIZE_FORMAT " to old reserve.", idx);
+     gen_heap->generation_sizer()->force_transfer_to_old(1);
+   }
+   // We do not ensure that the region is no longer trash, relying on try_allocate_in(), which always comes next,
+   // to recycle trash before attempting to allocate anything in the region.
+ }
+ 
  void ShenandoahFreeSet::flip_to_gc(ShenandoahHeapRegion* r) {
    size_t idx = r->index();
  
    assert(_partitions.partition_id_matches(idx, ShenandoahFreeSetPartitionId::Mutator), "Should be in mutator view");
    assert(can_allocate_from(r), "Should not be allocated");

@@ -940,174 +1290,396 @@
    clear_internal();
  }
  
  void ShenandoahFreeSet::clear_internal() {
    _partitions.make_all_regions_unavailable();
- }
  
- void ShenandoahFreeSet::find_regions_with_alloc_capacity(size_t &cset_regions) {
+   _alloc_bias_weight = 0;
+   _partitions.set_bias_from_left_to_right(ShenandoahFreeSetPartitionId::Mutator, true);
+   _partitions.set_bias_from_left_to_right(ShenandoahFreeSetPartitionId::Collector, false);
+   _partitions.set_bias_from_left_to_right(ShenandoahFreeSetPartitionId::OldCollector, false);
+ }
  
-   cset_regions = 0;
+ void ShenandoahFreeSet::find_regions_with_alloc_capacity(size_t &young_cset_regions, size_t &old_cset_regions,
+                                                          size_t &first_old_region, size_t &last_old_region,
+                                                          size_t &old_region_count) {
    clear_internal();
+ 
+   first_old_region = _heap->num_regions();
+   last_old_region = 0;
+   old_region_count = 0;
+   old_cset_regions = 0;
+   young_cset_regions = 0;
+ 
    size_t region_size_bytes = _partitions.region_size_bytes();
    size_t max_regions = _partitions.max_regions();
  
    size_t mutator_leftmost = max_regions;
    size_t mutator_rightmost = 0;
    size_t mutator_leftmost_empty = max_regions;
    size_t mutator_rightmost_empty = 0;
- 
    size_t mutator_regions = 0;
    size_t mutator_used = 0;
  
+   size_t old_collector_leftmost = max_regions;
+   size_t old_collector_rightmost = 0;
+   size_t old_collector_leftmost_empty = max_regions;
+   size_t old_collector_rightmost_empty = 0;
+   size_t old_collector_regions = 0;
+   size_t old_collector_used = 0;
+ 
    for (size_t idx = 0; idx < _heap->num_regions(); idx++) {
      ShenandoahHeapRegion* region = _heap->get_region(idx);
      if (region->is_trash()) {
        // Trashed regions represent regions that had been in the collection partition but have not yet been "cleaned up".
        // The cset regions are not "trashed" until we have finished update refs.
-       cset_regions++;
+       if (region->is_old()) {
+         old_cset_regions++;
+       } else {
+         assert(region->is_young(), "Trashed region should be old or young");
+         young_cset_regions++;
+       }
+     } else if (region->is_old()) {
+       // count both humongous and regular regions, but don't count trash (cset) regions.
+       old_region_count++;
+       if (first_old_region > idx) {
+         first_old_region = idx;
+       }
+       last_old_region = idx;
      }
      if (region->is_alloc_allowed() || region->is_trash()) {
+       assert(!region->is_cset(), "Shouldn't be adding cset regions to the free set");
  
        // Do not add regions that would almost surely fail allocation
        size_t ac = alloc_capacity(region);
        if (ac > PLAB::min_size() * HeapWordSize) {
-         _partitions.raw_assign_membership(idx, ShenandoahFreeSetPartitionId::Mutator);
- 
-         if (idx < mutator_leftmost) {
-           mutator_leftmost = idx;
-         }
-         if (idx > mutator_rightmost) {
-           mutator_rightmost = idx;
-         }
-         if (ac == region_size_bytes) {
-           if (idx < mutator_leftmost_empty) {
-             mutator_leftmost_empty = idx;
+         if (region->is_trash() || !region->is_old()) {
+           // Both young and old collected regions (trashed) are placed into the Mutator set
+           _partitions.raw_assign_membership(idx, ShenandoahFreeSetPartitionId::Mutator);
+           if (idx < mutator_leftmost) {
+             mutator_leftmost = idx;
            }
-           if (idx > mutator_rightmost_empty) {
-             mutator_rightmost_empty = idx;
+           if (idx > mutator_rightmost) {
+             mutator_rightmost = idx;
            }
+           if (ac == region_size_bytes) {
+             if (idx < mutator_leftmost_empty) {
+               mutator_leftmost_empty = idx;
+             }
+             if (idx > mutator_rightmost_empty) {
+               mutator_rightmost_empty = idx;
+             }
+           }
+           mutator_regions++;
+           mutator_used += (region_size_bytes - ac);
+         } else {
+           // !region->is_trash() && region is_old()
+           _partitions.raw_assign_membership(idx, ShenandoahFreeSetPartitionId::OldCollector);
+           if (idx < old_collector_leftmost) {
+             old_collector_leftmost = idx;
+           }
+           if (idx > old_collector_rightmost) {
+             old_collector_rightmost = idx;
+           }
+           if (ac == region_size_bytes) {
+             if (idx < old_collector_leftmost_empty) {
+               old_collector_leftmost_empty = idx;
+             }
+             if (idx > old_collector_rightmost_empty) {
+               old_collector_rightmost_empty = idx;
+             }
+           }
+           old_collector_regions++;
+           old_collector_used += (region_size_bytes - ac);
          }
-         mutator_regions++;
-         mutator_used += (region_size_bytes - ac);
- 
-         log_debug(gc)(
-           "  Adding Region " SIZE_FORMAT " (Free: " SIZE_FORMAT "%s, Used: " SIZE_FORMAT "%s) to mutator partition",
-           idx, byte_size_in_proper_unit(region->free()), proper_unit_for_byte_size(region->free()),
-           byte_size_in_proper_unit(region->used()), proper_unit_for_byte_size(region->used()));
        }
      }
    }
+   log_debug(gc)("  At end of prep_to_rebuild, mutator_leftmost: " SIZE_FORMAT
+                 ", mutator_rightmost: " SIZE_FORMAT
+                 ", mutator_leftmost_empty: " SIZE_FORMAT
+                 ", mutator_rightmost_empty: " SIZE_FORMAT
+                 ", mutator_regions: " SIZE_FORMAT
+                 ", mutator_used: " SIZE_FORMAT,
+                 mutator_leftmost, mutator_rightmost, mutator_leftmost_empty, mutator_rightmost_empty,
+                 mutator_regions, mutator_used);
+ 
+   log_debug(gc)("  old_collector_leftmost: " SIZE_FORMAT
+                 ", old_collector_rightmost: " SIZE_FORMAT
+                 ", old_collector_leftmost_empty: " SIZE_FORMAT
+                 ", old_collector_rightmost_empty: " SIZE_FORMAT
+                 ", old_collector_regions: " SIZE_FORMAT
+                 ", old_collector_used: " SIZE_FORMAT,
+                 old_collector_leftmost, old_collector_rightmost, old_collector_leftmost_empty, old_collector_rightmost_empty,
+                 old_collector_regions, old_collector_used);
+ 
    _partitions.establish_mutator_intervals(mutator_leftmost, mutator_rightmost, mutator_leftmost_empty, mutator_rightmost_empty,
                                            mutator_regions, mutator_used);
+   _partitions.establish_old_collector_intervals(old_collector_leftmost, old_collector_rightmost, old_collector_leftmost_empty,
+                                                 old_collector_rightmost_empty, old_collector_regions, old_collector_used);
+   log_debug(gc)("  After find_regions_with_alloc_capacity(), Mutator range [" SSIZE_FORMAT ", " SSIZE_FORMAT "],"
+                 "  Old Collector range [" SSIZE_FORMAT ", " SSIZE_FORMAT "]",
+                 _partitions.leftmost(ShenandoahFreeSetPartitionId::Mutator),
+                 _partitions.rightmost(ShenandoahFreeSetPartitionId::Mutator),
+                 _partitions.leftmost(ShenandoahFreeSetPartitionId::OldCollector),
+                 _partitions.rightmost(ShenandoahFreeSetPartitionId::OldCollector));
  }
  
- void ShenandoahFreeSet::move_regions_from_collector_to_mutator(size_t max_xfer_regions) {
+ // Returns number of regions transferred, adds transferred bytes to var argument bytes_transferred
+ size_t ShenandoahFreeSet::transfer_empty_regions_from_collector_set_to_mutator_set(ShenandoahFreeSetPartitionId which_collector,
+                                                                                    size_t max_xfer_regions,
+                                                                                    size_t& bytes_transferred) {
+   shenandoah_assert_heaplocked();
    size_t region_size_bytes = ShenandoahHeapRegion::region_size_bytes();
-   size_t collector_empty_xfer = 0;
-   size_t collector_not_empty_xfer = 0;
+   size_t transferred_regions = 0;
+   idx_t rightmost = _partitions.rightmost_empty(which_collector);
+   for (idx_t idx = _partitions.leftmost_empty(which_collector); (transferred_regions < max_xfer_regions) && (idx <= rightmost); ) {
+     assert(_partitions.in_free_set(which_collector, idx), "Boundaries or find_first_set_bit failed: " SSIZE_FORMAT, idx);
+     // Note: can_allocate_from() denotes that region is entirely empty
+     if (can_allocate_from(idx)) {
+       _partitions.move_from_partition_to_partition(idx, which_collector, ShenandoahFreeSetPartitionId::Mutator, region_size_bytes);
+       transferred_regions++;
+       bytes_transferred += region_size_bytes;
+     }
+     idx = _partitions.find_index_of_next_available_region(which_collector, idx + 1);
+   }
+   return transferred_regions;
+ }
+ 
+ // Returns number of regions transferred, adds transferred bytes to var argument bytes_transferred
+ size_t ShenandoahFreeSet::transfer_non_empty_regions_from_collector_set_to_mutator_set(ShenandoahFreeSetPartitionId collector_id,
+                                                                                        size_t max_xfer_regions,
+                                                                                        size_t& bytes_transferred) {
+   shenandoah_assert_heaplocked();
+   size_t transferred_regions = 0;
+   idx_t rightmost = _partitions.rightmost(collector_id);
+   for (idx_t idx = _partitions.leftmost(collector_id); (transferred_regions < max_xfer_regions) && (idx <= rightmost); ) {
+     assert(_partitions.in_free_set(collector_id, idx), "Boundaries or find_first_set_bit failed: " SSIZE_FORMAT, idx);
+     size_t ac = alloc_capacity(idx);
+     if (ac > 0) {
+       _partitions.move_from_partition_to_partition(idx, collector_id, ShenandoahFreeSetPartitionId::Mutator, ac);
+       transferred_regions++;
+       bytes_transferred += ac;
+     }
+     idx = _partitions.find_index_of_next_available_region(ShenandoahFreeSetPartitionId::Collector, idx + 1);
+   }
+   return transferred_regions;
+ }
+ 
+ void ShenandoahFreeSet::move_regions_from_collector_to_mutator(size_t max_xfer_regions) {
+   size_t collector_xfer = 0;
+   size_t old_collector_xfer = 0;
  
    // Process empty regions within the Collector free partition
    if ((max_xfer_regions > 0) &&
        (_partitions.leftmost_empty(ShenandoahFreeSetPartitionId::Collector)
         <= _partitions.rightmost_empty(ShenandoahFreeSetPartitionId::Collector))) {
      ShenandoahHeapLocker locker(_heap->lock());
-     idx_t rightmost = _partitions.rightmost_empty(ShenandoahFreeSetPartitionId::Collector);
-     for (idx_t idx = _partitions.leftmost_empty(ShenandoahFreeSetPartitionId::Collector);
-          (max_xfer_regions > 0) && (idx <= rightmost); ) {
-       assert(_partitions.in_free_set(ShenandoahFreeSetPartitionId::Collector, idx),
-              "Boundaries or find_first_set_bit failed: " SSIZE_FORMAT, idx);
-       // Note: can_allocate_from() denotes that region is entirely empty
-       if (can_allocate_from(idx)) {
-         _partitions.move_from_partition_to_partition(idx, ShenandoahFreeSetPartitionId::Collector,
-                                                      ShenandoahFreeSetPartitionId::Mutator, region_size_bytes);
-         max_xfer_regions--;
-         collector_empty_xfer += region_size_bytes;
-       }
-       idx = _partitions.find_index_of_next_available_region(ShenandoahFreeSetPartitionId::Collector, idx + 1);
+     max_xfer_regions -=
+       transfer_empty_regions_from_collector_set_to_mutator_set(ShenandoahFreeSetPartitionId::Collector, max_xfer_regions,
+                                                                collector_xfer);
+   }
+ 
+   // Process empty regions within the OldCollector free partition
+   if ((max_xfer_regions > 0) &&
+       (_partitions.leftmost_empty(ShenandoahFreeSetPartitionId::OldCollector)
+        <= _partitions.rightmost_empty(ShenandoahFreeSetPartitionId::OldCollector))) {
+     ShenandoahHeapLocker locker(_heap->lock());
+     size_t old_collector_regions =
+       transfer_empty_regions_from_collector_set_to_mutator_set(ShenandoahFreeSetPartitionId::OldCollector, max_xfer_regions,
+                                                                old_collector_xfer);
+     max_xfer_regions -= old_collector_regions;
+     if (old_collector_regions > 0) {
+       ShenandoahGenerationalHeap::cast(_heap)->generation_sizer()->transfer_to_young(old_collector_regions);
      }
    }
  
    // If there are any non-empty regions within Collector partition, we can also move them to the Mutator free partition
    if ((max_xfer_regions > 0) && (_partitions.leftmost(ShenandoahFreeSetPartitionId::Collector)
                                   <= _partitions.rightmost(ShenandoahFreeSetPartitionId::Collector))) {
      ShenandoahHeapLocker locker(_heap->lock());
-     idx_t rightmost = _partitions.rightmost(ShenandoahFreeSetPartitionId::Collector);
-     for (idx_t idx = _partitions.leftmost(ShenandoahFreeSetPartitionId::Collector);
-          (max_xfer_regions > 0) && (idx <= rightmost); ) {
-       assert(_partitions.in_free_set(ShenandoahFreeSetPartitionId::Collector, idx),
-              "Boundaries or find_first_set_bit failed: " SSIZE_FORMAT, idx);
-       size_t ac = alloc_capacity(idx);
-       if (ac > 0) {
-         _partitions.move_from_partition_to_partition(idx, ShenandoahFreeSetPartitionId::Collector,
-                                                      ShenandoahFreeSetPartitionId::Mutator, ac);
-         max_xfer_regions--;
-         collector_not_empty_xfer += ac;
-       }
-       idx = _partitions.find_index_of_next_available_region(ShenandoahFreeSetPartitionId::Collector, idx + 1);
-     }
+     max_xfer_regions -=
+       transfer_non_empty_regions_from_collector_set_to_mutator_set(ShenandoahFreeSetPartitionId::Collector, max_xfer_regions,
+                                                                    collector_xfer);
    }
  
-   size_t collector_xfer = collector_empty_xfer + collector_not_empty_xfer;
-   log_info(gc)("At start of update refs, moving " SIZE_FORMAT "%s to Mutator free partition from Collector Reserve",
-                byte_size_in_proper_unit(collector_xfer), proper_unit_for_byte_size(collector_xfer));
+   size_t total_xfer = collector_xfer + old_collector_xfer;
+   log_info(gc, free)("At start of update refs, moving " SIZE_FORMAT "%s to Mutator free set from Collector Reserve ("
+                      SIZE_FORMAT "%s) and from Old Collector Reserve (" SIZE_FORMAT "%s)",
+                      byte_size_in_proper_unit(total_xfer), proper_unit_for_byte_size(total_xfer),
+                      byte_size_in_proper_unit(collector_xfer), proper_unit_for_byte_size(collector_xfer),
+                      byte_size_in_proper_unit(old_collector_xfer), proper_unit_for_byte_size(old_collector_xfer));
  }
  
- void ShenandoahFreeSet::prepare_to_rebuild(size_t &cset_regions) {
+ 
+ // Overwrite arguments to represent the amount of memory in each generation that is about to be recycled
+ void ShenandoahFreeSet::prepare_to_rebuild(size_t &young_cset_regions, size_t &old_cset_regions,
+                                            size_t &first_old_region, size_t &last_old_region, size_t &old_region_count) {
    shenandoah_assert_heaplocked();
+   // This resets all state information, removing all regions from all sets.
+   clear();
+   log_debug(gc, free)("Rebuilding FreeSet");
  
-   log_debug(gc)("Rebuilding FreeSet");
+   // This places regions that have alloc_capacity into the old_collector set if they identify as is_old() or the
+   // mutator set otherwise.  All trashed (cset) regions are affiliated young and placed in mutator set.
+   find_regions_with_alloc_capacity(young_cset_regions, old_cset_regions, first_old_region, last_old_region, old_region_count);
+ }
  
-   // This places regions that have alloc_capacity into the mutator partition.
-   find_regions_with_alloc_capacity(cset_regions);
+ void ShenandoahFreeSet::establish_generation_sizes(size_t young_region_count, size_t old_region_count) {
+   assert(young_region_count + old_region_count == ShenandoahHeap::heap()->num_regions(), "Sanity");
+   if (ShenandoahHeap::heap()->mode()->is_generational()) {
+     ShenandoahGenerationalHeap* heap = ShenandoahGenerationalHeap::heap();
+     ShenandoahOldGeneration* old_gen = heap->old_generation();
+     ShenandoahYoungGeneration* young_gen = heap->young_generation();
+     size_t region_size_bytes = ShenandoahHeapRegion::region_size_bytes();
+ 
+     old_gen->set_capacity(old_region_count * region_size_bytes);
+     young_gen->set_capacity(young_region_count * region_size_bytes);
+   }
  }
  
- void ShenandoahFreeSet::finish_rebuild(size_t cset_regions) {
+ void ShenandoahFreeSet::finish_rebuild(size_t young_cset_regions, size_t old_cset_regions, size_t old_region_count,
+                                        bool have_evacuation_reserves) {
    shenandoah_assert_heaplocked();
+   size_t young_reserve(0), old_reserve(0);
  
-   // Our desire is to reserve this much memory for future evacuation.  We may end up reserving less, if
-   // memory is in short supply.
- 
-   size_t reserve = _heap->max_capacity() * ShenandoahEvacReserve / 100;
-   size_t available_in_collector_partition = (_partitions.capacity_of(ShenandoahFreeSetPartitionId::Collector)
-                                              - _partitions.used_by(ShenandoahFreeSetPartitionId::Collector));
-   size_t additional_reserve;
-   if (available_in_collector_partition < reserve) {
-     additional_reserve = reserve - available_in_collector_partition;
+   if (_heap->mode()->is_generational()) {
+     compute_young_and_old_reserves(young_cset_regions, old_cset_regions, have_evacuation_reserves,
+                                    young_reserve, old_reserve);
    } else {
-     additional_reserve = 0;
+     young_reserve = (_heap->max_capacity() / 100) * ShenandoahEvacReserve;
+     old_reserve = 0;
    }
  
-   reserve_regions(reserve);
+   // Move some of the mutator regions in the Collector and OldCollector partitions in order to satisfy
+   // young_reserve and old_reserve.
+   reserve_regions(young_reserve, old_reserve, old_region_count);
+   size_t young_region_count = _heap->num_regions() - old_region_count;
+   establish_generation_sizes(young_region_count, old_region_count);
+   establish_old_collector_alloc_bias();
    _partitions.assert_bounds();
    log_status();
  }
  
- void ShenandoahFreeSet::rebuild() {
-   size_t cset_regions;
-   prepare_to_rebuild(cset_regions);
-   finish_rebuild(cset_regions);
+ void ShenandoahFreeSet::compute_young_and_old_reserves(size_t young_cset_regions, size_t old_cset_regions,
+                                                        bool have_evacuation_reserves,
+                                                        size_t& young_reserve_result, size_t& old_reserve_result) const {
+   shenandoah_assert_generational();
+   const size_t region_size_bytes = ShenandoahHeapRegion::region_size_bytes();
+ 
+   ShenandoahOldGeneration* const old_generation = _heap->old_generation();
+   size_t old_available = old_generation->available();
+   size_t old_unaffiliated_regions = old_generation->free_unaffiliated_regions();
+   ShenandoahYoungGeneration* const young_generation = _heap->young_generation();
+   size_t young_capacity = young_generation->max_capacity();
+   size_t young_unaffiliated_regions = young_generation->free_unaffiliated_regions();
+ 
+   // Add in the regions we anticipate to be freed by evacuation of the collection set
+   old_unaffiliated_regions += old_cset_regions;
+   young_unaffiliated_regions += young_cset_regions;
+ 
+   // Consult old-region balance to make adjustments to current generation capacities and availability.
+   // The generation region transfers take place after we rebuild.
+   const ssize_t old_region_balance = old_generation->get_region_balance();
+   if (old_region_balance != 0) {
+ #ifdef ASSERT
+     if (old_region_balance > 0) {
+       assert(old_region_balance <= checked_cast<ssize_t>(old_unaffiliated_regions), "Cannot transfer regions that are affiliated");
+     } else {
+       assert(0 - old_region_balance <= checked_cast<ssize_t>(young_unaffiliated_regions), "Cannot transfer regions that are affiliated");
+     }
+ #endif
+ 
+     ssize_t xfer_bytes = old_region_balance * checked_cast<ssize_t>(region_size_bytes);
+     old_available -= xfer_bytes;
+     old_unaffiliated_regions -= old_region_balance;
+     young_capacity += xfer_bytes;
+     young_unaffiliated_regions += old_region_balance;
+   }
+ 
+   // All allocations taken from the old collector set are performed by GC, generally using PLABs for both
+   // promotions and evacuations.  The partition between which old memory is reserved for evacuation and
+   // which is reserved for promotion is enforced using thread-local variables that prescribe intentions for
+   // each PLAB's available memory.
+   if (have_evacuation_reserves) {
+     // We are rebuilding at the end of final mark, having already established evacuation budgets for this GC pass.
+     const size_t promoted_reserve = old_generation->get_promoted_reserve();
+     const size_t old_evac_reserve = old_generation->get_evacuation_reserve();
+     young_reserve_result = young_generation->get_evacuation_reserve();
+     old_reserve_result = promoted_reserve + old_evac_reserve;
+     assert(old_reserve_result <= old_available,
+            "Cannot reserve (" SIZE_FORMAT " + " SIZE_FORMAT") more OLD than is available: " SIZE_FORMAT,
+            promoted_reserve, old_evac_reserve, old_available);
+   } else {
+     // We are rebuilding at end of GC, so we set aside budgets specified on command line (or defaults)
+     young_reserve_result = (young_capacity * ShenandoahEvacReserve) / 100;
+     // The auto-sizer has already made old-gen large enough to hold all anticipated evacuations and promotions.
+     // Affiliated old-gen regions are already in the OldCollector free set.  Add in the relevant number of
+     // unaffiliated regions.
+     old_reserve_result = old_available;
+   }
+ 
+   // Old available regions that have less than PLAB::min_size() of available memory are not placed into the OldCollector
+   // free set.  Because of this, old_available may not have enough memory to represent the intended reserve.  Adjust
+   // the reserve downward to account for this possibility. This loss is part of the reason why the original budget
+   // was adjusted with ShenandoahOldEvacWaste and ShenandoahOldPromoWaste multipliers.
+   if (old_reserve_result >
+       _partitions.capacity_of(ShenandoahFreeSetPartitionId::OldCollector) + old_unaffiliated_regions * region_size_bytes) {
+     old_reserve_result =
+       _partitions.capacity_of(ShenandoahFreeSetPartitionId::OldCollector) + old_unaffiliated_regions * region_size_bytes;
+   }
+ 
+   if (young_reserve_result > young_unaffiliated_regions * region_size_bytes) {
+     young_reserve_result = young_unaffiliated_regions * region_size_bytes;
+   }
  }
  
- void ShenandoahFreeSet::reserve_regions(size_t to_reserve) {
+ // Having placed all regions that have allocation capacity into the mutator set if they identify as is_young()
+ // or into the old collector set if they identify as is_old(), move some of these regions from the mutator set
+ // into the collector set or old collector set in order to assure that the memory available for allocations within
+ // the collector set is at least to_reserve and the memory available for allocations within the old collector set
+ // is at least to_reserve_old.
+ void ShenandoahFreeSet::reserve_regions(size_t to_reserve, size_t to_reserve_old, size_t &old_region_count) {
    for (size_t i = _heap->num_regions(); i > 0; i--) {
      size_t idx = i - 1;
      ShenandoahHeapRegion* r = _heap->get_region(idx);
- 
      if (!_partitions.in_free_set(ShenandoahFreeSetPartitionId::Mutator, idx)) {
        continue;
      }
  
      size_t ac = alloc_capacity(r);
-     assert (ac > 0, "Membership in free partition implies has capacity");
+     assert (ac > 0, "Membership in free set implies has capacity");
+     assert (!r->is_old() || r->is_trash(), "Except for trash, mutator_is_free regions should not be affiliated OLD");
  
+     bool move_to_old_collector = _partitions.available_in(ShenandoahFreeSetPartitionId::OldCollector) < to_reserve_old;
      bool move_to_collector = _partitions.available_in(ShenandoahFreeSetPartitionId::Collector) < to_reserve;
-     if (!move_to_collector) {
-       // We've satisfied to_reserve
+ 
+     if (!move_to_collector && !move_to_old_collector) {
+       // We've satisfied both to_reserve and to_reserved_old
        break;
      }
  
+     if (move_to_old_collector) {
+       // We give priority to OldCollector partition because we desire to pack OldCollector regions into higher
+       // addresses than Collector regions.  Presumably, OldCollector regions are more "stable" and less likely to
+       // be collected in the near future.
+       if (r->is_trash() || !r->is_affiliated()) {
+         // OLD regions that have available memory are already in the old_collector free set.
+         _partitions.move_from_partition_to_partition(idx, ShenandoahFreeSetPartitionId::Mutator,
+                                                      ShenandoahFreeSetPartitionId::OldCollector, ac);
+         log_debug(gc)("  Shifting region " SIZE_FORMAT " from mutator_free to old_collector_free", idx);
+         log_debug(gc)("  Shifted Mutator range [" SSIZE_FORMAT ", " SSIZE_FORMAT "],"
+                       "  Old Collector range [" SSIZE_FORMAT ", " SSIZE_FORMAT "]",
+                       _partitions.leftmost(ShenandoahFreeSetPartitionId::Mutator),
+                       _partitions.rightmost(ShenandoahFreeSetPartitionId::Mutator),
+                       _partitions.leftmost(ShenandoahFreeSetPartitionId::OldCollector),
+                       _partitions.rightmost(ShenandoahFreeSetPartitionId::OldCollector));
+         old_region_count++;
+         continue;
+       }
+     }
+ 
      if (move_to_collector) {
        // Note: In a previous implementation, regions were only placed into the survivor space (collector_is_free) if
        // they were entirely empty.  This has the effect of causing new Mutator allocation to reside next to objects
        // that have already survived at least one GC, mixing ephemeral with longer-lived objects in the same region.
        // Any objects that have survived a GC are less likely to immediately become garbage, so a region that contains

@@ -1116,22 +1688,67 @@
        // occupy regions comprised entirely of ephemeral objects.  These regions are highly likely to be included in the next
        // collection set, and they are easily evacuated because they have low density of live objects.
        _partitions.move_from_partition_to_partition(idx, ShenandoahFreeSetPartitionId::Mutator,
                                                     ShenandoahFreeSetPartitionId::Collector, ac);
        log_debug(gc)("  Shifting region " SIZE_FORMAT " from mutator_free to collector_free", idx);
+       log_debug(gc)("  Shifted Mutator range [" SSIZE_FORMAT ", " SSIZE_FORMAT "],"
+                     "  Collector range [" SSIZE_FORMAT ", " SSIZE_FORMAT "]",
+                     _partitions.leftmost(ShenandoahFreeSetPartitionId::Mutator),
+                     _partitions.rightmost(ShenandoahFreeSetPartitionId::Mutator),
+                     _partitions.leftmost(ShenandoahFreeSetPartitionId::Collector),
+                     _partitions.rightmost(ShenandoahFreeSetPartitionId::Collector));
      }
    }
  
    if (LogTarget(Info, gc, free)::is_enabled()) {
+     size_t old_reserve = _partitions.capacity_of(ShenandoahFreeSetPartitionId::OldCollector);
+     if (old_reserve < to_reserve_old) {
+       log_info(gc, free)("Wanted " PROPERFMT " for old reserve, but only reserved: " PROPERFMT,
+                          PROPERFMTARGS(to_reserve_old), PROPERFMTARGS(old_reserve));
+     }
      size_t reserve = _partitions.capacity_of(ShenandoahFreeSetPartitionId::Collector);
      if (reserve < to_reserve) {
        log_debug(gc)("Wanted " PROPERFMT " for young reserve, but only reserved: " PROPERFMT,
                      PROPERFMTARGS(to_reserve), PROPERFMTARGS(reserve));
      }
    }
  }
  
+ void ShenandoahFreeSet::establish_old_collector_alloc_bias() {
+   ShenandoahHeap* heap = ShenandoahHeap::heap();
+   shenandoah_assert_heaplocked();
+ 
+   idx_t left_idx = _partitions.leftmost(ShenandoahFreeSetPartitionId::OldCollector);
+   idx_t right_idx = _partitions.rightmost(ShenandoahFreeSetPartitionId::OldCollector);
+   idx_t middle = (left_idx + right_idx) / 2;
+   size_t available_in_first_half = 0;
+   size_t available_in_second_half = 0;
+ 
+   for (idx_t index = left_idx; index < middle; index++) {
+     if (_partitions.in_free_set(ShenandoahFreeSetPartitionId::OldCollector, index)) {
+       ShenandoahHeapRegion* r = heap->get_region((size_t) index);
+       available_in_first_half += r->free();
+     }
+   }
+   for (idx_t index = middle; index <= right_idx; index++) {
+     if (_partitions.in_free_set(ShenandoahFreeSetPartitionId::OldCollector, index)) {
+       ShenandoahHeapRegion* r = heap->get_region(index);
+       available_in_second_half += r->free();
+     }
+   }
+ 
+   // We desire to first consume the sparsely distributed regions in order that the remaining regions are densely packed.
+   // Densely packing regions reduces the effort to search for a region that has sufficient memory to satisfy a new allocation
+   // request.  Regions become sparsely distributed following a Full GC, which tends to slide all regions to the front of the
+   // heap rather than allowing survivor regions to remain at the high end of the heap where we intend for them to congregate.
+ 
+   // TODO: In the future, we may modify Full GC so that it slides old objects to the end of the heap and young objects to the
+   // front of the heap. If this is done, we can always search survivor Collector and OldCollector regions right to left.
+   _partitions.set_bias_from_left_to_right(ShenandoahFreeSetPartitionId::OldCollector,
+                                           (available_in_second_half > available_in_first_half));
+ }
+ 
  void ShenandoahFreeSet::log_status_under_lock() {
    // Must not be heap locked, it acquires heap lock only when log is enabled
    shenandoah_assert_not_heaplocked();
    if (LogTarget(Info, gc, free)::is_enabled()
        DEBUG_ONLY(|| LogTarget(Debug, gc, free)::is_enabled())) {

@@ -1145,48 +1762,87 @@
  
  #ifdef ASSERT
    // Dump of the FreeSet details is only enabled if assertions are enabled
    if (LogTarget(Debug, gc, free)::is_enabled()) {
  #define BUFFER_SIZE 80
+     size_t retired_old = 0;
+     size_t retired_old_humongous = 0;
+     size_t retired_young = 0;
+     size_t retired_young_humongous = 0;
      size_t region_size_bytes = ShenandoahHeapRegion::region_size_bytes();
+     size_t retired_young_waste = 0;
+     size_t retired_old_waste = 0;
      size_t consumed_collector = 0;
-     size_t available_collector = 0;
+     size_t consumed_old_collector = 0;
      size_t consumed_mutator = 0;
+     size_t available_old = 0;
+     size_t available_young = 0;
      size_t available_mutator = 0;
+     size_t available_collector = 0;
+     size_t available_old_collector = 0;
  
      char buffer[BUFFER_SIZE];
      for (uint i = 0; i < BUFFER_SIZE; i++) {
        buffer[i] = '\0';
      }
-     log_debug(gc)("FreeSet map legend: M:mutator_free C:collector_free H:humongous _:retired");
-     log_debug(gc)(" mutator free range [" SIZE_FORMAT ".." SIZE_FORMAT "],"
-                   " collector free range [" SIZE_FORMAT ".." SIZE_FORMAT "]",
+ 
+     log_debug(gc)("FreeSet map legend:"
+                        " M:mutator_free C:collector_free O:old_collector_free"
+                        " H:humongous ~:retired old _:retired young");
+     log_debug(gc)(" mutator free range [" SIZE_FORMAT ".." SIZE_FORMAT "] allocating from %s, "
+                   " collector free range [" SIZE_FORMAT ".." SIZE_FORMAT "], "
+                   "old collector free range [" SIZE_FORMAT ".." SIZE_FORMAT "] allocates from %s",
                    _partitions.leftmost(ShenandoahFreeSetPartitionId::Mutator),
                    _partitions.rightmost(ShenandoahFreeSetPartitionId::Mutator),
+                   _partitions.alloc_from_left_bias(ShenandoahFreeSetPartitionId::Mutator)? "left to right": "right to left",
                    _partitions.leftmost(ShenandoahFreeSetPartitionId::Collector),
-                   _partitions.rightmost(ShenandoahFreeSetPartitionId::Collector));
+                   _partitions.rightmost(ShenandoahFreeSetPartitionId::Collector),
+                   _partitions.leftmost(ShenandoahFreeSetPartitionId::OldCollector),
+                   _partitions.rightmost(ShenandoahFreeSetPartitionId::OldCollector),
+                   _partitions.alloc_from_left_bias(ShenandoahFreeSetPartitionId::OldCollector)? "left to right": "right to left");
  
      for (uint i = 0; i < _heap->num_regions(); i++) {
        ShenandoahHeapRegion *r = _heap->get_region(i);
        uint idx = i % 64;
        if ((i != 0) && (idx == 0)) {
          log_debug(gc)(" %6u: %s", i-64, buffer);
        }
        if (_partitions.in_free_set(ShenandoahFreeSetPartitionId::Mutator, i)) {
          size_t capacity = alloc_capacity(r);
+         assert(!r->is_old() || r->is_trash(), "Old regions except trash regions should not be in mutator_free set");
          available_mutator += capacity;
          consumed_mutator += region_size_bytes - capacity;
          buffer[idx] = (capacity == region_size_bytes)? 'M': 'm';
        } else if (_partitions.in_free_set(ShenandoahFreeSetPartitionId::Collector, i)) {
          size_t capacity = alloc_capacity(r);
+         assert(!r->is_old() || r->is_trash(), "Old regions except trash regions should not be in collector_free set");
          available_collector += capacity;
          consumed_collector += region_size_bytes - capacity;
          buffer[idx] = (capacity == region_size_bytes)? 'C': 'c';
+       } else if (_partitions.in_free_set(ShenandoahFreeSetPartitionId::OldCollector, i)) {
+         size_t capacity = alloc_capacity(r);
+         available_old_collector += capacity;
+         consumed_old_collector += region_size_bytes - capacity;
+         buffer[idx] = (capacity == region_size_bytes)? 'O': 'o';
        } else if (r->is_humongous()) {
-         buffer[idx] = 'h';
+         if (r->is_old()) {
+           buffer[idx] = 'H';
+           retired_old_humongous += region_size_bytes;
+         } else {
+           buffer[idx] = 'h';
+           retired_young_humongous += region_size_bytes;
+         }
        } else {
-         buffer[idx] = '_';
+         if (r->is_old()) {
+           buffer[idx] = '~';
+           retired_old_waste += alloc_capacity(r);
+           retired_old += region_size_bytes;
+         } else {
+           buffer[idx] = '_';
+           retired_young_waste += alloc_capacity(r);
+           retired_young += region_size_bytes;
+         }
        }
      }
      uint remnant = _heap->num_regions() % 64;
      if (remnant > 0) {
        buffer[remnant] = '\0';

@@ -1240,13 +1896,12 @@
  
        // Since certain regions that belonged to the Mutator free partition at the time of most recent rebuild may have been
        // retired, the sum of used and capacities within regions that are still in the Mutator free partition may not match
        // my internally tracked values of used() and free().
        assert(free == total_free, "Free memory should match");
- 
        ls.print("Free: " SIZE_FORMAT "%s, Max: " SIZE_FORMAT "%s regular, " SIZE_FORMAT "%s humongous, ",
-                byte_size_in_proper_unit(free),          proper_unit_for_byte_size(free),
+                byte_size_in_proper_unit(total_free),    proper_unit_for_byte_size(total_free),
                 byte_size_in_proper_unit(max),           proper_unit_for_byte_size(max),
                 byte_size_in_proper_unit(max_humongous), proper_unit_for_byte_size(max_humongous)
        );
  
        ls.print("Frag: ");

@@ -1289,10 +1944,31 @@
        ls.print(" Collector Reserve: " SIZE_FORMAT "%s, Max: " SIZE_FORMAT "%s; Used: " SIZE_FORMAT "%s",
                 byte_size_in_proper_unit(total_free), proper_unit_for_byte_size(total_free),
                 byte_size_in_proper_unit(max),        proper_unit_for_byte_size(max),
                 byte_size_in_proper_unit(total_used), proper_unit_for_byte_size(total_used));
      }
+ 
+     if (_heap->mode()->is_generational()) {
+       size_t max = 0;
+       size_t total_free = 0;
+       size_t total_used = 0;
+ 
+       for (idx_t idx = _partitions.leftmost(ShenandoahFreeSetPartitionId::OldCollector);
+            idx <= _partitions.rightmost(ShenandoahFreeSetPartitionId::OldCollector); idx++) {
+         if (_partitions.in_free_set(ShenandoahFreeSetPartitionId::OldCollector, idx)) {
+           ShenandoahHeapRegion *r = _heap->get_region(idx);
+           size_t free = alloc_capacity(r);
+           max = MAX2(max, free);
+           total_free += free;
+           total_used += r->used();
+         }
+       }
+       ls.print_cr(" Old Collector Reserve: " SIZE_FORMAT "%s, Max: " SIZE_FORMAT "%s; Used: " SIZE_FORMAT "%s",
+                   byte_size_in_proper_unit(total_free), proper_unit_for_byte_size(total_free),
+                   byte_size_in_proper_unit(max),        proper_unit_for_byte_size(max),
+                   byte_size_in_proper_unit(total_used), proper_unit_for_byte_size(total_used));
+     }
    }
  }
  
  HeapWord* ShenandoahFreeSet::allocate(ShenandoahAllocRequest& req, bool& in_new_region) {
    shenandoah_assert_heaplocked();

@@ -1300,10 +1976,11 @@
      switch (req.type()) {
        case ShenandoahAllocRequest::_alloc_shared:
        case ShenandoahAllocRequest::_alloc_shared_gc:
          in_new_region = true;
          return allocate_contiguous(req);
+       case ShenandoahAllocRequest::_alloc_plab:
        case ShenandoahAllocRequest::_alloc_gclab:
        case ShenandoahAllocRequest::_alloc_tlab:
          in_new_region = false;
          assert(false, "Trying to allocate TLAB larger than the humongous threshold: " SIZE_FORMAT " > " SIZE_FORMAT,
                 req.size(), ShenandoahHeapRegion::humongous_threshold_words());

@@ -1332,10 +2009,19 @@
      assert(_partitions.in_free_set(ShenandoahFreeSetPartitionId::Collector, index),
             "Boundaries or find_first_set_bit failed: " SSIZE_FORMAT, index);
      _heap->get_region(index)->print_on(out);
      index = _partitions.find_index_of_next_available_region(ShenandoahFreeSetPartitionId::Collector, index + 1);
    }
+   if (_heap->mode()->is_generational()) {
+     out->print_cr("Old Collector Free Set: " SIZE_FORMAT "", _partitions.count(ShenandoahFreeSetPartitionId::OldCollector));
+     for (idx_t index = _partitions.leftmost(ShenandoahFreeSetPartitionId::OldCollector);
+          index <= _partitions.rightmost(ShenandoahFreeSetPartitionId::OldCollector); index++) {
+       if (_partitions.in_free_set(ShenandoahFreeSetPartitionId::OldCollector, index)) {
+         _heap->get_region(index)->print_on(out);
+       }
+     }
+   }
  }
  
  double ShenandoahFreeSet::internal_fragmentation() {
    double squared = 0;
    double linear = 0;
< prev index next >