1
0
mirror of https://github.com/SquidDev-CC/CC-Tweaked synced 2025-10-25 02:47:39 +00:00

Manage ComputerThread's lifecycle in ComputerContext

This converts ComputerThread from a singleton into a proper object,
which is setup when starting a computer, and tore down when the
ComputerContext is closed.

While this is mostly for conceptual elegance, it does offer some
concrete benefits:
 - You can now adjust the thread count without restarting the whole
   game (just leaving and rentering the world). Though, alas, no effect
   on servers.
 - We can run multiple ComputerThreads in parallel, which makes it much
   easier to run tests in parallel. This allows us to remove our rather
   silly IsolatedRunner test helper.
This commit is contained in:
Jonathan Coates
2022-10-22 14:36:25 +01:00
parent e9cde9e1bf
commit 57cf6084e2
10 changed files with 216 additions and 255 deletions

View File

@@ -5,6 +5,7 @@
*/ */
package dan200.computercraft.core; package dan200.computercraft.core;
import dan200.computercraft.core.computer.ComputerThread;
import dan200.computercraft.core.computer.GlobalEnvironment; import dan200.computercraft.core.computer.GlobalEnvironment;
import dan200.computercraft.core.computer.mainthread.MainThreadScheduler; import dan200.computercraft.core.computer.mainthread.MainThreadScheduler;
import dan200.computercraft.core.lua.CobaltLuaMachine; import dan200.computercraft.core.lua.CobaltLuaMachine;
@@ -16,12 +17,17 @@ import dan200.computercraft.core.lua.ILuaMachine;
public final class ComputerContext implements AutoCloseable public final class ComputerContext implements AutoCloseable
{ {
private final GlobalEnvironment globalEnvironment; private final GlobalEnvironment globalEnvironment;
private final ComputerThread computerScheduler;
private final MainThreadScheduler mainThreadScheduler; private final MainThreadScheduler mainThreadScheduler;
private final ILuaMachine.Factory factory; private final ILuaMachine.Factory factory;
public ComputerContext( GlobalEnvironment globalEnvironment, MainThreadScheduler mainThreadScheduler, ILuaMachine.Factory factory ) public ComputerContext(
GlobalEnvironment globalEnvironment, ComputerThread computerScheduler,
MainThreadScheduler mainThreadScheduler, ILuaMachine.Factory factory
)
{ {
this.globalEnvironment = globalEnvironment; this.globalEnvironment = globalEnvironment;
this.computerScheduler = computerScheduler;
this.mainThreadScheduler = mainThreadScheduler; this.mainThreadScheduler = mainThreadScheduler;
this.factory = factory; this.factory = factory;
} }
@@ -30,11 +36,12 @@ public final class ComputerContext implements AutoCloseable
* Create a default {@link ComputerContext} with the given global environment. * Create a default {@link ComputerContext} with the given global environment.
* *
* @param environment The current global environment. * @param environment The current global environment.
* @param threads The number of threads to use for the {@link #computerScheduler()}
* @param mainThreadScheduler The main thread scheduler to use. * @param mainThreadScheduler The main thread scheduler to use.
*/ */
public ComputerContext( GlobalEnvironment environment, MainThreadScheduler mainThreadScheduler ) public ComputerContext( GlobalEnvironment environment, int threads, MainThreadScheduler mainThreadScheduler )
{ {
this( environment, mainThreadScheduler, CobaltLuaMachine::new ); this( environment, new ComputerThread( threads ), mainThreadScheduler, CobaltLuaMachine::new );
} }
/** /**
@@ -47,6 +54,17 @@ public final class ComputerContext implements AutoCloseable
return globalEnvironment; return globalEnvironment;
} }
/**
* The {@link ComputerThread} instance under which computers are run. This is closed when the context is closed, and
* so should be unique per-context.
*
* @return The current computer thread manager.
*/
public ComputerThread computerScheduler()
{
return computerScheduler;
}
/** /**
* The {@link MainThreadScheduler} instance used to run main-thread tasks. * The {@link MainThreadScheduler} instance used to run main-thread tasks.
* *
@@ -73,5 +91,6 @@ public final class ComputerContext implements AutoCloseable
@Override @Override
public void close() public void close()
{ {
computerScheduler().stop();
} }
} }

View File

@@ -61,7 +61,8 @@ final class ComputerExecutor
private final ComputerEnvironment computerEnvironment; private final ComputerEnvironment computerEnvironment;
private final MetricsObserver metrics; private final MetricsObserver metrics;
private final List<ILuaAPI> apis = new ArrayList<>(); private final List<ILuaAPI> apis = new ArrayList<>();
final TimeoutState timeout = new TimeoutState(); private final ComputerThread scheduler;
final TimeoutState timeout;
private FileSystem fileSystem; private FileSystem fileSystem;
@@ -164,13 +165,15 @@ final class ComputerExecutor
ComputerExecutor( Computer computer, ComputerEnvironment computerEnvironment, ComputerContext context ) ComputerExecutor( Computer computer, ComputerEnvironment computerEnvironment, ComputerContext context )
{ {
// Ensure the computer thread is running as required.
ComputerThread.start();
this.computer = computer; this.computer = computer;
this.computerEnvironment = computerEnvironment; this.computerEnvironment = computerEnvironment;
metrics = computerEnvironment.getMetrics(); metrics = computerEnvironment.getMetrics();
luaFactory = context.luaFactory(); luaFactory = context.luaFactory();
scheduler = context.computerScheduler();
timeout = new TimeoutState( scheduler );
// Ensure the computer thread is running as required.
scheduler.start();
Environment environment = computer.getEnvironment(); Environment environment = computer.getEnvironment();
@@ -316,7 +319,7 @@ final class ComputerExecutor
{ {
synchronized( queueLock ) synchronized( queueLock )
{ {
if( !onComputerQueue ) ComputerThread.queue( this ); if( !onComputerQueue ) scheduler.queue( this );
} }
} }

View File

@@ -8,8 +8,8 @@ package dan200.computercraft.core.computer;
import dan200.computercraft.ComputerCraft; import dan200.computercraft.ComputerCraft;
import dan200.computercraft.shared.util.ThreadUtils; import dan200.computercraft.shared.util.ThreadUtils;
import javax.annotation.Nonnull;
import javax.annotation.Nullable; import javax.annotation.Nullable;
import java.util.Objects;
import java.util.TreeSet; import java.util.TreeSet;
import java.util.concurrent.ThreadFactory; import java.util.concurrent.ThreadFactory;
import java.util.concurrent.TimeUnit; import java.util.concurrent.TimeUnit;
@@ -19,28 +19,25 @@ import java.util.concurrent.locks.Condition;
import java.util.concurrent.locks.LockSupport; import java.util.concurrent.locks.LockSupport;
import java.util.concurrent.locks.ReentrantLock; import java.util.concurrent.locks.ReentrantLock;
import static dan200.computercraft.core.computer.TimeoutState.ABORT_TIMEOUT;
import static dan200.computercraft.core.computer.TimeoutState.TIMEOUT;
/** /**
* Responsible for running all tasks from a {@link Computer}. * Responsible for running all tasks from a {@link Computer}.
* * <p>
* This is split into two components: the {@link TaskRunner}s, which pull an executor from the queue and execute it, and * This is split into two components: the {@link TaskRunner}s, which pull an executor from the queue and execute it, and
* a single {@link Monitor} which observes all runners and kills them if they have not been terminated by * a single {@link Monitor} which observes all runners and kills them if they have not been terminated by
* {@link TimeoutState#isSoftAborted()}. * {@link TimeoutState#isSoftAborted()}.
* * <p>
* Computers are executed using a priority system, with those who have spent less time executing having a higher * Computers are executed using a priority system, with those who have spent less time executing having a higher
* priority than those hogging the thread. This, combined with {@link TimeoutState#isPaused()} means we can reduce the * priority than those hogging the thread. This, combined with {@link TimeoutState#isPaused()} means we can reduce the
* risk of badly behaved computers stalling execution for everyone else. * risk of badly behaved computers stalling execution for everyone else.
* * <p>
* This is done using an implementation of Linux's Completely Fair Scheduler. When a computer executes, we compute what * This is done using an implementation of Linux's Completely Fair Scheduler. When a computer executes, we compute what
* share of execution time it has used (time executed/number of tasks). We then pick the computer who has the least * share of execution time it has used (time executed/number of tasks). We then pick the computer who has the least
* "virtual execution time" (aka {@link ComputerExecutor#virtualRuntime}). * "virtual execution time" (aka {@link ComputerExecutor#virtualRuntime}).
* * <p>
* When adding a computer to the queue, we make sure its "virtual runtime" is at least as big as the smallest runtime. * When adding a computer to the queue, we make sure its "virtual runtime" is at least as big as the smallest runtime.
* This means that adding computers which have slept a lot do not then have massive priority over everyone else. See * This means that adding computers which have slept a lot do not then have massive priority over everyone else. See
* {@link #queue(ComputerExecutor)} for how this is implemented. * {@link #queue(ComputerExecutor)} for how this is implemented.
* * <p>
* In reality, it's unlikely that more than a few computers are waiting to execute at once, so this will not have much * In reality, it's unlikely that more than a few computers are waiting to execute at once, so this will not have much
* effect unless you have a computer hogging execution time. However, it is pretty effective in those situations. * effect unless you have a computer hogging execution time. However, it is pretty effective in those situations.
* *
@@ -49,6 +46,9 @@ import static dan200.computercraft.core.computer.TimeoutState.TIMEOUT;
*/ */
public final class ComputerThread public final class ComputerThread
{ {
private static final ThreadFactory monitorFactory = ThreadUtils.factory( "Computer-Monitor" );
private static final ThreadFactory runnerFactory = ThreadUtils.factory( "Computer-Runner" );
/** /**
* How often the computer thread monitor should run. * How often the computer thread monitor should run.
* *
@@ -58,7 +58,7 @@ public final class ComputerThread
/** /**
* The target latency between executing two tasks on a single machine. * The target latency between executing two tasks on a single machine.
* * <p>
* An average tick takes 50ms, and so we ideally need to have handled a couple of events within that window in order * An average tick takes 50ms, and so we ideally need to have handled a couple of events within that window in order
* to have a perceived low latency. * to have a perceived low latency.
*/ */
@@ -66,7 +66,7 @@ public final class ComputerThread
/** /**
* The minimum value that {@link #DEFAULT_LATENCY} can have when scaled. * The minimum value that {@link #DEFAULT_LATENCY} can have when scaled.
* * <p>
* From statistics gathered on SwitchCraft, almost all machines will execute under 15ms, 75% under 1.5ms, with the * From statistics gathered on SwitchCraft, almost all machines will execute under 15ms, 75% under 1.5ms, with the
* mean being about 3ms. Most computers shouldn't be too impacted with having such a short period to execute in. * mean being about 3ms. Most computers shouldn't be too impacted with having such a short period to execute in.
*/ */
@@ -87,36 +87,36 @@ public final class ComputerThread
/** /**
* Lock used for modifications to the array of current threads. * Lock used for modifications to the array of current threads.
*/ */
private static final Object threadLock = new Object(); private final Object threadLock = new Object();
/** /**
* Whether the computer thread system is currently running. * Whether the computer thread system is currently running.
*/ */
private static volatile boolean running = false; private volatile boolean running = false;
/** /**
* The current task manager. * The current task manager.
*/ */
private static Thread monitor; private @Nullable Thread monitor;
/** /**
* The array of current runners, and their owning threads. * The array of current runners, and their owning threads.
*/ */
private static TaskRunner[] runners; private final TaskRunner[] runners;
private static long latency; private final long latency;
private static long minPeriod; private final long minPeriod;
private static final ReentrantLock computerLock = new ReentrantLock(); private final ReentrantLock computerLock = new ReentrantLock();
private static final Condition hasWork = computerLock.newCondition(); private final Condition hasWork = computerLock.newCondition();
private static final AtomicInteger idleWorkers = new AtomicInteger( 0 ); private final AtomicInteger idleWorkers = new AtomicInteger( 0 );
private static final Condition monitorWakeup = computerLock.newCondition(); private final Condition monitorWakeup = computerLock.newCondition();
/** /**
* Active queues to execute. * Active queues to execute.
*/ */
private static final TreeSet<ComputerExecutor> computerQueue = new TreeSet<>( ( a, b ) -> { private final TreeSet<ComputerExecutor> computerQueue = new TreeSet<>( ( a, b ) -> {
if( a == b ) return 0; // Should never happen, but let's be consistent here if( a == b ) return 0; // Should never happen, but let's be consistent here
long at = a.virtualRuntime, bt = b.virtualRuntime; long at = a.virtualRuntime, bt = b.virtualRuntime;
@@ -127,34 +127,27 @@ public final class ComputerThread
/** /**
* The minimum {@link ComputerExecutor#virtualRuntime} time on the tree. * The minimum {@link ComputerExecutor#virtualRuntime} time on the tree.
*/ */
private static long minimumVirtualRuntime = 0; private long minimumVirtualRuntime = 0;
private static final ThreadFactory monitorFactory = ThreadUtils.factory( "Computer-Monitor" ); public ComputerThread( int threadCount )
private static final ThreadFactory runnerFactory = ThreadUtils.factory( "Computer-Runner" );
private ComputerThread() {}
/**
* Start the computer thread.
*/
static void start()
{ {
synchronized( threadLock ) runners = new TaskRunner[threadCount];
{
running = true;
if( runners == null )
{
// TODO: Update this on config reloads. Or possibly on world restarts?
runners = new TaskRunner[ComputerCraft.computerThreads];
// latency and minPeriod are scaled by 1 + floor(log2(threads)). We can afford to execute tasks for // latency and minPeriod are scaled by 1 + floor(log2(threads)). We can afford to execute tasks for
// longer when executing on more than one thread. // longer when executing on more than one thread.
long factor = 64 - Long.numberOfLeadingZeros( runners.length ); int factor = 64 - Long.numberOfLeadingZeros( runners.length );
latency = DEFAULT_LATENCY * factor; latency = DEFAULT_LATENCY * factor;
minPeriod = DEFAULT_MIN_PERIOD * factor; minPeriod = DEFAULT_MIN_PERIOD * factor;
} }
/**
* Start the computer thread.
*/
void start()
{
synchronized( threadLock )
{
running = true;
for( int i = 0; i < runners.length; i++ ) for( int i = 0; i < runners.length; i++ )
{ {
TaskRunner runner = runners[i]; TaskRunner runner = runners[i];
@@ -174,13 +167,11 @@ public final class ComputerThread
/** /**
* Attempt to stop the computer thread. This interrupts each runner, and clears the task queue. * Attempt to stop the computer thread. This interrupts each runner, and clears the task queue.
*/ */
public static void stop() public void stop()
{ {
synchronized( threadLock ) synchronized( threadLock )
{ {
running = false; running = false;
if( runners != null )
{
for( TaskRunner runner : runners ) for( TaskRunner runner : runners )
{ {
if( runner == null ) continue; if( runner == null ) continue;
@@ -188,7 +179,8 @@ public final class ComputerThread
runner.running = false; runner.running = false;
if( runner.owner != null ) runner.owner.interrupt(); if( runner.owner != null ) runner.owner.interrupt();
} }
}
if( monitor != null ) monitor.interrupt();
} }
computerLock.lock(); computerLock.lock();
@@ -200,17 +192,40 @@ public final class ComputerThread
{ {
computerLock.unlock(); computerLock.unlock();
} }
synchronized( threadLock )
{
if( monitor != null ) tryJoin( monitor );
for( TaskRunner runner : runners )
{
if( runner != null && runner.owner != null ) tryJoin( runner.owner );
}
}
}
private static void tryJoin( Thread thread )
{
try
{
thread.join( 100 );
}
catch( InterruptedException e )
{
throw new IllegalStateException( "Interrupted server thread while trying to stop " + thread.getName(), e );
}
if( thread.isAlive() ) ComputerCraft.log.error( "Failed to stop {}", thread.getName() );
} }
/** /**
* Mark a computer as having work, enqueuing it on the thread. * Mark a computer as having work, enqueuing it on the thread.
* * <p>
* You must be holding {@link ComputerExecutor}'s {@code queueLock} when calling this method - it should only * You must be holding {@link ComputerExecutor}'s {@code queueLock} when calling this method - it should only
* be called from {@code enqueue}. * be called from {@code enqueue}.
* *
* @param executor The computer to execute work on. * @param executor The computer to execute work on.
*/ */
static void queue( @Nonnull ComputerExecutor executor ) void queue( ComputerExecutor executor )
{ {
computerLock.lock(); computerLock.lock();
try try
@@ -256,12 +271,12 @@ public final class ComputerThread
/** /**
* Update the {@link ComputerExecutor#virtualRuntime}s of all running tasks, and then update the * Update the {@link ComputerExecutor#virtualRuntime}s of all running tasks, and then update the
* {@link #minimumVirtualRuntime} based on the current tasks. * {@link #minimumVirtualRuntime} based on the current tasks.
* * <p>
* This is called before queueing tasks, to ensure that {@link #minimumVirtualRuntime} is up-to-date. * This is called before queueing tasks, to ensure that {@link #minimumVirtualRuntime} is up-to-date.
* *
* @param current The machine which we updating runtimes from. * @param current The machine which we updating runtimes from.
*/ */
private static void updateRuntimes( @Nullable ComputerExecutor current ) private void updateRuntimes( @Nullable ComputerExecutor current )
{ {
long minRuntime = Long.MAX_VALUE; long minRuntime = Long.MAX_VALUE;
@@ -271,10 +286,7 @@ public final class ComputerThread
// Update all the currently executing tasks // Update all the currently executing tasks
long now = System.nanoTime(); long now = System.nanoTime();
int tasks = 1 + computerQueue.size(); int tasks = 1 + computerQueue.size();
TaskRunner[] currentRunners = runners; for( TaskRunner runner : runners )
if( currentRunners != null )
{
for( TaskRunner runner : currentRunners )
{ {
if( runner == null ) continue; if( runner == null ) continue;
ComputerExecutor executor = runner.currentExecutor.get(); ComputerExecutor executor = runner.currentExecutor.get();
@@ -285,7 +297,6 @@ public final class ComputerThread
minRuntime = Math.min( minRuntime, executor.virtualRuntime += (now - executor.vRuntimeStart) / tasks ); minRuntime = Math.min( minRuntime, executor.virtualRuntime += (now - executor.vRuntimeStart) / tasks );
executor.vRuntimeStart = now; executor.vRuntimeStart = now;
} }
}
// And update the most recently executed one (if set). // And update the most recently executed one (if set).
if( current != null ) if( current != null )
@@ -306,15 +317,18 @@ public final class ComputerThread
* @param runner The runner this task was on. * @param runner The runner this task was on.
* @param executor The executor to requeue * @param executor The executor to requeue
*/ */
private static void afterWork( TaskRunner runner, ComputerExecutor executor ) private void afterWork( TaskRunner runner, ComputerExecutor executor )
{ {
// Clear the executor's thread. // Clear the executor's thread.
Thread currentThread = executor.executingThread.getAndSet( null ); Thread currentThread = executor.executingThread.getAndSet( null );
if( currentThread != runner.owner ) if( currentThread != runner.owner )
{ {
ComputerCraft.log.error( ComputerCraft.log.error(
"Expected computer #{} to be running on {}, but already running on {}. This is a SERIOUS bug, please report with your debug.log.", "Expected computer #{} to be running on {}, but already running on {}. This is a SERIOUS bug, please report with your debug.log.",
executor.getComputer().getID(), runner.owner.getName(), currentThread == null ? "nothing" : currentThread.getName() executor.getComputer().getID(),
runner.owner == null ? "nothing" : runner.owner.getName(),
currentThread == null ? "nothing" : currentThread.getName()
); );
} }
@@ -344,7 +358,7 @@ public final class ComputerThread
* @see #DEFAULT_MIN_PERIOD * @see #DEFAULT_MIN_PERIOD
* @see #LATENCY_MAX_TASKS * @see #LATENCY_MAX_TASKS
*/ */
static long scaledPeriod() long scaledPeriod()
{ {
// +1 to include the current task // +1 to include the current task
int count = 1 + computerQueue.size(); int count = 1 + computerQueue.size();
@@ -356,7 +370,7 @@ public final class ComputerThread
* *
* @return If we have work queued up. * @return If we have work queued up.
*/ */
static boolean hasPendingWork() boolean hasPendingWork()
{ {
return !computerQueue.isEmpty(); return !computerQueue.isEmpty();
} }
@@ -367,7 +381,7 @@ public final class ComputerThread
* *
* @return If the computer threads are busy. * @return If the computer threads are busy.
*/ */
private static boolean isBusy() private boolean isBusy()
{ {
return computerQueue.size() > idleWorkers.get(); return computerQueue.size() > idleWorkers.get();
} }
@@ -378,7 +392,7 @@ public final class ComputerThread
* *
* @see TimeoutState * @see TimeoutState
*/ */
private static final class Monitor implements Runnable private final class Monitor implements Runnable
{ {
@Override @Override
public void run() public void run()
@@ -394,8 +408,11 @@ public final class ComputerThread
monitorWakeup.awaitNanos( isBusy() ? scaledPeriod() : MONITOR_WAKEUP ); monitorWakeup.awaitNanos( isBusy() ? scaledPeriod() : MONITOR_WAKEUP );
} }
catch( InterruptedException e ) catch( InterruptedException e )
{
if( running )
{ {
ComputerCraft.log.error( "Monitor thread interrupted. Computers may behave very badly!", e ); ComputerCraft.log.error( "Monitor thread interrupted. Computers may behave very badly!", e );
}
break; break;
} }
finally finally
@@ -407,11 +424,9 @@ public final class ComputerThread
} }
} }
private static void checkRunners() private void checkRunners()
{ {
TaskRunner[] currentRunners = ComputerThread.runners; TaskRunner[] currentRunners = ComputerThread.this.runners;
if( currentRunners == null ) return;
for( int i = 0; i < currentRunners.length; i++ ) for( int i = 0; i < currentRunners.length; i++ )
{ {
TaskRunner runner = currentRunners[i]; TaskRunner runner = currentRunners[i];
@@ -421,10 +436,9 @@ public final class ComputerThread
if( !running ) continue; if( !running ) continue;
// Mark the old runner as dead and start a new one. // Mark the old runner as dead and start a new one.
ComputerCraft.log.warn( "Previous runner ({}) has crashed, restarting!", ComputerCraft.log.warn( "Previous runner ({}) has crashed, restarting!", runner != null && runner.owner != null ? runner.owner.getName() : runner );
runner != null && runner.owner != null ? runner.owner.getName() : runner );
if( runner != null ) runner.running = false; if( runner != null ) runner.running = false;
runnerFactory.newThread( runners[i] = new TaskRunner() ).start(); runnerFactory.newThread( runner = runners[i] = new TaskRunner() ).start();
} }
// If the runner has no work, skip // If the runner has no work, skip
@@ -437,38 +451,38 @@ public final class ComputerThread
// If we're still within normal execution times (TIMEOUT) or soft abort (ABORT_TIMEOUT), // If we're still within normal execution times (TIMEOUT) or soft abort (ABORT_TIMEOUT),
// then we can let the Lua machine do its work. // then we can let the Lua machine do its work.
long afterStart = executor.timeout.nanoCumulative(); long afterStart = executor.timeout.nanoCumulative();
long afterHardAbort = afterStart - TIMEOUT - ABORT_TIMEOUT; long afterHardAbort = afterStart - TimeoutState.TIMEOUT - TimeoutState.ABORT_TIMEOUT;
if( afterHardAbort < 0 ) continue; if( afterHardAbort < 0 ) continue;
// Set the hard abort flag. // Set the hard abort flag.
executor.timeout.hardAbort(); executor.timeout.hardAbort();
executor.abort(); executor.abort();
if( afterHardAbort >= ABORT_TIMEOUT * 2 ) if( afterHardAbort >= TimeoutState.ABORT_TIMEOUT * 2 )
{ {
// If we've hard aborted and interrupted, and we're still not dead, then mark the runner // If we've hard aborted and interrupted, and we're still not dead, then mark the runner
// as dead, finish off the task, and spawn a new runner. // as dead, finish off the task, and spawn a new runner.
runner.reportTimeout( executor, afterStart ); runner.reportTimeout( executor, afterStart );
runner.running = false; runner.running = false;
runner.owner.interrupt(); if( runner.owner != null ) runner.owner.interrupt();
ComputerExecutor thisExecutor = runner.currentExecutor.getAndSet( null ); ComputerExecutor thisExecutor = runner.currentExecutor.getAndSet( null );
if( thisExecutor != null ) afterWork( runner, executor ); if( thisExecutor != null ) afterWork( runner, executor );
synchronized( threadLock ) synchronized( threadLock )
{ {
if( running && runners.length > i && runners[i] == runner ) if( running && runners[i] == runner )
{ {
runnerFactory.newThread( currentRunners[i] = new TaskRunner() ).start(); runnerFactory.newThread( currentRunners[i] = new TaskRunner() ).start();
} }
} }
} }
else if( afterHardAbort >= ABORT_TIMEOUT ) else if( afterHardAbort >= TimeoutState.ABORT_TIMEOUT )
{ {
// If we've hard aborted but we're still not dead, dump the stack trace and interrupt // If we've hard aborted but we're still not dead, dump the stack trace and interrupt
// the task. // the task.
runner.reportTimeout( executor, afterStart ); runner.reportTimeout( executor, afterStart );
runner.owner.interrupt(); if( runner.owner != null ) runner.owner.interrupt();
} }
} }
} }
@@ -476,13 +490,14 @@ public final class ComputerThread
/** /**
* Pulls tasks from the {@link #computerQueue} queue and runs them. * Pulls tasks from the {@link #computerQueue} queue and runs them.
* * <p>
* This is responsible for running the {@link ComputerExecutor#work()}, {@link ComputerExecutor#beforeWork()} and * This is responsible for running the {@link ComputerExecutor#work()}, {@link ComputerExecutor#beforeWork()} and
* {@link ComputerExecutor#afterWork()} functions. Everything else is either handled by the executor, timeout * {@link ComputerExecutor#afterWork()} functions. Everything else is either handled by the executor, timeout
* state or monitor. * state or monitor.
*/ */
private static final class TaskRunner implements Runnable private final class TaskRunner implements Runnable
{ {
@Nullable
Thread owner; Thread owner;
long lastReport = Long.MIN_VALUE; long lastReport = Long.MIN_VALUE;
volatile boolean running = true; volatile boolean running = true;
@@ -495,7 +510,7 @@ public final class ComputerThread
owner = Thread.currentThread(); owner = Thread.currentThread();
tasks: tasks:
while( running && ComputerThread.running ) while( running && ComputerThread.this.running )
{ {
// Wait for an active queue to execute // Wait for an active queue to execute
ComputerExecutor executor; ComputerExecutor executor;
@@ -572,6 +587,8 @@ public final class ComputerThread
if( lastReport != Long.MIN_VALUE && now - lastReport - REPORT_DEBOUNCE <= 0 ) return; if( lastReport != Long.MIN_VALUE && now - lastReport - REPORT_DEBOUNCE <= 0 ) return;
lastReport = now; lastReport = now;
Thread owner = Objects.requireNonNull( this.owner );
StringBuilder builder = new StringBuilder() StringBuilder builder = new StringBuilder()
.append( "Terminating computer #" ).append( executor.getComputer().getID() ) .append( "Terminating computer #" ).append( executor.getComputer().getID() )
.append( " due to timeout (running for " ).append( time * 1e-9 ) .append( " due to timeout (running for " ).append( time * 1e-9 )

View File

@@ -49,6 +49,8 @@ public final class TimeoutState
*/ */
public static final String ABORT_MESSAGE = "Too long without yielding"; public static final String ABORT_MESSAGE = "Too long without yielding";
private final ComputerThread scheduler;
private boolean paused; private boolean paused;
private boolean softAbort; private boolean softAbort;
private volatile boolean hardAbort; private volatile boolean hardAbort;
@@ -73,6 +75,11 @@ public final class TimeoutState
*/ */
private long currentDeadline; private long currentDeadline;
public TimeoutState( ComputerThread scheduler )
{
this.scheduler = scheduler;
}
long nanoCumulative() long nanoCumulative()
{ {
return System.nanoTime() - cumulativeStart; return System.nanoTime() - cumulativeStart;
@@ -91,7 +98,7 @@ public final class TimeoutState
// Important: The weird arithmetic here is important, as nanoTime may return negative values, and so we // Important: The weird arithmetic here is important, as nanoTime may return negative values, and so we
// need to handle overflow. // need to handle overflow.
long now = System.nanoTime(); long now = System.nanoTime();
if( !paused ) paused = currentDeadline - now <= 0 && ComputerThread.hasPendingWork(); // now >= currentDeadline if( !paused ) paused = currentDeadline - now <= 0 && scheduler.hasPendingWork(); // now >= currentDeadline
if( !softAbort ) softAbort = now - cumulativeStart - TIMEOUT >= 0; // now - cumulativeStart >= TIMEOUT if( !softAbort ) softAbort = now - cumulativeStart - TIMEOUT >= 0; // now - cumulativeStart >= TIMEOUT
} }
@@ -143,7 +150,7 @@ public final class TimeoutState
{ {
long now = System.nanoTime(); long now = System.nanoTime();
currentStart = now; currentStart = now;
currentDeadline = now + ComputerThread.scaledPeriod(); currentDeadline = now + scheduler.scaledPeriod();
// Compute the "nominal start time". // Compute the "nominal start time".
cumulativeStart = now - cumulativeElapsed; cumulativeStart = now - cumulativeElapsed;
} }

View File

@@ -56,7 +56,7 @@ public final class ServerContext
this.server = server; this.server = server;
storageDir = server.getWorldPath( FOLDER ); storageDir = server.getWorldPath( FOLDER );
mainThread = new MainThread(); mainThread = new MainThread();
context = new ComputerContext( new Environment( server ), mainThread ); context = new ComputerContext( new Environment( server ), ComputerCraft.computerThreads, mainThread );
idAssigner = new IDAssigner( storageDir.resolve( "ids.json" ) ); idAssigner = new IDAssigner( storageDir.resolve( "ids.json" ) );
} }

View File

@@ -114,7 +114,7 @@ public class ComputerTestDelegate
} }
BasicEnvironment environment = new BasicEnvironment( mount ); BasicEnvironment environment = new BasicEnvironment( mount );
context = new ComputerContext( environment, new FakeMainThreadScheduler() ); context = new ComputerContext( environment, 1, new FakeMainThreadScheduler() );
computer = new Computer( context, environment, term, 0 ); computer = new Computer( context, environment, term, 0 );
computer.getEnvironment().setPeripheral( ComputerSide.TOP, new FakeModem() ); computer.getEnvironment().setPeripheral( ComputerSide.TOP, new FakeModem() );
computer.addApi( new CctTestAPI() ); computer.addApi( new CctTestAPI() );

View File

@@ -50,7 +50,7 @@ public class ComputerBootstrap
Terminal term = new Terminal( ComputerCraft.computerTermWidth, ComputerCraft.computerTermHeight, true ); Terminal term = new Terminal( ComputerCraft.computerTermWidth, ComputerCraft.computerTermHeight, true );
MainThread mainThread = new MainThread(); MainThread mainThread = new MainThread();
BasicEnvironment environment = new BasicEnvironment( mount ); BasicEnvironment environment = new BasicEnvironment( mount );
ComputerContext context = new ComputerContext( environment, mainThread ); ComputerContext context = new ComputerContext( environment, 1, mainThread );
final Computer computer = new Computer( context, environment, term, 0 ); final Computer computer = new Computer( context, environment, term, 0 );
AssertApi api = new AssertApi(); AssertApi api = new AssertApi();

View File

@@ -5,15 +5,16 @@
*/ */
package dan200.computercraft.core.computer; package dan200.computercraft.core.computer;
import dan200.computercraft.ComputerCraft;
import dan200.computercraft.core.lua.MachineResult; import dan200.computercraft.core.lua.MachineResult;
import dan200.computercraft.support.ConcurrentHelpers; import dan200.computercraft.support.ConcurrentHelpers;
import dan200.computercraft.support.IsolatedRunner; import org.junit.jupiter.api.AfterEach;
import org.junit.jupiter.api.BeforeEach;
import org.junit.jupiter.api.Test; import org.junit.jupiter.api.Test;
import org.junit.jupiter.api.Timeout; import org.junit.jupiter.api.Timeout;
import org.junit.jupiter.api.extension.ExtendWith;
import org.junit.jupiter.api.parallel.Execution; import org.junit.jupiter.api.parallel.Execution;
import org.junit.jupiter.api.parallel.ExecutionMode; import org.junit.jupiter.api.parallel.ExecutionMode;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
import java.util.concurrent.TimeUnit; import java.util.concurrent.TimeUnit;
@@ -22,33 +23,48 @@ import static org.hamcrest.Matchers.closeTo;
import static org.junit.jupiter.api.Assertions.*; import static org.junit.jupiter.api.Assertions.*;
@Timeout( value = 15 ) @Timeout( value = 15 )
@ExtendWith( IsolatedRunner.class )
@Execution( ExecutionMode.CONCURRENT ) @Execution( ExecutionMode.CONCURRENT )
public class ComputerThreadTest public class ComputerThreadTest
{ {
private static final Logger LOGGER = LoggerFactory.getLogger( ComputerThreadTest.class );
private FakeComputerManager manager;
@BeforeEach
public void before()
{
manager = new FakeComputerManager();
}
@AfterEach
public void after()
{
manager.close();
}
@Test @Test
public void testSoftAbort() throws Exception public void testSoftAbort() throws Exception
{ {
Computer computer = FakeComputerManager.create(); Computer computer = manager.create();
FakeComputerManager.enqueue( computer, timeout -> { manager.enqueue( computer, timeout -> {
assertFalse( timeout.isSoftAborted(), "Should not start soft-aborted" ); assertFalse( timeout.isSoftAborted(), "Should not start soft-aborted" );
long delay = ConcurrentHelpers.waitUntil( timeout::isSoftAborted ); long delay = ConcurrentHelpers.waitUntil( timeout::isSoftAborted );
assertThat( "Should be soft aborted", delay * 1e-9, closeTo( 7, 0.5 ) ); assertThat( "Should be soft aborted", delay * 1e-9, closeTo( 7, 0.5 ) );
ComputerCraft.log.info( "Slept for {}", delay ); LOGGER.info( "Slept for {}", delay );
computer.shutdown(); computer.shutdown();
return MachineResult.OK; return MachineResult.OK;
} ); } );
FakeComputerManager.startAndWait( computer ); manager.startAndWait( computer );
} }
@Test @Test
public void testHardAbort() throws Exception public void testHardAbort() throws Exception
{ {
Computer computer = FakeComputerManager.create(); Computer computer = manager.create();
FakeComputerManager.enqueue( computer, timeout -> { manager.enqueue( computer, timeout -> {
assertFalse( timeout.isHardAborted(), "Should not start soft-aborted" ); assertFalse( timeout.isHardAborted(), "Should not start soft-aborted" );
assertThrows( InterruptedException.class, () -> Thread.sleep( 11_000 ), "Sleep should be hard aborted" ); assertThrows( InterruptedException.class, () -> Thread.sleep( 11_000 ), "Sleep should be hard aborted" );
@@ -58,14 +74,14 @@ public class ComputerThreadTest
return MachineResult.OK; return MachineResult.OK;
} ); } );
FakeComputerManager.startAndWait( computer ); manager.startAndWait( computer );
} }
@Test @Test
public void testNoPauseIfNoOtherMachines() throws Exception public void testNoPauseIfNoOtherMachines() throws Exception
{ {
Computer computer = FakeComputerManager.create(); Computer computer = manager.create();
FakeComputerManager.enqueue( computer, timeout -> { manager.enqueue( computer, timeout -> {
boolean didPause = ConcurrentHelpers.waitUntil( timeout::isPaused, 5, TimeUnit.SECONDS ); boolean didPause = ConcurrentHelpers.waitUntil( timeout::isPaused, 5, TimeUnit.SECONDS );
assertFalse( didPause, "Machine shouldn't have paused within 5s" ); assertFalse( didPause, "Machine shouldn't have paused within 5s" );
@@ -73,15 +89,15 @@ public class ComputerThreadTest
return MachineResult.OK; return MachineResult.OK;
} ); } );
FakeComputerManager.startAndWait( computer ); manager.startAndWait( computer );
} }
@Test @Test
public void testPauseIfSomeOtherMachine() throws Exception public void testPauseIfSomeOtherMachine() throws Exception
{ {
Computer computer = FakeComputerManager.create(); Computer computer = manager.create();
FakeComputerManager.enqueue( computer, timeout -> { manager.enqueue( computer, timeout -> {
long budget = ComputerThread.scaledPeriod(); long budget = manager.context().computerScheduler().scaledPeriod();
assertEquals( budget, TimeUnit.MILLISECONDS.toNanos( 25 ), "Budget should be 25ms" ); assertEquals( budget, TimeUnit.MILLISECONDS.toNanos( 25 ), "Budget should be 25ms" );
long delay = ConcurrentHelpers.waitUntil( timeout::isPaused ); long delay = ConcurrentHelpers.waitUntil( timeout::isPaused );
@@ -91,8 +107,8 @@ public class ComputerThreadTest
return MachineResult.OK; return MachineResult.OK;
} ); } );
FakeComputerManager.createLoopingComputer(); manager.createLoopingComputer();
FakeComputerManager.startAndWait( computer ); manager.startAndWait( computer );
} }
} }

View File

@@ -10,10 +10,9 @@ import dan200.computercraft.core.ComputerContext;
import dan200.computercraft.core.lua.ILuaMachine; import dan200.computercraft.core.lua.ILuaMachine;
import dan200.computercraft.core.lua.MachineResult; import dan200.computercraft.core.lua.MachineResult;
import dan200.computercraft.core.terminal.Terminal; import dan200.computercraft.core.terminal.Terminal;
import dan200.computercraft.support.IsolatedRunner;
import org.jetbrains.annotations.Nullable;
import javax.annotation.Nonnull; import javax.annotation.Nonnull;
import javax.annotation.Nullable;
import java.io.InputStream; import java.io.InputStream;
import java.util.HashMap; import java.util.HashMap;
import java.util.Map; import java.util.Map;
@@ -26,25 +25,36 @@ import java.util.concurrent.locks.ReentrantLock;
/** /**
* Creates "fake" computers, which just run user-defined tasks rather than Lua code. * Creates "fake" computers, which just run user-defined tasks rather than Lua code.
* <p>
* Note, this will clobber some parts of the global state. It's recommended you use this inside an {@link IsolatedRunner}.
*/ */
public class FakeComputerManager public class FakeComputerManager implements AutoCloseable
{ {
interface Task interface Task
{ {
MachineResult run( TimeoutState state ) throws Exception; MachineResult run( TimeoutState state ) throws Exception;
} }
private static final ComputerContext context = new ComputerContext( private final Map<Computer, Queue<Task>> machines = new HashMap<>();
new BasicEnvironment(), new FakeMainThreadScheduler(), private final ComputerContext context = new ComputerContext(
new BasicEnvironment(),
new ComputerThread( 1 ),
new FakeMainThreadScheduler(),
args -> new DummyLuaMachine( args.timeout ) args -> new DummyLuaMachine( args.timeout )
); );
private static final Map<Computer, Queue<Task>> machines = new HashMap<>();
private static final Lock errorLock = new ReentrantLock(); private final Lock errorLock = new ReentrantLock();
private static final Condition hasError = errorLock.newCondition(); private final Condition hasError = errorLock.newCondition();
private static volatile Throwable error; private volatile @Nullable Throwable error;
@Override
public void close()
{
context.close();
}
public ComputerContext context()
{
return context;
}
/** /**
* Create a new computer which pulls from our task queue. * Create a new computer which pulls from our task queue.
@@ -52,20 +62,19 @@ public class FakeComputerManager
* @return The computer. This will not be started yet, you must call {@link Computer#turnOn()} and * @return The computer. This will not be started yet, you must call {@link Computer#turnOn()} and
* {@link Computer#tick()} to do so. * {@link Computer#tick()} to do so.
*/ */
@Nonnull public Computer create()
public static Computer create()
{ {
Queue<Task> queue = new ConcurrentLinkedQueue<>();
Computer computer = new Computer( context, new BasicEnvironment(), new Terminal( 51, 19, true ), 0 ); Computer computer = new Computer( context, new BasicEnvironment(), new Terminal( 51, 19, true ), 0 );
ConcurrentLinkedQueue<Task> tasks = new ConcurrentLinkedQueue<>(); computer.addApi( new QueuePassingAPI( queue ) ); // Inject an extra API to pass the queue to the machine.
computer.addApi( new QueuePassingAPI( tasks ) ); machines.put( computer, queue );
machines.put( computer, tasks );
return computer; return computer;
} }
/** /**
* Create and start a new computer which loops forever. * Create and start a new computer which loops forever.
*/ */
public static void createLoopingComputer() public void createLoopingComputer()
{ {
Computer computer = create(); Computer computer = create();
enqueueForever( computer, t -> { enqueueForever( computer, t -> {
@@ -82,7 +91,7 @@ public class FakeComputerManager
* @param computer The computer to enqueue the work on. * @param computer The computer to enqueue the work on.
* @param task The task to run. * @param task The task to run.
*/ */
public static void enqueue( @Nonnull Computer computer, @Nonnull Task task ) public void enqueue( Computer computer, Task task )
{ {
machines.get( computer ).offer( task ); machines.get( computer ).offer( task );
} }
@@ -94,7 +103,7 @@ public class FakeComputerManager
* @param computer The computer to enqueue the work on. * @param computer The computer to enqueue the work on.
* @param task The task to run. * @param task The task to run.
*/ */
private static void enqueueForever( @Nonnull Computer computer, @Nonnull Task task ) private void enqueueForever( Computer computer, Task task )
{ {
machines.get( computer ).offer( t -> { machines.get( computer ).offer( t -> {
MachineResult result = task.run( t ); MachineResult result = task.run( t );
@@ -112,7 +121,7 @@ public class FakeComputerManager
* @param unit The time unit the duration is measured in. * @param unit The time unit the duration is measured in.
* @throws Exception An exception thrown by a running computer. * @throws Exception An exception thrown by a running computer.
*/ */
public static void sleep( long delay, TimeUnit unit ) throws Exception public void sleep( long delay, TimeUnit unit ) throws Exception
{ {
errorLock.lock(); errorLock.lock();
try try
@@ -132,7 +141,7 @@ public class FakeComputerManager
* @param computer The computer to wait for. * @param computer The computer to wait for.
* @throws Exception An exception thrown by a running computer. * @throws Exception An exception thrown by a running computer.
*/ */
public static void startAndWait( Computer computer ) throws Exception public void startAndWait( Computer computer ) throws Exception
{ {
computer.turnOn(); computer.turnOn();
computer.tick(); computer.tick();
@@ -140,16 +149,16 @@ public class FakeComputerManager
do do
{ {
sleep( 100, TimeUnit.MILLISECONDS ); sleep( 100, TimeUnit.MILLISECONDS );
} while( ComputerThread.hasPendingWork() || computer.isOn() ); } while( context.computerScheduler().hasPendingWork() || computer.isOn() );
rethrowIfNeeded(); rethrowIfNeeded();
} }
private static void rethrowIfNeeded() throws Exception private void rethrowIfNeeded() throws Exception
{ {
Throwable error = this.error;
if( error == null ) return; if( error == null ) return;
if( error instanceof Exception ) throw (Exception) error; if( error instanceof Exception ) throw (Exception) error;
if( error instanceof Error ) throw (Error) error;
rethrow( error ); rethrow( error );
} }
@@ -175,10 +184,10 @@ public class FakeComputerManager
} }
} }
private static class DummyLuaMachine implements ILuaMachine private final class DummyLuaMachine implements ILuaMachine
{ {
private final TimeoutState state; private final TimeoutState state;
private @javax.annotation.Nullable Queue<Task> tasks; private @Nullable Queue<Task> tasks;
DummyLuaMachine( TimeoutState state ) DummyLuaMachine( TimeoutState state )
{ {

View File

@@ -1,110 +0,0 @@
/*
* This file is part of ComputerCraft - http://www.computercraft.info
* Copyright Daniel Ratcliffe, 2011-2022. Do not distribute without permission.
* Send enquiries to dratcliffe@gmail.com
*/
package dan200.computercraft.support;
import com.google.common.io.ByteStreams;
import net.minecraftforge.fml.unsafe.UnsafeHacks;
import org.junit.jupiter.api.extension.*;
import java.io.IOException;
import java.io.InputStream;
import java.lang.reflect.Field;
import java.lang.reflect.InvocationTargetException;
import java.lang.reflect.Method;
import java.security.CodeSource;
import java.security.SecureClassLoader;
/**
* Runs a test method in an entirely isolated {@link ClassLoader}, so you can mess around with as much of
* {@link dan200.computercraft} as you like.
*
* This <strong>IS NOT</strong> a good idea, but helps us run some tests in parallel while having lots of (terrible)
* global state.
*/
public class IsolatedRunner implements InvocationInterceptor, BeforeEachCallback, AfterEachCallback
{
private static final ExtensionContext.Namespace NAMESPACE = ExtensionContext.Namespace.create( new Object() );
@Override
public void beforeEach( ExtensionContext context ) throws Exception
{
ClassLoader loader = context.getStore( NAMESPACE ).getOrComputeIfAbsent( IsolatedClassLoader.class );
// Rename the global thread group to something more obvious.
ThreadGroup group = (ThreadGroup) loader.loadClass( "dan200.computercraft.shared.util.ThreadUtils" ).getMethod( "group" ).invoke( null );
Field field = ThreadGroup.class.getDeclaredField( "name" );
UnsafeHacks.setField( field, group, "<" + context.getDisplayName() + ">" );
}
@Override
public void afterEach( ExtensionContext context ) throws Exception
{
ClassLoader loader = context.getStore( NAMESPACE ).get( IsolatedClassLoader.class, IsolatedClassLoader.class );
loader.loadClass( "dan200.computercraft.core.computer.ComputerThread" )
.getDeclaredMethod( "stop" )
.invoke( null );
}
@Override
public void interceptTestMethod( Invocation<Void> invocation, ReflectiveInvocationContext<Method> invocationContext, ExtensionContext extensionContext ) throws Throwable
{
invocation.skip();
ClassLoader loader = extensionContext.getStore( NAMESPACE ).get( IsolatedClassLoader.class, IsolatedClassLoader.class );
Method method = invocationContext.getExecutable();
Class<?> ourClass = loader.loadClass( method.getDeclaringClass().getName() );
Method ourMethod = ourClass.getDeclaredMethod( method.getName(), method.getParameterTypes() );
try
{
ourMethod.invoke( ourClass.getConstructor().newInstance(), invocationContext.getArguments().toArray() );
}
catch( InvocationTargetException e )
{
throw e.getTargetException();
}
}
private static class IsolatedClassLoader extends SecureClassLoader
{
IsolatedClassLoader()
{
super( IsolatedClassLoader.class.getClassLoader() );
}
@Override
public Class<?> loadClass( String name, boolean resolve ) throws ClassNotFoundException
{
synchronized( getClassLoadingLock( name ) )
{
Class<?> c = findLoadedClass( name );
if( c != null ) return c;
if( name.startsWith( "dan200.computercraft." ) )
{
CodeSource parentSource = getParent().loadClass( name ).getProtectionDomain().getCodeSource();
byte[] contents;
try( InputStream stream = getResourceAsStream( name.replace( '.', '/' ) + ".class" ) )
{
if( stream == null ) throw new ClassNotFoundException( name );
contents = ByteStreams.toByteArray( stream );
}
catch( IOException e )
{
throw new ClassNotFoundException( name, e );
}
return defineClass( name, contents, 0, contents.length, parentSource );
}
}
return super.loadClass( name, resolve );
}
}
}