 22b2cb39af
			
		
	
	
		22b2cb39af
		
			
		
	
	
	
	
		
			
			* Turn `MemoryOperand` into a struct
* Remove `IntrinsicOperation`
* Remove `PhiNode`
* Remove `Node`
* Turn `Operand` into a struct
* Turn `Operation` into a struct
* Clean up pool management methods
* Add `Arena` allocator
* Move `OperationHelper` to `Operation.Factory`
* Move `OperandHelper` to `Operand.Factory`
* Optimize `Operation` a bit
* Fix `Arena` initialization
* Rename `NativeList<T>` to `ArenaList<T>`
* Reduce `Operand` size from 88 to 56 bytes
* Reduce `Operation` size from 56 to 40 bytes
* Add optimistic interning of Register & Constant operands
* Optimize `RegisterUsage` pass a bit
* Optimize `RemoveUnusedNodes` pass a bit
Iterating in reverse-order allows killing dependency chains in a single
pass.
* Fix PPTC symbols
* Optimize `BasicBlock` a bit
Reduce allocations from `_successor` & `DominanceFrontiers`
* Fix `Operation` resize
* Make `Arena` expandable
Change the arena allocator to be expandable by allocating in pages, with
some of them being pooled. Currently 32 pages are pooled. An LRU removal
mechanism should probably be added to it.
Apparently MHR can allocate bitmaps large enough to exceed the 16MB
limit for the type.
* Move `Arena` & `ArenaList` to `Common`
* Remove `ThreadStaticPool` & co
* Add `PhiOperation`
* Reduce `Operand` size from 56 from 48 bytes
* Add linear-probing to `Operand` intern table
* Optimize `HybridAllocator` a bit
* Add `Allocators` class
* Tune `ArenaAllocator` sizes
* Add page removal mechanism to `ArenaAllocator`
Remove pages which have not been used for more than 5s after each reset.
I am on fence if this would be better using a Gen2 callback object like
the one in System.Buffers.ArrayPool<T>, to trim the pool. Because right
now if a large translation happens, the pages will be freed only after a
reset. This reset may not happen for a while because no new translation
is hit, but the arena base sizes are rather small.
* Fix `OOM` when allocating larger than page size in `ArenaAllocator`
Tweak resizing mechanism for Operand.Uses and Assignemnts.
* Optimize `Optimizer` a bit
* Optimize `Operand.Add<T>/Remove<T>` a bit
* Clean up `PreAllocator`
* Fix phi insertion order
Reduce codegen diffs.
* Fix code alignment
* Use new heuristics for degree of parallelism
* Suppress warnings
* Address gdkchan's feedback
Renamed `GetValue()` to `GetValueUnsafe()` to make it more clear that
`Operand.Value` should usually not be modified directly.
* Add fast path to `ArenaAllocator`
* Assembly for `ArenaAllocator.Allocate(ulong)`:
  .L0:
    mov rax, [rcx+0x18]
    lea r8, [rax+rdx]
    cmp r8, [rcx+0x10]
    ja short .L2
  .L1:
    mov rdx, [rcx+8]
    add rax, [rdx+8]
    mov [rcx+0x18], r8
    ret
  .L2:
    jmp ArenaAllocator.AllocateSlow(UInt64)
  A few variable/field had to be changed to ulong so that RyuJIT avoids
  emitting zero-extends.
* Implement a new heuristic to free pooled pages.
  If an arena is used often, it is more likely that its pages will be
  needed, so the pages are kept for longer (e.g: during PPTC rebuild or
  burst sof compilations). If is not used often, then it is more likely
  that its pages will not be needed (e.g: after PPTC rebuild or bursts
  of compilations).
* Address riperiperi's feedback
* Use `EqualityComparer<T>` in `IntrusiveList<T>`
Avoids a potential GC hole in `Equals(T, T)`.
		
	
			
		
			
				
	
	
		
			526 lines
		
	
	
	
		
			18 KiB
		
	
	
	
		
			C#
		
	
	
	
	
	
			
		
		
	
	
			526 lines
		
	
	
	
		
			18 KiB
		
	
	
	
		
			C#
		
	
	
	
	
	
