@Override public List<Item> makeRecommendation( String key, long userId, long numRecs, boolean isBoolean, List<String> displayColumns) { if (!this.loop.isAlive()) { Thread training = new Thread(new RecommenderRunnable()); training.setName("Training Thread"); this.loop = training; this.loop.start(); } if (!this.terminateModelRecs.isAlive()) { Thread terminateModel = new Thread(new TerminateModels()); terminateModel.setName("Terminate Model Thread"); this.terminateModelRecs = terminateModel; this.terminateModelRecs.start(); } if (key != null) { if (SESSIONS.get(key) != null) { return SESSIONS.get(key).makeRecommendation(userId, numRecs, isBoolean, displayColumns); } } return null; }
@Override public List<Item> getUserRatedItems(String key, long userId, List<String> displayColumns) { if (key != null) { if (SESSIONS.get(key) != null) { Thread.currentThread().setPriority(Thread.MAX_PRIORITY); return SESSIONS.get(key).getUserRatedItems(userId, displayColumns); } } if (!this.loop.isAlive()) { Thread training = new Thread(new RecommenderRunnable()); training.setName("Training Thread"); this.loop = training; this.loop.start(); } if (!this.terminateModelRecs.isAlive()) { Thread terminateModel = new Thread(new TerminateModels()); terminateModel.setName("Terminate Model Thread"); this.terminateModelRecs = terminateModel; this.terminateModelRecs.start(); } return null; }
@Override public void run() { try { batchImporter.importBatch(userId, target, batch, replaceExisting, dryRun); } catch (final Throwable t) { Throwable rootCause = getRootCause(t); String rootCauseClassName = rootCause.getClass().getName(); if (importStatus.isStopping() && (rootCause instanceof InterruptedException || rootCause instanceof ClosedByInterruptException || "com.hazelcast.core.RuntimeInterruptedException" .equals(rootCauseClassName))) // For compatibility across 4.x *sigh* { // A stop import was requested if (debug(log)) debug(log, Thread.currentThread().getName() + " was interrupted by a stop request.", t); Thread.currentThread().interrupt(); } else { // An unexpected exception during import of the batch - log it and kill the entire import error(log, "Bulk import from '" + source.getName() + "' failed.", t); importStatus.unexpectedError(t); if (debug(log)) debug(log, "Shutting down import thread pool."); importThreadPool.shutdownNow(); } } }
public KibitzServer(MysqlDataSource dataSource) { this.dataSource = dataSource; // Start thread to continuously train recommenders and terminate recommenders if (this.loop == null) { Thread training = new Thread(new RecommenderRunnable()); Thread terminateModel = new Thread(new TerminateModels()); training.setName("Training Thread"); terminateModel.setName("Terminate Model Thread"); this.loop = training; this.loop.start(); this.terminateModelRecs = terminateModel; this.terminateModelRecs.start(); } }
/** {@inheritDoc} */ @Override public void loadCache(GridBiInClosure<K, V> c, @Nullable Object... args) throws GridException { ExecutorService exec = new ThreadPoolExecutor( threadsCnt, threadsCnt, 0L, MILLISECONDS, new ArrayBlockingQueue<Runnable>(batchQueueSize), new BlockingRejectedExecutionHandler()); Iterator<I> iter = inputIterator(args); Collection<I> buf = new ArrayList<>(batchSize); try { while (iter.hasNext()) { if (Thread.currentThread().isInterrupted()) { U.warn(log, "Working thread was interrupted while loading data."); break; } buf.add(iter.next()); if (buf.size() == batchSize) { exec.submit(new Worker(c, buf, args)); buf = new ArrayList<>(batchSize); } } if (!buf.isEmpty()) exec.submit(new Worker(c, buf, args)); } catch (RejectedExecutionException ignored) { // Because of custom RejectedExecutionHandler. assert false : "RejectedExecutionException was thrown while it shouldn't."; } finally { exec.shutdown(); try { exec.awaitTermination(Long.MAX_VALUE, MILLISECONDS); } catch (InterruptedException ignored) { U.warn(log, "Working thread was interrupted while waiting for put operations to complete."); Thread.currentThread().interrupt(); } } }
/** @throws Exception If failed. */ public void testDisabledRest() throws Exception { restEnabled = false; final Grid g = startGrid("disabled-rest"); try { Thread.sleep(2 * TOP_REFRESH_FREQ); // As long as we have round robin load balancer this will cause every node to be queried. for (int i = 0; i < NODES_CNT + 1; i++) assertEquals(NODES_CNT + 1, client.compute().refreshTopology(false, false).size()); final GridClientData data = client.data(PARTITIONED_CACHE_NAME); // Check rest-disabled node is unavailable. try { String affKey; do { affKey = UUID.randomUUID().toString(); } while (!data.affinity(affKey).equals(g.localNode().id())); data.put(affKey, "asdf"); assertEquals("asdf", cache(0, PARTITIONED_CACHE_NAME).get(affKey)); } catch (GridServerUnreachableException e) { // Thrown for direct client-node connections. assertTrue( "Unexpected exception message: " + e.getMessage(), e.getMessage() .startsWith("No available endpoints to connect (is rest enabled for this node?)")); } catch (GridClientException e) { // Thrown for routed client-router-node connections. String msg = e.getMessage(); assertTrue( "Unexpected exception message: " + msg, protocol() == GridClientProtocol.TCP ? msg.contains("No available endpoints to connect (is rest enabled for this node?)") : // TCP router. msg.startsWith( "No available nodes on the router for destination node ID")); // HTTP router. } // Check rest-enabled nodes are available. String affKey; do { affKey = UUID.randomUUID().toString(); } while (data.affinity(affKey).equals(g.localNode().id())); data.put(affKey, "fdsa"); assertEquals("fdsa", cache(0, PARTITIONED_CACHE_NAME).get(affKey)); } finally { restEnabled = true; G.stop(g.name(), true); } }
public void run() { while (RUNNING) { try { Thread.sleep(400000000); } catch (InterruptedException e) { // TODO Auto-generated catch block e.printStackTrace(); } if (SESSIONS.size() != 0) { for (String key : SESSIONS.keySet()) { IndividualRecommender rec = SESSIONS.get(key); String stamp = Pattern.quote(rec.getTimestamp()).split("\\.")[0].substring(2); SimpleDateFormat formatter = new SimpleDateFormat("yyyy-MM-dd hh:mm:ss"); Date lastUpdateTime; try { lastUpdateTime = formatter.parse(stamp); Date today = new Date(); if ((today.getTime() - lastUpdateTime.getTime()) >= MILLISECONDS.convert(20, DAYS)) { SESSIONS.remove(key); } } catch (ParseException e) { // TODO Auto-generated catch block e.printStackTrace(); } } } } }
public void run() { try { while (!Thread.interrupted()) q.take().run(); // Run task with the current thread } catch (InterruptedException e) { // Acceptable way to exit } print("Finished DelayedTaskConsumer"); }
/** * @see * org.alfresco.extension.bulkimport.BulkImportCallback#submit(org.alfresco.extension.bulkimport.source.BulkImportItem) */ @Override @SuppressWarnings({"rawtypes", "unchecked"}) public synchronized void submit(final BulkImportItem item) throws InterruptedException { // PRECONDITIONS if (item == null) { throw new IllegalArgumentException( "Import source '" + source.getName() + "' has logic errors - a null import item was submitted."); } if (item.getVersions() == null || item.getVersions().size() <= 0) { throw new IllegalArgumentException( "Import source '" + source.getName() + "' has logic errors - an empty import item was submitted."); } // Body if (importStatus.isStopping() || Thread.currentThread().isInterrupted()) throw new InterruptedException( Thread.currentThread().getName() + " was interrupted. Terminating early."); // If the weight of the new item would blow out the current batch, submit the batch as-is (i.e. // *before* adding the newly submitted item). // This ensures that heavy items start a new batch (and possibly end up in a batch by // themselves). int weight = weight(item); if (weightOfCurrentBatch + weight > batchWeight) { submitCurrentBatch(); } // Create a new batch, if necessary if (currentBatch == null) { currentBatchNumber++; currentBatch = new ArrayList<>(batchWeight); weightOfCurrentBatch = 0; } // Finally, add the item to the current batch currentBatch.add(item); weightOfCurrentBatch += weight; }
/** @throws Exception If failed. */ public void testAffinityPut() throws Exception { Thread.sleep(2 * TOP_REFRESH_FREQ); assertEquals(NODES_CNT, client.compute().refreshTopology(false, false).size()); Map<UUID, Grid> gridsByLocNode = new HashMap<>(NODES_CNT); GridClientData partitioned = client.data(PARTITIONED_CACHE_NAME); GridClientCompute compute = client.compute(); for (int i = 0; i < NODES_CNT; i++) gridsByLocNode.put(grid(i).localNode().id(), grid(i)); for (int i = 0; i < 100; i++) { String key = "key" + i; UUID primaryNodeId = grid(0).mapKeyToNode(PARTITIONED_CACHE_NAME, key).id(); assertEquals("Affinity mismatch for key: " + key, primaryNodeId, partitioned.affinity(key)); assertEquals(primaryNodeId, partitioned.affinity(key)); // Must go to primary node only. Since backup count is 0, value must present on // primary node only. partitioned.put(key, "val" + key); for (Map.Entry<UUID, Grid> entry : gridsByLocNode.entrySet()) { Object val = entry.getValue().cache(PARTITIONED_CACHE_NAME).peek(key); if (primaryNodeId.equals(entry.getKey())) assertEquals("val" + key, val); else assertNull(val); } } // Now check that we will see value in near cache in pinned mode. for (int i = 100; i < 200; i++) { String pinnedKey = "key" + i; UUID primaryNodeId = grid(0).mapKeyToNode(PARTITIONED_CACHE_NAME, pinnedKey).id(); UUID pinnedNodeId = F.first(F.view(gridsByLocNode.keySet(), F.notEqualTo(primaryNodeId))); GridClientNode node = compute.node(pinnedNodeId); partitioned.pinNodes(node).put(pinnedKey, "val" + pinnedKey); for (Map.Entry<UUID, Grid> entry : gridsByLocNode.entrySet()) { Object val = entry.getValue().cache(PARTITIONED_CACHE_NAME).peek(pinnedKey); if (primaryNodeId.equals(entry.getKey()) || pinnedNodeId.equals(entry.getKey())) assertEquals("val" + pinnedKey, val); else assertNull(val); } } }
/** {@inheritDoc} */ @Override public void rejectedExecution(Runnable r, ThreadPoolExecutor executor) { try { if (executor.isShutdown()) throw new RejectedExecutionException(); else executor.getQueue().put(r); } catch (InterruptedException ignored) { U.warn(log, "Working thread was interrupted while loading data."); Thread.currentThread().interrupt(); } }
@Override public void deleteRatings(String key, long userId, long itemId) { if (key != null) { if (SESSIONS.get(key) != null) { SESSIONS.get(key).deleteRatings(userId, itemId); } } if (!this.loop.isAlive()) { Thread training = new Thread(new RecommenderRunnable()); training.setName("Training Thread"); this.loop = training; this.loop.start(); } if (!this.terminateModelRecs.isAlive()) { Thread terminateModel = new Thread(new TerminateModels()); terminateModel.setName("Terminate Model Thread"); this.terminateModelRecs = terminateModel; this.terminateModelRecs.start(); } }
public void run() { try { while (!Thread.interrupted()) { Event event = q.take(); print(event); event.run(); } } catch (InterruptedException e) { // Acceptable way to exit } print("Finished Controller"); }
// To be called exactly twice by the child process public static void rendezvousChild() { try { for (int i = 0; i < 100; i++) { System.gc(); System.runFinalization(); Thread.sleep(50); } System.out.write((byte) '\n'); System.out.flush(); System.in.read(); } catch (Throwable t) { throw new Error(t); } }
@Override public long retrieveUserId(String key, String username) { if (key != null) { if (SESSIONS.get(key) != null) { return SESSIONS.get(key).retrieveUserId(username); } } if (!this.loop.isAlive()) { Thread training = new Thread(new RecommenderRunnable()); training.setName("Training Thread"); this.loop = training; this.loop.start(); } if (!this.terminateModelRecs.isAlive()) { Thread terminateModel = new Thread(new TerminateModels()); terminateModel.setName("Terminate Model Thread"); this.terminateModelRecs = terminateModel; this.terminateModelRecs.start(); } return 0; }
@Override public void initiateModel(String key, String table, String username, String database) { if (key != null) { if (SESSIONS.get(key) != null) { Thread.currentThread().setPriority(Thread.MAX_PRIORITY); SESSIONS.get(key).initiateModel(key, table, username, database); } } if (!this.loop.isAlive()) { Thread training = new Thread(new RecommenderRunnable()); training.setName("Training Thread"); this.loop = training; this.loop.start(); } if (!this.terminateModelRecs.isAlive()) { Thread terminateModel = new Thread(new TerminateModels()); terminateModel.setName("Terminate Model Thread"); this.terminateModelRecs = terminateModel; this.terminateModelRecs.start(); } }
@Override public List<Item> getSearchItems( String key, String query, List<String> columnsToSearch, List<String> displayColumns) { if (key != null) { if (SESSIONS.get(key) != null) { return SESSIONS.get(key).getSearchItems(query, columnsToSearch, displayColumns); } } if (!this.loop.isAlive()) { Thread training = new Thread(new RecommenderRunnable()); training.setName("Training Thread"); this.loop = training; this.loop.start(); } if (!this.terminateModelRecs.isAlive()) { Thread terminateModel = new Thread(new TerminateModels()); terminateModel.setName("Terminate Model Thread"); this.terminateModelRecs = terminateModel; this.terminateModelRecs.start(); } return null; }
@Override public String createNewUser(String key, String username, boolean isKibitzUser) { if (key != null) { if (SESSIONS.get(key) != null) { return SESSIONS.get(key).createNewUser(username, isKibitzUser); } } if (!this.loop.isAlive()) { Thread training = new Thread(new RecommenderRunnable()); training.setName("Training Thread"); this.loop = training; this.loop.start(); } if (!this.terminateModelRecs.isAlive()) { Thread terminateModel = new Thread(new TerminateModels()); terminateModel.setName("Terminate Model Thread"); this.terminateModelRecs = terminateModel; this.terminateModelRecs.start(); } return null; }
public void run() { while (RUNNING) { try { Thread.sleep(1000); } catch (InterruptedException e) { // TODO Auto-generated catch block e.printStackTrace(); } if (SESSIONS.size() != 0) { for (String key : SESSIONS.keySet()) { IndividualRecommender rec = SESSIONS.get(key); if (updateDataModel(rec, key)) updateRecommender(RECOMMENDERS.get(key)); } } } }
/** Notifies all registered listeners. */ private void notifyListeners() { final Collection<GridInClosure<? super GridFuture<R>>> tmp; synchronized (mux) { tmp = new ArrayList<GridInClosure<? super GridFuture<R>>>(lsnrs); } boolean concurNotify = this.concurNotify; boolean syncNotify = this.syncNotify; if (concurNotify) { for (final GridInClosure<? super GridFuture<R>> lsnr : tmp) ctx.closure() .runLocalSafe( new GPR() { @Override public void run() { notifyListener(lsnr); } }, true); } else { // Always notify in the thread different from start thread. if (Thread.currentThread() == thread && !syncNotify) { ctx.closure() .runLocalSafe( new GPR() { @Override public void run() { // Since concurrent notifications are off, we notify // all listeners in one thread. for (GridInClosure<? super GridFuture<R>> lsnr : tmp) notifyListener(lsnr); } }, true); } else { for (GridInClosure<? super GridFuture<R>> lsnr : tmp) notifyListener(lsnr); } } }
/** {@inheritDoc} */ @Override public void testEvictExpired() throws Exception { IgniteCache<String, Integer> cache = jcache(); String key = primaryKeysForCache(cache, 1).get(0); cache.put(key, 1); assertEquals((Integer) 1, cache.get(key)); long ttl = 500; grid(0) .cache(null) .withExpiryPolicy(new TouchedExpiryPolicy(new Duration(MILLISECONDS, ttl))) .put(key, 1); Thread.sleep(ttl + 100); // Expired entry should not be swapped. cache.localEvict(Collections.singleton(key)); assertNull(cache.localPeek(key, CachePeekMode.ONHEAP)); cache.localPromote(Collections.singleton(key)); assertNull(cache.localPeek(key, CachePeekMode.ONHEAP)); assertTrue(cache.localSize() == 0); load(cache, key, true); Affinity<String> aff = ignite(0).affinity(null); for (int i = 0; i < gridCount(); i++) { if (aff.isPrimaryOrBackup(grid(i).cluster().localNode(), key)) assertEquals((Integer) 1, peek(jcache(i), key)); } }
/** * Future adapter. * * @author 2005-2011 Copyright (C) GridGain Systems, Inc. * @version 3.1.1c.19062011 */ public class GridFutureAdapter<R> extends GridMetadataAwareAdapter implements GridFuture<R>, Externalizable { /** Synchronous notification flag. */ private static final boolean SYNC_NOTIFY = U.isFutureNotificationSynchronous(); /** Concurrent notification flag. */ private static final boolean CONCUR_NOTIFY = U.isFutureNotificationConcurrent(); /** Done flag. */ private boolean done; /** Cancelled flag. */ private boolean cancelled; /** Result. */ @GridToStringInclude private R res; /** Error. */ private Throwable err; /** Set to {@code false} on deserialization whenever incomplete future is serialized. */ private boolean valid = true; /** Asynchronous listener. */ private final Set<GridInClosure<? super GridFuture<R>>> lsnrs = new GridLeanSet<GridInClosure<? super GridFuture<R>>>(); /** Creator thread. */ private Thread thread = Thread.currentThread(); /** Mutex. */ private final Object mux = new Object(); /** Context. */ protected GridKernalContext ctx; /** Logger. */ protected GridLogger log; /** Future start time. */ protected final long startTime = System.currentTimeMillis(); /** Synchronous notification flag. */ private volatile boolean syncNotify = SYNC_NOTIFY; /** Concurrent notification flag. */ private volatile boolean concurNotify = CONCUR_NOTIFY; /** Future end time. */ private volatile long endTime; /** Watch. */ protected GridStopwatch watch; /** Empty constructor required for {@link Externalizable}. */ public GridFutureAdapter() { // No-op. } /** @param ctx Kernal context. */ public GridFutureAdapter(GridKernalContext ctx) { assert ctx != null; this.ctx = ctx; log = ctx.log(getClass()); } /** {@inheritDoc} */ @Override public long startTime() { return startTime; } /** {@inheritDoc} */ @Override public long duration() { long endTime = this.endTime; return endTime == 0 ? System.currentTimeMillis() - startTime : endTime - startTime; } /** {@inheritDoc} */ @Override public boolean concurrentNotify() { return concurNotify; } /** {@inheritDoc} */ @Override public void concurrentNotify(boolean concurNotify) { this.concurNotify = concurNotify; } /** {@inheritDoc} */ @Override public boolean syncNotify() { return syncNotify; } /** {@inheritDoc} */ @Override public void syncNotify(boolean syncNotify) { this.syncNotify = syncNotify; } /** * Adds a watch to this future. * * @param name Name of the watch. */ public void addWatch(String name) { assert name != null; watch = W.stopwatch(name); } /** * Adds a watch to this future. * * @param watch Watch to add. */ public void addWatch(GridStopwatch watch) { assert watch != null; this.watch = watch; } /** Checks that future is in usable state. */ protected void checkValid() { if (!valid) throw new IllegalStateException( "Incomplete future was serialized and cannot " + "be used after deserialization."); } /** @return Valid flag. */ protected boolean isValid() { return valid; } /** * Gets internal mutex. * * @return Internal mutex. */ protected Object mutex() { checkValid(); return mux; } /** @return Value of error. */ protected Throwable error() { checkValid(); synchronized (mux) { return err; } } /** @return Value of result. */ protected R result() { checkValid(); synchronized (mux) { return res; } } /** {@inheritDoc} */ @Override public R call() throws Exception { return get(); } /** {@inheritDoc} */ @Override public R get(long timeout) throws GridException { return get(timeout, MILLISECONDS); } /** {@inheritDoc} */ @Override public R get() throws GridException { checkValid(); try { synchronized (mux) { while (!done && !cancelled) mux.wait(); if (done) { if (err != null) throw U.cast(err); return res; } throw new GridFutureCancelledException("Future was cancelled: " + this); } } catch (InterruptedException e) { throw new GridInterruptedException(e); } } /** {@inheritDoc} */ @Override public R get(long timeout, TimeUnit unit) throws GridException { A.ensure(timeout >= 0, "timeout cannot be negative: " + timeout); A.notNull(unit, "unit"); checkValid(); try { long now = System.currentTimeMillis(); long end = timeout == 0 ? Long.MAX_VALUE : now + MILLISECONDS.convert(timeout, unit); // Account for overflow. if (end < 0) end = Long.MAX_VALUE; synchronized (mux) { while (!done && !cancelled && now < end) { mux.wait(end - now); if (!done) now = System.currentTimeMillis(); } if (done) { if (err != null) throw U.cast(err); return res; } if (cancelled) throw new GridFutureCancelledException("Future was cancelled: " + this); throw new GridFutureTimeoutException( "Timeout was reached before computation completed [duration=" + duration() + "ms, timeout=" + unit.toMillis(timeout) + "ms]"); } } catch (InterruptedException e) { throw new GridInterruptedException( "Got interrupted while waiting for future to complete [duration=" + duration() + "ms, timeout=" + unit.toMillis(timeout) + "ms]", e); } } /** {@inheritDoc} */ @SuppressWarnings({"unchecked"}) @Override public void listenAsync(@Nullable final GridInClosure<? super GridFuture<R>> lsnr) { if (lsnr != null) { checkValid(); boolean done; synchronized (mux) { done = this.done; if (!done) lsnrs.add(lsnr); } if (done) { try { if (syncNotify) notifyListener(lsnr); else ctx.closure() .runLocalSafe( new GPR() { @Override public void run() { notifyListener(lsnr); } }, true); } catch (IllegalStateException ignore) { U.warn( null, "Future notification will not proceed because grid is stopped: " + ctx.gridName()); } } } } /** {@inheritDoc} */ @Override public void stopListenAsync(@Nullable GridInClosure<? super GridFuture<R>>... lsnr) { if (F.isEmpty(lsnr)) synchronized (mux) { lsnrs.clear(); } else synchronized (mux) { lsnrs.removeAll(F.asList(lsnr)); } } /** Notifies all registered listeners. */ private void notifyListeners() { final Collection<GridInClosure<? super GridFuture<R>>> tmp; synchronized (mux) { tmp = new ArrayList<GridInClosure<? super GridFuture<R>>>(lsnrs); } boolean concurNotify = this.concurNotify; boolean syncNotify = this.syncNotify; if (concurNotify) { for (final GridInClosure<? super GridFuture<R>> lsnr : tmp) ctx.closure() .runLocalSafe( new GPR() { @Override public void run() { notifyListener(lsnr); } }, true); } else { // Always notify in the thread different from start thread. if (Thread.currentThread() == thread && !syncNotify) { ctx.closure() .runLocalSafe( new GPR() { @Override public void run() { // Since concurrent notifications are off, we notify // all listeners in one thread. for (GridInClosure<? super GridFuture<R>> lsnr : tmp) notifyListener(lsnr); } }, true); } else { for (GridInClosure<? super GridFuture<R>> lsnr : tmp) notifyListener(lsnr); } } } /** * Notifies single listener. * * @param lsnr Listener. */ private void notifyListener(GridInClosure<? super GridFuture<R>> lsnr) { assert lsnr != null; try { lsnr.apply(this); } catch (IllegalStateException ignore) { U.warn( null, "Failed to notify listener (grid is stopped) [grid=" + ctx.gridName() + ", lsnr=" + lsnr + ']'); } catch (RuntimeException e) { U.error(log, "Failed to notify listener: " + lsnr, e); throw e; } catch (Error e) { U.error(log, "Failed to notify listener: " + lsnr, e); throw e; } } /** * Default no-op implementation that always returns {@code false}. Futures that do support * cancellation should override this method and call {@link #onCancelled()} callback explicitly if * cancellation indeed did happen. */ @Override public boolean cancel() throws GridException { checkValid(); return false; } /** {@inheritDoc} */ @Override public boolean isDone() { // Don't check for "valid" here, as "done" flag can be read // even in invalid state. synchronized (mux) { return done || cancelled; } } /** {@inheritDoc} */ @Override public GridAbsPredicate predicate() { return new PA() { @Override public boolean apply() { return isDone(); } }; } /** {@inheritDoc} */ @Override public boolean isCancelled() { checkValid(); synchronized (mux) { return cancelled; } } /** * Callback to notify that future is finished with {@code null} result. This method must delegate * to {@link #onDone(Object, Throwable)} method. * * @return {@code True} if result was set by this call. */ public final boolean onDone() { return onDone(null, null); } /** * Callback to notify that future is finished. This method must delegate to {@link #onDone(Object, * Throwable)} method. * * @param res Result. * @return {@code True} if result was set by this call. */ public final boolean onDone(@Nullable R res) { return onDone(res, null); } /** * Callback to notify that future is finished. This method must delegate to {@link #onDone(Object, * Throwable)} method. * * @param err Error. * @return {@code True} if result was set by this call. */ public final boolean onDone(@Nullable Throwable err) { return onDone(null, err); } /** * Callback to notify that future is finished. Note that if non-{@code null} exception is passed * in the result value will be ignored. * * @param res Optional result. * @param err Optional error. * @return {@code True} if result was set by this call. */ public boolean onDone(@Nullable R res, @Nullable Throwable err) { checkValid(); boolean notify = false; boolean gotDone = false; try { synchronized (mux) { if (!done) { gotDone = true; endTime = System.currentTimeMillis(); this.res = res; this.err = err; done = true; notify = true; mux.notifyAll(); // Notify possibly waiting child classes. return true; } return false; } } finally { if (gotDone) { GridStopwatch w = watch; if (w != null) w.stop(); } if (notify) notifyListeners(); } } /** * Callback to notify that future is cancelled. * * @return {@code True} if cancel flag was set by this call. */ public boolean onCancelled() { checkValid(); synchronized (mux) { if (cancelled || done) return false; cancelled = true; mux.notifyAll(); // Notify possibly waiting child classes. } return true; } /** {@inheritDoc} */ @Override public void writeExternal(ObjectOutput out) throws IOException { boolean done; boolean cancelled; Object res; Throwable err; boolean syncNotify; boolean concurNotify; synchronized (mux) { done = this.done; cancelled = this.cancelled; res = this.res; err = this.err; syncNotify = this.syncNotify; concurNotify = this.concurNotify; } out.writeBoolean(done); out.writeBoolean(syncNotify); out.writeBoolean(concurNotify); // Don't write any further if not done, as deserialized future // will be invalid anyways. if (done) { out.writeBoolean(cancelled); out.writeObject(res); out.writeObject(err); } } /** {@inheritDoc} */ @SuppressWarnings({"unchecked"}) @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException { boolean done = in.readBoolean(); syncNotify = in.readBoolean(); concurNotify = in.readBoolean(); if (!done) valid = false; else { boolean cancelled = in.readBoolean(); R res = (R) in.readObject(); Throwable err = (Throwable) in.readObject(); synchronized (mux) { this.done = done; this.cancelled = cancelled; this.res = res; this.err = err; } } } /** {@inheritDoc} */ @Override public String toString() { return S.toString(GridFutureAdapter.class, this); } }
static void fail() { failed++; Thread.dumpStack(); }
private static void test(ExecutorService executor) throws Throwable { Thread.currentThread().setName("mainThread"); // ---------------------------------------------------------------- // supplyAsync tests // ---------------------------------------------------------------- try { CompletableFuture<String> cf = supplyAsync(() -> "a test string"); checkCompletedNormally(cf, cf.join()); cf = supplyAsync(() -> "a test string", commonPool()); checkCompletedNormally(cf, cf.join()); cf = supplyAsync(() -> "a test string", executor); checkCompletedNormally(cf, cf.join()); cf = supplyAsync( () -> { throw new RuntimeException(); }); checkCompletedExceptionally(cf); cf = supplyAsync( () -> { throw new RuntimeException(); }, commonPool()); checkCompletedExceptionally(cf); cf = supplyAsync( () -> { throw new RuntimeException(); }, executor); checkCompletedExceptionally(cf); } catch (Throwable t) { unexpected(t); } // ---------------------------------------------------------------- // runAsync tests // ---------------------------------------------------------------- try { CompletableFuture<Void> cf = runAsync(() -> {}); checkCompletedNormally(cf, cf.join()); cf = runAsync(() -> {}, commonPool()); checkCompletedNormally(cf, cf.join()); cf = runAsync(() -> {}, executor); checkCompletedNormally(cf, cf.join()); cf = runAsync( () -> { throw new RuntimeException(); }); checkCompletedExceptionally(cf); cf = runAsync( () -> { throw new RuntimeException(); }, commonPool()); checkCompletedExceptionally(cf); cf = runAsync( () -> { throw new RuntimeException(); }, executor); checkCompletedExceptionally(cf); } catch (Throwable t) { unexpected(t); } // ---------------------------------------------------------------- // explicit completion // ---------------------------------------------------------------- try { final Phaser phaser = new Phaser(1); final int phase = phaser.getPhase(); CompletableFuture<Integer> cf; cf = supplyAsync( () -> { phaser.awaitAdvance(phase); return 1; }); cf.complete(2); phaser.arrive(); checkCompletedNormally(cf, 2); cf = supplyAsync( () -> { phaser.awaitAdvance(phase + 1); return 1; }); cf.completeExceptionally(new Throwable()); phaser.arrive(); checkCompletedExceptionally(cf); cf = supplyAsync( () -> { phaser.awaitAdvance(phase + 2); return 1; }); cf.cancel(true); phaser.arrive(); checkCompletedExceptionally(cf, true); cf = supplyAsync( () -> { phaser.awaitAdvance(phase + 3); return 1; }); check(cf.getNow(2) == 2); phaser.arrive(); checkCompletedNormally(cf, 1); check(cf.getNow(2) == 1); } catch (Throwable t) { unexpected(t); } // ---------------------------------------------------------------- // thenApplyXXX tests // ---------------------------------------------------------------- try { CompletableFuture<Integer> cf2; CompletableFuture<String> cf1 = supplyAsync(() -> "a test string"); cf2 = cf1.thenApply( (x) -> { if (x.equals("a test string")) return 1; else return 0; }); checkCompletedNormally(cf1, "a test string"); checkCompletedNormally(cf2, 1); cf1 = supplyAsync(() -> "a test string"); cf2 = cf1.thenApplyAsync( (x) -> { if (x.equals("a test string")) return 1; else return 0; }); checkCompletedNormally(cf1, "a test string"); checkCompletedNormally(cf2, 1); cf1 = supplyAsync(() -> "a test string"); cf2 = cf1.thenApplyAsync( (x) -> { if (x.equals("a test string")) return 1; else return 0; }, executor); checkCompletedNormally(cf1, "a test string"); checkCompletedNormally(cf2, 1); cf1 = supplyAsync( () -> { throw new RuntimeException(); }); cf2 = cf1.thenApply( (x) -> { return 0; }); checkCompletedExceptionally(cf1); checkCompletedExceptionally(cf2); cf1 = supplyAsync( () -> { throw new RuntimeException(); }); cf2 = cf1.thenApplyAsync( (x) -> { return 0; }); checkCompletedExceptionally(cf1); checkCompletedExceptionally(cf2); cf1 = supplyAsync( () -> { throw new RuntimeException(); }); cf2 = cf1.thenApplyAsync( (x) -> { return 0; }, executor); checkCompletedExceptionally(cf1); checkCompletedExceptionally(cf2); } catch (Throwable t) { unexpected(t); } // ---------------------------------------------------------------- // thenAcceptXXX tests // ---------------------------------------------------------------- try { CompletableFuture<Void> cf2; int before = atomicInt.get(); CompletableFuture<String> cf1 = supplyAsync(() -> "a test string"); cf2 = cf1.thenAccept( (x) -> { if (x.equals("a test string")) { atomicInt.incrementAndGet(); return; } throw new RuntimeException(); }); checkCompletedNormally(cf1, "a test string"); checkCompletedNormally(cf2, null); check(atomicInt.get() == (before + 1)); before = atomicInt.get(); cf1 = supplyAsync(() -> "a test string"); cf2 = cf1.thenAcceptAsync( (x) -> { if (x.equals("a test string")) { atomicInt.incrementAndGet(); return; } throw new RuntimeException(); }); checkCompletedNormally(cf1, "a test string"); checkCompletedNormally(cf2, null); check(atomicInt.get() == (before + 1)); before = atomicInt.get(); cf1 = supplyAsync(() -> "a test string"); cf2 = cf1.thenAcceptAsync( (x) -> { if (x.equals("a test string")) { atomicInt.incrementAndGet(); return; } throw new RuntimeException(); }, executor); checkCompletedNormally(cf1, "a test string"); checkCompletedNormally(cf2, null); check(atomicInt.get() == (before + 1)); before = atomicInt.get(); cf1 = supplyAsync( () -> { throw new RuntimeException(); }); cf2 = cf1.thenAccept( (x) -> { atomicInt.incrementAndGet(); }); checkCompletedExceptionally(cf1); checkCompletedExceptionally(cf2); check(atomicInt.get() == before); cf1 = supplyAsync( () -> { throw new RuntimeException(); }); cf2 = cf1.thenAcceptAsync( (x) -> { atomicInt.incrementAndGet(); }); checkCompletedExceptionally(cf1); checkCompletedExceptionally(cf2); check(atomicInt.get() == before); cf1 = supplyAsync( () -> { throw new RuntimeException(); }); cf2 = cf1.thenAcceptAsync( (x) -> { atomicInt.incrementAndGet(); }, executor); checkCompletedExceptionally(cf1); checkCompletedExceptionally(cf2); check(atomicInt.get() == before); } catch (Throwable t) { unexpected(t); } // ---------------------------------------------------------------- // thenRunXXX tests // ---------------------------------------------------------------- try { CompletableFuture<Void> cf2; int before = atomicInt.get(); CompletableFuture<String> cf1 = supplyAsync(() -> "a test string"); cf2 = cf1.thenRun( () -> { atomicInt.incrementAndGet(); }); checkCompletedNormally(cf1, "a test string"); checkCompletedNormally(cf2, null); check(atomicInt.get() == (before + 1)); before = atomicInt.get(); cf1 = supplyAsync(() -> "a test string"); cf2 = cf1.thenRunAsync( () -> { atomicInt.incrementAndGet(); }); checkCompletedNormally(cf1, "a test string"); checkCompletedNormally(cf2, null); check(atomicInt.get() == (before + 1)); before = atomicInt.get(); cf1 = supplyAsync(() -> "a test string"); cf2 = cf1.thenRunAsync( () -> { atomicInt.incrementAndGet(); }, executor); checkCompletedNormally(cf1, "a test string"); checkCompletedNormally(cf2, null); check(atomicInt.get() == (before + 1)); before = atomicInt.get(); cf1 = supplyAsync( () -> { throw new RuntimeException(); }); cf2 = cf1.thenRun( () -> { atomicInt.incrementAndGet(); }); checkCompletedExceptionally(cf1); checkCompletedExceptionally(cf2); check(atomicInt.get() == before); cf1 = supplyAsync( () -> { throw new RuntimeException(); }); cf2 = cf1.thenRunAsync( () -> { atomicInt.incrementAndGet(); }); checkCompletedExceptionally(cf1); checkCompletedExceptionally(cf2); check(atomicInt.get() == before); cf1 = supplyAsync( () -> { throw new RuntimeException(); }); cf2 = cf1.thenRunAsync( () -> { atomicInt.incrementAndGet(); }, executor); checkCompletedExceptionally(cf1); checkCompletedExceptionally(cf2); check(atomicInt.get() == before); } catch (Throwable t) { unexpected(t); } // ---------------------------------------------------------------- // thenCombineXXX tests // ---------------------------------------------------------------- try { CompletableFuture<Integer> cf3; CompletableFuture<Integer> cf1 = supplyAsync(() -> 1); CompletableFuture<Integer> cf2 = supplyAsync(() -> 1); cf3 = cf1.thenCombine( cf2, (x, y) -> { return x + y; }); checkCompletedNormally(cf1, 1); checkCompletedNormally(cf2, 1); checkCompletedNormally(cf3, 2); cf1 = supplyAsync(() -> 1); cf2 = supplyAsync(() -> 1); cf3 = cf1.thenCombineAsync( cf2, (x, y) -> { return x + y; }); checkCompletedNormally(cf1, 1); checkCompletedNormally(cf2, 1); checkCompletedNormally(cf3, 2); cf1 = supplyAsync(() -> 1); cf2 = supplyAsync(() -> 1); cf3 = cf1.thenCombineAsync( cf2, (x, y) -> { return x + y; }, executor); checkCompletedNormally(cf1, 1); checkCompletedNormally(cf2, 1); checkCompletedNormally(cf3, 2); cf1 = supplyAsync( () -> { throw new RuntimeException(); }); cf2 = supplyAsync(() -> 1); cf3 = cf1.thenCombine( cf2, (x, y) -> { return 0; }); checkCompletedExceptionally(cf1); checkCompletedNormally(cf2, 1); checkCompletedExceptionally(cf3); cf1 = supplyAsync(() -> 1); cf2 = supplyAsync( () -> { throw new RuntimeException(); }); cf3 = cf1.thenCombineAsync( cf2, (x, y) -> { return 0; }); checkCompletedNormally(cf1, 1); checkCompletedExceptionally(cf2); checkCompletedExceptionally(cf3); cf1 = supplyAsync( () -> { throw new RuntimeException(); }); cf2 = supplyAsync( () -> { throw new RuntimeException(); }); cf3 = cf1.thenCombineAsync( cf2, (x, y) -> { return 0; }, executor); checkCompletedExceptionally(cf1); checkCompletedExceptionally(cf2); checkCompletedExceptionally(cf3); } catch (Throwable t) { unexpected(t); } // ---------------------------------------------------------------- // thenAcceptBothXXX tests // ---------------------------------------------------------------- try { CompletableFuture<Void> cf3; int before = atomicInt.get(); CompletableFuture<Integer> cf1 = supplyAsync(() -> 1); CompletableFuture<Integer> cf2 = supplyAsync(() -> 1); cf3 = cf1.thenAcceptBoth( cf2, (x, y) -> { check(x + y == 2); atomicInt.incrementAndGet(); }); checkCompletedNormally(cf1, 1); checkCompletedNormally(cf2, 1); checkCompletedNormally(cf3, null); check(atomicInt.get() == (before + 1)); before = atomicInt.get(); cf1 = supplyAsync(() -> 1); cf2 = supplyAsync(() -> 1); cf3 = cf1.thenAcceptBothAsync( cf2, (x, y) -> { check(x + y == 2); atomicInt.incrementAndGet(); }); checkCompletedNormally(cf1, 1); checkCompletedNormally(cf2, 1); checkCompletedNormally(cf3, null); check(atomicInt.get() == (before + 1)); before = atomicInt.get(); cf1 = supplyAsync(() -> 1); cf2 = supplyAsync(() -> 1); cf3 = cf1.thenAcceptBothAsync( cf2, (x, y) -> { check(x + y == 2); atomicInt.incrementAndGet(); }, executor); checkCompletedNormally(cf1, 1); checkCompletedNormally(cf2, 1); checkCompletedNormally(cf3, null); check(atomicInt.get() == (before + 1)); before = atomicInt.get(); cf1 = supplyAsync( () -> { throw new RuntimeException(); }); cf2 = supplyAsync(() -> 1); cf3 = cf1.thenAcceptBoth( cf2, (x, y) -> { atomicInt.incrementAndGet(); }); checkCompletedExceptionally(cf1); checkCompletedNormally(cf2, 1); checkCompletedExceptionally(cf3); check(atomicInt.get() == before); cf1 = supplyAsync(() -> 1); cf2 = supplyAsync( () -> { throw new RuntimeException(); }); cf3 = cf1.thenAcceptBothAsync( cf2, (x, y) -> { atomicInt.incrementAndGet(); }); checkCompletedNormally(cf1, 1); checkCompletedExceptionally(cf2); checkCompletedExceptionally(cf3); check(atomicInt.get() == before); cf1 = supplyAsync( () -> { throw new RuntimeException(); }); cf2 = supplyAsync( () -> { throw new RuntimeException(); }); cf3 = cf1.thenAcceptBothAsync( cf2, (x, y) -> { atomicInt.incrementAndGet(); }, executor); checkCompletedExceptionally(cf1); checkCompletedExceptionally(cf2); checkCompletedExceptionally(cf3); check(atomicInt.get() == before); } catch (Throwable t) { unexpected(t); } // ---------------------------------------------------------------- // runAfterBothXXX tests // ---------------------------------------------------------------- try { CompletableFuture<Void> cf3; int before = atomicInt.get(); CompletableFuture<Integer> cf1 = supplyAsync(() -> 1); CompletableFuture<Integer> cf2 = supplyAsync(() -> 1); cf3 = cf1.runAfterBoth( cf2, () -> { check(cf1.isDone()); check(cf2.isDone()); atomicInt.incrementAndGet(); }); checkCompletedNormally(cf1, 1); checkCompletedNormally(cf2, 1); checkCompletedNormally(cf3, null); check(atomicInt.get() == (before + 1)); before = atomicInt.get(); CompletableFuture<Integer> cfa = supplyAsync(() -> 1); CompletableFuture<Integer> cfb = supplyAsync(() -> 1); cf3 = cfa.runAfterBothAsync( cfb, () -> { check(cfa.isDone()); check(cfb.isDone()); atomicInt.incrementAndGet(); }); checkCompletedNormally(cfa, 1); checkCompletedNormally(cfb, 1); checkCompletedNormally(cf3, null); check(atomicInt.get() == (before + 1)); before = atomicInt.get(); CompletableFuture<Integer> cfx = supplyAsync(() -> 1); CompletableFuture<Integer> cfy = supplyAsync(() -> 1); cf3 = cfy.runAfterBothAsync( cfx, () -> { check(cfx.isDone()); check(cfy.isDone()); atomicInt.incrementAndGet(); }, executor); checkCompletedNormally(cfx, 1); checkCompletedNormally(cfy, 1); checkCompletedNormally(cf3, null); check(atomicInt.get() == (before + 1)); before = atomicInt.get(); CompletableFuture<Integer> cf4 = supplyAsync( () -> { throw new RuntimeException(); }); CompletableFuture<Integer> cf5 = supplyAsync(() -> 1); cf3 = cf5.runAfterBothAsync( cf4, () -> { atomicInt.incrementAndGet(); }, executor); checkCompletedExceptionally(cf4); checkCompletedNormally(cf5, 1); checkCompletedExceptionally(cf3); check(atomicInt.get() == before); before = atomicInt.get(); cf4 = supplyAsync(() -> 1); cf5 = supplyAsync( () -> { throw new RuntimeException(); }); cf3 = cf5.runAfterBothAsync( cf4, () -> { atomicInt.incrementAndGet(); }); checkCompletedNormally(cf4, 1); checkCompletedExceptionally(cf5); checkCompletedExceptionally(cf3); check(atomicInt.get() == before); before = atomicInt.get(); cf4 = supplyAsync( () -> { throw new RuntimeException(); }); cf5 = supplyAsync( () -> { throw new RuntimeException(); }); cf3 = cf5.runAfterBoth( cf4, () -> { atomicInt.incrementAndGet(); }); checkCompletedExceptionally(cf4); checkCompletedExceptionally(cf5); checkCompletedExceptionally(cf3); check(atomicInt.get() == before); } catch (Throwable t) { unexpected(t); } // ---------------------------------------------------------------- // applyToEitherXXX tests // ---------------------------------------------------------------- try { CompletableFuture<Integer> cf3; CompletableFuture<Integer> cf1 = supplyAsync(() -> 1); CompletableFuture<Integer> cf2 = supplyAsync(() -> 2); cf3 = cf1.applyToEither( cf2, (x) -> { check(x == 1 || x == 2); return x; }); checkCompletedNormally(cf3, new Object[] {1, 2}); check(cf1.isDone() || cf2.isDone()); cf1 = supplyAsync(() -> 1); cf2 = supplyAsync(() -> 2); cf3 = cf1.applyToEitherAsync( cf2, (x) -> { check(x == 1 || x == 2); return x; }); checkCompletedNormally(cf3, new Object[] {1, 2}); check(cf1.isDone() || cf2.isDone()); cf1 = supplyAsync(() -> 1); cf2 = supplyAsync(() -> 2); cf3 = cf1.applyToEitherAsync( cf2, (x) -> { check(x == 1 || x == 2); return x; }, executor); checkCompletedNormally(cf3, new Object[] {1, 2}); check(cf1.isDone() || cf2.isDone()); cf1 = supplyAsync( () -> { throw new RuntimeException(); }); cf2 = supplyAsync(() -> 2); cf3 = cf1.applyToEither( cf2, (x) -> { check(x == 2); return x; }); try { check(cf3.join() == 2); } catch (CompletionException x) { pass(); } check(cf3.isDone()); check(cf1.isDone() || cf2.isDone()); cf1 = supplyAsync(() -> 1); cf2 = supplyAsync( () -> { throw new RuntimeException(); }); cf3 = cf1.applyToEitherAsync( cf2, (x) -> { check(x == 1); return x; }); try { check(cf3.join() == 1); } catch (CompletionException x) { pass(); } check(cf3.isDone()); check(cf1.isDone() || cf2.isDone()); cf1 = supplyAsync( () -> { throw new RuntimeException(); }); cf2 = supplyAsync( () -> { throw new RuntimeException(); }); cf3 = cf1.applyToEitherAsync( cf2, (x) -> { fail(); return x; }); checkCompletedExceptionally(cf3); check(cf1.isDone() || cf2.isDone()); final Phaser cf3Done = new Phaser(2); cf1 = supplyAsync( () -> { cf3Done.arriveAndAwaitAdvance(); return 1; }); cf2 = supplyAsync(() -> 2); cf3 = cf1.applyToEither( cf2, (x) -> { check(x == 2); return x; }); checkCompletedNormally(cf3, 2); checkCompletedNormally(cf2, 2); check(!cf1.isDone()); cf3Done.arrive(); checkCompletedNormally(cf1, 1); checkCompletedNormally(cf3, 2); cf1 = supplyAsync(() -> 1); cf2 = supplyAsync( () -> { cf3Done.arriveAndAwaitAdvance(); return 2; }); cf3 = cf1.applyToEitherAsync( cf2, (x) -> { check(x == 1); return x; }); checkCompletedNormally(cf3, 1); checkCompletedNormally(cf1, 1); check(!cf2.isDone()); cf3Done.arrive(); checkCompletedNormally(cf2, 2); checkCompletedNormally(cf3, 1); } catch (Throwable t) { unexpected(t); } // ---------------------------------------------------------------- // acceptEitherXXX tests // ---------------------------------------------------------------- try { CompletableFuture<Void> cf3; int before = atomicInt.get(); CompletableFuture<Integer> cf1 = supplyAsync(() -> 1); CompletableFuture<Integer> cf2 = supplyAsync(() -> 2); cf3 = cf1.acceptEither( cf2, (x) -> { check(x == 1 || x == 2); atomicInt.incrementAndGet(); }); checkCompletedNormally(cf3, null); check(cf1.isDone() || cf2.isDone()); check(atomicInt.get() == (before + 1)); before = atomicInt.get(); cf1 = supplyAsync(() -> 1); cf2 = supplyAsync(() -> 2); cf3 = cf1.acceptEitherAsync( cf2, (x) -> { check(x == 1 || x == 2); atomicInt.incrementAndGet(); }); checkCompletedNormally(cf3, null); check(cf1.isDone() || cf2.isDone()); check(atomicInt.get() == (before + 1)); before = atomicInt.get(); cf1 = supplyAsync(() -> 1); cf2 = supplyAsync(() -> 2); cf3 = cf2.acceptEitherAsync( cf1, (x) -> { check(x == 1 || x == 2); atomicInt.incrementAndGet(); }, executor); checkCompletedNormally(cf3, null); check(cf1.isDone() || cf2.isDone()); check(atomicInt.get() == (before + 1)); cf1 = supplyAsync( () -> { throw new RuntimeException(); }); cf2 = supplyAsync(() -> 2); cf3 = cf2.acceptEitherAsync( cf1, (x) -> { check(x == 2); }, executor); try { check(cf3.join() == null); } catch (CompletionException x) { pass(); } check(cf3.isDone()); check(cf1.isDone() || cf2.isDone()); cf1 = supplyAsync(() -> 1); cf2 = supplyAsync( () -> { throw new RuntimeException(); }); cf3 = cf2.acceptEitherAsync( cf1, (x) -> { check(x == 1); }); try { check(cf3.join() == null); } catch (CompletionException x) { pass(); } check(cf3.isDone()); check(cf1.isDone() || cf2.isDone()); cf1 = supplyAsync( () -> { throw new RuntimeException(); }); cf2 = supplyAsync( () -> { throw new RuntimeException(); }); cf3 = cf2.acceptEitherAsync( cf1, (x) -> { fail(); }); checkCompletedExceptionally(cf3); check(cf1.isDone() || cf2.isDone()); final Phaser cf3Done = new Phaser(2); cf1 = supplyAsync( () -> { cf3Done.arriveAndAwaitAdvance(); return 1; }); cf2 = supplyAsync(() -> 2); cf3 = cf1.acceptEither( cf2, (x) -> { check(x == 2); }); checkCompletedNormally(cf3, null); checkCompletedNormally(cf2, 2); check(!cf1.isDone()); cf3Done.arrive(); checkCompletedNormally(cf1, 1); checkCompletedNormally(cf3, null); cf1 = supplyAsync(() -> 1); cf2 = supplyAsync( () -> { cf3Done.arriveAndAwaitAdvance(); return 2; }); cf3 = cf1.acceptEitherAsync( cf2, (x) -> { check(x == 1); }); checkCompletedNormally(cf3, null); checkCompletedNormally(cf1, 1); check(!cf2.isDone()); cf3Done.arrive(); checkCompletedNormally(cf2, 2); checkCompletedNormally(cf3, null); } catch (Throwable t) { unexpected(t); } // ---------------------------------------------------------------- // runAfterEitherXXX tests // ---------------------------------------------------------------- try { CompletableFuture<Void> cf3; int before = atomicInt.get(); CompletableFuture<Void> cf1 = runAsync(() -> {}); CompletableFuture<Void> cf2 = runAsync(() -> {}); cf3 = cf1.runAfterEither( cf2, () -> { atomicInt.incrementAndGet(); }); checkCompletedNormally(cf3, null); check(cf1.isDone() || cf2.isDone()); check(atomicInt.get() == (before + 1)); before = atomicInt.get(); cf1 = runAsync(() -> {}); cf2 = runAsync(() -> {}); cf3 = cf1.runAfterEitherAsync( cf2, () -> { atomicInt.incrementAndGet(); }); checkCompletedNormally(cf3, null); check(cf1.isDone() || cf2.isDone()); check(atomicInt.get() == (before + 1)); before = atomicInt.get(); cf1 = runAsync(() -> {}); cf2 = runAsync(() -> {}); cf3 = cf2.runAfterEitherAsync( cf1, () -> { atomicInt.incrementAndGet(); }, executor); checkCompletedNormally(cf3, null); check(cf1.isDone() || cf2.isDone()); check(atomicInt.get() == (before + 1)); before = atomicInt.get(); cf1 = runAsync( () -> { throw new RuntimeException(); }); cf2 = runAsync(() -> {}); cf3 = cf2.runAfterEither( cf1, () -> { atomicInt.incrementAndGet(); }); try { check(cf3.join() == null); check(atomicInt.get() == (before + 1)); } catch (CompletionException x) { pass(); } check(cf3.isDone()); check(cf1.isDone() || cf2.isDone()); before = atomicInt.get(); cf1 = runAsync(() -> {}); cf2 = runAsync( () -> { throw new RuntimeException(); }); cf3 = cf1.runAfterEitherAsync( cf2, () -> { atomicInt.incrementAndGet(); }); try { check(cf3.join() == null); check(atomicInt.get() == (before + 1)); } catch (CompletionException x) { pass(); } check(cf3.isDone()); check(cf1.isDone() || cf2.isDone()); before = atomicInt.get(); cf1 = runAsync( () -> { throw new RuntimeException(); }); cf2 = runAsync( () -> { throw new RuntimeException(); }); cf3 = cf2.runAfterEitherAsync( cf1, () -> { atomicInt.incrementAndGet(); }, executor); checkCompletedExceptionally(cf3); check(cf1.isDone() || cf2.isDone()); check(atomicInt.get() == before); final Phaser cf3Done = new Phaser(2); before = atomicInt.get(); cf1 = runAsync( () -> { cf3Done.arriveAndAwaitAdvance(); }); cf2 = runAsync(() -> {}); cf3 = cf1.runAfterEither( cf2, () -> { atomicInt.incrementAndGet(); }); checkCompletedNormally(cf3, null); checkCompletedNormally(cf2, null); check(!cf1.isDone()); check(atomicInt.get() == (before + 1)); cf3Done.arrive(); checkCompletedNormally(cf1, null); checkCompletedNormally(cf3, null); before = atomicInt.get(); cf1 = runAsync(() -> {}); cf2 = runAsync( () -> { cf3Done.arriveAndAwaitAdvance(); }); cf3 = cf1.runAfterEitherAsync( cf2, () -> { atomicInt.incrementAndGet(); }); checkCompletedNormally(cf3, null); checkCompletedNormally(cf1, null); check(!cf2.isDone()); check(atomicInt.get() == (before + 1)); cf3Done.arrive(); checkCompletedNormally(cf2, null); checkCompletedNormally(cf3, null); } catch (Throwable t) { unexpected(t); } // ---------------------------------------------------------------- // thenComposeXXX tests // ---------------------------------------------------------------- try { CompletableFuture<Integer> cf2; CompletableFuture<Integer> cf1 = supplyAsync(() -> 1); cf2 = cf1.thenCompose( (x) -> { check(x == 1); return CompletableFuture.completedFuture(2); }); checkCompletedNormally(cf1, 1); checkCompletedNormally(cf2, 2); cf1 = supplyAsync(() -> 1); cf2 = cf1.thenComposeAsync( (x) -> { check(x == 1); return CompletableFuture.completedFuture(2); }); checkCompletedNormally(cf1, 1); checkCompletedNormally(cf2, 2); cf1 = supplyAsync(() -> 1); cf2 = cf1.thenComposeAsync( (x) -> { check(x == 1); return CompletableFuture.completedFuture(2); }, executor); checkCompletedNormally(cf1, 1); checkCompletedNormally(cf2, 2); int before = atomicInt.get(); cf1 = supplyAsync( () -> { throw new RuntimeException(); }); cf2 = cf1.thenCompose( (x) -> { atomicInt.incrementAndGet(); return CompletableFuture.completedFuture(2); }); checkCompletedExceptionally(cf1); checkCompletedExceptionally(cf2); check(atomicInt.get() == before); cf1 = supplyAsync( () -> { throw new RuntimeException(); }); cf2 = cf1.thenComposeAsync( (x) -> { atomicInt.incrementAndGet(); return CompletableFuture.completedFuture(2); }); checkCompletedExceptionally(cf1); checkCompletedExceptionally(cf2); check(atomicInt.get() == before); cf1 = supplyAsync(() -> 1); cf2 = cf1.thenComposeAsync( (x) -> { throw new RuntimeException(); }, executor); checkCompletedNormally(cf1, 1); checkCompletedExceptionally(cf2); } catch (Throwable t) { unexpected(t); } // ---------------------------------------------------------------- // anyOf tests // ---------------------------------------------------------------- try { CompletableFuture<Object> cf3; for (int k = 0; k < 10; k++) { CompletableFuture<Integer> cf1 = supplyAsync(() -> 1); CompletableFuture<Integer> cf2 = supplyAsync(() -> 2); cf3 = CompletableFuture.anyOf(cf1, cf2); checkCompletedNormally(cf3, new Object[] {1, 2}); check(cf1.isDone() || cf2.isDone()); } } catch (Throwable t) { unexpected(t); } // ---------------------------------------------------------------- // allOf tests // ---------------------------------------------------------------- try { CompletableFuture<?> cf3; for (int k = 0; k < 10; k++) { CompletableFuture<Integer>[] cfs = (CompletableFuture<Integer>[]) Array.newInstance(CompletableFuture.class, 10); for (int j = 0; j < 10; j++) { final int v = j; cfs[j] = supplyAsync(() -> v); } cf3 = CompletableFuture.allOf(cfs); for (int j = 0; j < 10; j++) checkCompletedNormally(cfs[j], j); checkCompletedNormally(cf3, null); } } catch (Throwable t) { unexpected(t); } // ---------------------------------------------------------------- // exceptionally tests // ---------------------------------------------------------------- try { CompletableFuture<Integer> cf2; CompletableFuture<Integer> cf1 = supplyAsync(() -> 1); cf2 = cf1.exceptionally( (t) -> { fail("function should never be called"); return 2; }); checkCompletedNormally(cf1, 1); checkCompletedNormally(cf2, 1); final RuntimeException t = new RuntimeException(); cf1 = supplyAsync( () -> { throw t; }); cf2 = cf1.exceptionally( (x) -> { check(x.getCause() == t); return 2; }); checkCompletedExceptionally(cf1); checkCompletedNormally(cf2, 2); } catch (Throwable t) { unexpected(t); } // ---------------------------------------------------------------- // handle tests // ---------------------------------------------------------------- try { CompletableFuture<Integer> cf2; CompletableFuture<Integer> cf1 = supplyAsync(() -> 1); cf2 = cf1.handle((x, t) -> x + 1); checkCompletedNormally(cf1, 1); checkCompletedNormally(cf2, 2); final RuntimeException ex = new RuntimeException(); cf1 = supplyAsync( () -> { throw ex; }); cf2 = cf1.handle( (x, t) -> { check(t.getCause() == ex); return 2; }); checkCompletedExceptionally(cf1); checkCompletedNormally(cf2, 2); } catch (Throwable t) { unexpected(t); } }
/** @see java.lang.Runnable#run() */ @Override public void run() { boolean inPlacePossible = false; try { source.init(importStatus, parameters); inPlacePossible = source.inPlaceImportPossible(); if (info(log)) info( log, "Import (" + (inPlacePossible ? "in-place" : "streaming") + ") started from " + source.getName() + "."); importStatus.importStarted( userId, source, targetAsPath, importThreadPool, batchWeight, inPlacePossible, dryRun); // ------------------------------------------------------------------ // Phase 1 - Folder scanning (single threaded) // ------------------------------------------------------------------ source.scanFolders(importStatus, this); if (debug(log)) debug( log, "Folder import complete in " + getHumanReadableDuration(importStatus.getDurationInNs()) + "."); // ------------------------------------------------------------------ // Phase 2 - File scanning // ------------------------------------------------------------------ filePhase = true; // Maximise level of concurrency, since there's no longer any risk of out-of-order batches source.scanFiles(importStatus, this); if (debug(log)) debug( log, "File scan complete in " + getHumanReadableDuration(importStatus.getDurationInNs()) + "."); importStatus.scanningComplete(); // ------------------------------------------------------------------ // Phase 3 - Wait for multi-threaded import to complete and shutdown // ------------------------------------------------------------------ submitCurrentBatch(); // Submit whatever is left in the final (partial) batch... awaitCompletion(); if (debug(log)) debug(log, "Import complete" + (multiThreadedImport ? ", thread pool shutdown" : "") + "."); } catch (final Throwable t) { Throwable rootCause = getRootCause(t); String rootCauseClassName = rootCause.getClass().getName(); if (importStatus.isStopping() && (rootCause instanceof InterruptedException || rootCause instanceof ClosedByInterruptException || "com.hazelcast.core.RuntimeInterruptedException" .equals(rootCauseClassName))) // For compatibility across 4.x *sigh* { // A stop import was requested if (debug(log)) debug(log, Thread.currentThread().getName() + " was interrupted by a stop request.", t); } else { // An unexpected exception occurred during scanning - log it and kill the import error(log, "Bulk import from '" + source.getName() + "' failed.", t); importStatus.unexpectedError(t); } if (debug(log)) debug(log, "Forcibly shutting down import thread pool and awaiting shutdown..."); importThreadPool.shutdownNow(); try { importThreadPool.awaitTermination( Long.MAX_VALUE, TimeUnit.DAYS); // Wait forever (technically merely a very long time, but whatevs...) } catch (final InterruptedException ie) { // Not much we can do here but log it and keep on truckin' if (warn(log)) warn( log, Thread.currentThread().getName() + " was interrupted while awaiting shutdown of import thread pool.", ie); } } finally { // Reset the thread factory if (importThreadPool.getThreadFactory() instanceof BulkImportThreadFactory) { ((BulkImportThreadFactory) importThreadPool.getThreadFactory()).reset(); } // Mark the import complete importStatus.importComplete(); // Invoke the completion handlers (if any) if (completionHandlers != null) { for (final BulkImportCompletionHandler handler : completionHandlers) { try { handler.importComplete(importStatus); } catch (final Exception e) { if (error(log)) error( log, "Completion handler threw an unexpected exception. It will be ignored.", e); } } } // Always invoke the logging completion handler last loggingBulkImportCompletionHandler.importComplete(importStatus); } }