Implement priority based task scheduling.

1. Removes the marker task used by schedule() and instead limits the number of task resumptions to the initial length of the task queue
2. Assigns a static and a dynamic priority to each task. The dynamic priority starts with the same value as the static priority and gets incremented by the static priority each time the task gets overtaken by a higher priority task, eventually leading to the task becoming the highest priority (unless the static priority is zero). Tasks with a higher dynamic priority generally take precedence, unless the concurrency exceeds 10 scheduled tasks, in which case the front of the queue is scheduled in normal FIFO order.
This commit is contained in:
Sönke Ludwig 2020-03-14 19:47:20 +01:00
parent 3de7cb0042
commit 6a2dfa468b
3 changed files with 244 additions and 40 deletions

View file

@ -1,7 +1,7 @@
/** /**
This module contains the core functionality of the vibe.d framework. This module contains the core functionality of the vibe.d framework.
Copyright: © 2012-2019 Sönke Ludwig Copyright: © 2012-2020 Sönke Ludwig
License: Subject to the terms of the MIT license, as written in the included LICENSE.txt file. License: Subject to the terms of the MIT license, as written in the included LICENSE.txt file.
Authors: Sönke Ludwig Authors: Sönke Ludwig
*/ */
@ -319,7 +319,7 @@ Task runTask(ARGS...)(void delegate(ARGS) @safe task, auto ref ARGS args)
{ {
return runTask_internal!((ref tfi) { tfi.set(task, args); }); return runTask_internal!((ref tfi) { tfi.set(task, args); });
} }
/// /// ditto
Task runTask(ARGS...)(void delegate(ARGS) @system task, auto ref ARGS args) Task runTask(ARGS...)(void delegate(ARGS) @system task, auto ref ARGS args)
@system { @system {
return runTask_internal!((ref tfi) { tfi.set(task, args); }); return runTask_internal!((ref tfi) { tfi.set(task, args); });
@ -330,6 +330,50 @@ Task runTask(CALLABLE, ARGS...)(CALLABLE task, auto ref ARGS args)
{ {
return runTask_internal!((ref tfi) { tfi.set(task, args); }); return runTask_internal!((ref tfi) { tfi.set(task, args); });
} }
/// ditto
Task runTask(ARGS...)(TaskSettings settings, void delegate(ARGS) @safe task, auto ref ARGS args)
{
return runTask_internal!((ref tfi) {
tfi.settings = settings;
tfi.set(task, args);
});
}
/// ditto
Task runTask(ARGS...)(TaskSettings settings, void delegate(ARGS) @system task, auto ref ARGS args)
@system {
return runTask_internal!((ref tfi) {
tfi.settings = settings;
tfi.set(task, args);
});
}
/// ditto
Task runTask(CALLABLE, ARGS...)(TaskSettings settings, CALLABLE task, auto ref ARGS args)
if (!is(CALLABLE : void delegate(ARGS)) && is(typeof(CALLABLE.init(ARGS.init))))
{
return runTask_internal!((ref tfi) {
tfi.settings = settings;
tfi.set(task, args);
});
}
unittest { // test proportional priority scheduling
auto tm = setTimer(1000.msecs, { assert(false, "Test timeout"); });
scope (exit) tm.stop();
size_t a, b;
auto t1 = runTask(TaskSettings(1), { while (a + b < 100) { a++; yield(); } });
auto t2 = runTask(TaskSettings(10), { while (a + b < 100) { b++; yield(); } });
runTask({
t1.join();
t2.join();
exitEventLoop();
});
runEventLoop();
assert(a + b == 100);
assert(b.among(90, 91, 92)); // expect 1:10 ratio +-1
}
/** /**
Runs an asyncronous task that is guaranteed to finish before the caller's Runs an asyncronous task that is guaranteed to finish before the caller's
@ -429,6 +473,21 @@ void runWorkerTask(alias method, T, ARGS...)(shared(T) object, auto ref ARGS arg
setupWorkerThreads(); setupWorkerThreads();
st_workerPool.runTask!method(object, args); st_workerPool.runTask!method(object, args);
} }
/// ditto
void runWorkerTask(FT, ARGS...)(TaskSettings settings, FT func, auto ref ARGS args)
if (isFunctionPointer!FT)
{
setupWorkerThreads();
st_workerPool.runTask(settings, func, args);
}
/// ditto
void runWorkerTask(alias method, T, ARGS...)(TaskSettings settings, shared(T) object, auto ref ARGS args)
if (is(typeof(__traits(getMember, object, __traits(identifier, method)))))
{
setupWorkerThreads();
st_workerPool.runTask!method(settings, object, args);
}
/** /**
Runs a new asynchronous task in a worker thread, returning the task handle. Runs a new asynchronous task in a worker thread, returning the task handle.
@ -452,6 +511,20 @@ Task runWorkerTaskH(alias method, T, ARGS...)(shared(T) object, auto ref ARGS ar
setupWorkerThreads(); setupWorkerThreads();
return st_workerPool.runTaskH!method(object, args); return st_workerPool.runTaskH!method(object, args);
} }
/// ditto
Task runWorkerTaskH(FT, ARGS...)(TaskSettings settings, FT func, auto ref ARGS args)
if (isFunctionPointer!FT)
{
setupWorkerThreads();
return st_workerPool.runTaskH(settings, func, args);
}
/// ditto
Task runWorkerTaskH(alias method, T, ARGS...)(TaskSettings settings, shared(T) object, auto ref ARGS args)
if (is(typeof(__traits(getMember, object, __traits(identifier, method)))))
{
setupWorkerThreads();
return st_workerPool.runTaskH!method(settings, object, args);
}
/// Running a worker task using a function /// Running a worker task using a function
unittest { unittest {

View file

@ -1,7 +1,7 @@
/** /**
Contains interfaces and enums for evented I/O drivers. Contains interfaces and enums for evented I/O drivers.
Copyright: © 2012-2016 Sönke Ludwig Copyright: © 2012-2020 Sönke Ludwig
Authors: Sönke Ludwig Authors: Sönke Ludwig
License: Subject to the terms of the MIT license, as written in the included LICENSE.txt file. License: Subject to the terms of the MIT license, as written in the included LICENSE.txt file.
*/ */
@ -31,6 +31,8 @@ struct Task {
static ThreadInfo s_tidInfo; static ThreadInfo s_tidInfo;
} }
enum basePriority = 0x00010000;
private this(TaskFiber fiber, size_t task_counter) private this(TaskFiber fiber, size_t task_counter)
@safe nothrow { @safe nothrow {
() @trusted { m_fiber = cast(shared)fiber; } (); () @trusted { m_fiber = cast(shared)fiber; } ();
@ -129,6 +131,27 @@ struct Task {
bool opEquals(in Task other) const @safe nothrow { return m_fiber is other.m_fiber && m_taskCounter == other.m_taskCounter; } bool opEquals(in Task other) const @safe nothrow { return m_fiber is other.m_fiber && m_taskCounter == other.m_taskCounter; }
} }
/** Settings to control the behavior of newly started tasks.
*/
struct TaskSettings {
/** Scheduling priority of the task
The priority of a task is roughly proportional to the amount of
times it gets scheduled in comparison to competing tasks. For
example, a task with priority 100 will be scheduled every 10 rounds
when competing against a task with priority 1000.
The default priority is defined by `basePriority` and has a value
of 65536. Priorities should be computed relative to `basePriority`.
A task with a priority of zero will only be executed if no other
non-zero task is competing.
*/
uint priority = Task.basePriority;
}
/** /**
Implements a task local storage variable. Implements a task local storage variable.
@ -316,7 +339,9 @@ final package class TaskFiber : Fiber {
Thread m_thread; Thread m_thread;
ThreadInfo m_tidInfo; ThreadInfo m_tidInfo;
uint m_staticPriority, m_dynamicPriority;
shared ulong m_taskCounterAndFlags = 0; // bits 0-Flags.shiftAmount are flags shared ulong m_taskCounterAndFlags = 0; // bits 0-Flags.shiftAmount are flags
bool m_shutdown = false; bool m_shutdown = false;
shared(ManualEvent) m_onExit; shared(ManualEvent) m_onExit;
@ -384,6 +409,7 @@ final package class TaskFiber : Fiber {
TaskFuncInfo task; TaskFuncInfo task;
swap(task, m_taskFunc); swap(task, m_taskFunc);
m_dynamicPriority = m_staticPriority = task.settings.priority;
Task handle = this.task; Task handle = this.task;
try { try {
atomicOp!"|="(m_taskCounterAndFlags, Flags.running); // set running atomicOp!"|="(m_taskCounterAndFlags, Flags.running); // set running
@ -621,6 +647,7 @@ package struct TaskFuncInfo {
void[2*size_t.sizeof] callable; void[2*size_t.sizeof] callable;
void[maxTaskParameterSize] args; void[maxTaskParameterSize] args;
debug ulong functionPointer; debug ulong functionPointer;
TaskSettings settings;
void set(CALLABLE, ARGS...)(ref CALLABLE callable, ref ARGS args) void set(CALLABLE, ARGS...)(ref CALLABLE callable, ref ARGS args)
{ {
@ -715,7 +742,6 @@ package struct TaskScheduler {
private { private {
TaskFiberQueue m_taskQueue; TaskFiberQueue m_taskQueue;
TaskFiber m_markerTask;
} }
@safe: @safe:
@ -738,8 +764,7 @@ package struct TaskScheduler {
debug (VibeTaskLog) logTrace("Yielding (interrupt=%s)", () @trusted { return (cast(shared)tf).getTaskStatus().interrupt; } ()); debug (VibeTaskLog) logTrace("Yielding (interrupt=%s)", () @trusted { return (cast(shared)tf).getTaskStatus().interrupt; } ());
tf.handleInterrupt(); tf.handleInterrupt();
if (tf.m_queue !is null) return; // already scheduled to be resumed if (tf.m_queue !is null) return; // already scheduled to be resumed
m_taskQueue.insertBack(tf); doYieldAndReschedule(t);
doYield(t);
tf.handleInterrupt(); tf.handleInterrupt();
} }
@ -846,13 +871,10 @@ package struct TaskScheduler {
if (t == Task.init) return; // not really a task -> no-op if (t == Task.init) return; // not really a task -> no-op
auto tf = () @trusted { return t.taskFiber; } (); auto tf = () @trusted { return t.taskFiber; } ();
if (tf.m_queue !is null) return; // already scheduled to be resumed if (tf.m_queue !is null) return; // already scheduled to be resumed
m_taskQueue.insertBack(tf); doYieldAndReschedule(t);
doYield(t);
} }
/** Holds execution until the task gets explicitly resumed. /** Holds execution until the task gets explicitly resumed.
*/ */
void hibernate() void hibernate()
{ {
@ -923,33 +945,26 @@ package struct TaskScheduler {
return ScheduleStatus.idle; return ScheduleStatus.idle;
if (!m_markerTask) m_markerTask = new TaskFiber; // TODO: avoid allocating an actual task here!
scope (exit) assert(!m_markerTask.m_queue, "Marker task still in queue!?");
assert(Task.getThis() == Task.init, "TaskScheduler.schedule() may not be called from a task!"); assert(Task.getThis() == Task.init, "TaskScheduler.schedule() may not be called from a task!");
assert(!m_markerTask.m_queue, "TaskScheduler.schedule() was called recursively!");
// keep track of the end of the queue, so that we don't process tasks if (m_taskQueue.empty) return ScheduleStatus.idle;
// infinitely
m_taskQueue.insertBack(m_markerTask);
while (m_taskQueue.front !is m_markerTask) { foreach (i; 0 .. m_taskQueue.length) {
auto t = m_taskQueue.front; auto t = m_taskQueue.front;
m_taskQueue.popFront(); m_taskQueue.popFront();
// reset priority
t.m_dynamicPriority = t.m_staticPriority;
debug (VibeTaskLog) logTrace("resuming task"); debug (VibeTaskLog) logTrace("resuming task");
auto task = t.task; auto task = t.task;
if (task != Task.init) if (task != Task.init)
resumeTask(t.task); resumeTask(t.task);
debug (VibeTaskLog) logTrace("task out"); debug (VibeTaskLog) logTrace("task out");
assert(!m_taskQueue.empty, "Marker task got removed from tasks queue!?"); if (m_taskQueue.empty) break;
if (m_taskQueue.empty) return ScheduleStatus.idle; // handle gracefully in release mode
} }
// remove marker task
m_taskQueue.popFront();
debug (VibeTaskLog) logDebugV("schedule finished - %s tasks left in queue", m_taskQueue.length); debug (VibeTaskLog) logDebugV("schedule finished - %s tasks left in queue", m_taskQueue.length);
return m_taskQueue.empty ? ScheduleStatus.allProcessed : ScheduleStatus.busy; return m_taskQueue.empty ? ScheduleStatus.allProcessed : ScheduleStatus.busy;
@ -979,6 +994,25 @@ package struct TaskScheduler {
} }
} }
private void doYieldAndReschedule(Task task)
{
auto tf = () @trusted { return task.taskFiber; } ();
// insert according to priority, limited to a priority
// factor of 1:10 in case of heavy concurrency
m_taskQueue.insertBackPred(tf, 10, (t) {
if (t.m_dynamicPriority >= tf.m_dynamicPriority)
return true;
// increase dynamic priority each time a task gets overtaken to
// ensure a fair schedule
t.m_dynamicPriority += t.m_staticPriority;
return false;
});
doYield(task);
}
private void doYield(Task task) private void doYield(Task task)
{ {
assert(() @trusted { return task.taskFiber; } ().m_yieldLockCount == 0, "May not yield while in an active yieldLock()!"); assert(() @trusted { return task.taskFiber; } ().m_yieldLockCount == 0, "May not yield while in an active yieldLock()!");
@ -1041,6 +1075,31 @@ private struct TaskFiberQueue {
length++; length++;
} }
// inserts a task after the first task for which the predicate yields `true`,
// starting from the back. a maximum of max_skip tasks will be skipped
// before the task is inserted regardless of the predicate.
void insertBackPred(TaskFiber task, size_t max_skip,
scope bool delegate(TaskFiber) @safe nothrow pred)
{
assert(task.m_queue is null, "Task is already scheduled to be resumed!");
assert(task.m_prev is null, "Task has m_prev set without being in a queue!?");
assert(task.m_next is null, "Task has m_next set without being in a queue!?");
for (auto t = last; t; t = t.m_prev) {
if (!max_skip-- || pred(t)) {
task.m_queue = &this;
task.m_next = t.m_next;
t.m_next = task;
task.m_prev = t;
if (!task.m_next) last = task;
length++;
return;
}
}
insertFront(task);
}
void popFront() void popFront()
{ {
if (first is last) last = null; if (first is last) last = null;
@ -1086,6 +1145,26 @@ unittest {
assert(q.empty && q.length == 0); assert(q.empty && q.length == 0);
} }
unittest {
auto f1 = new TaskFiber;
auto f2 = new TaskFiber;
auto f3 = new TaskFiber;
auto f4 = new TaskFiber;
auto f5 = new TaskFiber;
TaskFiberQueue q;
q.insertBackPred(f1, 0, delegate bool(tf) { assert(false); });
assert(q.first == f1 && q.last == f1);
q.insertBackPred(f2, 0, delegate bool(tf) { assert(false); });
assert(q.first == f1 && q.last == f2);
q.insertBackPred(f3, 1, (tf) => false);
assert(q.first == f1 && q.last == f2);
q.insertBackPred(f4, 10, (tf) => false);
assert(q.first == f4 && q.last == f2);
q.insertBackPred(f5, 10, (tf) => true);
assert(q.first == f4 && q.last == f5);
}
private struct FLSInfo { private struct FLSInfo {
void function(void[], size_t) fct; void function(void[], size_t) fct;
size_t offset; size_t offset;

View file

@ -1,7 +1,7 @@
/** /**
Multi-threaded task pool implementation. Multi-threaded task pool implementation.
Copyright: © 2012-2017 Sönke Ludwig Copyright: © 2012-2020 Sönke Ludwig
License: Subject to the terms of the MIT license, as written in the included LICENSE.txt file. License: Subject to the terms of the MIT license, as written in the included LICENSE.txt file.
Authors: Sönke Ludwig Authors: Sönke Ludwig
*/ */
@ -11,7 +11,7 @@ import vibe.core.concurrency : isWeaklyIsolated;
import vibe.core.core : exitEventLoop, logicalProcessorCount, runEventLoop, runTask, runTask_internal; import vibe.core.core : exitEventLoop, logicalProcessorCount, runEventLoop, runTask, runTask_internal;
import vibe.core.log; import vibe.core.log;
import vibe.core.sync : ManualEvent, Monitor, createSharedManualEvent, createMonitor; import vibe.core.sync : ManualEvent, Monitor, createSharedManualEvent, createMonitor;
import vibe.core.task : Task, TaskFuncInfo, callWithMove; import vibe.core.task : Task, TaskFuncInfo, TaskSettings, callWithMove;
import core.sync.mutex : Mutex; import core.sync.mutex : Mutex;
import core.thread : Thread; import core.thread : Thread;
import std.concurrency : prioritySend, receiveOnly; import std.concurrency : prioritySend, receiveOnly;
@ -113,16 +113,30 @@ shared final class TaskPool {
if (isFunctionPointer!FT) if (isFunctionPointer!FT)
{ {
foreach (T; ARGS) static assert(isWeaklyIsolated!T, "Argument type "~T.stringof~" is not safe to pass between threads."); foreach (T; ARGS) static assert(isWeaklyIsolated!T, "Argument type "~T.stringof~" is not safe to pass between threads.");
runTask_unsafe(func, args); runTask_unsafe(TaskSettings.init, func, args);
} }
/// ditto /// ditto
void runTask(alias method, T, ARGS...)(shared(T) object, auto ref ARGS args) void runTask(alias method, T, ARGS...)(shared(T) object, auto ref ARGS args)
if (is(typeof(__traits(getMember, object, __traits(identifier, method))))) if (is(typeof(__traits(getMember, object, __traits(identifier, method)))))
{ {
foreach (T; ARGS) static assert(isWeaklyIsolated!T, "Argument type "~T.stringof~" is not safe to pass between threads."); foreach (T; ARGS) static assert(isWeaklyIsolated!T, "Argument type "~T.stringof~" is not safe to pass between threads.");
auto func = &__traits(getMember, object, __traits(identifier, method)); auto func = &__traits(getMember, object, __traits(identifier, method));
runTask_unsafe(func, args); runTask_unsafe(TaskSettings.init, func, args);
}
/// ditto
void runTask(FT, ARGS...)(TaskSettings settings, FT func, auto ref ARGS args)
if (isFunctionPointer!FT)
{
foreach (T; ARGS) static assert(isWeaklyIsolated!T, "Argument type "~T.stringof~" is not safe to pass between threads.");
runTask_unsafe(settings, func, args);
}
/// ditto
void runTask(alias method, T, ARGS...)(TaskSettings settings, shared(T) object, auto ref ARGS args)
if (is(typeof(__traits(getMember, object, __traits(identifier, method)))))
{
foreach (T; ARGS) static assert(isWeaklyIsolated!T, "Argument type "~T.stringof~" is not safe to pass between threads.");
auto func = &__traits(getMember, object, __traits(identifier, method));
runTask_unsafe(settings, func, args);
} }
/** Runs a new asynchronous task in a worker thread, returning the task handle. /** Runs a new asynchronous task in a worker thread, returning the task handle.
@ -141,9 +155,9 @@ shared final class TaskPool {
// workaround for runWorkerTaskH to work when called outside of a task // workaround for runWorkerTaskH to work when called outside of a task
if (Task.getThis() == Task.init) { if (Task.getThis() == Task.init) {
Task ret; Task ret;
.runTask({ ret = doRunTaskH(func, args); }).join(); .runTask({ ret = doRunTaskH(TaskSettings.init, func, args); }).join();
return ret; return ret;
} else return doRunTaskH(func, args); } else return doRunTaskH(TaskSettings.init, func, args);
} }
/// ditto /// ditto
Task runTaskH(alias method, T, ARGS...)(shared(T) object, auto ref ARGS args) Task runTaskH(alias method, T, ARGS...)(shared(T) object, auto ref ARGS args)
@ -154,10 +168,32 @@ shared final class TaskPool {
} }
return runTaskH(&wrapper!(), object, args); return runTaskH(&wrapper!(), object, args);
} }
/// ditto
Task runTaskH(FT, ARGS...)(TaskSettings settings, FT func, auto ref ARGS args)
if (isFunctionPointer!FT)
{
foreach (T; ARGS) static assert(isWeaklyIsolated!T, "Argument type "~T.stringof~" is not safe to pass between threads.");
// workaround for runWorkerTaskH to work when called outside of a task
if (Task.getThis() == Task.init) {
Task ret;
.runTask({ ret = doRunTaskH(settings, func, args); }).join();
return ret;
} else return doRunTaskH(settings, func, args);
}
/// ditto
Task runTaskH(alias method, T, ARGS...)(TaskSettings settings, shared(T) object, auto ref ARGS args)
if (is(typeof(__traits(getMember, object, __traits(identifier, method)))))
{
static void wrapper()(shared(T) object, ref ARGS args) {
__traits(getMember, object, __traits(identifier, method))(args);
}
return runTaskH(settings, &wrapper!(), object, args);
}
// NOTE: needs to be a separate function to avoid recursion for the // NOTE: needs to be a separate function to avoid recursion for the
// workaround above, which breaks @safe inference // workaround above, which breaks @safe inference
private Task doRunTaskH(FT, ARGS...)(FT func, ref ARGS args) private Task doRunTaskH(FT, ARGS...)(TaskSettings settings, FT func, ref ARGS args)
if (isFunctionPointer!FT) if (isFunctionPointer!FT)
{ {
import std.typecons : Typedef; import std.typecons : Typedef;
@ -173,7 +209,7 @@ shared final class TaskPool {
caller.tid.prioritySend(callee); caller.tid.prioritySend(callee);
mixin(callWithMove!ARGS("func", "args")); mixin(callWithMove!ARGS("func", "args"));
} }
runTask_unsafe(&taskFun, caller, func, args); runTask_unsafe(settings, &taskFun, caller, func, args);
return cast(Task)() @trusted { return receiveOnly!PrivateTask(); } (); return cast(Task)() @trusted { return receiveOnly!PrivateTask(); } ();
} }
@ -191,7 +227,7 @@ shared final class TaskPool {
if (is(typeof(*func) == function)) if (is(typeof(*func) == function))
{ {
foreach (T; ARGS) static assert(isWeaklyIsolated!T, "Argument type "~T.stringof~" is not safe to pass between threads."); foreach (T; ARGS) static assert(isWeaklyIsolated!T, "Argument type "~T.stringof~" is not safe to pass between threads.");
runTaskDist_unsafe(func, args); runTaskDist_unsafe(TaskSettings.init, func, args);
} }
/// ditto /// ditto
void runTaskDist(alias method, T, ARGS...)(shared(T) object, auto ref ARGS args) void runTaskDist(alias method, T, ARGS...)(shared(T) object, auto ref ARGS args)
@ -199,7 +235,22 @@ shared final class TaskPool {
auto func = &__traits(getMember, object, __traits(identifier, method)); auto func = &__traits(getMember, object, __traits(identifier, method));
foreach (T; ARGS) static assert(isWeaklyIsolated!T, "Argument type "~T.stringof~" is not safe to pass between threads."); foreach (T; ARGS) static assert(isWeaklyIsolated!T, "Argument type "~T.stringof~" is not safe to pass between threads.");
runTaskDist_unsafe(func, args); runTaskDist_unsafe(TaskSettings.init, func, args);
}
/// ditto
void runTaskDist(FT, ARGS...)(TaskSettings settings, FT func, auto ref ARGS args)
if (is(typeof(*func) == function))
{
foreach (T; ARGS) static assert(isWeaklyIsolated!T, "Argument type "~T.stringof~" is not safe to pass between threads.");
runTaskDist_unsafe(settings, func, args);
}
/// ditto
void runTaskDist(alias method, T, ARGS...)(TaskSettings settings, shared(T) object, auto ref ARGS args)
{
auto func = &__traits(getMember, object, __traits(identifier, method));
foreach (T; ARGS) static assert(isWeaklyIsolated!T, "Argument type "~T.stringof~" is not safe to pass between threads.");
runTaskDist_unsafe(settings, func, args);
} }
/** Runs a new asynchronous task in all worker threads and returns the handles. /** Runs a new asynchronous task in all worker threads and returns the handles.
@ -232,7 +283,7 @@ shared final class TaskPool {
on_handle(receiveOnly!Task); on_handle(receiveOnly!Task);
} }
private void runTask_unsafe(CALLABLE, ARGS...)(CALLABLE callable, ref ARGS args) private void runTask_unsafe(CALLABLE, ARGS...)(TaskSettings settings, CALLABLE callable, ref ARGS args)
{ {
import std.traits : ParameterTypeTuple; import std.traits : ParameterTypeTuple;
import vibe.internal.traits : areConvertibleTo; import vibe.internal.traits : areConvertibleTo;
@ -242,11 +293,11 @@ shared final class TaskPool {
static assert(areConvertibleTo!(Group!ARGS, Group!FARGS), static assert(areConvertibleTo!(Group!ARGS, Group!FARGS),
"Cannot convert arguments '"~ARGS.stringof~"' to function arguments '"~FARGS.stringof~"'."); "Cannot convert arguments '"~ARGS.stringof~"' to function arguments '"~FARGS.stringof~"'.");
m_state.lock.queue.put(callable, args); m_state.lock.queue.put(settings, callable, args);
m_signal.emitSingle(); m_signal.emitSingle();
} }
private void runTaskDist_unsafe(CALLABLE, ARGS...)(ref CALLABLE callable, ARGS args) // NOTE: no ref for args, to disallow non-copyable types! private void runTaskDist_unsafe(CALLABLE, ARGS...)(TaskSettings settings, ref CALLABLE callable, ARGS args) // NOTE: no ref for args, to disallow non-copyable types!
{ {
import std.traits : ParameterTypeTuple; import std.traits : ParameterTypeTuple;
import vibe.internal.traits : areConvertibleTo; import vibe.internal.traits : areConvertibleTo;
@ -260,7 +311,7 @@ shared final class TaskPool {
auto st = m_state.lock; auto st = m_state.lock;
foreach (thr; st.threads) { foreach (thr; st.threads) {
// create one TFI per thread to properly account for elaborate assignment operators/postblit // create one TFI per thread to properly account for elaborate assignment operators/postblit
thr.m_queue.put(callable, args); thr.m_queue.put(settings, callable, args);
} }
} }
m_signal.emit(); m_signal.emit();
@ -355,12 +406,13 @@ nothrow @safe:
@property size_t length() const { return m_queue.length; } @property size_t length() const { return m_queue.length; }
void put(CALLABLE, ARGS...)(ref CALLABLE c, ref ARGS args) void put(CALLABLE, ARGS...)(TaskSettings settings, ref CALLABLE c, ref ARGS args)
{ {
import std.algorithm.comparison : max; import std.algorithm.comparison : max;
if (m_queue.full) m_queue.capacity = max(16, m_queue.capacity * 3 / 2); if (m_queue.full) m_queue.capacity = max(16, m_queue.capacity * 3 / 2);
assert(!m_queue.full); assert(!m_queue.full);
m_queue.peekDst[0].settings = settings;
m_queue.peekDst[0].set(c, args); m_queue.peekDst[0].set(c, args);
m_queue.putN(1); m_queue.putN(1);
} }