| using ARMeilleure.Common;
 | |
| using ARMeilleure.Decoders;
 | |
| using ARMeilleure.Diagnostics;
 | |
| using ARMeilleure.Instructions;
 | |
| using ARMeilleure.IntermediateRepresentation;
 | |
| using ARMeilleure.Memory;
 | |
| using ARMeilleure.Signal;
 | |
| using ARMeilleure.State;
 | |
| using ARMeilleure.Translation.Cache;
 | |
| using ARMeilleure.Translation.PTC;
 | |
| using Ryujinx.Common;
 | |
| using System;
 | |
| using System.Collections.Concurrent;
 | |
| using System.Collections.Generic;
 | |
| using System.Diagnostics;
 | |
| using System.Threading;
 | |
| using static ARMeilleure.IntermediateRepresentation.Operand.Factory;
 | |
| 
 | |
| namespace ARMeilleure.Translation
 | |
| {
 | |
|     public class Translator
 | |
|     {
 | |
|         private static readonly AddressTable<ulong>.Level[] Levels64Bit =
 | |
|             new AddressTable<ulong>.Level[]
 | |
|             {
 | |
|                 new(31, 17),
 | |
|                 new(23,  8),
 | |
|                 new(15,  8),
 | |
|                 new( 7,  8),
 | |
|                 new( 2,  5)
 | |
|             };
 | |
| 
 | |
|         private static readonly AddressTable<ulong>.Level[] Levels32Bit =
 | |
|             new AddressTable<ulong>.Level[]
 | |
|             {
 | |
|                 new(31, 17),
 | |
|                 new(23,  8),
 | |
|                 new(15,  8),
 | |
|                 new( 7,  8),
 | |
|                 new( 1,  6)
 | |
|             };
 | |
| 
 | |
|         private readonly IJitMemoryAllocator _allocator;
 | |
|         private readonly ConcurrentQueue<KeyValuePair<ulong, TranslatedFunction>> _oldFuncs;
 | |
| 
 | |
|         private readonly ConcurrentDictionary<ulong, object> _backgroundSet;
 | |
|         private readonly ConcurrentStack<RejitRequest> _backgroundStack;
 | |
|         private readonly AutoResetEvent _backgroundTranslatorEvent;
 | |
|         private readonly ReaderWriterLock _backgroundTranslatorLock;
 | |
| 
 | |
|         internal ConcurrentDictionary<ulong, TranslatedFunction> Functions { get; }
 | |
|         internal AddressTable<ulong> FunctionTable { get; }
 | |
|         internal EntryTable<uint> CountTable { get; }
 | |
|         internal TranslatorStubs Stubs { get; }
 | |
|         internal IMemoryManager Memory { get; }
 | |
| 
 | |
|         private volatile int _threadCount;
 | |
| 
 | |
|         // FIXME: Remove this once the init logic of the emulator will be redone.
 | |
|         public static readonly ManualResetEvent IsReadyForTranslation = new(false);
 | |
| 
 | |
|         public Translator(IJitMemoryAllocator allocator, IMemoryManager memory, bool for64Bits)
 | |
|         {
 | |
|             _allocator = allocator;
 | |
|             Memory = memory;
 | |
| 
 | |
|             _oldFuncs = new ConcurrentQueue<KeyValuePair<ulong, TranslatedFunction>>();
 | |
| 
 | |
|             _backgroundSet = new ConcurrentDictionary<ulong, object>();
 | |
|             _backgroundStack = new ConcurrentStack<RejitRequest>();
 | |
|             _backgroundTranslatorEvent = new AutoResetEvent(false);
 | |
|             _backgroundTranslatorLock = new ReaderWriterLock();
 | |
| 
 | |
|             JitCache.Initialize(allocator);
 | |
| 
 | |
|             CountTable = new EntryTable<uint>();
 | |
|             Functions = new ConcurrentDictionary<ulong, TranslatedFunction>();
 | |
|             FunctionTable = new AddressTable<ulong>(for64Bits ? Levels64Bit : Levels32Bit);
 | |
|             Stubs = new TranslatorStubs(this);
 | |
| 
 | |
|             FunctionTable.Fill = (ulong)Stubs.SlowDispatchStub;
 | |
| 
 | |
|             if (memory.Type.IsHostMapped())
 | |
|             {
 | |
|                 NativeSignalHandler.InitializeSignalHandler();
 | |
|             }
 | |
|         }
 | |
| 
 | |
|         private void TranslateStackedSubs()
 | |
|         {
 | |
|             while (_threadCount != 0)
 | |
|             {
 | |
|                 _backgroundTranslatorLock.AcquireReaderLock(Timeout.Infinite);
 | |
| 
 | |
|                 if (_backgroundStack.TryPop(out RejitRequest request) && 
 | |
|                     _backgroundSet.TryRemove(request.Address, out _))
 | |
|                 {
 | |
|                     TranslatedFunction func = Translate(request.Address, request.Mode, highCq: true);
 | |
| 
 | |
|                     Functions.AddOrUpdate(request.Address, func, (key, oldFunc) =>
 | |
|                     {
 | |
|                         EnqueueForDeletion(key, oldFunc);
 | |
|                         return func;
 | |
|                     });
 | |
| 
 | |
|                     if (PtcProfiler.Enabled)
 | |
|                     {
 | |
|                         PtcProfiler.UpdateEntry(request.Address, request.Mode, highCq: true);
 | |
|                     }
 | |
| 
 | |
|                     RegisterFunction(request.Address, func);
 | |
| 
 | |
|                     _backgroundTranslatorLock.ReleaseReaderLock();
 | |
|                 }
 | |
|                 else
 | |
|                 {
 | |
|                     _backgroundTranslatorLock.ReleaseReaderLock();
 | |
|                     _backgroundTranslatorEvent.WaitOne();
 | |
|                 }
 | |
|             }
 | |
| 
 | |
|              // Wake up any other background translator threads, to encourage them to exit.
 | |
|             _backgroundTranslatorEvent.Set();
 | |
|         }
 | |
| 
 | |
|         public void Execute(State.ExecutionContext context, ulong address)
 | |
|         {
 | |
|             if (Interlocked.Increment(ref _threadCount) == 1)
 | |
|             {
 | |
|                 IsReadyForTranslation.WaitOne();
 | |
| 
 | |
|                 if (Ptc.State == PtcState.Enabled)
 | |
|                 {
 | |
|                     Debug.Assert(Functions.Count == 0);
 | |
|                     Ptc.LoadTranslations(this);
 | |
|                     Ptc.MakeAndSaveTranslations(this);
 | |
|                 }
 | |
| 
 | |
|                 PtcProfiler.Start();
 | |
| 
 | |
|                 Ptc.Disable();
 | |
| 
 | |
|                 // Simple heuristic, should be user configurable in future. (1 for 4 core/ht or less, 2 for 6 core + ht
 | |
|                 // etc). All threads are normal priority except from the last, which just fills as much of the last core
 | |
|                 // as the os lets it with a low priority. If we only have one rejit thread, it should be normal priority
 | |
|                 // as highCq code is performance critical.
 | |
|                 //
 | |
|                 // TODO: Use physical cores rather than logical. This only really makes sense for processors with
 | |
|                 // hyperthreading. Requires OS specific code.
 | |
|                 int unboundedThreadCount = Math.Max(1, (Environment.ProcessorCount - 6) / 3);
 | |
|                 int threadCount          = Math.Min(4, unboundedThreadCount);
 | |
| 
 | |
|                 for (int i = 0; i < threadCount; i++)
 | |
|                 {
 | |
|                     bool last = i != 0 && i == unboundedThreadCount - 1;
 | |
| 
 | |
|                     Thread backgroundTranslatorThread = new Thread(TranslateStackedSubs)
 | |
|                     {
 | |
|                         Name = "CPU.BackgroundTranslatorThread." + i,
 | |
|                         Priority = last ? ThreadPriority.Lowest : ThreadPriority.Normal
 | |
|                     };
 | |
| 
 | |
|                     backgroundTranslatorThread.Start();
 | |
|                 }
 | |
|             }
 | |
| 
 | |
|             Statistics.InitializeTimer();
 | |
| 
 | |
|             NativeInterface.RegisterThread(context, Memory, this);
 | |
| 
 | |
|             if (Optimizations.UseUnmanagedDispatchLoop)
 | |
|             {
 | |
|                 Stubs.DispatchLoop(context.NativeContextPtr, address);
 | |
|             }
 | |
|             else
 | |
|             {
 | |
|                 do
 | |
|                 {
 | |
|                     address = ExecuteSingle(context, address);
 | |
|                 }
 | |
|                 while (context.Running && address != 0);
 | |
|             }
 | |
| 
 | |
|             NativeInterface.UnregisterThread();
 | |
| 
 | |
|             if (Interlocked.Decrement(ref _threadCount) == 0)
 | |
|             {
 | |
|                 _backgroundTranslatorEvent.Set();
 | |
| 
 | |
|                 ClearJitCache();
 | |
| 
 | |
|                 Stubs.Dispose();
 | |
|                 FunctionTable.Dispose();
 | |
|                 CountTable.Dispose();
 | |
|             }
 | |
|         }
 | |
| 
 | |
|         public ulong ExecuteSingle(State.ExecutionContext context, ulong address)
 | |
|         {
 | |
|             TranslatedFunction func = GetOrTranslate(address, context.ExecutionMode);
 | |
| 
 | |
|             Statistics.StartTimer();
 | |
| 
 | |
|             ulong nextAddr = func.Execute(context);
 | |
| 
 | |
|             Statistics.StopTimer(address);
 | |
| 
 | |
|             return nextAddr;
 | |
|         }
 | |
| 
 | |
|         internal TranslatedFunction GetOrTranslate(ulong address, ExecutionMode mode)
 | |
|         {
 | |
|             if (!Functions.TryGetValue(address, out TranslatedFunction func))
 | |
|             {
 | |
|                 func = Translate(address, mode, highCq: false);
 | |
| 
 | |
|                 TranslatedFunction oldFunc = Functions.GetOrAdd(address, func);
 | |
| 
 | |
|                 if (oldFunc != func)
 | |
|                 {
 | |
|                     JitCache.Unmap(func.FuncPtr);
 | |
|                     func = oldFunc;
 | |
|                 }
 | |
| 
 | |
|                 if (PtcProfiler.Enabled)
 | |
|                 {
 | |
|                     PtcProfiler.AddEntry(address, mode, highCq: false);
 | |
|                 }
 | |
| 
 | |
|                 RegisterFunction(address, func);
 | |
|             }
 | |
| 
 | |
|             return func;
 | |
|         }
 | |
| 
 | |
|         internal void RegisterFunction(ulong guestAddress, TranslatedFunction func)
 | |
|         {
 | |
|             if (FunctionTable.IsValid(guestAddress) && (Optimizations.AllowLcqInFunctionTable || func.HighCq))
 | |
|             {
 | |
|                 Volatile.Write(ref FunctionTable.GetValue(guestAddress), (ulong)func.FuncPtr);
 | |
|             }
 | |
|         }
 | |
| 
 | |
|         internal TranslatedFunction Translate(ulong address, ExecutionMode mode, bool highCq)
 | |
|         {
 | |
|             var context = new ArmEmitterContext(
 | |
|                 Memory,
 | |
|                 CountTable,
 | |
|                 FunctionTable,
 | |
|                 Stubs,
 | |
|                 address,
 | |
|                 highCq,
 | |
|                 mode: Aarch32Mode.User);
 | |
| 
 | |
|             Logger.StartPass(PassName.Decoding);
 | |
| 
 | |
|             Block[] blocks = Decoder.Decode(Memory, address, mode, highCq, singleBlock: false);
 | |
| 
 | |
|             Logger.EndPass(PassName.Decoding);
 | |
| 
 | |
|             Logger.StartPass(PassName.Translation);
 | |
| 
 | |
|             EmitSynchronization(context);
 | |
| 
 | |
|             if (blocks[0].Address != address)
 | |
|             {
 | |
|                 context.Branch(context.GetLabel(address));
 | |
|             }
 | |
| 
 | |
|             ControlFlowGraph cfg = EmitAndGetCFG(context, blocks, out Range funcRange, out Counter<uint> counter);
 | |
| 
 | |
|             ulong funcSize = funcRange.End - funcRange.Start;
 | |
| 
 | |
|             Logger.EndPass(PassName.Translation, cfg);
 | |
| 
 | |
|             Logger.StartPass(PassName.RegisterUsage);
 | |
| 
 | |
|             RegisterUsage.RunPass(cfg, mode);
 | |
| 
 | |
|             Logger.EndPass(PassName.RegisterUsage);
 | |
| 
 | |
|             OperandType[] argTypes = new OperandType[] { OperandType.I64 };
 | |
| 
 | |
|             CompilerOptions options = highCq ? CompilerOptions.HighCq : CompilerOptions.None;
 | |
| 
 | |
|             GuestFunction func;
 | |
| 
 | |
|             if (!context.HasPtc)
 | |
|             {
 | |
|                 func = Compiler.Compile<GuestFunction>(cfg, argTypes, OperandType.I64, options);
 | |
|             }
 | |
|             else
 | |
|             {
 | |
|                 using PtcInfo ptcInfo = new PtcInfo();
 | |
| 
 | |
|                 func = Compiler.Compile<GuestFunction>(cfg, argTypes, OperandType.I64, options, ptcInfo);
 | |
| 
 | |
|                 Hash128 hash = Ptc.ComputeHash(Memory, address, funcSize);
 | |
| 
 | |
|                 Ptc.WriteInfoCodeRelocUnwindInfo(address, funcSize, hash, highCq, ptcInfo);
 | |
|             }
 | |
| 
 | |
|             var result = new TranslatedFunction(func, counter, funcSize, highCq);
 | |
| 
 | |
|             Allocators.ResetAll();
 | |
| 
 | |
|             return result;
 | |
|         }
 | |
| 
 | |
|         private struct Range
 | |
|         {
 | |
|             public ulong Start { get; }
 | |
|             public ulong End { get; }
 | |
| 
 | |
|             public Range(ulong start, ulong end)
 | |
|             {
 | |
|                 Start = start;
 | |
|                 End = end;
 | |
|             }
 | |
|         }
 | |
| 
 | |
|         private static ControlFlowGraph EmitAndGetCFG(
 | |
|             ArmEmitterContext context,
 | |
|             Block[] blocks,
 | |
|             out Range range,
 | |
|             out Counter<uint> counter)
 | |
|         {
 | |
|             counter = null;
 | |
| 
 | |
|             ulong rangeStart = ulong.MaxValue;
 | |
|             ulong rangeEnd = 0;
 | |
| 
 | |
|             for (int blkIndex = 0; blkIndex < blocks.Length; blkIndex++)
 | |
|             {
 | |
|                 Block block = blocks[blkIndex];
 | |
| 
 | |
|                 if (!block.Exit)
 | |
|                 {
 | |
|                     if (rangeStart > block.Address)
 | |
|                     {
 | |
|                         rangeStart = block.Address;
 | |
|                     }
 | |
| 
 | |
|                     if (rangeEnd < block.EndAddress)
 | |
|                     {
 | |
|                         rangeEnd = block.EndAddress;
 | |
|                     }
 | |
|                 }
 | |
| 
 | |
|                 if (block.Address == context.EntryAddress && !context.HighCq)
 | |
|                 {
 | |
|                     EmitRejitCheck(context, out counter);
 | |
|                 }
 | |
| 
 | |
|                 context.CurrBlock = block;
 | |
| 
 | |
|                 context.MarkLabel(context.GetLabel(block.Address));
 | |
| 
 | |
|                 if (block.Exit)
 | |
|                 {
 | |
|                     // Left option here as it may be useful if we need to return to managed rather than tail call in
 | |
|                     // future. (eg. for debug)
 | |
|                     bool useReturns = false;
 | |
| 
 | |
|                     InstEmitFlowHelper.EmitVirtualJump(context, Const(block.Address), isReturn: useReturns);
 | |
|                 }
 | |
|                 else
 | |
|                 {
 | |
|                     for (int opcIndex = 0; opcIndex < block.OpCodes.Count; opcIndex++)
 | |
|                     {
 | |
|                         OpCode opCode = block.OpCodes[opcIndex];
 | |
| 
 | |
|                         context.CurrOp = opCode;
 | |
| 
 | |
|                         bool isLastOp = opcIndex == block.OpCodes.Count - 1;
 | |
| 
 | |
|                         if (isLastOp && block.Branch != null && !block.Branch.Exit && block.Branch.Address <= block.Address)
 | |
|                         {
 | |
|                             EmitSynchronization(context);
 | |
|                         }
 | |
| 
 | |
|                         Operand lblPredicateSkip = default;
 | |
| 
 | |
|                         if (opCode is OpCode32 op && op.Cond < Condition.Al)
 | |
|                         {
 | |
|                             lblPredicateSkip = Label();
 | |
| 
 | |
|                             InstEmitFlowHelper.EmitCondBranch(context, lblPredicateSkip, op.Cond.Invert());
 | |
|                         }
 | |
| 
 | |
|                         if (opCode.Instruction.Emitter != null)
 | |
|                         {
 | |
|                             opCode.Instruction.Emitter(context);
 | |
|                         }
 | |
|                         else
 | |
|                         {
 | |
|                             throw new InvalidOperationException($"Invalid instruction \"{opCode.Instruction.Name}\".");
 | |
|                         }
 | |
| 
 | |
|                         if (lblPredicateSkip != default)
 | |
|                         {
 | |
|                             context.MarkLabel(lblPredicateSkip);
 | |
|                         }
 | |
|                     }
 | |
|                 }
 | |
|             }
 | |
| 
 | |
|             range = new Range(rangeStart, rangeEnd);
 | |
| 
 | |
|             return context.GetControlFlowGraph();
 | |
|         }
 | |
| 
 | |
|         internal static void EmitRejitCheck(ArmEmitterContext context, out Counter<uint> counter)
 | |
|         {
 | |
|             const int MinsCallForRejit = 100;
 | |
| 
 | |
|             counter = new Counter<uint>(context.CountTable);
 | |
| 
 | |
|             Operand lblEnd = Label();
 | |
| 
 | |
|             Operand address = !context.HasPtc ?
 | |
|                 Const(ref counter.Value) :
 | |
|                 Const(ref counter.Value, Ptc.CountTableSymbol);
 | |
| 
 | |
|             Operand curCount = context.Load(OperandType.I32, address);
 | |
|             Operand count = context.Add(curCount, Const(1));
 | |
|             context.Store(address, count);
 | |
|             context.BranchIf(lblEnd, curCount, Const(MinsCallForRejit), Comparison.NotEqual, BasicBlockFrequency.Cold);
 | |
| 
 | |
|             context.Call(typeof(NativeInterface).GetMethod(nameof(NativeInterface.EnqueueForRejit)), Const(context.EntryAddress));
 | |
| 
 | |
|             context.MarkLabel(lblEnd);
 | |
|         }
 | |
| 
 | |
|         internal static void EmitSynchronization(EmitterContext context)
 | |
|         {
 | |
|             long countOffs = NativeContext.GetCounterOffset();
 | |
| 
 | |
|             Operand lblNonZero = Label();
 | |
|             Operand lblExit = Label();
 | |
| 
 | |
|             Operand countAddr = context.Add(context.LoadArgument(OperandType.I64, 0), Const(countOffs));
 | |
|             Operand count = context.Load(OperandType.I32, countAddr);
 | |
|             context.BranchIfTrue(lblNonZero, count, BasicBlockFrequency.Cold);
 | |
| 
 | |
|             Operand running = context.Call(typeof(NativeInterface).GetMethod(nameof(NativeInterface.CheckSynchronization)));
 | |
|             context.BranchIfTrue(lblExit, running, BasicBlockFrequency.Cold);
 | |
| 
 | |
|             context.Return(Const(0L));
 | |
| 
 | |
|             context.MarkLabel(lblNonZero);
 | |
|             count = context.Subtract(count, Const(1));
 | |
|             context.Store(countAddr, count);
 | |
| 
 | |
|             context.MarkLabel(lblExit);
 | |
|         }
 | |
| 
 | |
|         public void InvalidateJitCacheRegion(ulong address, ulong size)
 | |
|         {
 | |
|             // If rejit is running, stop it as it may be trying to rejit a function on the invalidated region.
 | |
|             ClearRejitQueue(allowRequeue: true);
 | |
| 
 | |
|             // TODO: Completely remove functions overlapping the specified range from the cache.
 | |
|         }
 | |
| 
 | |
|         internal void EnqueueForRejit(ulong guestAddress, ExecutionMode mode)
 | |
|         {
 | |
|             if (_backgroundSet.TryAdd(guestAddress, null))
 | |
|             {
 | |
|                 _backgroundStack.Push(new RejitRequest(guestAddress, mode));
 | |
|                 _backgroundTranslatorEvent.Set();
 | |
|             }
 | |
|         }
 | |
| 
 | |
|         private void EnqueueForDeletion(ulong guestAddress, TranslatedFunction func)
 | |
|         {
 | |
|             _oldFuncs.Enqueue(new(guestAddress, func));
 | |
|         }
 | |
| 
 | |
|         private void ClearJitCache()
 | |
|         {
 | |
|             // Ensure no attempt will be made to compile new functions due to rejit.
 | |
|             ClearRejitQueue(allowRequeue: false);
 | |
| 
 | |
|             foreach (var func in Functions.Values)
 | |
|             {
 | |
|                 JitCache.Unmap(func.FuncPtr);
 | |
| 
 | |
|                 func.CallCounter?.Dispose();
 | |
|             }
 | |
| 
 | |
|             Functions.Clear();
 | |
| 
 | |
|             while (_oldFuncs.TryDequeue(out var kv))
 | |
|             {
 | |
|                 JitCache.Unmap(kv.Value.FuncPtr);
 | |
| 
 | |
|                 kv.Value.CallCounter?.Dispose();
 | |
|             }
 | |
|         }
 | |
| 
 | |
|         private void ClearRejitQueue(bool allowRequeue)
 | |
|         {
 | |
|             _backgroundTranslatorLock.AcquireWriterLock(Timeout.Infinite);
 | |
| 
 | |
|             if (allowRequeue)
 | |
|             {
 | |
|                 while (_backgroundStack.TryPop(out var request))
 | |
|                 {
 | |
|                     if (Functions.TryGetValue(request.Address, out var func) && func.CallCounter != null)
 | |
|                     {
 | |
|                         Volatile.Write(ref func.CallCounter.Value, 0);
 | |
|                     }
 | |
| 
 | |
|                     _backgroundSet.TryRemove(request.Address, out _);
 | |
|                 }
 | |
|             }
 | |
|             else
 | |
|             {
 | |
|                 _backgroundStack.Clear();
 | |
|             }
 | |
| 
 | |
|             _backgroundTranslatorLock.ReleaseWriterLock();
 | |
|         }
 | |
|     }
 | |
| }
 |