All Downloads are FREE. Search and download functionalities are using the official Maven repository.

org.apache.ratis.util.ConcurrentUtils Maven / Gradle / Ivy

There is a newer version: 3.1.2
Show newest version
/*
 * Licensed to the Apache Software Foundation (ASF) under one
 * or more contributor license agreements.  See the NOTICE file
 * distributed with this work for additional information
 * regarding copyright ownership.  The ASF licenses this file
 * to you under the Apache License, Version 2.0 (the
 * "License"); you may not use this file except in compliance
 * with the License.  You may obtain a copy of the License at
 *
 *     http://www.apache.org/licenses/LICENSE-2.0
 *
 * Unless required by applicable law or agreed to in writing, software
 * distributed under the License is distributed on an "AS IS" BASIS,
 * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
package org.apache.ratis.util;

import org.apache.ratis.util.function.CheckedConsumer;
import org.apache.ratis.util.function.CheckedFunction;

import java.util.ArrayList;
import java.util.Collection;
import java.util.List;
import java.util.concurrent.CompletableFuture;
import java.util.concurrent.Executor;
import java.util.concurrent.ExecutorService;
import java.util.concurrent.Executors;
import java.util.concurrent.LinkedBlockingQueue;
import java.util.concurrent.ThreadFactory;
import java.util.concurrent.ThreadPoolExecutor;
import java.util.concurrent.TimeUnit;
import java.util.concurrent.atomic.AtomicInteger;
import java.util.concurrent.atomic.AtomicReference;
import java.util.function.Consumer;
import java.util.stream.Stream;

/**
 * Utilities related to concurrent programming.
 */
public interface ConcurrentUtils {
  /**
   * Similar to {@link AtomicReference#updateAndGet(java.util.function.UnaryOperator)}
   * except that the update function is checked.
   */
  static  E updateAndGet(AtomicReference reference,
      CheckedFunction update) throws THROWABLE {
    final AtomicReference throwableRef = new AtomicReference<>();
    final E updated = reference.updateAndGet(value -> {
      try {
        return update.apply(value);
      } catch (Error | RuntimeException e) {
        throw e;
      } catch (Throwable t) {
        throwableRef.set(t);
        return value;
      }
    });
    @SuppressWarnings("unchecked")
    final THROWABLE t = (THROWABLE) throwableRef.get();
    if (t != null) {
      throw t;
    }
    return updated;
  }

  /**
   * Creates a {@link ThreadFactory} so that the threads created by the factory are named with the given name prefix.
   *
   * @param namePrefix the prefix used in the name of the threads created.
   * @return a new {@link ThreadFactory}.
   */
  static ThreadFactory newThreadFactory(String namePrefix) {
    final AtomicInteger numThread = new AtomicInteger();
    return runnable -> {
      final int id = numThread.incrementAndGet();
      final Thread t = new Thread(runnable);
      t.setName(namePrefix + "-thread" + id);
      return t;
    };
  }

  /**
    * This method is similar to {@link java.util.concurrent.Executors#newSingleThreadExecutor(ThreadFactory)}
    * except that this method takes a specific thread name as there is only one thread.g
    *
    * @param name the thread name for only one thread.
    * @return a new {@link ExecutorService}.
    */
  static ExecutorService newSingleThreadExecutor(String name) {
      return Executors.newSingleThreadExecutor(runnable -> {
          final Thread t = new Thread(runnable);
          t.setName(name);
          return t;
        });
  }

  /**
   * The same as {@link java.util.concurrent.Executors#newCachedThreadPool(ThreadFactory)}
   * except that this method takes a maximumPoolSize parameter.
   *
   * @param maximumPoolSize the maximum number of threads to allow in the pool.
   *                        When maximumPoolSize == 0, this method is the same as
   *                        {@link java.util.concurrent.Executors#newCachedThreadPool(ThreadFactory)}.
   * @return a new {@link ExecutorService}.
   */
  static ExecutorService newCachedThreadPool(int maximumPoolSize, ThreadFactory threadFactory) {
    return maximumPoolSize == 0? Executors.newCachedThreadPool(threadFactory)
        : new ThreadPoolExecutor(0, maximumPoolSize, 60L, TimeUnit.SECONDS,
        new LinkedBlockingQueue<>(), threadFactory);
  }

