data:image/s3,"s3://crabby-images/02ace/02ace956f9868cf2a1a780bd2c0a517cd3a46077" alt="JAR search and dependency download from the Maven repository"
org.rx.core.ThreadPool Maven / Gradle / Ivy
package org.rx.core;
import com.google.common.util.concurrent.ThreadFactoryBuilder;
import com.sun.management.OperatingSystemMXBean;
import io.netty.util.HashedWheelTimer;
import io.netty.util.Timeout;
import io.netty.util.TimerTask;
import io.netty.util.concurrent.FastThreadLocal;
import io.netty.util.concurrent.FastThreadLocalThread;
import io.netty.util.internal.InternalThreadLocalMap;
import lombok.*;
import lombok.extern.slf4j.Slf4j;
import org.apache.commons.collections4.CollectionUtils;
import org.rx.bean.*;
import org.rx.exception.ExceptionHandler;
import org.rx.exception.InvalidException;
import org.rx.util.function.Action;
import org.rx.util.function.Func;
import java.lang.management.ManagementFactory;
import java.util.*;
import java.util.concurrent.*;
import java.util.concurrent.atomic.AtomicInteger;
import java.util.concurrent.locks.ReentrantLock;
import java.util.function.Supplier;
import static org.rx.core.Constants.NON_UNCHECKED;
import static org.rx.core.Extends.*;
@SuppressWarnings(NON_UNCHECKED)
@Slf4j
public class ThreadPool extends ThreadPoolExecutor {
@RequiredArgsConstructor
@Getter
public static class MultiTaskFuture {
static final MultiTaskFuture NULL = new MultiTaskFuture<>(CompletableFuture.completedFuture(null), new CompletableFuture[0]);
final CompletableFuture future;
final CompletableFuture[] subFutures;
}
@RequiredArgsConstructor
public static class ThreadQueue extends LinkedTransferQueue {
private static final long serialVersionUID = 4283369202482437480L;
final int queueCapacity;
//todo cache len
final AtomicInteger counter = new AtomicInteger();
public boolean isFullLoad() {
return counter.get() >= queueCapacity;
}
@Override
public int size() {
return counter.get();
}
@SneakyThrows
@Override
public boolean offer(T t) {
if (isFullLoad()) {
boolean logged = false;
while (isFullLoad()) {
if (!logged) {
log.warn("Block caller thread[{}] until queue[{}/{}] polled then offer {}", Thread.currentThread().getName(),
counter.get(), queueCapacity, t);
logged = true;
}
synchronized (this) {
wait(500);
}
}
log.debug("Wait poll ok");
}
counter.incrementAndGet();
return super.offer(t);
}
@Override
public T poll(long timeout, TimeUnit unit) throws InterruptedException {
boolean ok = true;
try {
T t = super.poll(timeout, unit);
ok = t != null;
return t;
} catch (InterruptedException e) {
ok = false;
throw e;
} finally {
if (ok) {
log.debug("Notify poll");
doNotify();
}
}
}
@Override
public T take() throws InterruptedException {
try {
return super.take();
} finally {
log.debug("Notify take");
doNotify();
}
}
@Override
public boolean remove(Object o) {
boolean ok = super.remove(o);
if (ok) {
log.debug("Notify remove");
doNotify();
}
return ok;
}
private void doNotify() {
int c = counter.decrementAndGet();
synchronized (this) {
if (c < 0) {
counter.set(super.size());
ExceptionHandler.INSTANCE.saveMetrics(Constants.THREAD_POOL_QUEUE, String.format("FIX SIZE %s -> %s", c, counter));
}
notify();
}
}
}
static class Task implements Runnable, Callable, Supplier {
final InternalThreadLocalMap parent;
final Object id;
final FlagsEnum flags;
final Func fn;
Task(Object id, FlagsEnum flags, Func fn) {
if (flags == null) {
flags = RunFlag.NONE.flags();
}
if (RxConfig.INSTANCE.threadPool.enableInheritThreadLocals) {
flags.add(RunFlag.INHERIT_THREAD_LOCALS);
}
this.id = id;
this.flags = flags;
parent = flags.has(RunFlag.INHERIT_THREAD_LOCALS) ? InternalThreadLocalMap.getIfSet() : null;
this.fn = fn;
}
@SneakyThrows
@Override
public T call() {
try {
return fn.invoke();
} catch (Throwable e) {
ExceptionHandler.INSTANCE.log(toString(), e);
throw e;
}
}
@Override
public void run() {
call();
}
@Override
public T get() {
return call();
}
@Override
public String toString() {
return String.format("Task-%s[%s]", ifNull(id, 0), flags.getValue());
}
}
static class FutureTaskAdapter extends FutureTask {
final Task task;
public FutureTaskAdapter(Callable callable) {
super(callable);
task = as(callable, Task.class);
}
public FutureTaskAdapter(Runnable runnable, T result) {
super(runnable, result);
task = (Task) runnable;
}
}
static class TaskContext {
ReentrantLock lock;
AtomicInteger lockRefCnt;
}
static class DynamicSizer implements TimerTask {
static final long SAMPLING_PERIOD = 3000L;
static final int SAMPLING_TIMES = 2;
final OperatingSystemMXBean os = (OperatingSystemMXBean) ManagementFactory.getOperatingSystemMXBean();
final HashedWheelTimer timer = new HashedWheelTimer(newThreadFactory("DynamicSizer"), 800L, TimeUnit.MILLISECONDS, 8);
final Map> hold = Collections.synchronizedMap(new WeakHashMap<>(8));
DynamicSizer() {
timer.newTimeout(this, SAMPLING_PERIOD, TimeUnit.MILLISECONDS);
}
@Override
public void run(Timeout timeout) throws Exception {
try {
Decimal cpuLoad = Decimal.valueOf(os.getSystemCpuLoad() * 100);
for (Map.Entry> entry : hold.entrySet()) {
ThreadPoolExecutor pool = entry.getKey();
if (pool instanceof ScheduledExecutorService) {
scheduledThread(cpuLoad, pool, entry.getValue());
continue;
}
thread(cpuLoad, pool, entry.getValue());
}
} finally {
timer.newTimeout(this, SAMPLING_PERIOD, TimeUnit.MILLISECONDS);
}
}
private void thread(Decimal cpuLoad, ThreadPoolExecutor pool, BiTuple tuple) {
IntWaterMark waterMark = tuple.left;
int decrementCounter = tuple.middle;
int incrementCounter = tuple.right;
String prefix = pool.toString();
if (log.isDebugEnabled()) {
log.debug("{} PoolSize={}+[{}] Threshold={}[{}-{}]% de/incrementCounter={}/{}", prefix,
pool.getPoolSize(), pool.getQueue().size(),
cpuLoad, waterMark.getLow(), waterMark.getHigh(), decrementCounter, incrementCounter);
}
if (cpuLoad.gt(waterMark.getHigh())) {
if (++decrementCounter >= SAMPLING_TIMES) {
log.info("{} PoolSize={}+[{}] Threshold={}[{}-{}]% decrement to {}", prefix,
pool.getPoolSize(), pool.getQueue().size(),
cpuLoad, waterMark.getLow(), waterMark.getHigh(), decrSize(pool));
decrementCounter = 0;
}
} else {
decrementCounter = 0;
}
if (!pool.getQueue().isEmpty() && cpuLoad.lt(waterMark.getLow())) {
if (++incrementCounter >= SAMPLING_TIMES) {
log.info("{} PoolSize={}+[{}] Threshold={}[{}-{}]% increment to {}", prefix,
pool.getPoolSize(), pool.getQueue().size(),
cpuLoad, waterMark.getLow(), waterMark.getHigh(), incrSize(pool));
incrementCounter = 0;
}
} else {
incrementCounter = 0;
}
tuple.middle = decrementCounter;
tuple.right = incrementCounter;
}
private void scheduledThread(Decimal cpuLoad, ThreadPoolExecutor pool, BiTuple tuple) {
IntWaterMark waterMark = tuple.left;
int decrementCounter = tuple.middle;
int incrementCounter = tuple.right;
String prefix = pool.toString();
int active = pool.getActiveCount();
int size = pool.getCorePoolSize();
float idle = (float) active / size * 100;
log.debug("{} PoolSize={} QueueSize={} Threshold={}[{}-{}]% idle={} de/incrementCounter={}/{}", prefix,
pool.getCorePoolSize(), pool.getQueue().size(),
cpuLoad, waterMark.getLow(), waterMark.getHigh(), 100 - idle, decrementCounter, incrementCounter);
if (size > MIN_CORE_SIZE && (idle <= waterMark.getHigh() || cpuLoad.gt(waterMark.getHigh()))) {
if (++decrementCounter >= SAMPLING_TIMES) {
log.info("{} Threshold={}[{}-{}]% idle={} decrement to {}", prefix,
cpuLoad, waterMark.getLow(), waterMark.getHigh(), 100 - idle, decrSize(pool));
decrementCounter = 0;
}
} else {
decrementCounter = 0;
}
if (active >= size && cpuLoad.lt(waterMark.getLow())) {
if (++incrementCounter >= SAMPLING_TIMES) {
log.info("{} Threshold={}[{}-{}]% increment to {}", prefix,
cpuLoad, waterMark.getLow(), waterMark.getHigh(), incrSize(pool));
incrementCounter = 0;
}
} else {
incrementCounter = 0;
}
tuple.middle = decrementCounter;
tuple.right = incrementCounter;
}
public void register(ThreadPoolExecutor pool, IntWaterMark cpuWaterMark) {
if (cpuWaterMark == null) {
return;
}
hold.put(pool, BiTuple.of(cpuWaterMark, 0, 0));
}
}
//region static members
static final String POOL_NAME_PREFIX = "℞Threads-";
static final IntWaterMark DEFAULT_CPU_WATER_MARK = new IntWaterMark(RxConfig.INSTANCE.threadPool.lowCpuWaterMark,
RxConfig.INSTANCE.threadPool.highCpuWaterMark);
static final int MIN_CORE_SIZE = 2, MAX_CORE_SIZE = 1000;
static final DynamicSizer SIZER = new DynamicSizer();
static final FastThreadLocal ASYNC_CONTINUE = new FastThreadLocal<>();
static ThreadFactory newThreadFactory(String name) {
//setUncaughtExceptionHandler跟全局ExceptionHandler.INSTANCE重复
return new ThreadFactoryBuilder().setThreadFactory(FastThreadLocalThread::new)
.setDaemon(true).setNameFormat(String.format("%s%s-%%d", POOL_NAME_PREFIX, name)).build();
}
static int incrSize(ThreadPoolExecutor pool) {
int poolSize = pool.getCorePoolSize() + RxConfig.INSTANCE.threadPool.resizeQuantity;
if (poolSize > MAX_CORE_SIZE) {
return MAX_CORE_SIZE;
}
pool.setCorePoolSize(poolSize);
return poolSize;
}
static int decrSize(ThreadPoolExecutor pool) {
int poolSize = Math.max(MIN_CORE_SIZE, pool.getCorePoolSize() - RxConfig.INSTANCE.threadPool.resizeQuantity);
pool.setCorePoolSize(poolSize);
return poolSize;
}
static boolean asyncContinueFlag(boolean def) {
Boolean ac = ASYNC_CONTINUE.getIfExists();
ASYNC_CONTINUE.remove();
if (ac == null) {
return def;
}
return ac;
}
public static int computeThreads(double cpuUtilization, long waitTime, long cpuTime) {
require(cpuUtilization, 0 <= cpuUtilization && cpuUtilization <= 1);
return (int) Math.max(Constants.CPU_THREADS, Math.floor(Constants.CPU_THREADS * cpuUtilization * (1 + (double) waitTime / cpuTime)));
}
//endregion
//region instance members
@Getter
final String poolName;
final Map> taskMap = new ConcurrentHashMap<>();
final Map
© 2015 - 2025 Weber Informatics LLC | Privacy Policy