-
akka.dispatch.Future.await()
-
at.molindo.esi4j.rebuild.util.BulkIndexHelper.await()
await termination of all running batch index tasks
-
co.paralleluniverse.strands.Condition.await()
-
co.paralleluniverse.strands.SimpleConditionSynchronizer.await()
-
com.alibaba.otter.node.etl.load.loader.weight.WeightBarrier.await()
阻塞等待weight允许执行
阻塞返回条件: 1. 中断事件 2. 其他线程single()的weight > 当前阻塞等待的weight
@throws InterruptedException
-
com.basho.riak.client.core.operations.DtUpdateOperation.await()
-
com.basho.riak.client.core.operations.FetchOperation.await()
-
com.basho.riak.client.core.operations.MapReduceOperation.await()
-
com.basho.riak.client.core.operations.PingOperation.await()
-
com.basho.riak.client.core.operations.SearchOperation.await()
-
com.basho.riak.client.core.operations.StoreBucketPropsOperation.await()
-
com.basho.riak.client.core.operations.YzDeleteIndexOperation.await()
-
com.basho.riak.client.core.operations.YzFetchIndexOperation.await()
-
com.basho.riak.client.core.operations.YzPutIndexOperation.await()
-
com.betfair.cougar.netutil.nio.ClientHandshake.await()
-
com.cloudera.oryx.lambda.serving.ServingLayer.await()
Blocks and waits until the server shuts down.
-
com.cloudhopper.commons.util.windowing.WindowFuture.await()
Waits for this future to be completed within the amount of time remaining from the original offerTimeoutMillis minus the amount of time it took for the Window to accept the offer. For example, if Window.offer was called with an offerTimeoutMillis of 5000 milliseconds and it took 1000 milliseconds for the Window to accept the offer, then this method would wait for 4000 milliseconds.
@return True if and only if the future was completed within the specifiedtime limit
@throws InterruptedException Thrown if the current thread was interrupted
-
com.google.code.hs4j.Command.await()
-
com.hazelcast.core.ICondition.await()
{@inheritDoc}
-
com.hazelcast.core.ICountDownLatch.await()
Causes the current thread to wait until the latch has counted down to zero, an exception is thrown, or the specified waiting time elapses.
If the current count is zero then this method returns immediately with the value {@code true}.
If the current count is greater than zero then the current thread becomes disabled for thread scheduling purposes and lies dormant until one of five things happen:
- The count reaches zero due to invocations of the {@link #countDown} method;
- This ICountDownLatch instance is destroyed;
- The countdown owner becomes disconnected;
- Some other thread {@linkplain Thread#interrupt interrupts}the current thread; or
- The specified waiting time elapses.
If the count reaches zero then the method returns with the value {@code true}.
If the current thread:
- has its interrupted status set on entry to this method; or
- is {@linkplain Thread#interrupt interrupted} while waiting,
then {@link InterruptedException} is thrown and the current thread'sinterrupted status is cleared.
If the specified waiting time elapses then the value {@code false}is returned. If the time is less than or equal to zero, the method will not wait at all.
@param timeout the maximum time to wait
@param unit the time unit of the {@code timeout} argument
@return {@code true} if the count reached zero and {@code false}if the waiting time elapsed before the count reached zero
@throws InterruptedException if the current thread is interrupted
@throws IllegalStateException if hazelcast instance is shutdown while waiting
-
com.jogamp.opencl.util.MultiQueueBarrier.await()
Blocks until all Threads which called {@link #waitFor}continue execution. This method blocks only once, all subsequent calls are ignored.
-
com.linkedin.databus.core.DbusEventBuffer.DbusEventIterator.await()
-
com.netflix.astyanax.test.TestDriver.await()
-
com.netflix.governator.guice.runner.TerminationEvent.await()
Block until the termination event is fired.
@throws InterruptedException
-
com.netflix.governator.guice.runner.events.SelfDestructingTerminationEvent.await()
-
com.sonian.elasticsearch.http.jetty.JettyHttpServerRestChannel.await()
-
com.sun.sgs.test.util.AwaitDone.await()
Waits for the operations to complete, throwing an exception if any operation fails or does not complete in the specified amount of time.
@param timeout the maximum time to wait
@param unit the time unit of the {@code timeout} argument
@throws InterruptedException if the thread is interrupted
-
com.yahoo.omid.client.SyncAbortCompleteCallback.await()
-
com.yz.net.IoFuture.await()
等待完成,一直等待,直到IO操作完成为止,长时间等待是一个相对的说明,程序为在一些不可预
测的情况下设定了一个最长等待,如果在超过最长等待还未得到IO操作完成的信号,则立即返回出
来,以避免程序产生死循环。
-
de.fu_berlin.inf.dpp.util.BlockingProgressMonitor.await()
-
edu.emory.mathcs.backport.java.util.concurrent.CountDownLatch.await()
Causes the current thread to wait until the latch has counted down to zero, unless the thread is {@link Thread#interrupt interrupted}.
If the current {@link #getCount count} is zero then this methodreturns immediately.
If the current {@link #getCount count} is greater than zero thenthe current thread becomes disabled for thread scheduling purposes and lies dormant until one of two things happen:
- The count reaches zero due to invocations of the {@link #countDown} method; or
- Some other thread {@link Thread#interrupt interrupts} the currentthread.
If the current thread:
- has its interrupted status set on entry to this method; or
- is {@link Thread#interrupt interrupted} while waiting,
then {@link InterruptedException} is thrown and the current thread'sinterrupted status is cleared.
@throws InterruptedException if the current thread is interruptedwhile waiting.
-
edu.emory.mathcs.backport.java.util.concurrent.CyclicBarrier.await()
Waits until all {@link #getParties parties} have invoked
awaiton this barrier.
If the current thread is not the last to arrive then it is disabled for thread scheduling purposes and lies dormant until one of following things happens:
- The last thread arrives; or
- Some other thread {@link Thread#interrupt interrupts} the currentthread; or
- Some other thread {@link Thread#interrupt interrupts} one of theother waiting threads; or
- Some other thread times out while waiting for barrier; or
- Some other thread invokes {@link #reset} on this barrier.
If the current thread:
- has its interrupted status set on entry to this method; or
- is {@link Thread#interrupt interrupted} while waiting
then {@link InterruptedException} is thrown and the current thread'sinterrupted status is cleared.
If the barrier is {@link #reset} while any thread is waiting, or ifthe barrier {@link #isBroken is broken} when await is invoked,or while any thread is waiting, then {@link BrokenBarrierException} is thrown.
If any thread is {@link Thread#interrupt interrupted} while waiting,then all other waiting threads will throw {@link BrokenBarrierException} and the barrier is placed in the brokenstate.
If the current thread is the last thread to arrive, and a non-null barrier action was supplied in the constructor, then the current thread runs the action before allowing the other threads to continue. If an exception occurs during the barrier action then that exception will be propagated in the current thread and the barrier is placed in the broken state.
@return the arrival index of the current thread, where index {@link #getParties()} - 1 indicates the first to arrive andzero indicates the last to arrive.
@throws InterruptedException if the current thread was interruptedwhile waiting.
@throws BrokenBarrierException if another thread wasinterrupted or timed out while the current thread was waiting, or the barrier was reset, or the barrier was broken when await was called, or the barrier action (if present) failed due an exception.
-
edu.ucla.sspace.util.WorkQueue.await()
Waits until all the tasks associated with the group identifier have finished. Once a task group has been successfully waited upon, the group identifier is removed from the queue and is valid to be reused for a new task group.
@throws IllegalArgumentException if the {@code taskGroupId} is notcurrently associated with any active taskGroup
-
eu.mosaic_cloud.components.implementations.basic.BasicComponent.await()
-
io.netty.channel.ChannelFuture.await()
-
io.netty.channel.ChannelPromise.await()
-
io.undertow.util.CompletionLatchHandler.await()
-
java.util.concurrent.CountDownLatch.await()
Causes the current thread to wait until the latch has counted down to zero, unless the thread is {@linkplain Thread#interrupt interrupted}.
If the current count is zero then this method returns immediately.
If the current count is greater than zero then the current thread becomes disabled for thread scheduling purposes and lies dormant until one of two things happen:
- The count reaches zero due to invocations of the {@link #countDown} method; or
- Some other thread {@linkplain Thread#interrupt interrupts}the current thread.
If the current thread:
- has its interrupted status set on entry to this method; or
- is {@linkplain Thread#interrupt interrupted} while waiting,
then {@link InterruptedException} is thrown and the current thread'sinterrupted status is cleared.
@throws InterruptedException if the current thread is interruptedwhile waiting
-
java.util.concurrent.CyclicBarrier.await()
Waits until all {@linkplain #getParties parties} have invoked{@code await} on this barrier.
If the current thread is not the last to arrive then it is disabled for thread scheduling purposes and lies dormant until one of the following things happens:
- The last thread arrives; or
- Some other thread {@linkplain Thread#interrupt interrupts}the current thread; or
- Some other thread {@linkplain Thread#interrupt interrupts}one of the other waiting threads; or
- Some other thread times out while waiting for barrier; or
- Some other thread invokes {@link #reset} on this barrier.
If the current thread:
- has its interrupted status set on entry to this method; or
- is {@linkplain Thread#interrupt interrupted} while waiting
then {@link InterruptedException} is thrown and the current thread'sinterrupted status is cleared.
If the barrier is {@link #reset} while any thread is waiting,or if the barrier {@linkplain #isBroken is broken} when{@code await} is invoked, or while any thread is waiting, then{@link BrokenBarrierException} is thrown.
If any thread is {@linkplain Thread#interrupt interrupted} while waiting,then all other waiting threads will throw {@link BrokenBarrierException} and the barrier is placed in the brokenstate.
If the current thread is the last thread to arrive, and a non-null barrier action was supplied in the constructor, then the current thread runs the action before allowing the other threads to continue. If an exception occurs during the barrier action then that exception will be propagated in the current thread and the barrier is placed in the broken state.
@return the arrival index of the current thread, where index{@code getParties() - 1} indicates the firstto arrive and zero indicates the last to arrive
@throws InterruptedException if the current thread was interruptedwhile waiting
@throws BrokenBarrierException if another thread wasinterrupted or timed out while the current thread was waiting, or the barrier was reset, or the barrier was broken when {@code await} was called, or the barrieraction (if present) failed due to an exception
-
java.util.concurrent.atomic.AtomicInteger.await()
-
java.util.concurrent.locks.Condition.await()
Causes the current thread to wait until it is signalled or {@linkplain Thread#interrupt interrupted}.
The lock associated with this {@code Condition} is atomicallyreleased and the current thread becomes disabled for thread scheduling purposes and lies dormant until one of four things happens:
- Some other thread invokes the {@link #signal} method for this{@code Condition} and the current thread happens to be chosen as thethread to be awakened; or
- Some other thread invokes the {@link #signalAll} method for this{@code Condition}; or
- Some other thread {@linkplain Thread#interrupt interrupts} thecurrent thread, and interruption of thread suspension is supported; or
- A "spurious wakeup" occurs.
In all cases, before this method can return the current thread must re-acquire the lock associated with this condition. When the thread returns it is guaranteed to hold this lock.
If the current thread:
- has its interrupted status set on entry to this method; or
- is {@linkplain Thread#interrupt interrupted} while waitingand interruption of thread suspension is supported,
then {@link InterruptedException} is thrown and the current thread'sinterrupted status is cleared. It is not specified, in the first case, whether or not the test for interruption occurs before the lock is released.
Implementation Considerations
The current thread is assumed to hold the lock associated with this {@code Condition} when this method is called.It is up to the implementation to determine if this is the case and if not, how to respond. Typically, an exception will be thrown (such as {@link IllegalMonitorStateException}) and the implementation must document that fact.
An implementation can favor responding to an interrupt over normal method return in response to a signal. In that case the implementation must ensure that the signal is redirected to another waiting thread, if there is one.
@throws InterruptedException if the current thread is interrupted(and interruption of thread suspension is supported)
-
net.jodah.concurrentunit.Waiter.await()
Waits until {@link #resume()} is called the expected number of times, or the test is failed.
@throws IllegalStateException if called from outside the main test thread
@throws TimeoutException if the operation times out while waiting for a result
@throws Throwable if any assertion fails
-
net.kuujo.copycat.test.TestNode.await()
Returns test event listeners.
-
net.myrrix.online.ServerRecommender.await()
-
net.tomp2p.futures.FutureDirect.await()
-
net.tomp2p.futures.FutureResponse.await()
-
org.apache.accumulo.server.tabletserver.log.DfsLogger.LoggerOperation.await()
-
org.apache.accumulo.tserver.log.DfsLogger.LoggerOperation.await()
-
org.apache.activemq.leveldb.CountDownFuture.await()
-
org.apache.bookkeeper.replication.ReplicationEnableCb.await()
This is a blocking call and causes the current thread to wait until the replication process is enabled
@throws InterruptedException interrupted while waiting
-
org.apache.camel.component.mock.MockEndpoint.await()
-
org.apache.camel.component.salesforce.internal.client.SyncResponseCallback.await()
-
org.apache.camel.util.concurrent.CountingLatch.await()
Await the latch reaching the count of 0
@throws InterruptedException if the threads gets interrupted while waiting
-
org.apache.cassandra.utils.SimpleCondition.await()
-
org.apache.cassandra.utils.concurrent.SimpleCondition.await()
-
org.apache.catalina.Server.await()
Wait until a proper shutdown command is received, then return.
-
org.apache.catalina.core.StandardServer.await()
Wait until a proper shutdown command is received, then return. This keeps the main thread alive - the thread pool listening for http connections is daemon threads.
-
org.apache.curator.framework.recipes.leader.LeaderLatch.await()
Causes the current thread to wait until this instance acquires leadership unless the thread is {@linkplain Thread#interrupt interrupted} or {@linkplain #close() closed}.
If this instance already is the leader then this method returns immediately.
Otherwise the current thread becomes disabled for thread scheduling purposes and lies dormant until one of three things happen:
- This instance becomes the leader
- Some other thread {@linkplain Thread#interrupt interrupts}the current thread
- The instance is {@linkplain #close() closed}
If the current thread:
- has its interrupted status set on entry to this method; or
- is {@linkplain Thread#interrupt interrupted} while waiting,
then {@link InterruptedException} is thrown and the current thread'sinterrupted status is cleared.
@throws InterruptedException if the current thread is interruptedwhile waiting
@throws EOFException if the instance is {@linkplain #close() closed}while waiting
-
org.apache.derbyTesting.functionTests.util.Barrier.await()
Wait until {@code numThreads} have called {@code await()} on thisbarrier, then proceed.
@throws InterruptedException if the thread is interrupted whilewaiting for the other threads to reach the barrier.
-
org.apache.drill.exec.client.PrintingResultsListener.await()
-
org.apache.felix.framework.util.ThreadGate.await()
Wait for the gate to open.
@return true if the gate was opened or false if the timeout expired.
@throws java.lang.InterruptedException If the calling thread is interrupted;the gate still remains closed until opened.
-
org.apache.hadoop.hbase.hbql.client.QueryFuture.await()
-
org.apache.hadoop.hdfs.server.namenode.bookkeeper.zk.ConnectionWatcher.await()
Wait until either a specified timeout expires or a connection is created to ZooKeeper.
@see {@link CountDownLatch#await(long,TimeUnit)}
@param timeoutMillis Wait this long (in milliseconds) for a connectionto be established to ZooKeeper.
@return True if a connection was established within the specified timeout,false if a timeout has occurred before a connection to ZooKeeper could be established.
@throws IOException If we interrupted while awaiting for connection toZooKeeper to be established
-
org.apache.hadoop.yarn.event.DrainDispatcher.await()
Busy loop waiting for all queued events to drain.
-
org.apache.http.impl.nio.mockup.CountingEventListener.await()
-
org.apache.http.mockup.RequestCount.await()
-
org.apache.http.nio.mockup.CountingEventListener.await()
-
org.apache.karaf.features.internal.download.Downloader.await()
-
org.apache.mina.common.ConnectFuture.await()
-
org.apache.mina.core.future.ConnectFuture.await()
-
org.apache.mina.core.future.IoFuture.await()
Wait for the asynchronous operation to complete. The attached listeners will be notified when the operation is completed.
-
org.apache.mina.core.future.WriteFuture.await()
Wait for the asynchronous operation to complete. The attached listeners will be notified when the operation is completed.
@return the created {@link WriteFuture}
@throws InterruptedException
-
org.apache.openejb.util.OutputScanner.await()
-
org.apache.qpid.client.state.StateWaiter.await()
Await for the required State to be achieved within the default timeout.
@return The achieved state that was requested.
@throws AMQException The exception that prevented the required state from being achieved.
-
org.apache.qpid.test.utils.Piper.await()
-
org.apache.qpid.transport.util.Waiter.await()
-
org.apache.sshd.client.future.AuthFuture.await()
-
org.apache.sshd.client.future.ConnectFuture.await()
-
org.apache.sshd.client.future.OpenFuture.await()
-
org.apache.sshd.common.future.CloseFuture.await()
-
org.apache.sshd.common.io.IoWriteFuture.await()
-
org.apache.tomcat.util.threads.CounterLatch.await()
Causes the calling thread to wait if the counter holds the waitValue. If the counter holds any other value, the thread will return If the thread is interrupted or becomes interrupted an InterruptedException is thrown
@throws InterruptedException
-
org.ardverk.dht.utils.Idle.await()
-
org.cometd.javascript.Latch.await()
-
org.eclipse.jetty.client.util.InputStreamResponseListener.await()
-
org.fusesource.hawtdispatch.internal.util.RunnableCountDownLatch.await()
-
org.fusesource.mqtt.client.Promise.await()
-
org.glassfish.admin.mbeanserver.PendingConfigBeanJob.await()
-
org.hive2hive.core.network.data.futures.FutureChangeProtectionListener.await()
Wait (blocking) until the change of the protection key is done
@return true if successful, false if not successful
-
org.hive2hive.core.network.data.futures.FuturePutListener.await()
Wait (blocking) until the put is done
@return true if successful, false if not successful
-
org.hive2hive.core.network.data.futures.FutureRemoveListener.await()
Wait (blocking) until the remove is done
@return true if successful, false if not successful
-
org.hive2hive.core.network.messages.futures.FutureDirectListener.await()
Wait (blocking) until the message is sent
@return true if successful, false if not successful
-
org.hive2hive.core.network.messages.futures.FutureRoutedListener.await()
Wait (blocking) until the message is sent
@return true if successful, false if not successful
-
org.hive2hive.core.processes.framework.concretes.SequentialProcess.await()
-
org.hive2hive.core.processes.framework.decorators.AsyncComponent.await()
-
org.hive2hive.core.processes.framework.interfaces.IProcessComponent.await()
Wait for the process component to terminate. Blocks execution until then.
@throws InterruptedException
-
org.hornetq.utils.Future.await()
-
org.hornetq.utils.FutureLatch.await()
-
org.hornetq.utils.ReusableLatch.await()
-
org.infinispan.test.fwk.CheckPoint.await()
-
org.jboss.dna.graph.request.CompositeRequestChannel.await()
Await until this channel has completed.
@throws CancellationException if the channel was cancelled
@throws ExecutionException if the channel execution threw an exception
@throws InterruptedException if the current thread is interrupted while waiting
-
org.jboss.netty.channel.ChannelFuture.await()
Waits for this future to be completed.
@throws InterruptedException if the current thread was interrupted
-
org.jboss.netty.channel.group.ChannelGroupFuture.await()
Waits for this future to be completed.
@throws InterruptedException if the current thread was interrupted
-
org.menagerie.latches.spi.ZkCyclicBarrier.await()
Waits until all parties have been invoked on this barrier.
If the current thread is not the last to arrive, then it is disabled for thread-scheduling purposes and lies dormant until one of the following conditions are realized:
- The Last party arrives
- Some other thread interrupts the current thread
- Some other Thread interrupts one of the other waiting parties
- Some other party times out while waiting for the barrier
- This barrier is intolerant of party failures, and some other party prematurely leaves the barrier due to an external system event such as a network failure
- Some other party invokes {@link #reset()} on this barrier
If the current thread:
- has its interrupted status set on entry to this method; or
- is interrupted while waiting
Then the Barrier is broken for all other parties, and an {@link InterruptedException}is thrown on this thread, clearing the current interrupted status.
This Barrier is considered broken if one of the following conditions apply:
- Another party times out while waiting for the barrier
- Another party invoked {@link #reset()} on this barrier
- Another party prematurely leaves the barrier due to an external system event such as a network failure, and this barrier is set to be intolerant of party failures
- Another party received notification of a Thread Interruption
If any of these situations occur, a {@link java.util.concurrent.BrokenBarrierException} is thrown.
@return the index of this thread with respect to all other parties in the Barrier. If this thread is thefirst to arrive, index is {@link #getParties()}-1; the last thread to arrive will return 0
@throws InterruptedException if the local thread is interrupted, or if there is a communication errorwith ZooKeeper
@throws BrokenBarrierException if another party breaks the barrier, or another party calls reset whilewaiting for the Barrier to complete
-
org.mule.tck.functional.CountdownCallback.await()
-
org.mule.util.concurrent.Latch.await()
-
org.ofbiz.base.concurrent.DependencyPool.await()
-
org.openrdf.sail.federation.evaluation.FederationStatistics.await()
-
org.redisson.core.RCountDownLatch.await()
Causes the current thread to wait until the latch has counted down to zero, unless the thread is {@linkplain Thread#interrupt interrupted}.
If the current count is zero then this method returns immediately.
If the current count is greater than zero then the current thread becomes disabled for thread scheduling purposes and lies dormant until one of two things happen:
- The count reaches zero due to invocations of the {@link #countDown} method; or
- Some other thread {@linkplain Thread#interrupt interrupts}the current thread.
If the current thread:
- has its interrupted status set on entry to this method; or
- is {@linkplain Thread#interrupt interrupted} while waiting,
then {@link InterruptedException} is thrown and the current thread'sinterrupted status is cleared.
@throws InterruptedException if the current thread is interruptedwhile waiting
-
org.sonatype.aether.util.concurrency.RunnableErrorForwarder.await()
Causes the current thread to wait until all previously {@link #wrap(Runnable) wrapped} runnables have terminatedand potentially re-throws an uncaught {@link RuntimeException} or {@link Error} from any of the runnables. Incase multiple runnables encountered uncaught errors, one error is arbitrarily selected.
-
org.springframework.boot.cli.infrastructure.CommandLineInvoker.Invocation.await()
-
org.voltcore.zk.ZKCountdownLatch.await()
-
programming5.net.ReceiveRequest.await()
Waits on this condition until signaled or interrupted
-
uk.co.caprica.vlcj.player.condition.conditions.ParsedCondition.await()
-
uk.co.caprica.vlcj.player.condition.conditions.PausedCondition.await()
-
uk.co.caprica.vlcj.player.condition.conditions.PlayingCondition.await()
-
uk.co.caprica.vlcj.player.condition.conditions.SnapshotTakenCondition.await()
-
uk.co.caprica.vlcj.player.condition.conditions.TimeReachedCondition.await()