  /**
   * Create a new {@link ExecutorService} with a maximum pool size.
   * If it is cached, this method is similar to {@link #newCachedThreadPool(int, ThreadFactory)}.
   * Otherwise, this method is similar to {@link java.util.concurrent.Executors#newFixedThreadPool(int)}.
   *
   * @param cached Use cached thread pool?  If not, use a fixed thread pool.
   * @param maximumPoolSize the maximum number of threads to allow in the pool.
   * @param namePrefix the prefix used in the name of the threads created.
   * @return a new {@link ExecutorService}.
   */
  static ExecutorService newThreadPoolWithMax(boolean cached, int maximumPoolSize, String namePrefix) {
    final ThreadFactory f = newThreadFactory(namePrefix);
    return cached ? newCachedThreadPool(maximumPoolSize, f)
        : Executors.newFixedThreadPool(maximumPoolSize, f);
  }

  /**
   * Shutdown the given executor and wait for its termination.
   *
   * @param executor The executor to be shut down.
   */
  static void shutdownAndWait(ExecutorService executor) {
    shutdownAndWait(TimeDuration.ONE_DAY, executor, timeout -> {
      throw new IllegalStateException(executor.getClass().getName() + " shutdown timeout in " + timeout);
    });
  }

  static void shutdownAndWait(TimeDuration waitTime, ExecutorService executor, Consumer timoutHandler) {
    executor.shutdown();
    try {
      if (executor.awaitTermination(waitTime.getDuration(), waitTime.getUnit())) {
        return;
      }
    } catch (InterruptedException ignored) {
      Thread.currentThread().interrupt();
      return;
    }
    if (timoutHandler != null) {
      timoutHandler.accept(waitTime);
    }
  }

  /**
   * The same as {@link Collection#parallelStream()}.forEach(action) except that
   * (1) this method is asynchronous,
   * (2) this method has an executor parameter, and
   * (3) the action can throw a checked exception.
   *
   * @param stream The stream to be processed.
   * @param size The estimated size of the stream.
   * @param action To act on each element in the stream.
   * @param executor To execute the action.
   * @param  The element type.
   * @param  the exception type.
   *
   * @return a {@link CompletableFuture} that is completed
   *         when the action is completed for each element in the collection.
   *         When the action throws an exception, the future will be completed exceptionally.
   *
   * @see Collection#parallelStream()
   * @see java.util.stream.Stream#forEach(Consumer)
   */
  static  CompletableFuture parallelForEachAsync(
      Stream stream, int size, CheckedConsumer action, Executor executor) {
    final List> futures = new ArrayList<>(size);
    stream.forEach(element -> {
      final CompletableFuture f = new CompletableFuture<>();
      futures.add(f);
      executor.execute(() -> accept(action, element, f));
    });
    return JavaUtils.allOf(futures);
  }

  /** The same as parallelForEachAsync(collection.stream(), collection.size(), action, executor). */
  static  CompletableFuture parallelForEachAsync(
      Collection collection, CheckedConsumer action, Executor executor) {
    return parallelForEachAsync(collection.stream(), collection.size(), action, executor);
  }

  /** The same as parallelForEachAsync(collection.stream(), collection.size(), action, executor). */
  static  CompletableFuture parallelForEachAsync(
      int size, CheckedConsumer action, Executor executor) {
    final AtomicInteger i = new AtomicInteger();
    return parallelForEachAsync(Stream.generate(i::getAndIncrement).limit(size), size, action, executor);
  }

  static  void accept(
      CheckedConsumer action, E element, CompletableFuture f) {
    try {
      action.accept(element);
      f.complete(element);
    } catch (Throwable t) {
      f.completeExceptionally(t);
    }
  }
}




© 2015 - 2025 Weber Informatics LLC | Privacy Policy