gpt4 book ai didi

java - Reactor 2.0 中的多线程 - 为什么我不能将信号输出到多个线程

转载 作者:行者123 更新时间:2023-12-01 11:43:30 25 4
gpt4 key购买 nike

我在 Reactor 2.0 版本中遇到了问题。也就是说,我试图建立一个响应式(Reactive)信号流,将信号扇出到等待线程池中。我非常熟悉 Rx 和 Reactive Cocoa,但我在这里缺少一些基本的东西。

我有一个基本的转换如下:

 WorkQueueDispatcher dispatcher = new WorkQueueDispatcher("dispatch", 10, 64, {... Exception handle code here ...}


return objectStream
.partition(partitions)
.dispatchOn(dispatcher)
.merge()
.map(new Function<Object, Object>() {
@Override
public Object apply(Object o) {
try {
return extension.eval(o, null);
} catch (UnableToEvaluateException e) {
e.printStackTrace();
return null;
}

}
});
我已经尝试了大约七八种不同的方式,包括不同的调度程序等。我尝试将其分解为分组事件流,并单独处理每个元素,然后写入单独的流进行处理。在每种情况下,我要么看到每个请求在同一线程上处理(这有效,而不是多线程),要么收到我害怕的错误消息:

   java.lang.IllegalStateException: Dispatcher provided doesn't support event     ordering.  For concurrent signal dispatching, refer to #partition()/groupBy()     method and assign individual single dispatchers. 
at reactor.core.support.Assert.state(Assert.java:387)
at reactor.rx.Stream.dispatchOn(Stream.java:720)
at reactor.rx.Stream.dispatchOn(Stream.java:650)

我尝试过以下方法:

  1. 手动进行分区/分组。
  2. 为前面的步骤显式设置一个单独的单线程调度程序(环)。
  3. 只是说 eff 它,没有功能,只是转储到我自己的队列中进行处理。

我在这里缺少什么?我不应该使用广播器来启动消息循环吗?我真的根本不关心这里的订单执行。

(已编辑)

以下是我使用自己开发的横向扩展代码所做的事情:

objectStream
.consume(new Consumer<Object>() {
@Override
public void accept(Object o) {
final Object target = o;
tpe.execute(new Runnable(){
/**
* When an object implementing interface <code>Runnable</code> is used
* to create a thread, starting the thread causes the object's
* <code>run</code> method to be called in that separately executing
* thread.
* <p/>
* The general contract of the method <code>run</code> is that it may
* take any action whatsoever.
*
* @see Thread#run()
*/
@Override
public void run() {
try {
//System.out.println("On thread "+ Thread.currentThread().getName());
Timer.Context onNext = onNextTimer.time();
Timer.Context timer = callComponentTimer.time();
Object translated = extension.eval(target, null);
timer.close();
broadcaster.onNext(translated);
onNext.close();
} catch (UnableToEvaluateException e) {
e.printStackTrace();
}
}
});

编辑

好的,我更新如下:

 MetricRegistry reg = DMPContext.getContext().getMetricRegistry();


de.init(null);


ConsoleReporter reporter = ConsoleReporter.forRegistry(DMPContext.getContext().getMetricRegistry())
.convertRatesTo(TimeUnit.SECONDS)
.convertDurationsTo(TimeUnit.MILLISECONDS)
.build();

reporter.start(10, TimeUnit.SECONDS);

final CountDownLatch latch = new CountDownLatch(COUNT);

final Function<String, Object> translator = JSON.from(Request.class);
String content = new String(Files.readAllBytes(Paths.get("/svn/DMPidea/Request.json")));

Broadcaster<String> stringBroadcaster = Broadcaster.create();

final Exec exec = new Exec();


stringBroadcaster
.partition(10)
.consume(new Consumer<GroupedStream<Integer, String>>() {
@Override
public void accept(GroupedStream<Integer, String> groupedStream) {

groupedStream.dispatchOn(Environment.cachedDispatcher()).map(translator).map(new Function<Object, Object>() {
@Override
public Object apply(Object o) {
try {
System.out.println("Got thread " +Thread.currentThread().getName());
return de.eval(o, null);
} catch (UnableToEvaluateException e) {
e.printStackTrace();
return null;
}
}
}).consume(new Consumer<Object>() {
@Override
public void accept(Object o) {
latch.countDown();
}
});
}
});

for (int i=0; i<COUNT; i++)
{

stringBroadcaster.onNext(content);

}
latch.await();

我仍然看到单线程执行:

获得线程dispatcherGroup-1获得线程 DispatcherGroup-1获得线程 DispatcherGroup-1获得线程 DispatcherGroup-1获得线程 DispatcherGroup-1获得线程 DispatcherGroup-1得到线程dispatcherGroup-1

最佳答案

Reactor2.0中的模式是使用单独的CachedDispatcher s ( RingBufferDispatcher s) 而不是使用 WorkQueueDispatcherThreadPoolExecutorDispatcher 。这提供了将流分割成不同的线程。这适用于将小型(通常是非阻塞)操作并行化为逻辑流。

要在单独的线程池中完全非阻塞执行,请参阅底部的我的编辑。

您将需要使用 Stream.groupBy() 或 Stream.partition() 将流拆分为多个流,每个流都可以在单独的线程上分派(dispatch)。

  1. Stream.groupBy() - 根据您返回的键将数据桶放入流中
  2. Stream.partition([int]) - 根据流对象(信号)的 hashCode 将存储桶存储到流中,也可以选择存储到您指定的存储桶数量

将流分区/分组为单独的流后,您可以使用 flatMap()告诉您的新流分派(dispatch)到单独的线程上。

.flatMap(stream -> stream.dispatchOn(Environment.cachedDispatcher())

调用Environment.cachedDispatcher()实际上得到了 CachedDispatcher (RingBufferDispatcher) 来自它们的池。默认情况下,池的大小等于计算机的处理器数量。 CachedDispatcher是延迟创建的,因此在对 .dispatchOn(Dispatcher) 的调用中执行此操作并不理想。 .

创建 DispatcherSupplier 的池 ( CachedDispatchers )事先,您可以使用Environment.newCachedDispatchers(int, [groupName]) 。以下是 ProjectReactor 文档中的一个示例,说明如何组合所有这些:

    DispatcherSupplier supplier1 = Environment.newCachedDispatchers(2, "groupByPool");
DispatcherSupplier supplier2 = Environment.newCachedDispatchers(5, "partitionPool");

Streams
.range(1, 10)
.groupBy(n -> n % 2 == 0)
.flatMap(stream -> stream
.dispatchOn(supplier1.get())
.log("groupBy")
)
.partition(5)
.flatMap(stream -> stream
.dispatchOn(supplier2.get())
.log("partition")
)
.dispatchOn(Environment.sharedDispatcher())
.log("join")
.consume();

Reactor Docs: Partitioning Streams into separate threads

请注意,在此示例中,他们还称为 .dispatchOn(Environment.sharedDispatcher())最后flatMap()之后称呼。这只是将流重新加入到单个 Dispatcher 中。线。在这种情况下 Environment.sharedDispatcher() ,这是另一个RingBufferDispatcher .

我使用此策略将流划分为单独的线程,以便在单独的CachedDispatcher上并行进行阻塞调用。 s,然后将它们重新加入到主 Environment.sharedDispatcher() 上的单个线程中,全部以非阻塞/响应式(Reactive)方式进行,如下所示:

    // Spring's RestTemplate for making simple REST (HTTP) calls
RestTemplate restTemplate = new RestTemplate();
List<String> urls = Arrays.asList("http://www.google.com", "http://www.imgur.com");
Streams
.from(urls)
.groupBy(s -> s) // unique group (stream) per URL
.flatMap(stream ->
// dispatch on separate threads per stream
stream.dispatchOn(Environment.cachedDispatcher())
// blocking call in separate dispatching thread
.map(s -> restTemplate.getForObject(s, String.class)))
// rejoin into single dispatcher thread
.dispatchOn(Environment.sharedDispatcher())
.consume(
s -> { // consumer
System.out.println("---complete in stream---");
},
t -> { // error consumer
System.out.println("---exception---");
System.out.println(t);
},
s -> { // complete consumer
latch.countDown();
System.out.println("---complete---");
});



编辑:为了并行执行阻塞操作,您可能仍然需要使用线程池。在 Reactor 2.0 中,您可以使用由线程池(最好是 Executors.newCachedThreadPool())支持的调度程序来完成此操作。因为它会重用线程来限制 GC 压力。

我发现执行此操作的最简单方法是使用 EventBus使用ThreadPoolExecutorDispatcherExecutors.newCachedThreadPool() 支持(如果您查看创建 newCachedThreadPool 的函数,这实际上只是一个带有一些特定设置的 ThreadPoolExecutor):

    // dispatcher backed by cached thread pool for limited GC pressure
Dispatcher dispatcher = new ThreadPoolExecutorDispatcher(1024, 1024, Executors.newCachedThreadPool());

int n = 1000000;
EventBus bus = EventBus.create(dispatcher);
CountDownLatch latch = new CountDownLatch(n);
bus.on($("topic"), (Event<Integer> ev) -> {
blockingServiceCall(100); // block for 100ms
latch.countDown();
if (ev.getData() % 1000 == 0) {
System.out.println(Thread.currentThread() + " " + Thread.activeCount());
}
});

long start = System.currentTimeMillis();
for(int i = 0; i < n; i++) {
bus.notify("topic", Event.wrap(i));
}
latch.await();
System.out.println("ops/sec: " + (n * 1.0) / ((System.currentTimeMillis() - start) / 1000.0) );

如果您想返回使用 Streams,则需要在消费者内部完成阻塞调用后分派(dispatch)回 Stream。据我所知,您不能简单地将它们自动合并回流中,也不能通过执行 Stream.dispatchOn(threadPoolExecutorDispatcher) 直接使用由缓存线程池支持的 ThreadPoolExecutorDispatcher .

关于java - Reactor 2.0 中的多线程 - 为什么我不能将信号输出到多个线程,我们在Stack Overflow上找到一个类似的问题: https://stackoverflow.com/questions/29324341/

25 4 0
Copyright 2021 - 2024 cfsdn All Rights Reserved 蜀ICP备2022000587号
广告合作:1813099741@qq.com 6ren.com