A B C D E F G H I J L M N O P Q R S T U V W Y Z 
All Classes All Packages

A

AbstractFuture<V> - Class in co.paralleluniverse.strands
 
AbstractFuture() - Constructor for class co.paralleluniverse.strands.AbstractFuture
 
AbstractOwnableSynchronizer - Class in co.paralleluniverse.strands.concurrent
A synchronizer that may be exclusively owned by a strand.
AbstractOwnableSynchronizer() - Constructor for class co.paralleluniverse.strands.concurrent.AbstractOwnableSynchronizer
Empty constructor for use by subclasses.
AbstractQueuedLongSynchronizer - Class in co.paralleluniverse.strands.concurrent
A version of AbstractQueuedSynchronizer in which synchronization state is maintained as a long.
AbstractQueuedLongSynchronizer() - Constructor for class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Creates a new AbstractQueuedLongSynchronizer instance with initial synchronization state of zero.
AbstractQueuedLongSynchronizer.ConditionObject - Class in co.paralleluniverse.strands.concurrent
Condition implementation for a AbstractQueuedLongSynchronizer serving as the basis of a Lock implementation.
AbstractQueuedSynchronizer - Class in co.paralleluniverse.strands.concurrent
Provides a framework for implementing blocking locks and related synchronizers (semaphores, events, etc) that rely on first-in-first-out (FIFO) wait queues.
AbstractQueuedSynchronizer() - Constructor for class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Creates a new AbstractQueuedSynchronizer instance with initial synchronization state of zero.
AbstractQueuedSynchronizer.ConditionObject - Class in co.paralleluniverse.strands.concurrent
Condition implementation for a AbstractQueuedSynchronizer serving as the basis of a Lock implementation.
AbstractServerHandler<CallMessage,​V,​CastMessage> - Class in co.paralleluniverse.actors.behaviors
A convenience class implementing the ServerHandler interface.
AbstractServerHandler() - Constructor for class co.paralleluniverse.actors.behaviors.AbstractServerHandler
 
accept() - Method in class co.paralleluniverse.fibers.io.FiberServerSocketChannel
Accepts a connection.
acquire() - Method in class co.paralleluniverse.strands.concurrent.Semaphore
Acquires a permit from this semaphore, blocking until one is available, or the thread is interrupted.
acquire(int) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Acquires in exclusive mode, ignoring interrupts.
acquire(int) - Method in class co.paralleluniverse.strands.concurrent.Semaphore
Acquires the given number of permits from this semaphore, blocking until all are available, or the thread is interrupted.
acquire(long) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Acquires in exclusive mode, ignoring interrupts.
acquireInterruptibly(int) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Acquires in exclusive mode, aborting if interrupted.
acquireInterruptibly(long) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Acquires in exclusive mode, aborting if interrupted.
acquireShared(int) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Acquires in shared mode, ignoring interrupts.
acquireShared(long) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Acquires in shared mode, ignoring interrupts.
acquireSharedInterruptibly(int) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Acquires in shared mode, aborting if interrupted.
acquireSharedInterruptibly(long) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Acquires in shared mode, aborting if interrupted.
acquireUninterruptibly() - Method in class co.paralleluniverse.strands.concurrent.Semaphore
Acquires a permit from this semaphore, blocking until one is available.
acquireUninterruptibly(int) - Method in class co.paralleluniverse.strands.concurrent.Semaphore
Acquires the given number of permits from this semaphore, blocking until all are available.
actor - Variable in class co.paralleluniverse.actors.ExitMessage
 
Actor<Message,​V> - Class in co.paralleluniverse.actors
An actor is a self-contained execution unit - an object running in its own strand and communicating with other actors via messages.
Actor() - Constructor for class co.paralleluniverse.actors.Actor
This constructor must only be called by hot code-swap actors, and never, ever, called by application code.
Actor(Strand, String, MailboxConfig) - Constructor for class co.paralleluniverse.actors.Actor
Creates a new actor.
Actor(String, MailboxConfig) - Constructor for class co.paralleluniverse.actors.Actor
Creates a new actor.
ActorBuilder<Message,​V> - Interface in co.paralleluniverse.actors
An object that can construct a new actor
ActorImpl<Message> - Class in co.paralleluniverse.actors
 
ActorImpl(String, SendPort<Object>, ActorRef<Message>) - Constructor for class co.paralleluniverse.actors.ActorImpl
 
ActorImpl.ActorLifecycleListener - Class in co.paralleluniverse.actors
 
ActorInfo - Class in co.paralleluniverse.actors
Information about an actor returned by ActorsMXBean.
ActorInfo(long, String, boolean, long, int, int, String[], String[], String) - Constructor for class co.paralleluniverse.actors.ActorInfo
 
ActorLifecycleListener(ActorRef, Object) - Constructor for class co.paralleluniverse.actors.ActorImpl.ActorLifecycleListener
 
ActorLoader - Class in co.paralleluniverse.actors
Loads actor, and actor-related classes for hot code-swapping.
ActorLoaderMXBean - Interface in co.paralleluniverse.actors
 
ActorMessage - Class in co.paralleluniverse.actors.behaviors
A class extended by all standard actor messages in this package.
ActorMessage() - Constructor for class co.paralleluniverse.actors.behaviors.ActorMessage
 
ActorMXBean - Interface in co.paralleluniverse.actors
An MXBean monitoring a single actor.
ActorRef<Message> - Class in co.paralleluniverse.actors
An actor's external API (for use by code not part of the actor).
ActorRef() - Constructor for class co.paralleluniverse.actors.ActorRef
 
ActorRef(ActorImpl<Message>) - Constructor for class co.paralleluniverse.actors.ActorRef
 
ActorRefDelegate<Message> - Class in co.paralleluniverse.actors
An ActorRef which delegates all operations to another ActorRef.
ActorRefDelegate(ActorRef<Message>) - Constructor for class co.paralleluniverse.actors.ActorRefDelegate
Constructs an ActorRefDelegate
ActorRegistry - Class in co.paralleluniverse.actors
A registry used to find registered actors by name.
ActorRegistry() - Constructor for class co.paralleluniverse.actors.ActorRegistry
 
ActorsMXBean - Interface in co.paralleluniverse.actors
An MXBean that monitors all actors.
ActorSpec<T extends Actor<Message,​V>,​Message,​V> - Class in co.paralleluniverse.actors
A specification of how to construct an actor
ActorSpec(Class<T>, Object[]) - Constructor for class co.paralleluniverse.actors.ActorSpec
Specifies an actor of a given type and given constructor parameters.
ActorSpec(Constructor<T>, Object[]) - Constructor for class co.paralleluniverse.actors.ActorSpec
Specifies an actor with given constructor and given constructor parameters.
ActorSpec(String, Object[]) - Constructor for class co.paralleluniverse.actors.ActorSpec
Specifies an actor of a given type and given constructor parameters.
actorToString(ActorRef<?>) - Static method in class co.paralleluniverse.actors.LocalActor
 
ActorUtil - Class in co.paralleluniverse.actors
Static utility methods for working with actors.
add(T...) - Method in interface co.paralleluniverse.strands.channels.Mix
 
add(T...) - Method in class co.paralleluniverse.strands.channels.ReceivePortGroup
 
addChild(Supervisor.ChildSpec) - Method in class co.paralleluniverse.actors.behaviors.Supervisor
Adds a new child actor to the supervisor.
addChild(Supervisor.ChildSpec) - Method in class co.paralleluniverse.actors.behaviors.SupervisorActor
Adds a new child actor to the supervisor.
addHandler(EventHandler<Event>) - Method in class co.paralleluniverse.actors.behaviors.EventSource
Adds an EventHandler that will be notified of every event sent to this actor.
addHandler(EventHandler<Event>) - Method in class co.paralleluniverse.actors.behaviors.EventSourceActor
 
addLifecycleListener(LifecycleListener) - Method in class co.paralleluniverse.actors.Actor
 
addLifecycleListener(LifecycleListener) - Method in class co.paralleluniverse.actors.ActorImpl
 
addLifecycleListener(LifecycleListener) - Method in class co.paralleluniverse.actors.FakeActor
 
addLifecycleListener(LifecycleListener) - Method in class co.paralleluniverse.actors.RemoteActor
 
addNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class co.paralleluniverse.actors.ActorLoader
 
addWatch(long) - Method in interface co.paralleluniverse.actors.ActorsMXBean
Add an actor to the list of watched actors.
ALL_FOR_ONE - co.paralleluniverse.actors.behaviors.SupervisorActor.RestartStrategy
Kill all surviving children, and restart them all.
arrive() - Method in class co.paralleluniverse.strands.concurrent.Phaser
Arrives at this phaser, without waiting for others to arrive.
arriveAndAwaitAdvance() - Method in class co.paralleluniverse.strands.concurrent.Phaser
Arrives at this phaser and awaits others.
arriveAndDeregister() - Method in class co.paralleluniverse.strands.concurrent.Phaser
Arrives at this phaser and deregisters from it without waiting for others to arrive.
asReadLock() - Method in class co.paralleluniverse.strands.concurrent.StampedLock
Returns a plain Lock view of this StampedLock in which the Lock.lock() method is mapped to StampedLock.readLock(), and similarly for other methods.
asReadWriteLock() - Method in class co.paralleluniverse.strands.concurrent.StampedLock
Returns a ReadWriteLock view of this StampedLock in which the ReadWriteLock.readLock() method is mapped to StampedLock.asReadLock(), and ReadWriteLock.writeLock() to StampedLock.asWriteLock().
asSuspendable(Runnable) - Static method in class co.paralleluniverse.strands.SuspendableUtils
 
asSuspendable(Callable<V>) - Static method in class co.paralleluniverse.strands.SuspendableUtils
 
asSuspendableCallable(CheckedSuspendableCallable<V, E>) - Static method in class co.paralleluniverse.strands.SuspendableUtils
 
asWriteLock() - Method in class co.paralleluniverse.strands.concurrent.StampedLock
Returns a plain Lock view of this StampedLock in which the Lock.lock() method is mapped to StampedLock.writeLock(), and similarly for other methods.
asyncCompleted(V) - Method in class co.paralleluniverse.fibers.FiberAsync
This method must be called by the callback upon successful completion of the asynchronous operation.
AsyncCompletionStage<V> - Class in co.paralleluniverse.fibers.futures
Turns CompletableFutures into fiber-blocking operations.
asyncFailed(Throwable) - Method in class co.paralleluniverse.fibers.FiberAsync
This method must be called by the callback upon a failure of the asynchronous operation.
AsyncListenableFuture<V> - Class in co.paralleluniverse.fibers.futures
Turns Google Guava's ListenableFutures into a fiber-blocking operation.
availablePermits() - Method in class co.paralleluniverse.strands.concurrent.Semaphore
Returns the current number of permits available in this semaphore.
await() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer.ConditionObject
Implements interruptible condition wait.
await() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer.ConditionObject
Implements interruptible condition wait.
await() - Method in class co.paralleluniverse.strands.concurrent.CountDownLatch
Causes the current thread to wait until the latch has counted down to zero, unless the thread is interrupted.
await() - Method in class co.paralleluniverse.strands.concurrent.CyclicBarrier
Waits until all parties have invoked await on this barrier.
await(int) - Method in class co.paralleluniverse.actors.Mailbox
 
await(int) - Method in interface co.paralleluniverse.strands.Condition
 
await(int) - Method in class co.paralleluniverse.strands.ConditionSynchronizer
 
await(int) - Method in class co.paralleluniverse.strands.DoneSynchronizer
 
await(int, long, TimeUnit) - Method in class co.paralleluniverse.actors.Mailbox
 
await(int, long, TimeUnit) - Method in interface co.paralleluniverse.strands.Condition
 
await(int, long, TimeUnit) - Method in class co.paralleluniverse.strands.ConditionSynchronizer
 
await(int, long, TimeUnit) - Method in class co.paralleluniverse.strands.DoneSynchronizer
 
await(long, TimeUnit) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer.ConditionObject
Implements timed condition wait.
await(long, TimeUnit) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer.ConditionObject
Implements timed condition wait.
await(long, TimeUnit) - Method in class co.paralleluniverse.strands.concurrent.CountDownLatch
Causes the current thread to wait until the latch has counted down to zero, unless the thread is interrupted, or the specified waiting time elapses.
await(long, TimeUnit) - Method in class co.paralleluniverse.strands.concurrent.CyclicBarrier
Waits until all parties have invoked await on this barrier, or the specified waiting time elapses.
awaitAdvance(int) - Method in class co.paralleluniverse.strands.concurrent.Phaser
Awaits the phase of this phaser to advance from the given phase value, returning immediately if the current phase is not equal to the given phase value or this phaser is terminated.
awaitAdvanceInterruptibly(int) - Method in class co.paralleluniverse.strands.concurrent.Phaser
Awaits the phase of this phaser to advance from the given phase value, throwing InterruptedException if interrupted while waiting, or returning immediately if the current phase is not equal to the given phase value or this phaser is terminated.
awaitAdvanceInterruptibly(int, long, TimeUnit) - Method in class co.paralleluniverse.strands.concurrent.Phaser
Awaits the phase of this phaser to advance from the given phase value or the given timeout to elapse, throwing InterruptedException if interrupted while waiting, or returning immediately if the current phase is not equal to the given phase value or this phaser is terminated.
awaitNanos(int, long) - Method in class co.paralleluniverse.strands.ConditionSynchronizer
 
awaitNanos(long) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer.ConditionObject
Implements timed condition wait.
awaitNanos(long) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer.ConditionObject
Implements timed condition wait.
awaitUninterruptibly() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer.ConditionObject
Implements uninterruptible condition wait.
awaitUninterruptibly() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer.ConditionObject
Implements uninterruptible condition wait.
awaitUntil(Date) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer.ConditionObject
Implements absolute timed condition wait.
awaitUntil(Date) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer.ConditionObject
Implements absolute timed condition wait.

B

BACKOFF - co.paralleluniverse.strands.channels.Channels.OverflowPolicy
The sender will block for some time, and retry.
BasicActor<Message,​V> - Class in co.paralleluniverse.actors
A subclass of Actor that provides selective receive capabilities.
BasicActor() - Constructor for class co.paralleluniverse.actors.BasicActor
Creates a new unnamed actor.
BasicActor(MailboxConfig) - Constructor for class co.paralleluniverse.actors.BasicActor
Creates a new, unnamed actor.
BasicActor(Strand, MailboxConfig) - Constructor for class co.paralleluniverse.actors.BasicActor
 
BasicActor(Strand, String, MailboxConfig) - Constructor for class co.paralleluniverse.actors.BasicActor
 
BasicActor(String) - Constructor for class co.paralleluniverse.actors.BasicActor
Creates a new actor.
BasicActor(String, MailboxConfig) - Constructor for class co.paralleluniverse.actors.BasicActor
Creates a new actor.
behavior() - Method in class co.paralleluniverse.actors.behaviors.BehaviorActor
Called by BehaviorActor.doRun() as the body of the logic.
behavior() - Method in class co.paralleluniverse.actors.behaviors.FiniteStateMachineActor
 
behavior() - Method in class co.paralleluniverse.actors.behaviors.ServerActor
 
Behavior - Class in co.paralleluniverse.actors.behaviors
A general behavior-actor interface
Behavior(ActorRef<Object>) - Constructor for class co.paralleluniverse.actors.behaviors.Behavior
 
BehaviorActor - Class in co.paralleluniverse.actors.behaviors
A general behavior-actor class, extended by all behaviors.
BehaviorActor() - Constructor for class co.paralleluniverse.actors.behaviors.BehaviorActor
Creates a new behavior actor.
BehaviorActor(Initializer) - Constructor for class co.paralleluniverse.actors.behaviors.BehaviorActor
Creates a new behavior actor.
BehaviorActor(Initializer, MailboxConfig) - Constructor for class co.paralleluniverse.actors.behaviors.BehaviorActor
Creates a new behavior actor.
BehaviorActor(MailboxConfig) - Constructor for class co.paralleluniverse.actors.behaviors.BehaviorActor
Creates a new behavior actor.
BehaviorActor(String) - Constructor for class co.paralleluniverse.actors.behaviors.BehaviorActor
Creates a new behavior actor.
BehaviorActor(String, Initializer) - Constructor for class co.paralleluniverse.actors.behaviors.BehaviorActor
Creates a new behavior actor.
BehaviorActor(String, Initializer, MailboxConfig) - Constructor for class co.paralleluniverse.actors.behaviors.BehaviorActor
Creates a new behavior actor.
BehaviorActor(String, Initializer, Strand, MailboxConfig) - Constructor for class co.paralleluniverse.actors.behaviors.BehaviorActor
Creates a new behavior actor.
BehaviorActor(String, MailboxConfig) - Constructor for class co.paralleluniverse.actors.behaviors.BehaviorActor
Creates a new behavior actor.
bind(SocketAddress) - Method in class co.paralleluniverse.fibers.io.FiberServerSocketChannel
Binds the channel's socket to a local address and configures the socket to listen for connections.
bind(SocketAddress) - Method in class co.paralleluniverse.fibers.io.FiberSocketChannel
 
bind(SocketAddress, int) - Method in class co.paralleluniverse.fibers.io.FiberServerSocketChannel
Binds the channel's socket to a local address and configures the socket to listen for connections.
BLOCK - co.paralleluniverse.strands.channels.Channels.OverflowPolicy
The sender will block until there's a vacancy in the channel.
build() - Method in class co.paralleluniverse.actors.Actor
 
build() - Method in interface co.paralleluniverse.actors.ActorBuilder
Constructs a new actor
build() - Method in class co.paralleluniverse.actors.ActorSpec
 
build() - Method in class co.paralleluniverse.strands.StrandFactoryBuilder
Creates and returns the StrandFactory that will create new strands based on this builder's settings.
bulkRegister(int) - Method in class co.paralleluniverse.strands.concurrent.Phaser
Adds the given number of new unarrived parties to this phaser.

C

call() - Method in interface co.paralleluniverse.strands.CheckedSuspendableCallable
 
call(CallMessage) - Method in class co.paralleluniverse.actors.behaviors.Server
Sends a synchronous request to the actor, and awaits a response.
call(CallMessage, long, TimeUnit) - Method in class co.paralleluniverse.actors.behaviors.Server
Sends a synchronous request to the actor, and awaits a response, but no longer than the given timeout.
call(CallMessage, Timeout) - Method in class co.paralleluniverse.actors.behaviors.Server
Sends a synchronous request to the actor, and awaits a response, but no longer than the given timeout.
call(ActorRef<? super M>, M) - Static method in class co.paralleluniverse.actors.behaviors.RequestReplyHelper
Sends a request message to an actor, awaits a response value and returns it.
call(ActorRef, RequestMessage<V>, long, TimeUnit) - Static method in class co.paralleluniverse.actors.behaviors.RequestReplyHelper
Sends a request message to an actor, awaits a response value (but no longer than the given timeout) and returns it.
call(ActorRef, RequestMessage<V>, Timeout) - Static method in class co.paralleluniverse.actors.behaviors.RequestReplyHelper
Sends a request message to an actor, awaits a response value (but no longer than the given timeout) and returns it.
call(S) - Method in interface co.paralleluniverse.strands.SuspendableAction1
 
call(S1, S2) - Method in interface co.paralleluniverse.strands.SuspendableAction2
 
cancel(boolean) - Method in class co.paralleluniverse.fibers.Fiber
 
cancel(boolean) - Method in class co.paralleluniverse.strands.AbstractFuture
 
cancel(boolean) - Method in class co.paralleluniverse.strands.dataflow.Val
Throws UnsupportedOperationException.
capacity() - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
capacity() - Method in interface co.paralleluniverse.strands.channels.StandardChannel
The channel's internal buffer capacity.
capacity() - Method in class co.paralleluniverse.strands.channels.TransferChannel
 
cast(CastMessage) - Method in class co.paralleluniverse.actors.behaviors.Server
Sends an asynchronous request to the actor and returns immediately (may block until there's room available in the actor's mailbox).
cause - Variable in class co.paralleluniverse.actors.ExitMessage
 
Channel<Message> - Interface in co.paralleluniverse.strands.channels
A message-passing channel.
ChannelClosedException - Exception in co.paralleluniverse.strands.channels
 
ChannelClosedException() - Constructor for exception co.paralleluniverse.strands.channels.ChannelClosedException
 
ChannelClosedException(SendPort<?>) - Constructor for exception co.paralleluniverse.strands.channels.ChannelClosedException
 
ChannelClosedException(SendPort<?>, Throwable) - Constructor for exception co.paralleluniverse.strands.channels.ChannelClosedException
 
ChannelClosedException(String) - Constructor for exception co.paralleluniverse.strands.channels.ChannelClosedException
 
ChannelClosedException(String, Throwable) - Constructor for exception co.paralleluniverse.strands.channels.ChannelClosedException
 
ChannelClosedException(Throwable) - Constructor for exception co.paralleluniverse.strands.channels.ChannelClosedException
 
ChannelGroup - Class in co.paralleluniverse.fibers.io
A grouping of channels for the purpose of resource sharing.
ChannelGroup() - Constructor for class co.paralleluniverse.fibers.io.ChannelGroup
 
Channels - Class in co.paralleluniverse.strands.channels
A utility class for creating and manipulating channels.
Channels.OverflowPolicy - Enum in co.paralleluniverse.strands.channels
Determines how a channel behaves when its internal buffer (if it has one) overflows.
checkClosed() - Method in class co.paralleluniverse.strands.channels.QueuePrimitiveChannel
 
checkClosed() - Method in class co.paralleluniverse.strands.channels.SingleConsumerQueueChannel
 
checkClosed() - Method in class co.paralleluniverse.strands.channels.TickerChannelConsumer
 
checkCodeSwap() - Method in class co.paralleluniverse.actors.Actor
Tests whether this actor has been upgraded via hot code-swapping.
checkCodeSwap() - Method in class co.paralleluniverse.actors.behaviors.BehaviorActor
 
checkCodeSwap() - Method in class co.paralleluniverse.actors.behaviors.ProxyServerActor
 
CheckedSuspendableCallable<V,​E extends java.lang.Exception> - Interface in co.paralleluniverse.strands
This interface can represent any operation that may suspend the currently executing Strand (i.e.
checkThrownIn() - Method in class co.paralleluniverse.actors.Actor
Tests whether an exception has been thrown into this actor, and if so, throws it.
ChildSpec(String, Supervisor.ChildMode, int, long, TimeUnit, long, ActorBuilder<?, ?>) - Constructor for class co.paralleluniverse.actors.behaviors.Supervisor.ChildSpec
A new spec.
ChildSpec(String, Supervisor.ChildMode, int, long, TimeUnit, long, ActorRef<?>) - Constructor for class co.paralleluniverse.actors.behaviors.Supervisor.ChildSpec
A new spec.
clear() - Static method in class co.paralleluniverse.actors.ActorRegistry
Clears the registry (use only in tests!).
clone(Strand, SuspendableCallable<?>) - Static method in class co.paralleluniverse.strands.Strand
 
clone(Strand, SuspendableRunnable) - Static method in class co.paralleluniverse.strands.Strand
 
close() - Method in class co.paralleluniverse.actors.Actor
 
close() - Method in class co.paralleluniverse.actors.ActorImpl
 
close() - Method in class co.paralleluniverse.actors.ActorRef
This implementation throws UnsupportedOperationException.
close() - Method in class co.paralleluniverse.actors.Mailbox
 
close() - Method in class co.paralleluniverse.fibers.io.FiberFileChannel
 
close() - Method in class co.paralleluniverse.fibers.io.FiberServerSocketChannel
 
close() - Method in class co.paralleluniverse.fibers.io.FiberSocketChannel
 
close() - Method in class co.paralleluniverse.strands.channels.DelegatingReceivePort
 
close() - Method in class co.paralleluniverse.strands.channels.DelegatingSendPort
 
close() - Method in interface co.paralleluniverse.strands.channels.PortAutoCloseable
Closes the channel so that no more messages could be sent to it.
close() - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
close() - Method in class co.paralleluniverse.strands.channels.ReceivePortGroup
 
close() - Method in class co.paralleluniverse.strands.channels.SplitSendPort
 
close() - Method in class co.paralleluniverse.strands.channels.ThreadReceivePort
Closes the channel so that no more messages could be sent to it.
close() - Method in class co.paralleluniverse.strands.channels.ThreadSendPort
Closes the channel so that no more messages could be sent to it.
close() - Method in class co.paralleluniverse.strands.channels.TickerChannelConsumer
 
close() - Method in class co.paralleluniverse.strands.channels.Topic
 
close() - Method in class co.paralleluniverse.strands.channels.TransferChannel
 
close() - Method in class co.paralleluniverse.strands.channels.ZippingReceivePort
 
close() - Method in class co.paralleluniverse.strands.dataflow.ValChannel
 
close(Throwable) - Method in class co.paralleluniverse.actors.ActorImpl
 
close(Throwable) - Method in class co.paralleluniverse.actors.ActorRef
This implementation throws UnsupportedOperationException.
close(Throwable) - Method in class co.paralleluniverse.strands.channels.DelegatingSendPort
 
close(Throwable) - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
close(Throwable) - Method in interface co.paralleluniverse.strands.channels.SendPort
Closes the channel so that no more messages could be sent to it, and signifies an exception occurred in the producer.
close(Throwable) - Method in class co.paralleluniverse.strands.channels.SplitSendPort
 
close(Throwable) - Method in class co.paralleluniverse.strands.channels.Topic
 
close(Throwable) - Method in class co.paralleluniverse.strands.channels.TransferChannel
 
co.paralleluniverse.actors - package co.paralleluniverse.actors
Quasar Actors
co.paralleluniverse.actors.behaviors - package co.paralleluniverse.actors.behaviors
Standard behavior actors (Server, EventSource, Supervisor)
co.paralleluniverse.fibers - package co.paralleluniverse.fibers
Fibers - lightweight threads
co.paralleluniverse.fibers.futures - package co.paralleluniverse.fibers.futures
Common future implementations as fiber-blocking operations
co.paralleluniverse.fibers.io - package co.paralleluniverse.fibers.io
Fiber-blocking NIO
co.paralleluniverse.strands - package co.paralleluniverse.strands
Strands - abstractions over fibers and threads
co.paralleluniverse.strands.channels - package co.paralleluniverse.strands.channels
Channels - a CSP (Communicating Sequential Processes) construct
co.paralleluniverse.strands.channels.reactivestreams - package co.paralleluniverse.strands.channels.reactivestreams
Reactive Streams
co.paralleluniverse.strands.channels.transfer - package co.paralleluniverse.strands.channels.transfer
 
co.paralleluniverse.strands.concurrent - package co.paralleluniverse.strands.concurrent
Concurrency primitives for strands - ports of java.util.concurrent classes compatible with strands
co.paralleluniverse.strands.dataflow - package co.paralleluniverse.strands.dataflow
 
compareAndSetState(int, int) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Atomically sets synchronization state to the given updated value if the current state value equals the expected value.
compareAndSetState(long, long) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Atomically sets synchronization state to the given updated value if the current state value equals the expected value.
ConcurrencyException - Exception in co.paralleluniverse.actors
 
ConcurrencyException() - Constructor for exception co.paralleluniverse.actors.ConcurrencyException
 
ConcurrencyException(String) - Constructor for exception co.paralleluniverse.actors.ConcurrencyException
 
ConcurrencyException(String, Throwable) - Constructor for exception co.paralleluniverse.actors.ConcurrencyException
 
ConcurrencyException(Throwable) - Constructor for exception co.paralleluniverse.actors.ConcurrencyException
 
Condition - Interface in co.paralleluniverse.strands
 
ConditionObject() - Constructor for class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer.ConditionObject
Creates a new ConditionObject instance.
ConditionObject() - Constructor for class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer.ConditionObject
Creates a new ConditionObject instance.
ConditionSelector - Class in co.paralleluniverse.strands
 
ConditionSelector(Object, Condition...) - Constructor for class co.paralleluniverse.strands.ConditionSelector
 
ConditionSelector(Object, Collection<Condition>) - Constructor for class co.paralleluniverse.strands.ConditionSelector
 
ConditionSynchronizer - Class in co.paralleluniverse.strands
 
ConditionSynchronizer(Object) - Constructor for class co.paralleluniverse.strands.ConditionSynchronizer
 
connect(SocketAddress) - Method in class co.paralleluniverse.fibers.io.FiberSocketChannel
Connects this channel.
connect(SocketAddress, long, TimeUnit) - Method in class co.paralleluniverse.fibers.io.FiberSocketChannel
Connects this channel.
contentString() - Method in class co.paralleluniverse.actors.behaviors.ActorMessage
 
contentString() - Method in class co.paralleluniverse.actors.behaviors.ErrorResponseMessage
 
contentString() - Method in class co.paralleluniverse.actors.behaviors.RequestMessage
 
contentString() - Method in class co.paralleluniverse.actors.behaviors.ResponseMessage
 
contentString() - Method in class co.paralleluniverse.actors.behaviors.ValueResponseMessage
 
countDown() - Method in class co.paralleluniverse.strands.concurrent.CountDownLatch
Decrements the count of the latch, releasing all waiting threads if the count reaches zero.
CountDownLatch - Class in co.paralleluniverse.strands.concurrent
A synchronization aid that allows one or more threads to wait until a set of operations being performed in other threads completes.
CountDownLatch(int) - Constructor for class co.paralleluniverse.strands.concurrent.CountDownLatch
Constructs a CountDownLatch initialized with the given count.
current() - Static method in class co.paralleluniverse.strands.StrandLocalRandom
Returns the current thread's ThreadLocalRandom.
currentActor() - Static method in class co.paralleluniverse.actors.Actor
Returns the actor currently running in the current strand.
currentClassFor(Class<T>) - Static method in class co.paralleluniverse.actors.ActorLoader
 
currentClassFor(String) - Static method in class co.paralleluniverse.actors.ActorLoader
 
currentEventSourceActor() - Static method in class co.paralleluniverse.actors.behaviors.EventSourceActor
 
currentFiber() - Static method in class co.paralleluniverse.fibers.Fiber
Returns the active Fiber on this thread or NULL if no Fiber is running.
currentFiniteStateMachineActor() - Static method in class co.paralleluniverse.actors.behaviors.FiniteStateMachineActor
 
currentServerActor() - Static method in class co.paralleluniverse.actors.behaviors.ServerActor
 
currentStrand - Static variable in class co.paralleluniverse.strands.Strand
 
currentStrand() - Static method in class co.paralleluniverse.strands.Strand
Returns the current strand.
currentSupervisor() - Static method in class co.paralleluniverse.actors.behaviors.SupervisorActor
 
CustomFiberWriter - Interface in co.paralleluniverse.fibers
CustomFiberWriterSerializer - Class in co.paralleluniverse.fibers
 
CustomFiberWriterSerializer() - Constructor for class co.paralleluniverse.fibers.CustomFiberWriterSerializer
 
CyclicBarrier - Class in co.paralleluniverse.strands.concurrent
A synchronization aid that allows a set of threads to all wait for each other to reach a common barrier point.
CyclicBarrier(int) - Constructor for class co.paralleluniverse.strands.concurrent.CyclicBarrier
Creates a new CyclicBarrier that will trip when the given number of parties (threads) are waiting upon it, and does not perform a predefined action when the barrier is tripped.
CyclicBarrier(int, Runnable) - Constructor for class co.paralleluniverse.strands.concurrent.CyclicBarrier
Creates a new CyclicBarrier that will trip when the given number of parties (threads) are waiting upon it, and which will execute the given barrier action when the barrier is tripped, performed by the last thread entering the barrier.

D

dead(ActorRef, Throwable) - Method in class co.paralleluniverse.actors.ActorImpl.ActorLifecycleListener
 
DEFAULT_STACK_SIZE - Static variable in class co.paralleluniverse.fibers.Fiber
 
DefaultFiberScheduler - Class in co.paralleluniverse.fibers
The default FiberScheduler used to schedule fibers that do not specify a particular scheduler.
DefaultFiberScheduler() - Constructor for class co.paralleluniverse.fibers.DefaultFiberScheduler
 
DelegatingReceivePort<T> - Class in co.paralleluniverse.strands.channels
 
DelegatingReceivePort(ReceivePort<T>) - Constructor for class co.paralleluniverse.strands.channels.DelegatingReceivePort
 
DelegatingSendPort<T> - Class in co.paralleluniverse.strands.channels
 
DelegatingSendPort(SendPort<T>) - Constructor for class co.paralleluniverse.strands.channels.DelegatingSendPort
 
die(Throwable) - Method in class co.paralleluniverse.actors.FakeActor
 
DISPLACE - co.paralleluniverse.strands.channels.Channels.OverflowPolicy
The oldest message in the queue will be removed to make room for the new message.
DoneSynchronizer - Class in co.paralleluniverse.strands
 
doRun() - Method in class co.paralleluniverse.actors.Actor
An actor must implement this method, which contains the actor's logic.
doRun() - Method in class co.paralleluniverse.actors.behaviors.BehaviorActor
An actor must implement this method, which contains the actor's logic.
DoubleChannel - Interface in co.paralleluniverse.strands.channels
A channel for primitive double messages.
DoubleReceivePort - Interface in co.paralleluniverse.strands.channels
A primitive double channel's consumer-side interface.
DoubleSendPort - Interface in co.paralleluniverse.strands.channels
A primitive double channel's producer-side interface.
drainPermits() - Method in class co.paralleluniverse.strands.concurrent.Semaphore
Acquires and returns all permits that are immediately available.
DROP - co.paralleluniverse.strands.channels.Channels.OverflowPolicy
The message will be silently dropped.
dumpStack() - Static method in class co.paralleluniverse.fibers.Fiber
 
dumpStack() - Static method in class co.paralleluniverse.strands.Strand
Prints a stack trace of the current strand to the standard error stream.

E

emptyReceivePort() - Static method in class co.paralleluniverse.strands.channels.Channels
Returns an empty ReceivePort.
equals(Object) - Method in class co.paralleluniverse.actors.ActorImpl.ActorLifecycleListener
 
equals(Object) - Method in class co.paralleluniverse.actors.ActorRef
 
equals(Object) - Method in class co.paralleluniverse.actors.ExitMessage
 
equals(Object) - Method in class co.paralleluniverse.actors.ShutdownMessage
 
equals(Object) - Method in class co.paralleluniverse.fibers.Fiber
 
equals(Object) - Method in class co.paralleluniverse.strands.channels.DelegatingReceivePort
 
equals(Object) - Method in class co.paralleluniverse.strands.channels.DelegatingSendPort
 
equals(Object) - Method in class co.paralleluniverse.strands.channels.Mix.State
 
equals(Object) - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
equals(Object) - Method in class co.paralleluniverse.strands.channels.ThreadReceivePort
 
equals(Object) - Method in class co.paralleluniverse.strands.channels.ThreadSendPort
 
equals(Object) - Method in class co.paralleluniverse.strands.channels.TransferChannel
 
equals(Object, Object) - Static method in class co.paralleluniverse.strands.Strand
Tests whether two strands represent the same fiber or thread.
ErrorMessage - Interface in co.paralleluniverse.actors.behaviors
An actor message signifying some error
ErrorResponseMessage - Class in co.paralleluniverse.actors.behaviors
A simple subclass of ResponseMessage that represents an error in processing the request.
ErrorResponseMessage(Object, Throwable) - Constructor for class co.paralleluniverse.actors.behaviors.ErrorResponseMessage
Constructs a ErrorResponseMessage.
ESCALATE - co.paralleluniverse.actors.behaviors.SupervisorActor.RestartStrategy
Kill the supervisor along with all children.
EventHandler<Event> - Interface in co.paralleluniverse.actors.behaviors
A handler that can be registered with an EventSource actor to receive all events sent to the actor.
EventSource<Event> - Class in co.paralleluniverse.actors.behaviors
An interface to an EventSourceActor.
EventSourceActor<Event> - Class in co.paralleluniverse.actors.behaviors
A behavior actor that can be notified of *event* messages, which are delivered to *event handlers* which may be registered with the actor.
EventSourceActor() - Constructor for class co.paralleluniverse.actors.behaviors.EventSourceActor
Creates a new event-source actor.
EventSourceActor(Initializer) - Constructor for class co.paralleluniverse.actors.behaviors.EventSourceActor
Creates a new event-source actor.
EventSourceActor(Initializer, MailboxConfig) - Constructor for class co.paralleluniverse.actors.behaviors.EventSourceActor
Creates a new event-source actor.
EventSourceActor(MailboxConfig) - Constructor for class co.paralleluniverse.actors.behaviors.EventSourceActor
Creates a new event-source actor.
EventSourceActor(String) - Constructor for class co.paralleluniverse.actors.behaviors.EventSourceActor
Creates a new event-source actor.
EventSourceActor(String, Initializer) - Constructor for class co.paralleluniverse.actors.behaviors.EventSourceActor
Creates a new event-source actor.
EventSourceActor(String, Initializer, MailboxConfig) - Constructor for class co.paralleluniverse.actors.behaviors.EventSourceActor
Creates a new event-source actor.
EventSourceActor(String, Initializer, Strand, MailboxConfig) - Constructor for class co.paralleluniverse.actors.behaviors.EventSourceActor
Creates a new event-source actor.
EventSourceActor(String, MailboxConfig) - Constructor for class co.paralleluniverse.actors.behaviors.EventSourceActor
Creates a new event-source actor.
execute(Runnable) - Method in class co.paralleluniverse.fibers.FiberExecutorScheduler
 
ExitMessage - Class in co.paralleluniverse.actors
A LifecycleMessage signifying an actor's death.
ExitMessage(ActorRef, Throwable) - Constructor for class co.paralleluniverse.actors.ExitMessage
 
ExitMessage(ActorRef, Throwable, Object) - Constructor for class co.paralleluniverse.actors.ExitMessage
 

F

FakeActor<Message> - Class in co.paralleluniverse.actors
An ActorRef which is not backed by any actual Actor.
FakeActor(String, SendPort<Message>) - Constructor for class co.paralleluniverse.actors.FakeActor
 
Fiber<V> - Class in co.paralleluniverse.fibers
A lightweight thread.
Fiber() - Constructor for class co.paralleluniverse.fibers.Fiber
Creates a new child Fiber subclassing the Fiber class and overriding the run method.
Fiber(Fiber, FiberScheduler, SuspendableCallable<V>) - Constructor for class co.paralleluniverse.fibers.Fiber
 
Fiber(Fiber, FiberScheduler, SuspendableRunnable) - Constructor for class co.paralleluniverse.fibers.Fiber
 
Fiber(Fiber, SuspendableCallable<V>) - Constructor for class co.paralleluniverse.fibers.Fiber
 
Fiber(Fiber, SuspendableRunnable) - Constructor for class co.paralleluniverse.fibers.Fiber
 
Fiber(FiberScheduler) - Constructor for class co.paralleluniverse.fibers.Fiber
Creates a new Fiber subclassing the Fiber class and overriding the run method.
Fiber(FiberScheduler, SuspendableCallable<V>) - Constructor for class co.paralleluniverse.fibers.Fiber
Creates a new Fiber from the given SuspendableCallable.
Fiber(FiberScheduler, SuspendableRunnable) - Constructor for class co.paralleluniverse.fibers.Fiber
Creates a new Fiber from the given SuspendableRunnable.
Fiber(SuspendableCallable<V>) - Constructor for class co.paralleluniverse.fibers.Fiber
Creates a new child Fiber from the given SuspendableCallable.
Fiber(SuspendableRunnable) - Constructor for class co.paralleluniverse.fibers.Fiber
Creates a new child Fiber from the given SuspendableRunnable.
Fiber(String) - Constructor for class co.paralleluniverse.fibers.Fiber
Creates a new child Fiber subclassing the Fiber class and overriding the run method.
Fiber(String, int) - Constructor for class co.paralleluniverse.fibers.Fiber
Creates a new child Fiber subclassing the Fiber class and overriding the run method.
Fiber(String, int, SuspendableCallable<V>) - Constructor for class co.paralleluniverse.fibers.Fiber
Creates a new fiber from the given SuspendableCallable scheduled in the default fiber scheduler
Fiber(String, int, SuspendableRunnable) - Constructor for class co.paralleluniverse.fibers.Fiber
Creates a new child Fiber from the given SuspendableRunnable.
Fiber(String, FiberScheduler) - Constructor for class co.paralleluniverse.fibers.Fiber
Creates a new Fiber subclassing the Fiber class and overriding the run method.
Fiber(String, FiberScheduler, int) - Constructor for class co.paralleluniverse.fibers.Fiber
Creates a new Fiber subclassing the Fiber class and overriding the run method.
Fiber(String, FiberScheduler, int, SuspendableCallable<V>) - Constructor for class co.paralleluniverse.fibers.Fiber
Creates a new fiber from the given SuspendableCallable.
Fiber(String, FiberScheduler, int, SuspendableRunnable) - Constructor for class co.paralleluniverse.fibers.Fiber
Creates a new Fiber from the given SuspendableRunnable.
Fiber(String, FiberScheduler, SuspendableCallable<V>) - Constructor for class co.paralleluniverse.fibers.Fiber
Creates a new Fiber from the given SuspendableCallable.
Fiber(String, FiberScheduler, SuspendableRunnable) - Constructor for class co.paralleluniverse.fibers.Fiber
Creates a new Fiber from the given SuspendableRunnable.
Fiber(String, SuspendableCallable<V>) - Constructor for class co.paralleluniverse.fibers.Fiber
Creates a new child Fiber from the given SuspendableCallable.
Fiber(String, SuspendableRunnable) - Constructor for class co.paralleluniverse.fibers.Fiber
Creates a new child Fiber from the given SuspendableRunnable.
FiberAsync<V,​E extends java.lang.Throwable> - Class in co.paralleluniverse.fibers
A general helper class that transforms asynchronous requests to synchronous (fiber-blocking) calls.
FiberAsync() - Constructor for class co.paralleluniverse.fibers.FiberAsync
Same as `FiberAsync(false)`
FiberAsync(boolean) - Constructor for class co.paralleluniverse.fibers.FiberAsync
 
FiberControl - Class in co.paralleluniverse.fibers
 
FiberExecutorScheduler - Class in co.paralleluniverse.fibers
A fiber scheduler that uses a given Executor for scheduling.
FiberExecutorScheduler(String, Executor) - Constructor for class co.paralleluniverse.fibers.FiberExecutorScheduler
Creates a new fiber scheduler with no monitor.
FiberExecutorScheduler(String, Executor, MonitorType, boolean) - Constructor for class co.paralleluniverse.fibers.FiberExecutorScheduler
Creates a new fiber scheduler.
FiberFactory - Interface in co.paralleluniverse.fibers
Creates new fibers on demand.
FiberFileChannel - Class in co.paralleluniverse.fibers.io
A fiber-blocking version of FileChannel.
FiberForkJoinScheduler - Class in co.paralleluniverse.fibers
A ForkJoinPool based scheduler for fibers.
FiberForkJoinScheduler(String, int) - Constructor for class co.paralleluniverse.fibers.FiberForkJoinScheduler
Creates a new fiber scheduler using a default UncaughtExceptionHandler and no monitoring.
FiberForkJoinScheduler(String, int, MonitorType, boolean) - Constructor for class co.paralleluniverse.fibers.FiberForkJoinScheduler
Creates a new fiber scheduler using a default UncaughtExceptionHandler.
FiberForkJoinScheduler(String, int, Thread.UncaughtExceptionHandler, MonitorType, boolean) - Constructor for class co.paralleluniverse.fibers.FiberForkJoinScheduler
Creates a new fiber scheduler.
FiberInfo - Class in co.paralleluniverse.fibers
Current information about a fiber returned by FibersMXBean.
FiberInfo(long, String, Strand.State, Object, StackTraceElement[]) - Constructor for class co.paralleluniverse.fibers.FiberInfo
 
FiberInfo(long, String, Strand.State, String, StackTraceElement[]) - Constructor for class co.paralleluniverse.fibers.FiberInfo
 
FiberScheduler - Class in co.paralleluniverse.fibers
A thread-pool based scheduler for fibers.
FiberSchedulerTask - Interface in co.paralleluniverse.fibers
The Runnable tasks passed to a FiberExecutorScheduler's Executor implement this interface.
FiberServerSocketChannel - Class in co.paralleluniverse.fibers.io
A fiber-blocking version of ServerSocketChannel.
FiberServerSocketChannel() - Constructor for class co.paralleluniverse.fibers.io.FiberServerSocketChannel
 
FibersMXBean - Interface in co.paralleluniverse.fibers
An MXBean that monitors fibers scheduled by a single FiberScheduler.
FiberSocketChannel - Class in co.paralleluniverse.fibers.io
A fiber-blocking version of SocketChannel.
FiberSocketChannel() - Constructor for class co.paralleluniverse.fibers.io.FiberSocketChannel
 
fiberTransform(FiberFactory, ReceivePort<S>, SendPort<T>, SuspendableAction2<? extends ReceivePort<? super S>, ? extends SendPort<? extends T>>) - Static method in class co.paralleluniverse.strands.channels.Channels
Spawns a fiber that transforms values read from the in channel and writes values to the out channel.
fiberTransform(FiberFactory, SuspendableAction2<? extends ReceivePort<? super T>, ? extends SendPort<? extends U>>, Channel<U>) - Method in class co.paralleluniverse.strands.channels.TransformingReceivePort
Spawns a fiber that transforms values read from this channel and writes values to the out channel.
fiberTransform(FiberFactory, SuspendableAction2<? extends ReceivePort<? super U>, ? extends SendPort<? extends T>>, Channel<U>) - Method in class co.paralleluniverse.strands.channels.TransformingSendPort
Spawns a fiber that transforms values read from the in channel and writes values to this channel.
fiberTransform(ReceivePort<S>, SendPort<T>, SuspendableAction2<? extends ReceivePort<? super S>, ? extends SendPort<? extends T>>) - Static method in class co.paralleluniverse.strands.channels.Channels
Spawns a fiber that transforms values read from the in channel and writes values to the out channel.
fiberTransform(SuspendableAction2<? extends ReceivePort<? super T>, ? extends SendPort<? extends U>>, Channel<U>) - Method in class co.paralleluniverse.strands.channels.TransformingReceivePort
Spawns a fiber that transforms values read from this channel and writes values to the out channel.
fiberTransform(SuspendableAction2<? extends ReceivePort<? super U>, ? extends SendPort<? extends T>>, Channel<U>) - Method in class co.paralleluniverse.strands.channels.TransformingSendPort
Spawns a fiber that transforms values read from the in channel and writes values to this channel.
FiberUtil - Class in co.paralleluniverse.fibers
Static utility methods for working with fibers.
FiberWriter - Interface in co.paralleluniverse.fibers
A callback used by Fiber.parkAndSerialize..
fillInStackTrace() - Method in exception co.paralleluniverse.fibers.RuntimeSuspendExecution
 
fillInStackTrace() - Method in exception co.paralleluniverse.fibers.SuspendExecution
 
fillInStackTrace() - Method in exception co.paralleluniverse.strands.channels.ReceivePort.EOFException
 
filter(ReceivePort<M>, Predicate<M>) - Static method in class co.paralleluniverse.strands.channels.Channels
Returns a ReceivePort that filters messages that satisfy a predicate from a given channel.
filter(Predicate<T>) - Method in class co.paralleluniverse.strands.channels.TransformingReceivePort
Returns a TransformingReceivePort that filters messages that satisfy a predicate from this given channel.
filter(Predicate<T>) - Method in class co.paralleluniverse.strands.channels.TransformingSendPort
Returns a TransformingSendPort that filters messages that satisfy a predicate before sending to this channel.
filterMessage(Object) - Method in class co.paralleluniverse.actors.Actor
All messages received from the mailbox are passed to this method.
filterMessage(Object) - Method in class co.paralleluniverse.actors.FakeActor
All messages sent to the mailbox are passed to this method.
filterSend(SendPort<M>, Predicate<M>) - Static method in class co.paralleluniverse.strands.channels.Channels
Returns a SendPort that filters messages that satisfy a predicate before sending to a given channel.
findClass(String) - Method in class co.paralleluniverse.actors.ActorLoader
 
FiniteStateMachineActor - Class in co.paralleluniverse.actors.behaviors
A behavior implementing a finite-state-machine.
FiniteStateMachineActor() - Constructor for class co.paralleluniverse.actors.behaviors.FiniteStateMachineActor
Creates a new FSM actor
FiniteStateMachineActor(Initializer) - Constructor for class co.paralleluniverse.actors.behaviors.FiniteStateMachineActor
Creates a new FSM actor
FiniteStateMachineActor(Initializer, MailboxConfig) - Constructor for class co.paralleluniverse.actors.behaviors.FiniteStateMachineActor
Creates a new FSM actor
FiniteStateMachineActor(MailboxConfig) - Constructor for class co.paralleluniverse.actors.behaviors.FiniteStateMachineActor
Creates a new FSM actor
FiniteStateMachineActor(String) - Constructor for class co.paralleluniverse.actors.behaviors.FiniteStateMachineActor
Creates a new FSM actor
FiniteStateMachineActor(String, Initializer) - Constructor for class co.paralleluniverse.actors.behaviors.FiniteStateMachineActor
Creates a new FSM actor
FiniteStateMachineActor(String, Initializer, MailboxConfig) - Constructor for class co.paralleluniverse.actors.behaviors.FiniteStateMachineActor
Creates a new FSM actor
FiniteStateMachineActor(String, Initializer, Strand, MailboxConfig) - Constructor for class co.paralleluniverse.actors.behaviors.FiniteStateMachineActor
Creates a new FSM actor
FiniteStateMachineActor(String, Initializer, Strand, MailboxConfig, SuspendableCallable<SuspendableCallable>) - Constructor for class co.paralleluniverse.actors.behaviors.FiniteStateMachineActor
Creates a new FSM actor
FiniteStateMachineActor(String, MailboxConfig) - Constructor for class co.paralleluniverse.actors.behaviors.FiniteStateMachineActor
Creates a new FSM actor
flatMap(Channel<S>, Function<S, ReceivePort<T>>) - Method in class co.paralleluniverse.strands.channels.TransformingSendPort
Returns a SendPort that sends messages that are transformed by a given flat-mapping function into this channel.
flatMap(ReceivePort<S>, Function<S, ReceivePort<T>>) - Static method in class co.paralleluniverse.strands.channels.Channels
Returns a ReceivePort that receives messages that are transformed by a given flat-mapping function from a given channel.
flatMap(Function<T, ReceivePort<U>>) - Method in class co.paralleluniverse.strands.channels.TransformingReceivePort
Returns a TransformingReceivePort that receives messages that are transformed by a given flat-mapping function from this channel.
FlatMappingReceivePort<S,​T> - Class in co.paralleluniverse.strands.channels
 
FlatMappingReceivePort(ReceivePort<S>) - Constructor for class co.paralleluniverse.strands.channels.FlatMappingReceivePort
 
FlatMappingReceivePort(ReceivePort<S>, Function<S, ReceivePort<T>>) - Constructor for class co.paralleluniverse.strands.channels.FlatMappingReceivePort
 
flatMapSend(FiberFactory, Channel<S>, SendPort<T>, Function<S, ReceivePort<T>>) - Static method in class co.paralleluniverse.strands.channels.Channels
Returns a SendPort that sends messages that are transformed by a given flat-mapping function into a given channel.
flatMapSend(Channel<S>, SendPort<T>, Function<S, ReceivePort<T>>) - Static method in class co.paralleluniverse.strands.channels.Channels
 
flightRecorder - Variable in class co.paralleluniverse.actors.ActorImpl
 
flightRecorder - Static variable in class co.paralleluniverse.fibers.Fiber
 
FloatChannel - Interface in co.paralleluniverse.strands.channels
A channel for primitive float messages.
FloatReceivePort - Interface in co.paralleluniverse.strands.channels
A primitive float channel's consumer-side interface.
FloatSendPort - Interface in co.paralleluniverse.strands.channels
A primitive float channel's producer-side interface.
force(boolean) - Method in class co.paralleluniverse.fibers.io.FiberFileChannel
 
forceTermination() - Method in class co.paralleluniverse.strands.concurrent.Phaser
Forces this phaser to enter termination state.
forEach(ReceivePort<T>, SuspendableAction1<T>) - Static method in class co.paralleluniverse.strands.channels.Channels
Performs the given action on each message received by the given channel.
forEach(SuspendableAction1<T>) - Method in class co.paralleluniverse.strands.channels.TransformingReceivePort
Performs the given action on each message received by this channel.
from() - Static method in class co.paralleluniverse.actors.behaviors.RequestReplyHelper
Returns an ActorRef that should be used as the from property of a RequestMessage.
from(ActorRef<?>) - Method in class co.paralleluniverse.actors.behaviors.MessageSelector
Creates a MessageProcessor that selects FromMessages from the given actor.
from(FiberFactory) - Static method in class co.paralleluniverse.strands.StrandFactoryBuilder
Converts a FiberFactory into a StrandFactory.
from(ThreadFactory) - Static method in class co.paralleluniverse.strands.StrandFactoryBuilder
Converts a ThreadFactory into a StrandFactory.
FromMessage - Interface in co.paralleluniverse.actors.behaviors
An actor message that identifies its sender

G

get() - Method in class co.paralleluniverse.actors.Actor
 
get() - Method in class co.paralleluniverse.fibers.Fiber
 
get() - Method in interface co.paralleluniverse.fibers.Joinable
 
get() - Method in class co.paralleluniverse.fibers.SchedulerLocal
Returns the scheduler-local value of this SchedulerLocal.
get() - Method in class co.paralleluniverse.fibers.TrueThreadLocal
 
get() - Method in class co.paralleluniverse.strands.AbstractFuture
 
get() - Method in class co.paralleluniverse.strands.dataflow.Val
Returns the delayed value, blocking until it has been set.
get() - Method in class co.paralleluniverse.strands.dataflow.Var
Returns the Var's current value (more precisely: it returns the oldest value in the maintained history that has not yet been returned), unless this Var does not yet have a value; only in that case will this method block.
get() - Method in class co.paralleluniverse.strands.Strand
 
get(long, TimeUnit) - Method in class co.paralleluniverse.actors.Actor
 
get(long, TimeUnit) - Method in class co.paralleluniverse.fibers.Fiber
 
get(long, TimeUnit) - Method in interface co.paralleluniverse.fibers.Joinable
 
get(long, TimeUnit) - Method in class co.paralleluniverse.strands.AbstractFuture
 
get(long, TimeUnit) - Method in class co.paralleluniverse.strands.dataflow.Val
Returns the delayed value, blocking until it has been set, but no longer than the given timeout.
get(long, TimeUnit) - Method in class co.paralleluniverse.strands.Strand
 
get(long, TimeUnit, Fiber<V>...) - Static method in class co.paralleluniverse.fibers.FiberUtil
Blocks on the input fibers and creates a new list from the results.
get(long, TimeUnit, List<Fiber<V>>) - Static method in class co.paralleluniverse.fibers.FiberUtil
Blocks on the input fibers and creates a new list from the results.
get(ActorRef<?>) - Static method in class co.paralleluniverse.actors.LocalActor
 
get(ActorRef<?>, long, TimeUnit) - Static method in class co.paralleluniverse.actors.LocalActor
 
get(Fiber<V>...) - Static method in class co.paralleluniverse.fibers.FiberUtil
Blocks on the input fibers and creates a new list from the results.
get(Timeout) - Method in class co.paralleluniverse.strands.dataflow.Val
 
get(ListenableFuture<V>) - Static method in class co.paralleluniverse.fibers.futures.AsyncListenableFuture
Blocks the current strand (either fiber or thread) until the given future completes, and returns its result.
get(ListenableFuture<V>, long, TimeUnit) - Static method in class co.paralleluniverse.fibers.futures.AsyncListenableFuture
Blocks the current strand (either fiber or thread) until the given future completes - but no longer than the given timeout - and returns its result.
get(ListenableFuture<V>, Timeout) - Static method in class co.paralleluniverse.fibers.futures.AsyncListenableFuture
Blocks the current strand (either fiber or thread) until the given future completes - but no longer than the given timeout - and returns its result.
get(CompletionStage<V>) - Static method in class co.paralleluniverse.fibers.futures.AsyncCompletionStage
Blocks the current strand (either fiber or thread) until the given future completes, and returns its result.
get(CompletionStage<V>, long, TimeUnit) - Static method in class co.paralleluniverse.fibers.futures.AsyncCompletionStage
Blocks the current strand (either fiber or thread) until the given future completes - but no longer than the given timeout - and returns its result.
get(CompletionStage<V>, Timeout) - Static method in class co.paralleluniverse.fibers.futures.AsyncCompletionStage
Blocks the current strand (either fiber or thread) until the given future completes - but no longer than the given timeout - and returns its result.
get(List<Fiber<V>>) - Static method in class co.paralleluniverse.fibers.FiberUtil
Blocks on the input fibers and creates a new list from the results.
getActor() - Method in class co.paralleluniverse.actors.ExitMessage
Returns the actor that originated this message (the dying actor).
getActor() - Method in class co.paralleluniverse.actors.RemoteActor
 
getActor(Strand) - Static method in class co.paralleluniverse.actors.Actor
Returns the actor associated with the given strand, or null if none is.
getActor(String) - Static method in class co.paralleluniverse.actors.ActorRegistry
Locates a registered actor by name, or blocks until one is registered.
getActor(String, long, TimeUnit) - Static method in class co.paralleluniverse.actors.ActorRegistry
Locates a registered actor by name, or blocks until one is registered, but no more than the given timeout.
getAllActorIds() - Method in interface co.paralleluniverse.actors.ActorsMXBean
The strand IDs of all currently running actors.
getAllFiberIds() - Method in interface co.paralleluniverse.fibers.FibersMXBean
The IDs of all fibers in the scheduler.
getArrivedParties() - Method in class co.paralleluniverse.strands.concurrent.Phaser
Returns the number of registered parties that have arrived at the current phase of this phaser.
getBlocker() - Method in class co.paralleluniverse.fibers.Fiber
 
getBlocker() - Method in class co.paralleluniverse.fibers.FiberInfo
The fiber's current blocker.
getBlocker() - Method in class co.paralleluniverse.strands.Strand
Returns the blocker object supplied to the most recent invocation of a park method that has not yet unblocked, or null if not blocked.
getBuilder() - Method in class co.paralleluniverse.actors.behaviors.Supervisor.ChildSpec
The child's builder
getCause() - Method in class co.paralleluniverse.actors.ExitMessage
Returns the actor's cause of death exception, or null if the actor terminated normally.
getChild(Object) - Method in class co.paralleluniverse.actors.behaviors.Supervisor
Retrieves a child actor by its id This method does not block when called from within the Supervisor's context, so, in particular, it may be called by an actor constructor, constructed by the supervisor.
getChild(Object) - Method in class co.paralleluniverse.actors.behaviors.SupervisorActor
Retrieves a child actor by its id
getChildren() - Method in class co.paralleluniverse.actors.behaviors.Supervisor
Retrieves the children actor references as an immutable list.
getChildren() - Method in class co.paralleluniverse.actors.behaviors.SupervisorActor
Retrieves the children actor references as an immutable list.
getClass(ActorRef<?>) - Static method in class co.paralleluniverse.actors.LocalActor
 
getCloseException() - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
getCount() - Method in class co.paralleluniverse.strands.concurrent.CountDownLatch
Returns the current count.
getCurrentRun() - Static method in class co.paralleluniverse.fibers.Fiber
 
getDeathCause() - Method in class co.paralleluniverse.actors.Actor
Returns this actor's cause of death
getDeathCause() - Method in class co.paralleluniverse.actors.FakeActor
Returns this actor's cause of death
getDeathCause(ActorRef<?>) - Static method in class co.paralleluniverse.actors.LocalActor
 
getDefaultUncaughtExceptionHandler() - Static method in class co.paralleluniverse.fibers.Fiber
Returns the default handler invoked when a fiber abruptly terminates due to an uncaught exception.
getDouble(int) - Method in class co.paralleluniverse.fibers.Stack
 
getDuration() - Method in class co.paralleluniverse.actors.behaviors.Supervisor.ChildSpec
The duration in which the number of restarts is counted towards the max restarts.
getDurationUnit() - Method in class co.paralleluniverse.actors.behaviors.Supervisor.ChildSpec
The time unit of the duration for max restarts.
getError() - Method in interface co.paralleluniverse.actors.behaviors.ErrorMessage
The error
getError() - Method in class co.paralleluniverse.actors.behaviors.ErrorResponseMessage
The error that occurred while processing the request.
getExclusiveOwnerStrand() - Method in class co.paralleluniverse.strands.concurrent.AbstractOwnableSynchronizer
Returns the strand last set by setExclusiveOwnerStrand, or null if never set.
getExclusiveQueuedStrands() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Returns a collection containing strands that may be waiting to acquire in exclusive mode.
getExclusiveQueuedStrands() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Returns a collection containing strands that may be waiting to acquire in exclusive mode.
getExecutor() - Method in class co.paralleluniverse.fibers.FiberExecutorScheduler
 
getExecutor() - Method in class co.paralleluniverse.fibers.FiberForkJoinScheduler
 
getExecutor() - Method in class co.paralleluniverse.fibers.FiberScheduler
 
getFiber() - Method in interface co.paralleluniverse.fibers.FiberSchedulerTask
 
getFiberInfo(long[], boolean) - Method in interface co.paralleluniverse.fibers.FibersMXBean
Returns an array FiberInfo objects for a set of fibers.
getFiberInfo(long, boolean) - Method in interface co.paralleluniverse.fibers.FibersMXBean
Returns a FiberInfo object for a single fiber.
getFiberSerializer() - Static method in class co.paralleluniverse.fibers.Fiber
Returns a ByteArraySerializer capable of serializing an object graph containing fibers.
getFiberSerializer(boolean) - Static method in class co.paralleluniverse.fibers.Fiber
Returns a ByteArraySerializer capable of serializing an object graph containing fibers.
getFirstQueuedStrand() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Returns the first (longest-waiting) strand in the queue, or null if no strands are currently queued.
getFirstQueuedStrand() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Returns the first (longest-waiting) strand in the queue, or null if no strands are currently queued.
getFloat(int) - Method in class co.paralleluniverse.fibers.Stack
 
getForkJoinPool() - Method in class co.paralleluniverse.fibers.FiberForkJoinScheduler
 
getFrom() - Method in interface co.paralleluniverse.actors.behaviors.FromMessage
The actor that sent the message.
getFrom() - Method in class co.paralleluniverse.actors.behaviors.RequestMessage
The actor that sent the request.
getHoldCount() - Method in class co.paralleluniverse.strands.concurrent.ReentrantLock
Queries the number of holds on this lock by the current strand.
getHoldCount() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock.WriteLock
Queries the number of holds on this write lock by the current strand.
getId() - Method in class co.paralleluniverse.actors.ActorImpl.ActorLifecycleListener
 
getId() - Method in class co.paralleluniverse.actors.ActorInfo
The actor's strand's ID
getId() - Method in interface co.paralleluniverse.actors.behaviors.IdMessage
A unique message identifier.
getId() - Method in class co.paralleluniverse.actors.behaviors.RequestMessage
A unique message identifier.
getId() - Method in class co.paralleluniverse.actors.behaviors.ResponseMessage
The id of the RequestMessage this is a response to.
getId() - Method in class co.paralleluniverse.actors.behaviors.Supervisor.ChildSpec
The child's (optional) identifier (name)
getId() - Method in class co.paralleluniverse.fibers.Fiber
 
getId() - Method in class co.paralleluniverse.fibers.FiberInfo
The fiber's ID.
getId() - Method in class co.paralleluniverse.strands.Strand
Returns the strand's id.
getImpl() - Method in class co.paralleluniverse.actors.ActorRef
 
getImpl() - Method in class co.paralleluniverse.actors.ActorRefDelegate
 
getImpl(ActorRef<?>) - Static method in class co.paralleluniverse.actors.RemoteActor
 
getInitializer() - Method in class co.paralleluniverse.actors.behaviors.BehaviorActor
The initializer passed at construction which performs initialization and termination.
getInstance() - Static method in class co.paralleluniverse.fibers.DefaultFiberScheduler
Returns the The default FiberScheduler instance.
getInt(int) - Method in class co.paralleluniverse.fibers.Stack
 
getInterruptStack() - Method in class co.paralleluniverse.fibers.Fiber
 
getInterruptStack() - Method in class co.paralleluniverse.strands.Strand
Returns an InterruptedException that was created when the Strand.interrupt() method was called, and can be used to retrieve the stack trace of the strand that interrupted this strand.
getLastDeathCauses() - Method in class co.paralleluniverse.actors.ActorInfo
The latest few death-causes for this actor (relevant if it's been restarted by a SupervisorActor.
getLastDeathCauses() - Method in interface co.paralleluniverse.actors.ActorMXBean
The latest few death-causes for this actor (relevant if it's been restarted by a SupervisorActor.
getLastIndexRead() - Method in class co.paralleluniverse.strands.channels.TickerChannelConsumer
 
getLifecycleListener() - Method in class co.paralleluniverse.actors.ActorImpl
 
getLoadedModules() - Method in class co.paralleluniverse.actors.ActorLoader
 
getLoadedModules() - Method in interface co.paralleluniverse.actors.ActorLoaderMXBean
All currently loaded modules
getLocalAddress() - Method in class co.paralleluniverse.fibers.io.FiberServerSocketChannel
 
getLocalAddress() - Method in class co.paralleluniverse.fibers.io.FiberSocketChannel
 
getLong(int) - Method in class co.paralleluniverse.fibers.Stack
 
getMailbox() - Method in class co.paralleluniverse.actors.ActorImpl
 
getMailbox() - Method in class co.paralleluniverse.actors.ActorInfo
The messages currently waiting in the actor's mailbox
getMailbox(long) - Method in interface co.paralleluniverse.actors.ActorsMXBean
Returns all messages currently awaiting in a given actor's mailbox.
getMailbox(ActorRef<?>) - Static method in class co.paralleluniverse.actors.LocalActor
 
getMailboxSize() - Method in class co.paralleluniverse.actors.MailboxConfig
 
getMaxRestarts() - Method in class co.paralleluniverse.actors.behaviors.Supervisor.ChildSpec
The maximum number of times the child actor is allowed to restart within a given duration before the supervisor gives up and kills itself.
getMeanTimedWakeupLatency() - Method in interface co.paralleluniverse.fibers.FibersMXBean
The average latency between the time fibers in the scheduler have asked to be awakened (by a sleep or any other timed wait) and the time they've actually been awakened in the last 5 seconds.
getMethod() - Method in class co.paralleluniverse.actors.behaviors.ProxyServerActor.Invocation
 
getMode() - Method in class co.paralleluniverse.actors.behaviors.Supervisor.ChildSpec
The child's mode.
getMode() - Method in class co.paralleluniverse.strands.channels.Mix.State
 
getMonitor() - Method in class co.paralleluniverse.actors.Actor
 
getMonitor() - Method in class co.paralleluniverse.fibers.Fiber
 
getMonitor() - Method in class co.paralleluniverse.fibers.FiberScheduler
 
getMonitor(ActorRef<?>) - Static method in class co.paralleluniverse.actors.LocalActor
 
getName() - Method in class co.paralleluniverse.actors.Actor
Returns this actor's name.
getName() - Method in class co.paralleluniverse.actors.ActorImpl
 
getName() - Method in class co.paralleluniverse.actors.ActorInfo
The actor's name
getName() - Method in class co.paralleluniverse.actors.ActorRef
 
getName() - Method in class co.paralleluniverse.actors.BasicActor
 
getName() - Method in class co.paralleluniverse.fibers.Fiber
 
getName() - Method in class co.paralleluniverse.fibers.FiberInfo
The fiber's name.
getName() - Method in class co.paralleluniverse.fibers.FiberScheduler
 
getName() - Method in class co.paralleluniverse.strands.Strand
Returns the strand's name.
getNext() - Method in class co.paralleluniverse.strands.dataflow.Var
Blocks until a new value has been set and returns it.
getNoLocals() - Method in class co.paralleluniverse.fibers.Fiber
Deprecated.
getNotificationInfo() - Method in class co.paralleluniverse.actors.ActorLoader
 
getNumActiveActors() - Method in interface co.paralleluniverse.actors.ActorsMXBean
The number of currently active actors.
getNumActiveFibers() - Method in interface co.paralleluniverse.fibers.FibersMXBean
The number of non-terminated fibers in the scheduler.
getNumberWaiting() - Method in class co.paralleluniverse.strands.concurrent.CyclicBarrier
Returns the number of parties currently waiting at the barrier.
getNumRunnableFibers() - Method in interface co.paralleluniverse.fibers.FibersMXBean
The number of fibers currently in the RUNNING state.
getNumWaitingFibers() - Method in interface co.paralleluniverse.fibers.FibersMXBean
The number of fibers that are currently blocking.
getObject(int) - Method in class co.paralleluniverse.fibers.Stack
 
getObserver() - Method in class co.paralleluniverse.actors.ActorImpl.ActorLifecycleListener
 
getOption(SocketOption<T>) - Method in class co.paralleluniverse.fibers.io.FiberServerSocketChannel
 
getOption(SocketOption<T>) - Method in class co.paralleluniverse.fibers.io.FiberSocketChannel
 
getOrRegisterActor(String, Callable<Actor<Message, ?>>) - Static method in class co.paralleluniverse.actors.ActorRegistry
Locates a registered actor by name, or, if not actor by that name is currently registered, spawns and registers it.
getOrRegisterActor(String, Callable<Actor<Message, ?>>, FiberScheduler) - Static method in class co.paralleluniverse.actors.ActorRegistry
Locates a registered actor by name, or, if not actor by that name is currently registered, spawns and registers it.
getOverflowPolicy() - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
getOwner() - Method in class co.paralleluniverse.strands.channels.SingleConsumerQueueChannel
 
getOwner() - Method in class co.paralleluniverse.strands.concurrent.ReentrantLock
Returns the strand that currently owns this lock, or null if not owned.
getOwner() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock
Returns the strand that currently owns the write lock, or null if not owned.
getParams() - Method in class co.paralleluniverse.actors.behaviors.ProxyServerActor.Invocation
 
getParent() - Method in class co.paralleluniverse.strands.concurrent.Phaser
Returns the parent of this phaser, or null if none.
getParties() - Method in class co.paralleluniverse.strands.concurrent.CyclicBarrier
Returns the number of parties required to trip this barrier.
getPhase() - Method in class co.paralleluniverse.strands.concurrent.Phaser
Returns the current phase number.
getPolicy() - Method in class co.paralleluniverse.actors.MailboxConfig
 
getPriority() - Method in class co.paralleluniverse.fibers.Fiber
Returns this fiber's priority.
getPriority() - Method in class co.paralleluniverse.strands.Strand
Returns this strand's priority.
getQueuedReaderStrands() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock
Returns a collection containing strands that may be waiting to acquire the read lock.
getQueuedStrands() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Returns a collection containing strands that may be waiting to acquire.
getQueuedStrands() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Returns a collection containing strands that may be waiting to acquire.
getQueuedStrands() - Method in class co.paralleluniverse.strands.concurrent.ReentrantLock
Returns a collection containing strands that may be waiting to acquire this lock.
getQueuedStrands() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock
Returns a collection containing strands that may be waiting to acquire either the read or write lock.
getQueuedStrands() - Method in class co.paralleluniverse.strands.concurrent.Semaphore
Returns a collection containing threads that may be waiting to acquire.
getQueuedWriterStrands() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock
Returns a collection containing strands that may be waiting to acquire the write lock.
getQueueLength() - Method in class co.paralleluniverse.actors.Actor
Returns the number of messages currently waiting in the mailbox.
getQueueLength() - Method in class co.paralleluniverse.actors.ActorInfo
The number of messages currently waiting in the actor's mailbox.
getQueueLength() - Method in interface co.paralleluniverse.actors.ActorMXBean
The number of messages currently waiting in the actor's mailbox.
getQueueLength() - Method in class co.paralleluniverse.fibers.FiberExecutorScheduler
 
getQueueLength() - Method in class co.paralleluniverse.fibers.FiberForkJoinScheduler
 
getQueueLength() - Method in class co.paralleluniverse.fibers.FiberScheduler
 
getQueueLength() - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
getQueueLength() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Returns an estimate of the number of strands waiting to acquire.
getQueueLength() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Returns an estimate of the number of strands waiting to acquire.
getQueueLength() - Method in class co.paralleluniverse.strands.concurrent.ReentrantLock
Returns an estimate of the number of strands waiting to acquire this lock.
getQueueLength() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock
Returns an estimate of the number of strands waiting to acquire either the read or write lock.
getQueueLength() - Method in class co.paralleluniverse.strands.concurrent.Semaphore
Returns an estimate of the number of threads waiting to acquire.
getQueueLength(ActorRef<?>) - Static method in class co.paralleluniverse.actors.LocalActor
 
getReadHoldCount() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock
Queries the number of reentrant read holds on this lock by the current strand.
getReadLockCount() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock
Queries the number of read locks held for this lock.
getReceivedMessages() - Method in class co.paralleluniverse.actors.ActorInfo
The number of messages this actor has received.
getReceivedMessages() - Method in interface co.paralleluniverse.actors.ActorMXBean
The number of messages this actor has received.
getRegisteredParties() - Method in class co.paralleluniverse.strands.concurrent.Phaser
Returns the number of parties registered at this phaser.
getRemoteAddress() - Method in class co.paralleluniverse.fibers.io.FiberSocketChannel
Returns the remote address to which this channel's socket is connected.
getReplacementFor(T) - Static method in class co.paralleluniverse.actors.ActorLoader
 
getRequester() - Method in class co.paralleluniverse.actors.ShutdownMessage
The actor requesting the shutdown (or null if requesting code isn't an actor.
getResource(String) - Method in class co.paralleluniverse.actors.ActorLoader
 
getRestarts() - Method in class co.paralleluniverse.actors.ActorInfo
The number of times this actor has been restarted by a SupervisorActor.
getRestarts() - Method in interface co.paralleluniverse.actors.ActorMXBean
The number of times this actor has been restarted by a SupervisorActor.
getResult() - Method in class co.paralleluniverse.fibers.FiberAsync
Returns the result of the asynchronous operation if it has completed, or throws an exception if it completed unsuccessfully.
getRoot() - Method in class co.paralleluniverse.strands.concurrent.Phaser
Returns the root ancestor of this phaser, which is the same as this phaser if it has no parent.
getRunawayFibers() - Method in interface co.paralleluniverse.fibers.FibersMXBean
The fibers (and respective stack traces) that are currently holding their thread for a lengthy duration, either due to blocking or a lengthy loop.
getRunnable() - Method in class co.paralleluniverse.strands.SuspendableUtils.VoidSuspendableCallable
 
getRunningFibers() - Method in class co.paralleluniverse.fibers.FiberExecutorScheduler
 
getScheduler() - Method in class co.paralleluniverse.fibers.Fiber
 
getSharedQueuedStrands() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Returns a collection containing strands that may be waiting to acquire in shared mode.
getSharedQueuedStrands() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Returns a collection containing strands that may be waiting to acquire in shared mode.
getShutdownDeadline() - Method in class co.paralleluniverse.actors.behaviors.Supervisor.ChildSpec
The time in milliseconds the supervisor should wait for the child actor to terminate from the time it was requested to shutdown; after the deadline expires, the child actor is terminated forcefully.
getSolo() - Method in class co.paralleluniverse.strands.channels.Mix.State
 
getSoloEffect() - Method in interface co.paralleluniverse.strands.channels.Mix
 
getSoloEffect() - Method in class co.paralleluniverse.strands.channels.ReceivePortGroup
 
getSpuriousWakeups() - Method in interface co.paralleluniverse.fibers.FibersMXBean
 
getStack() - Static method in class co.paralleluniverse.fibers.Stack
 
getStackTrace() - Method in class co.paralleluniverse.actors.ActorInfo
The actor's current call-stack
getStackTrace() - Method in class co.paralleluniverse.fibers.Fiber
 
getStackTrace() - Method in class co.paralleluniverse.fibers.FiberInfo
The fiber's current call stack.
getStackTrace() - Method in class co.paralleluniverse.strands.Strand
Returns an array of stack trace elements representing the stack dump of this strand.
getStackTrace(long) - Method in interface co.paralleluniverse.actors.ActorsMXBean
Returns the stack trace of the strand running a given actor.
getState() - Method in class co.paralleluniverse.fibers.Fiber
 
getState() - Method in class co.paralleluniverse.fibers.FiberInfo
The fiber's current state.
getState() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Returns the current value of synchronization state.
getState() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Returns the current value of synchronization state.
getState() - Method in class co.paralleluniverse.strands.Strand
Returns the strand's current running state.
getState(T...) - Method in interface co.paralleluniverse.strands.channels.Mix
 
getState(T...) - Method in class co.paralleluniverse.strands.channels.ReceivePortGroup
 
getStrand() - Method in class co.paralleluniverse.actors.Actor
 
getStrand() - Method in class co.paralleluniverse.strands.channels.QueuePrimitiveChannel
 
getStrand() - Method in class co.paralleluniverse.strands.channels.SingleConsumerQueueChannel
 
getStrand() - Method in interface co.paralleluniverse.strands.Stranded
 
getStrand(ActorRef<?>) - Static method in class co.paralleluniverse.actors.LocalActor
 
getSubscribers() - Method in class co.paralleluniverse.strands.channels.Topic
Provides read-only access to subscribers for extentions.
getSync() - Method in class co.paralleluniverse.strands.dataflow.Val
 
getTarget() - Method in class co.paralleluniverse.fibers.Fiber
 
getTask() - Method in class co.paralleluniverse.fibers.Fiber
 
getTimedQueueLength() - Method in interface co.paralleluniverse.fibers.FibersMXBean
 
getTransferred() - Method in class co.paralleluniverse.strands.channels.transfer.Pipeline
 
getUnarrivedParties() - Method in class co.paralleluniverse.strands.concurrent.Phaser
Returns the number of registered parties that have not yet arrived at the current phase of this phaser.
getUncaughtExceptionHandler() - Method in class co.paralleluniverse.fibers.Fiber
Returns the handler invoked when this fiber abruptly terminates due to an uncaught exception.
getUncaughtExceptionHandler() - Method in class co.paralleluniverse.strands.Strand
Returns the handler invoked when this strand abruptly terminates due to an uncaught exception.
getUnderlying() - Method in class co.paralleluniverse.fibers.Fiber
 
getUnderlying() - Method in class co.paralleluniverse.strands.Strand
Returns the underlying object of this strand, namely a Thread or a Fiber.
getValue() - Method in class co.paralleluniverse.actors.behaviors.ValueResponseMessage
The response value, i.e.
getWaitingConsumerCount() - Method in class co.paralleluniverse.strands.channels.TransferChannel
 
getWaitingStrands() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer.ConditionObject
Returns a collection containing those strands that may be waiting on this Condition.
getWaitingStrands() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer.ConditionObject
Returns a collection containing those strands that may be waiting on this Condition.
getWaitingStrands(AbstractQueuedLongSynchronizer.ConditionObject) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Returns a collection containing those strands that may be waiting on the given condition associated with this synchronizer.
getWaitingStrands(AbstractQueuedSynchronizer.ConditionObject) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Returns a collection containing those strands that may be waiting on the given condition associated with this synchronizer.
getWaitingStrands(Condition) - Method in class co.paralleluniverse.strands.concurrent.ReentrantLock
Returns a collection containing those strands that may be waiting on the given condition associated with this lock.
getWaitingStrands(Condition) - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock
Returns a collection containing those strands that may be waiting on the given condition associated with the write lock.
getWaitQueueLength() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer.ConditionObject
Returns an estimate of the number of strands waiting on this condition.
getWaitQueueLength() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer.ConditionObject
Returns an estimate of the number of strands waiting on this condition.
getWaitQueueLength(AbstractQueuedLongSynchronizer.ConditionObject) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Returns an estimate of the number of strands waiting on the given condition associated with this synchronizer.
getWaitQueueLength(AbstractQueuedSynchronizer.ConditionObject) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Returns an estimate of the number of strands waiting on the given condition associated with this synchronizer.
getWaitQueueLength(Condition) - Method in class co.paralleluniverse.strands.concurrent.ReentrantLock
Returns an estimate of the number of strands waiting on the given condition associated with this lock.
getWaitQueueLength(Condition) - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock
Returns an estimate of the number of strands waiting on the given condition associated with the write lock.
getWatch() - Method in class co.paralleluniverse.actors.ExitMessage
Returns the watch object that is the reason for this message being sent to the receiving actor, returned by the watch method, or null if the message is sent as a result of a link.
getWatchedActorsInfo() - Method in interface co.paralleluniverse.actors.ActorsMXBean
Actor information for all watched actors.
getWinner() - Method in class co.paralleluniverse.strands.channels.Selector
 
getWriteHoldCount() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock
Queries the number of reentrant write holds on this lock by the current strand.
group(ReceivePort<? extends M>...) - Static method in class co.paralleluniverse.strands.channels.Channels
Returns a ReceivePort that receives messages from a set of channels.
group(Collection<? extends ReceivePort<? extends M>>) - Static method in class co.paralleluniverse.strands.channels.Channels
Returns a ReceivePort that receives messages from a set of channels.

H

handleAdminMessage(RemoteActor.RemoteActorAdminMessage) - Method in class co.paralleluniverse.actors.RemoteActor
 
handleCall(ActorRef<?>, Object, CallMessage) - Method in class co.paralleluniverse.actors.behaviors.AbstractServerHandler
Called to handle a synchronous request (one waiting for a response).
handleCall(ActorRef<?>, Object, CallMessage) - Method in class co.paralleluniverse.actors.behaviors.ServerActor
Called to handle a synchronous request (one waiting for a response).
handleCall(ActorRef<?>, Object, CallMessage) - Method in interface co.paralleluniverse.actors.behaviors.ServerHandler
Called to handle a synchronous request (one waiting for a response).
handleCall(ActorRef<?>, Object, ProxyServerActor.Invocation) - Method in class co.paralleluniverse.actors.behaviors.ProxyServerActor
 
handleCast(ActorRef<?>, Object, CastMessage) - Method in class co.paralleluniverse.actors.behaviors.AbstractServerHandler
Called to handle an asynchronous request (one that does not for a response).
handleCast(ActorRef<?>, Object, CastMessage) - Method in class co.paralleluniverse.actors.behaviors.ServerActor
Called to handle an asynchronous request (one that does not for a response).
handleCast(ActorRef<?>, Object, CastMessage) - Method in interface co.paralleluniverse.actors.behaviors.ServerHandler
Called to handle an asynchronous request (one that does not for a response).
handleCast(ActorRef<?>, Object, ProxyServerActor.Invocation) - Method in class co.paralleluniverse.actors.behaviors.ProxyServerActor
 
handleEvent(Event) - Method in interface co.paralleluniverse.actors.behaviors.EventHandler
 
handleInfo(Object) - Method in class co.paralleluniverse.actors.behaviors.AbstractServerHandler
Called to handle any message sent to this actor that is neither a call nor a cast.
handleInfo(Object) - Method in class co.paralleluniverse.actors.behaviors.ServerActor
Called to handle any message sent to this actor that is neither a call nor a cast.
handleInfo(Object) - Method in interface co.paralleluniverse.actors.behaviors.ServerHandler
Called to handle any message sent to this actor that is neither a call nor a cast.
handleLifecycleMessage(LifecycleMessage) - Method in class co.paralleluniverse.actors.Actor
This method is called by this class during a call to any of the receive methods if a LifecycleMessage is found in the mailbox.
handleLifecycleMessage(LifecycleMessage) - Method in class co.paralleluniverse.actors.behaviors.BehaviorActor
This method is called by this class during a call to any of the receive methods if a LifecycleMessage is found in the mailbox.
handleLifecycleMessage(LifecycleMessage) - Method in class co.paralleluniverse.actors.behaviors.SupervisorActor
 
handleLifecycleMessage(LifecycleMessage) - Method in class co.paralleluniverse.actors.FakeActor
 
handleLifecycleMessage(LifecycleMessage) - Method in class co.paralleluniverse.actors.SelectiveReceiveHelper
 
handleMessage(Object) - Method in class co.paralleluniverse.actors.behaviors.BehaviorActor
Called by the default BehaviorActor.behavior() method to handle each incoming message.
handleMessage(Object) - Method in class co.paralleluniverse.actors.behaviors.EventSourceActor
 
handleMessage(Object) - Method in class co.paralleluniverse.actors.behaviors.ServerActor
Called by the default BehaviorActor.behavior() method to handle each incoming message.
handleMessage(Object) - Method in class co.paralleluniverse.actors.behaviors.SupervisorActor
 
handleTimeout() - Method in class co.paralleluniverse.actors.behaviors.AbstractServerHandler
Called whenever the timeout set with setTimeout or supplied at construction expires without any message received.
handleTimeout() - Method in class co.paralleluniverse.actors.behaviors.ServerActor
Called whenever the timeout set with setTimeout or supplied at construction expires without any message received.
handleTimeout() - Method in interface co.paralleluniverse.actors.behaviors.ServerHandler
Called whenever the timeout set with setTimeout or supplied at construction expires without any message received.
hasContended() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Queries whether any strands have ever contended to acquire this synchronizer; that is if an acquire method has ever blocked.
hasContended() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Queries whether any strands have ever contended to acquire this synchronizer; that is if an acquire method has ever blocked.
hasGlobalRegistry() - Static method in class co.paralleluniverse.actors.ActorRegistry
Checks whether the registry is global to the entire cluster.
hashCode() - Method in class co.paralleluniverse.actors.ActorImpl.ActorLifecycleListener
 
hashCode() - Method in class co.paralleluniverse.actors.ActorRef
 
hashCode() - Method in class co.paralleluniverse.actors.ExitMessage
 
hashCode() - Method in class co.paralleluniverse.actors.ShutdownMessage
 
hashCode() - Method in class co.paralleluniverse.fibers.Fiber
 
hashCode() - Method in class co.paralleluniverse.strands.channels.DelegatingReceivePort
 
hashCode() - Method in class co.paralleluniverse.strands.channels.DelegatingSendPort
 
hashCode() - Method in class co.paralleluniverse.strands.channels.Mix.State
 
hashCode() - Method in class co.paralleluniverse.strands.channels.ThreadReceivePort
 
hashCode() - Method in class co.paralleluniverse.strands.channels.ThreadSendPort
 
hasMessage() - Method in interface co.paralleluniverse.strands.channels.DoubleReceivePort
Tests whether a value is pending in the channel.
hasMessage() - Method in interface co.paralleluniverse.strands.channels.FloatReceivePort
Tests whether a value is pending in the channel.
hasMessage() - Method in interface co.paralleluniverse.strands.channels.IntReceivePort
Tests whether a value is pending in the channel.
hasMessage() - Method in interface co.paralleluniverse.strands.channels.LongReceivePort
Tests whether a value is pending in the channel.
hasMessage() - Method in class co.paralleluniverse.strands.channels.QueuePrimitiveChannel
 
hasMessage() - Method in class co.paralleluniverse.strands.channels.TickerChannelConsumer
 
hasQueuedPredecessors() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Queries whether any strands have been waiting to acquire longer than the current strand.
hasQueuedPredecessors() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Queries whether any strands have been waiting to acquire longer than the current strand.
hasQueuedStrand(Strand) - Method in class co.paralleluniverse.strands.concurrent.ReentrantLock
Queries whether the given strand is waiting to acquire this lock.
hasQueuedStrand(Strand) - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock
Queries whether the given strand is waiting to acquire either the read or write lock.
hasQueuedStrands() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Queries whether any strands are waiting to acquire.
hasQueuedStrands() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Queries whether any strands are waiting to acquire.
hasQueuedStrands() - Method in class co.paralleluniverse.strands.concurrent.ReentrantLock
Queries whether any strands are waiting to acquire this lock.
hasQueuedStrands() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock
Queries whether any strands are waiting to acquire the read or write lock.
hasQueuedStrands() - Method in class co.paralleluniverse.strands.concurrent.Semaphore
Queries whether any threads are waiting to acquire.
hasWaiters() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer.ConditionObject
Queries whether any strands are waiting on this condition.
hasWaiters() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer.ConditionObject
Queries whether any strands are waiting on this condition.
hasWaiters(AbstractQueuedLongSynchronizer.ConditionObject) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Queries whether any strands are waiting on the given condition associated with this synchronizer.
hasWaiters(AbstractQueuedSynchronizer.ConditionObject) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Queries whether any strands are waiting on the given condition associated with this synchronizer.
hasWaiters(Condition) - Method in class co.paralleluniverse.strands.concurrent.ReentrantLock
Queries whether any strands are waiting on the given condition associated with this lock.
hasWaiters(Condition) - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock
Queries whether any strands are waiting on the given condition associated with the write lock.
hire(ActorRef<M>) - Static method in class co.paralleluniverse.actors.Actor
Hires and resumes/restarts a migrated actor.
hire(ActorRef<M>, FiberScheduler) - Static method in class co.paralleluniverse.actors.Actor
Hires and resumes/restarts a migrated actor.

I

IdMessage - Interface in co.paralleluniverse.actors.behaviors
An actor message with a unique (or unique with a high probability) ID (usually generated by ActorUtil.randtag() or RequestReplyHelper.makeId()).
index() - Method in class co.paralleluniverse.strands.channels.SelectAction
 
inheritThreadLocals() - Method in class co.paralleluniverse.fibers.Fiber
Causes the current strand's thread-locals to be inherited by this fiber.
init() - Method in class co.paralleluniverse.actors.behaviors.AbstractServerHandler
init() - Method in class co.paralleluniverse.actors.behaviors.BehaviorActor
Called by onStart to initialize the actor.
init() - Method in interface co.paralleluniverse.actors.behaviors.Initializer
 
init() - Method in class co.paralleluniverse.actors.behaviors.SupervisorActor
 
Initializer - Interface in co.paralleluniverse.actors.behaviors
A delegate object that can be used instead of subclassing BehaviorActor and overriding its methods.
initialState() - Method in class co.paralleluniverse.actors.behaviors.FiniteStateMachineActor
Returns this finite-state-machine actor's initial state; the default implementation returns TERMINATE.
initialValue(FiberScheduler) - Method in class co.paralleluniverse.fibers.SchedulerLocal
Computes the initial value for the current FiberScheduler.
instance - Static variable in exception co.paralleluniverse.strands.channels.ReceivePort.EOFException
 
instance - Static variable in class co.paralleluniverse.strands.DoneSynchronizer
 
IntChannel - Interface in co.paralleluniverse.strands.channels
A channel for primitive int messages.
internalSend(Object) - Method in class co.paralleluniverse.actors.Actor
 
internalSend(Object) - Method in class co.paralleluniverse.actors.ActorImpl
For internal use
internalSend(Object) - Method in class co.paralleluniverse.actors.FakeActor
For internal use
internalSend(Object) - Method in class co.paralleluniverse.actors.RemoteActor
 
internalSendNonSuspendable(Object) - Method in class co.paralleluniverse.actors.Actor
 
internalSendNonSuspendable(Object) - Method in class co.paralleluniverse.actors.ActorImpl
 
internalSendNonSuspendable(Object) - Method in class co.paralleluniverse.actors.FakeActor
 
internalSendNonSuspendable(Object) - Method in class co.paralleluniverse.actors.RemoteActor
 
interrupt() - Method in class co.paralleluniverse.actors.Actor
Interrupts the actor's strand.
interrupt() - Method in class co.paralleluniverse.actors.ActorImpl
 
interrupt() - Method in class co.paralleluniverse.actors.ActorRef
Interrupts the actor's strand
interrupt() - Method in class co.paralleluniverse.actors.RemoteActor
 
interrupt() - Method in class co.paralleluniverse.fibers.Fiber
 
interrupt() - Method in class co.paralleluniverse.strands.Strand
Interrupts this strand.
interrupted() - Static method in class co.paralleluniverse.fibers.Fiber
 
interrupted() - Method in class co.paralleluniverse.fibers.FiberAsync
Called when the fiber calling FiberAsync.run() is interrupted during the call.
interrupted() - Static method in class co.paralleluniverse.strands.Strand
Tests whether the current strand has been interrupted.
interruptTask() - Method in class co.paralleluniverse.strands.AbstractFuture
 
IntReceivePort - Interface in co.paralleluniverse.strands.channels
A primitive int channel's consumer-side interface.
IntSendPort - Interface in co.paralleluniverse.strands.channels
A primitive int channel's producer-side interface.
Invocation(Method, Object...) - Constructor for class co.paralleluniverse.actors.behaviors.ProxyServerActor.Invocation
 
Invocation(Method, List<Object>) - Constructor for class co.paralleluniverse.actors.behaviors.ProxyServerActor.Invocation
 
isAlive() - Method in class co.paralleluniverse.fibers.Fiber
 
isAlive() - Method in class co.paralleluniverse.strands.Strand
Tests whether this strand is alive, namely it has been started but not yet terminated.
isBroken() - Method in class co.paralleluniverse.strands.concurrent.CyclicBarrier
Queries if this barrier is in a broken state.
isCancelled() - Method in class co.paralleluniverse.fibers.Fiber
 
isCancelled() - Method in class co.paralleluniverse.strands.AbstractFuture
 
isCancelled() - Method in class co.paralleluniverse.strands.dataflow.Val
 
isClosed() - Method in class co.paralleluniverse.actors.Actor
 
isClosed() - Method in class co.paralleluniverse.actors.Mailbox
 
isClosed() - Method in class co.paralleluniverse.strands.channels.DelegatingReceivePort
 
isClosed() - Method in class co.paralleluniverse.strands.channels.FlatMappingReceivePort
 
isClosed() - Method in interface co.paralleluniverse.strands.channels.PortAutoCloseable
Tests whether the channel has been closed and no more messages await in the channel.
isClosed() - Method in class co.paralleluniverse.strands.channels.QueueChannel
This method must only be called by the channel's owner (the receiver)
isClosed() - Method in class co.paralleluniverse.strands.channels.ReceivePortGroup
 
isClosed() - Method in class co.paralleluniverse.strands.channels.ThreadReceivePort
Tests whether the channel has been closed and no more messages await in the channel.
isClosed() - Method in class co.paralleluniverse.strands.channels.TickerChannelConsumer
 
isClosed() - Method in class co.paralleluniverse.strands.channels.TransferChannel
 
isClosed() - Method in class co.paralleluniverse.strands.channels.ZippingReceivePort
 
isClosed() - Method in class co.paralleluniverse.strands.dataflow.ValChannel
 
isCompleted() - Method in class co.paralleluniverse.fibers.FiberAsync
Tests whether or not the asynchronous operation represented by this `FiberAsyc` has completed.
isCurrentFiber() - Static method in class co.paralleluniverse.fibers.Fiber
Tests whether current code is executing in a fiber.
isCurrentFiber() - Static method in class co.paralleluniverse.strands.Strand
Tests whether this function is called within a fiber.
isCurrentThreadInScheduler() - Method in class co.paralleluniverse.fibers.FiberExecutorScheduler
 
isCurrentThreadInScheduler() - Method in class co.paralleluniverse.fibers.FiberForkJoinScheduler
 
isCurrentThreadInScheduler() - Method in class co.paralleluniverse.fibers.FiberScheduler
 
isDone() - Method in class co.paralleluniverse.actors.Actor
Tests whether this actor has terminated.
isDone() - Method in class co.paralleluniverse.actors.FakeActor
Tests whether this fake actor has terminated.
isDone() - Method in class co.paralleluniverse.fibers.Fiber
 
isDone() - Method in interface co.paralleluniverse.fibers.Joinable
 
isDone() - Method in class co.paralleluniverse.strands.AbstractFuture
 
isDone() - Method in class co.paralleluniverse.strands.channels.SelectAction
Tests whether this operation is the one operation that has been selected and completed by the selector.
isDone() - Method in class co.paralleluniverse.strands.dataflow.Val
 
isDone() - Method in class co.paralleluniverse.strands.Strand
 
isDone(ActorRef<?>) - Static method in class co.paralleluniverse.actors.LocalActor
 
isExpired() - Method in class co.paralleluniverse.strands.Timeout
Tests whether the timeout has expired.
isFair() - Method in class co.paralleluniverse.strands.concurrent.ReentrantLock
Returns true if this lock has fairness set true.
isFair() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock
Returns true if this lock has fairness set true.
isFair() - Method in class co.paralleluniverse.strands.concurrent.Semaphore
Returns true if this semaphore has fairness set true.
isFiber() - Method in class co.paralleluniverse.actors.ActorInfo
Whether the actor's strand is a fiber
isFiber() - Method in class co.paralleluniverse.fibers.Fiber
 
isFiber() - Method in class co.paralleluniverse.strands.Strand
Tests whether this strand is a fiber.
isFiberThread(Thread) - Static method in class co.paralleluniverse.fibers.FiberForkJoinScheduler
 
isFirstInStackOrPushed() - Method in class co.paralleluniverse.fibers.Stack
called when nextMethodEntry returns 0
isHeldByCurrentStrand() - Method in class co.paralleluniverse.strands.concurrent.ReentrantLock
Queries if this lock is held by the current strand.
isHeldByCurrentStrand() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock.WriteLock
Queries if this write lock is held by the current strand.
isHeldExclusively() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Returns true if synchronization is held exclusively with respect to the current (calling) strand.
isHeldExclusively() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Returns true if synchronization is held exclusively with respect to the current (calling) strand.
isInActor() - Method in class co.paralleluniverse.actors.Actor
Tests whether this code is executing in this actor's strand.
isInActor() - Method in class co.paralleluniverse.actors.ActorRefDelegate
 
isInstance(ActorRef<?>, Class<? extends Actor>) - Static method in class co.paralleluniverse.actors.LocalActor
 
isInterrupted() - Method in class co.paralleluniverse.fibers.Fiber
 
isInterrupted() - Method in class co.paralleluniverse.strands.Strand
Tests whether this strand has been interrupted.
isLocal(ActorRef<?>) - Static method in class co.paralleluniverse.actors.LocalActor
 
isLocked() - Method in class co.paralleluniverse.strands.concurrent.ReentrantLock
Queries if this lock is held by any strand.
isOpen() - Method in class co.paralleluniverse.fibers.io.FiberFileChannel
 
isOpen() - Method in class co.paralleluniverse.fibers.io.FiberServerSocketChannel
 
isOpen() - Method in class co.paralleluniverse.fibers.io.FiberSocketChannel
 
isOwnerAlive() - Method in class co.paralleluniverse.strands.channels.SingleConsumerQueueChannel
 
isQueued(Strand) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Returns true if the given strand is currently queued.
isQueued(Strand) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Returns true if the given strand is currently queued.
isReadLocked() - Method in class co.paralleluniverse.strands.concurrent.StampedLock
Returns true if the lock is currently held non-exclusively.
isRecordingLevel(int) - Method in class co.paralleluniverse.actors.ActorImpl
 
isRecordingLevel(int) - Method in class co.paralleluniverse.fibers.Fiber
 
isRegistered() - Method in class co.paralleluniverse.actors.Actor
Tests whether this actor has been registered.
isRunning() - Method in class co.paralleluniverse.actors.behaviors.BehaviorActor
 
isSingleConsumer() - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
isSingleConsumer() - Method in interface co.paralleluniverse.strands.channels.StandardChannel
Whether or not the channel supports a single consumer only.
isSingleConsumer() - Method in class co.paralleluniverse.strands.channels.TransferChannel
 
isSingleProducer() - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
isSingleProducer() - Method in interface co.paralleluniverse.strands.channels.StandardChannel
Whether or not the channel supports a single producer only.
isSingleProducer() - Method in class co.paralleluniverse.strands.channels.TransferChannel
 
isStarted() - Method in class co.paralleluniverse.actors.Actor
Tests whether this actor has been started, i.e.
isTerminated() - Method in class co.paralleluniverse.fibers.Fiber
 
isTerminated() - Method in class co.paralleluniverse.strands.concurrent.Phaser
Returns true if this phaser has been terminated.
isTerminated() - Method in class co.paralleluniverse.strands.Strand
Tests whether this strand has terminated.
isTickerChannel(ReceivePort<?>) - Static method in class co.paralleluniverse.strands.channels.Channels
Tests whether a given channel is a ticker channel, namely a channel with a bounded buffer and an overflow policy of DISPLACE.
isWriteLocked() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock
Queries if the write lock is held by any strand.
isWriteLocked() - Method in class co.paralleluniverse.strands.concurrent.StampedLock
Returns true if the lock is currently held exclusively.
isWriteLockedByCurrentStrand() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock
Queries if the write lock is held by the current strand.

J

join() - Method in class co.paralleluniverse.actors.Actor
 
join() - Method in class co.paralleluniverse.fibers.Fiber
 
join() - Method in interface co.paralleluniverse.fibers.Joinable
 
join() - Method in class co.paralleluniverse.strands.Strand
Awaits the termination of this strand.
join(long, TimeUnit) - Method in class co.paralleluniverse.actors.Actor
 
join(long, TimeUnit) - Method in class co.paralleluniverse.fibers.Fiber
 
join(long, TimeUnit) - Method in interface co.paralleluniverse.fibers.Joinable
 
join(long, TimeUnit) - Method in class co.paralleluniverse.strands.Strand
Awaits the termination of this strand, at most for the timeout duration specified.
join(ActorRef<?>) - Static method in class co.paralleluniverse.actors.LocalActor
 
join(ActorRef<?>, long, TimeUnit) - Static method in class co.paralleluniverse.actors.LocalActor
 
join(Object) - Static method in class co.paralleluniverse.strands.Strand
Awaits the termination of a given strand.
join(Object, long, TimeUnit) - Static method in class co.paralleluniverse.strands.Strand
Awaits the termination of a given strand, at most for the timeout duration specified.
Joinable<V> - Interface in co.paralleluniverse.fibers
 
joinNoSuspend() - Method in class co.paralleluniverse.fibers.Fiber
 
joinNoSuspend(long, TimeUnit) - Method in class co.paralleluniverse.fibers.Fiber
 

L

LifecycleException - Exception in co.paralleluniverse.actors
An exception that is generated by an actor's handleLifecycle method (and thrown by the receive method) if an ExitMessage is received from a linked actor.
LifecycleException(LifecycleMessage) - Constructor for exception co.paralleluniverse.actors.LifecycleException
 
LifecycleMessage - Interface in co.paralleluniverse.actors
A message that is automatically generated by an actor upon some lifecycle event (like death) and sent to its watchers or linked actors.
link(ActorRef) - Method in class co.paralleluniverse.actors.Actor
Links this actor to another.
link(ActorRef<?>, ActorRef<?>) - Static method in class co.paralleluniverse.actors.LocalActor
 
linked(ActorRef) - Method in class co.paralleluniverse.actors.Actor
 
linked(ActorRef) - Method in class co.paralleluniverse.actors.ActorImpl
 
linked(ActorRef) - Method in class co.paralleluniverse.actors.RemoteActor
 
loadModule(String) - Method in class co.paralleluniverse.actors.ActorLoader
 
loadModule(URL) - Method in class co.paralleluniverse.actors.ActorLoader
 
LocalActor - Class in co.paralleluniverse.actors
Static methods that provide access to Actor's functionality through an ActorRef if the actor is local.
lock() - Method in class co.paralleluniverse.actors.Mailbox
 
lock() - Method in class co.paralleluniverse.strands.concurrent.ReentrantLock
Acquires the lock.
lock() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock.ReadLock
Acquires the read lock.
lock() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock.WriteLock
Acquires the write lock.
lock(long, long, boolean) - Method in class co.paralleluniverse.fibers.io.FiberFileChannel
 
lockInterruptibly() - Method in class co.paralleluniverse.strands.concurrent.ReentrantLock
Acquires the lock unless the current strand is interrupted.
lockInterruptibly() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock.ReadLock
Acquires the read lock unless the current strand is interrupted.
lockInterruptibly() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock.WriteLock
Acquires the write lock unless the current strand is interrupted.
log() - Method in class co.paralleluniverse.actors.behaviors.BehaviorActor
The Logger object associated with this actor.
log() - Method in class co.paralleluniverse.actors.behaviors.EventSourceActor
 
log() - Method in class co.paralleluniverse.actors.behaviors.FiniteStateMachineActor
 
log() - Method in class co.paralleluniverse.actors.behaviors.ServerActor
 
log() - Method in class co.paralleluniverse.actors.behaviors.SupervisorActor
 
LongChannel - Interface in co.paralleluniverse.strands.channels
A channel for primitive double messages.
LongReceivePort - Interface in co.paralleluniverse.strands.channels
A primitive long channel's consumer-side interface.
LongSendPort - Interface in co.paralleluniverse.strands.channels
A primitive long channel's producer-side interface.

M

mailbox() - Method in class co.paralleluniverse.actors.Actor
Returns this actor's mailbox channel.
mailbox() - Method in class co.paralleluniverse.actors.ActorImpl
 
mailbox() - Method in interface co.paralleluniverse.actors.ActorMXBean
The messages currently waiting in the actor's mailbox
Mailbox<Message> - Class in co.paralleluniverse.actors
A channel that is used as an actor's mailbox.
MailboxConfig - Class in co.paralleluniverse.actors
An actor mailbox configuration.
MailboxConfig() - Constructor for class co.paralleluniverse.actors.MailboxConfig
Specifies a default mailbox configuration - an unbounded mailbox.
MailboxConfig(int, Channels.OverflowPolicy) - Constructor for class co.paralleluniverse.actors.MailboxConfig
Specifies a mailbox configuration with a given size and overflow policy.
makeId() - Static method in class co.paralleluniverse.actors.behaviors.RequestReplyHelper
Generates a random, probably unique, message identifier.
makeRef(ActorRef<Object>) - Method in class co.paralleluniverse.actors.behaviors.BehaviorActor
 
makeRef(ActorRef<Object>) - Method in class co.paralleluniverse.actors.behaviors.EventSourceActor
 
makeRef(ActorRef<Object>) - Method in class co.paralleluniverse.actors.behaviors.ProxyServerActor
 
makeRef(ActorRef<Object>) - Method in class co.paralleluniverse.actors.behaviors.ServerActor
 
makeRef(ActorRef<Object>) - Method in class co.paralleluniverse.actors.behaviors.SupervisorActor
 
makeRef(ActorRef<Message>) - Method in class co.paralleluniverse.actors.Actor
 
map(ReceivePort<S>, Function<S, T>) - Static method in class co.paralleluniverse.strands.channels.Channels
Returns a ReceivePort that receives messages that are transformed by a given mapping function from a given channel.
map(Function<S, T>) - Method in class co.paralleluniverse.strands.channels.TransformingSendPort
Returns a TransformingSendPort that transforms messages by applying a given mapping function before sending this channel.
map(Function<T, U>) - Method in class co.paralleluniverse.strands.channels.TransformingReceivePort
Returns a TransformingReceivePort that receives messages that are transformed by a given mapping function from this channel.
map(FileChannel.MapMode, long, long) - Method in class co.paralleluniverse.fibers.io.FiberFileChannel
 
map(S) - Method in class co.paralleluniverse.strands.channels.FlatMappingReceivePort
 
mapErrors(ReceivePort<T>, Function<Exception, T>) - Static method in class co.paralleluniverse.strands.channels.Channels
Returns a ReceivePort that maps exceptions thrown by the underlying channel (by channel transformations, or as a result of SendPort.close(Throwable) ) into messages.
mapSend(SendPort<T>, Function<S, T>) - Static method in class co.paralleluniverse.strands.channels.Channels
Returns a SendPort that transforms messages by applying a given mapping function before sending them to a given channel.
matches(M1) - Method in class co.paralleluniverse.actors.behaviors.MessageSelector
 
MAX_ENTRY - Static variable in class co.paralleluniverse.fibers.Stack
 
MAX_PRIORITY - Static variable in class co.paralleluniverse.strands.Strand
The maximum priority that a strand can have.
MAX_SLOTS - Static variable in class co.paralleluniverse.fibers.Stack
 
maybeSetCurrentStrandAsOwner() - Method in class co.paralleluniverse.actors.Mailbox
 
maybeSetCurrentStrandAsOwner() - Method in class co.paralleluniverse.strands.channels.QueuePrimitiveChannel
 
maybeSetCurrentStrandAsOwner() - Method in class co.paralleluniverse.strands.channels.SingleConsumerQueueChannel
 
message() - Method in exception co.paralleluniverse.actors.LifecycleException
 
message() - Method in class co.paralleluniverse.strands.channels.SelectAction
Returns the message to send if this is a send operation, or the message that has been received if this is a receive operation and has been successfully completed by the selector.
MessageProcessor<Message,​T> - Interface in co.paralleluniverse.actors
An interface that is used by BasicActor.receive for selective receive.
MessageSelector<M1,​M2> - Class in co.paralleluniverse.actors.behaviors
A fluent interface for creating MessageProcessors that select messages matching a few simple criteria.
migrate() - Method in class co.paralleluniverse.actors.Actor
Suspends and migrate the actor.
migrateAndRestart() - Method in class co.paralleluniverse.actors.Actor
Suspends and migrates the actor in such a way that when it is later hired, the actor is restarted (i.e., its `doRun` method will be called again and run from the top), but the current value of the actor's fields will be preserved.
MigratingActor - Interface in co.paralleluniverse.actors
A marker interface that must be implemented by actors wishing to support migration
MIN_PRIORITY - Static variable in class co.paralleluniverse.strands.Strand
The minimum priority that a strand can have.
mix(ReceivePort<? extends M>...) - Static method in class co.paralleluniverse.strands.channels.Channels
Returns a Mix that receives messages from a set of channels.
mix(Collection<? extends ReceivePort<? extends M>>) - Static method in class co.paralleluniverse.strands.channels.Channels
Returns a Mix that receives messages from a set of channels.
Mix<M> - Interface in co.paralleluniverse.strands.channels
ReceivePort with Mix operations.
Mix.Mode - Enum in co.paralleluniverse.strands.channels
 
Mix.SoloEffect - Enum in co.paralleluniverse.strands.channels
 
Mix.State - Class in co.paralleluniverse.strands.channels
 
mode - Variable in class co.paralleluniverse.strands.channels.Mix.State
 
monitor() - Method in class co.paralleluniverse.actors.Actor
Starts a monitor that exposes information about this actor via a JMX MBean.
monitorAddDeath(Object) - Method in class co.paralleluniverse.actors.Actor
 
monitorAddMessage() - Method in class co.paralleluniverse.actors.Actor
 
monitorResetSkippedMessages() - Method in class co.paralleluniverse.actors.Actor
 
monitorSkippedMessage() - Method in class co.paralleluniverse.actors.Actor
 
MUTE - co.paralleluniverse.strands.channels.Mix.Mode
 
MUTE_OTHERS - co.paralleluniverse.strands.channels.Mix.SoloEffect
 

N

nanosLeft() - Method in class co.paralleluniverse.strands.Timeout
Returns how many nanoseconds are left before the timeout expires, or a negative number indicating how many nanoseconds have elapsed since the timeout expired.
NEW - co.paralleluniverse.strands.Strand.State
Strand created but not started
newActor(ActorSpec<T, Message, V>) - Static method in class co.paralleluniverse.actors.Actor
Creates a new actor from an ActorSpec.
newActor(Class<T>, Object...) - Static method in class co.paralleluniverse.actors.Actor
Creates a new actor.
newChannel(int) - Static method in class co.paralleluniverse.strands.channels.Channels
Creates a new channel with the given mailbox size with other properties set to their default values.
newChannel(int, Channels.OverflowPolicy) - Static method in class co.paralleluniverse.strands.channels.Channels
Creates a new channel with the given mailbox size and Channels.OverflowPolicy, with other properties set to their default values.
newChannel(int, Channels.OverflowPolicy, boolean, boolean) - Static method in class co.paralleluniverse.strands.channels.Channels
Creates a new channel with the given properties.
newCondition() - Method in class co.paralleluniverse.strands.concurrent.ReentrantLock
Returns a Condition instance for use with this Lock instance.
newCondition() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock.ReadLock
Throws UnsupportedOperationException because ReadLocks do not support conditions.
newCondition() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock.WriteLock
Returns a Condition instance for use with this Lock instance.
newDoubleChannel(int) - Static method in class co.paralleluniverse.strands.channels.Channels
Creates a new primitive double channel with the given mailbox size with other properties set to their default values.
newDoubleChannel(int, Channels.OverflowPolicy) - Static method in class co.paralleluniverse.strands.channels.Channels
Creates a new primitive double channel with the given mailbox size and Channels.OverflowPolicy, with other properties set to their default values.
newDoubleChannel(int, Channels.OverflowPolicy, boolean, boolean) - Static method in class co.paralleluniverse.strands.channels.Channels
Creates a new primitive double channel with the given properties.
newFiber(SuspendableCallable<T>) - Method in interface co.paralleluniverse.fibers.FiberFactory
 
newFiber(SuspendableCallable<T>) - Method in class co.paralleluniverse.fibers.FiberScheduler
 
newFloatChannel(int) - Static method in class co.paralleluniverse.strands.channels.Channels
Creates a new primitive float channel with the given mailbox size with other properties set to their default values.
newFloatChannel(int, Channels.OverflowPolicy) - Static method in class co.paralleluniverse.strands.channels.Channels
Creates a new primitive float channel with the given mailbox size and Channels.OverflowPolicy, with other properties set to their default values.
newFloatChannel(int, Channels.OverflowPolicy, boolean, boolean) - Static method in class co.paralleluniverse.strands.channels.Channels
Creates a new primitive float channel with the given properties.
newIntChannel(int) - Static method in class co.paralleluniverse.strands.channels.Channels
Creates a new primitive int channel with the given mailbox size with other properties set to their default values.
newIntChannel(int, Channels.OverflowPolicy) - Static method in class co.paralleluniverse.strands.channels.Channels
Creates a new primitive int channel with the given mailbox size and Channels.OverflowPolicy, with other properties set to their default values.
newIntChannel(int, Channels.OverflowPolicy, boolean, boolean) - Static method in class co.paralleluniverse.strands.channels.Channels
Creates a new primitive int channel with the given properties.
newLongChannel(int) - Static method in class co.paralleluniverse.strands.channels.Channels
Creates a new primitive long channel with the given mailbox size with other properties set to their default values.
newLongChannel(int, Channels.OverflowPolicy) - Static method in class co.paralleluniverse.strands.channels.Channels
Creates a new primitive long channel with the given mailbox size and Channels.OverflowPolicy, with other properties set to their default values.
newLongChannel(int, Channels.OverflowPolicy, boolean, boolean) - Static method in class co.paralleluniverse.strands.channels.Channels
Creates a new primitive long channel with the given properties.
newStrand(SuspendableCallable<?>) - Method in class co.paralleluniverse.fibers.FiberScheduler
 
newStrand(SuspendableCallable<?>) - Method in interface co.paralleluniverse.strands.StrandFactory
 
newTickerConsumerFor(Channel<Message>) - Static method in class co.paralleluniverse.strands.channels.Channels
Creates a ReceivePort that can be used to receive messages from a a ticker channel: a channel of bounded capacity and the DISPLACE overflow policy.
newTickerConsumerFor(DoubleChannel) - Static method in class co.paralleluniverse.strands.channels.Channels
Creates a DoubleReceivePort that can be used to receive messages from a a ticker channel: a channel of bounded capacity and the DISPLACE overflow policy.
newTickerConsumerFor(FloatChannel) - Static method in class co.paralleluniverse.strands.channels.Channels
Creates a FloatReceivePort that can be used to receive messages from a a ticker channel: a channel of bounded capacity and the DISPLACE overflow policy.
newTickerConsumerFor(IntChannel) - Static method in class co.paralleluniverse.strands.channels.Channels
Creates an IntReceivePort that can be used to receive messages from a a ticker channel: a channel of bounded capacity and the DISPLACE overflow policy.
newTickerConsumerFor(LongChannel) - Static method in class co.paralleluniverse.strands.channels.Channels
Creates a LongReceivePort that can be used to receive messages from a a ticker channel: a channel of bounded capacity and the DISPLACE overflow policy.
next(int) - Method in class co.paralleluniverse.strands.StrandLocalRandom
 
nextDouble(double) - Method in class co.paralleluniverse.strands.StrandLocalRandom
Returns a pseudorandom, uniformly distributed double value between 0 (inclusive) and the specified value (exclusive).
nextDouble(double, double) - Method in class co.paralleluniverse.strands.StrandLocalRandom
Returns a pseudorandom, uniformly distributed value between the given least value (inclusive) and bound (exclusive).
nextInt(int, int) - Method in class co.paralleluniverse.strands.StrandLocalRandom
Returns a pseudorandom, uniformly distributed value between the given least value (inclusive) and bound (exclusive).
nextLong(long) - Method in class co.paralleluniverse.strands.StrandLocalRandom
Returns a pseudorandom, uniformly distributed value between 0 (inclusive) and the specified value (exclusive).
nextLong(long, long) - Method in class co.paralleluniverse.strands.StrandLocalRandom
Returns a pseudorandom, uniformly distributed value between the given least value (inclusive) and bound (exclusive).
nextMethodEntry() - Method in class co.paralleluniverse.fibers.Stack
called at the beginning of a method
NORM_PRIORITY - Static variable in class co.paralleluniverse.strands.Strand
The default priority that is assigned to a strand.
NORMAL - co.paralleluniverse.strands.channels.Mix.Mode
 
notify(Event) - Method in class co.paralleluniverse.actors.behaviors.EventSource
Sends an event to the actor, which will be delivered to all registered event handlers.
notify(Event) - Method in class co.paralleluniverse.actors.behaviors.EventSourceActor
 
NULL_RETURN_VALUE - Static variable in class co.paralleluniverse.actors.behaviors.FiniteStateMachineActor
 
NULL_RETURN_VALUE - Static variable in class co.paralleluniverse.actors.behaviors.ServerActor
 

O

of(Fiber) - Static method in class co.paralleluniverse.strands.Strand
Returns a strand representing the given fiber.
of(SuspendExecution) - Static method in exception co.paralleluniverse.fibers.RuntimeSuspendExecution
 
of(TypeToken<T>, Object...) - Static method in class co.paralleluniverse.actors.ActorSpec
Creates an ActorSpec
of(Class<T>, Object...) - Static method in class co.paralleluniverse.actors.ActorSpec
Creates an ActorSpec
of(Object) - Static method in class co.paralleluniverse.strands.Strand
 
of(Thread) - Static method in class co.paralleluniverse.strands.Strand
Returns a strand representing the given thread.
ofType(Class<M>) - Method in class co.paralleluniverse.actors.behaviors.MessageSelector
Selects messages of the given class.
ofType(Class<M>) - Static method in class co.paralleluniverse.actors.SelectiveReceiveHelper
Creates a MessageProcessor that selects messages of the given class.
onAdvance(int, int) - Method in class co.paralleluniverse.strands.concurrent.Phaser
Overridable method to perform an action upon impending phase advance, and to control termination.
onCodeChange() - Method in class co.paralleluniverse.actors.Actor
This method is called on an actor instance replacing an active instance via hot code-swapping.
onCompletion() - Method in class co.paralleluniverse.fibers.Fiber
 
ONE_FOR_ONE - co.paralleluniverse.actors.behaviors.SupervisorActor.RestartStrategy
Restart the dead actor.
onException(Throwable) - Method in class co.paralleluniverse.fibers.Fiber
 
onIdle() - Method in class co.paralleluniverse.fibers.FiberForkJoinScheduler
 
onParked() - Method in class co.paralleluniverse.fibers.Fiber
 
onReceive(Message) - Method in interface co.paralleluniverse.strands.channels.SelectReceiveListener
 
onResume() - Method in class co.paralleluniverse.fibers.Fiber
 
onSend() - Method in interface co.paralleluniverse.strands.channels.SelectSendListener
 
onStart() - Method in class co.paralleluniverse.actors.behaviors.BehaviorActor
This method is called by the BehaviorActor at the beginning of BehaviorActor.doRun().
onStart() - Method in class co.paralleluniverse.actors.behaviors.SupervisorActor
 
onTerminate(Throwable) - Method in class co.paralleluniverse.actors.behaviors.BehaviorActor
This method is called by the BehaviorActor at the end of BehaviorActor.doRun().
onTerminate(Throwable) - Method in class co.paralleluniverse.actors.behaviors.EventSourceActor
 
onTerminate(Throwable) - Method in class co.paralleluniverse.actors.behaviors.SupervisorActor
 
OnUpgrade - Annotation Type in co.paralleluniverse.actors
Specifies that a method is to be called after its class has been upgraded.
open() - Static method in class co.paralleluniverse.fibers.io.FiberServerSocketChannel
Opens a server-socket channel.
open() - Static method in class co.paralleluniverse.fibers.io.FiberSocketChannel
Opens a socket channel.
open(ChannelGroup) - Static method in class co.paralleluniverse.fibers.io.FiberServerSocketChannel
Opens an server-socket channel.
open(ChannelGroup) - Static method in class co.paralleluniverse.fibers.io.FiberSocketChannel
Opens a socket channel.
open(ChannelGroup, SocketAddress) - Static method in class co.paralleluniverse.fibers.io.FiberSocketChannel
Opens a socket channel and connects it to a remote address.
open(SocketAddress) - Static method in class co.paralleluniverse.fibers.io.FiberSocketChannel
Opens a socket channel and connects it to a remote address.
open(Path, OpenOption...) - Static method in class co.paralleluniverse.fibers.io.FiberFileChannel
Opens or creates a file for reading and/or writing, returning a file channel to access the file.
open(ExecutorService, Path, Set<? extends OpenOption>, FileAttribute<?>...) - Static method in class co.paralleluniverse.fibers.io.FiberFileChannel
Opens or creates a file, returning a file channel to access the file.
OwnedSynchronizer - Class in co.paralleluniverse.strands
 
OwnedSynchronizer(Object) - Constructor for class co.paralleluniverse.strands.OwnedSynchronizer
 
owns(AbstractQueuedLongSynchronizer.ConditionObject) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Queries whether the given ConditionObject uses this synchronizer as its lock.
owns(AbstractQueuedSynchronizer.ConditionObject) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Queries whether the given ConditionObject uses this synchronizer as its lock.

P

park() - Static method in class co.paralleluniverse.fibers.Fiber
 
park() - Static method in class co.paralleluniverse.strands.Strand
Disables the current strand for scheduling purposes unless the permit is available.
park(long, TimeUnit) - Static method in class co.paralleluniverse.fibers.Fiber
 
park(Object) - Static method in class co.paralleluniverse.fibers.Fiber
 
park(Object) - Static method in class co.paralleluniverse.strands.Strand
Disables the current strand for scheduling purposes unless the permit is available.
park(Object, long, TimeUnit) - Static method in class co.paralleluniverse.fibers.Fiber
 
parkAndCustomSerialize(CustomFiberWriter) - Static method in class co.paralleluniverse.fibers.Fiber
Parks the fiber and allows the given callback to serialize it, optimized for use cases where the callback object has a custom way to obtain the required serializer (e.g.
parkAndSerialize(FiberWriter) - Static method in class co.paralleluniverse.fibers.Fiber
Parks the fiber and allows the given callback to serialize it.
parkAndUnpark(Fiber) - Static method in class co.paralleluniverse.fibers.Fiber
 
parkAndUnpark(Fiber, Object) - Static method in class co.paralleluniverse.fibers.Fiber
 
parkAndUnpark(Strand) - Static method in class co.paralleluniverse.strands.Strand
 
parkAndUnpark(Strand, Object) - Static method in class co.paralleluniverse.strands.Strand
 
parkNanos(long) - Static method in class co.paralleluniverse.strands.Strand
Disables the current strand for thread scheduling purposes, for up to the specified waiting time, unless the permit is available.
parkNanos(Object, long) - Static method in class co.paralleluniverse.strands.Strand
Disables the current strand for thread scheduling purposes, for up to the specified waiting time, unless the permit is available.
parkUntil(Object, long) - Static method in class co.paralleluniverse.strands.Strand
Disables the current strand for scheduling purposes, until the specified deadline, unless the permit is available.
PAUSE - co.paralleluniverse.strands.channels.Mix.Mode
 
PAUSE_OTHERS - co.paralleluniverse.strands.channels.Mix.SoloEffect
 
PERMANENT - co.paralleluniverse.actors.behaviors.Supervisor.ChildMode
The child actor should be restarted if it dies for whatever reason if the supervisor's restart strategy states that it should be restarted.
Phaser - Class in co.paralleluniverse.strands.concurrent
A reusable synchronization barrier, similar in functionality to CyclicBarrier and CountDownLatch but supporting more flexible usage.
Phaser() - Constructor for class co.paralleluniverse.strands.concurrent.Phaser
Creates a new phaser with no initially registered parties, no parent, and initial phase number 0.
Phaser(int) - Constructor for class co.paralleluniverse.strands.concurrent.Phaser
Creates a new phaser with the given number of registered unarrived parties, no parent, and initial phase number 0.
Phaser(Phaser) - Constructor for class co.paralleluniverse.strands.concurrent.Phaser
Equivalent to Phaser(parent, 0).
Phaser(Phaser, int) - Constructor for class co.paralleluniverse.strands.concurrent.Phaser
Creates a new phaser with the given parent and number of registered unarrived parties.
Pipeline<S,​T> - Class in co.paralleluniverse.strands.channels.transfer
 
Pipeline(ReceivePort<? extends S>, SendPort<? super T>, SuspendableAction2<S, Channel<T>>) - Constructor for class co.paralleluniverse.strands.channels.transfer.Pipeline
 
Pipeline(ReceivePort<? extends S>, SendPort<? super T>, SuspendableAction2<S, Channel<T>>, int) - Constructor for class co.paralleluniverse.strands.channels.transfer.Pipeline
 
Pipeline(ReceivePort<? extends S>, SendPort<? super T>, SuspendableAction2<S, Channel<T>>, int, boolean) - Constructor for class co.paralleluniverse.strands.channels.transfer.Pipeline
 
Pipeline(ReceivePort<? extends S>, SendPort<? super T>, SuspendableAction2<S, Channel<T>>, int, boolean, SuspendableCallable<Channel<T>>) - Constructor for class co.paralleluniverse.strands.channels.transfer.Pipeline
 
Pipeline(ReceivePort<? extends S>, SendPort<? super T>, SuspendableAction2<S, Channel<T>>, int, boolean, SuspendableCallable<Channel<T>>, StrandFactory) - Constructor for class co.paralleluniverse.strands.channels.transfer.Pipeline
 
popMethod(int) - Method in class co.paralleluniverse.fibers.Stack
 
port() - Method in class co.paralleluniverse.strands.channels.SelectAction
Returns the channel for this operation.
Port<Message> - Interface in co.paralleluniverse.strands.channels
An empty super-interface of SendPort and ReceivePort extend.
PortAutoCloseable - Interface in co.paralleluniverse.strands.channels
 
position() - Method in class co.paralleluniverse.fibers.io.FiberFileChannel
 
position(long) - Method in class co.paralleluniverse.fibers.io.FiberFileChannel
 
postRestore() - Method in class co.paralleluniverse.fibers.Stack
 
preemptionPoint(int) - Method in class co.paralleluniverse.fibers.Stack
 
prepark() - Method in class co.paralleluniverse.fibers.FiberAsync
Called by the fiber if this `FiberAsync` is in immediate-exec mode, immediately before attempting to block while running in the callback's thread.
PRINT_WARNINGS_ON_UNSERIALIZABLE_THREAD_LOCAL - Static variable in class co.paralleluniverse.fibers.ThreadLocalSerializer
 
printStackTrace(StackTraceElement[], PrintStream) - Static method in class co.paralleluniverse.strands.Strand
This utility method prints a stack-trace into a PrintStream
printStackTrace(StackTraceElement[], PrintWriter) - Static method in class co.paralleluniverse.strands.Strand
This utility method prints a stack-trace into a PrintWriter
process(Object) - Method in class co.paralleluniverse.actors.behaviors.MessageSelector
 
process(Message) - Method in interface co.paralleluniverse.actors.MessageProcessor
An implementation of this method is used to select messages off an actor's queue for the purpose of selective receive.
ProducerException - Exception in co.paralleluniverse.strands.channels
This exception is thrown by a ReceivePort's receive or tryReceive methods if the channel has been closed with an exception.
ProducerException(Throwable) - Constructor for exception co.paralleluniverse.strands.channels.ProducerException
 
provider() - Method in class co.paralleluniverse.fibers.io.FiberServerSocketChannel
Returns the IO provider that created this channel.
provider() - Method in class co.paralleluniverse.fibers.io.FiberSocketChannel
Returns the IO provider that created this channel.
ProxyServerActor - Class in co.paralleluniverse.actors.behaviors
Wraps a Java object in a ServerActor that exposes the object's methods as an interface and processes them in an actor (on a dedicated strand).
ProxyServerActor(boolean) - Constructor for class co.paralleluniverse.actors.behaviors.ProxyServerActor
This constructor is for use by subclasses that are intended to serve as the target.
ProxyServerActor(boolean, Class<?>...) - Constructor for class co.paralleluniverse.actors.behaviors.ProxyServerActor
This constructor is for use by subclasses that are intended to serve as the target.
ProxyServerActor(boolean, Object) - Constructor for class co.paralleluniverse.actors.behaviors.ProxyServerActor
Creates a new ProxyServerActor with the default mailbox settings, which exposes all interfaces implemented by the given target.
ProxyServerActor(boolean, Object, Class<?>...) - Constructor for class co.paralleluniverse.actors.behaviors.ProxyServerActor
Creates a new ProxyServerActor with the default mailbox settings.
ProxyServerActor(MailboxConfig, boolean) - Constructor for class co.paralleluniverse.actors.behaviors.ProxyServerActor
This constructor is for use by subclasses that are intended to serve as the target.
ProxyServerActor(MailboxConfig, boolean, Class<?>...) - Constructor for class co.paralleluniverse.actors.behaviors.ProxyServerActor
This constructor is for use by subclasses that are intended to serve as the target.
ProxyServerActor(MailboxConfig, boolean, Object) - Constructor for class co.paralleluniverse.actors.behaviors.ProxyServerActor
Creates a new ProxyServerActor, which exposes all interfaces implemented by the given target.
ProxyServerActor(MailboxConfig, boolean, Object, Class<?>...) - Constructor for class co.paralleluniverse.actors.behaviors.ProxyServerActor
Creates a new ProxyServerActor
ProxyServerActor(String, boolean) - Constructor for class co.paralleluniverse.actors.behaviors.ProxyServerActor
This constructor is for use by subclasses that are intended to serve as the target.
ProxyServerActor(String, boolean, Class<?>...) - Constructor for class co.paralleluniverse.actors.behaviors.ProxyServerActor
This constructor is for use by subclasses that are intended to serve as the target.
ProxyServerActor(String, boolean, Object) - Constructor for class co.paralleluniverse.actors.behaviors.ProxyServerActor
Creates a new ProxyServerActor with the default mailbox settings, which exposes all interfaces implemented by the given target.
ProxyServerActor(String, boolean, Object, Class<?>...) - Constructor for class co.paralleluniverse.actors.behaviors.ProxyServerActor
Creates a new ProxyServerActor with the default mailbox settings.
ProxyServerActor(String, MailboxConfig, boolean) - Constructor for class co.paralleluniverse.actors.behaviors.ProxyServerActor
This constructor is for use by subclasses that are intended to serve as the target.
ProxyServerActor(String, MailboxConfig, boolean, Class<?>...) - Constructor for class co.paralleluniverse.actors.behaviors.ProxyServerActor
This constructor is for use by subclasses that are intended to serve as the target.
ProxyServerActor(String, MailboxConfig, boolean, Object) - Constructor for class co.paralleluniverse.actors.behaviors.ProxyServerActor
Creates a new ProxyServerActor, which exposes all interfaces implemented by the given target.
ProxyServerActor(String, MailboxConfig, boolean, Object, Class<?>...) - Constructor for class co.paralleluniverse.actors.behaviors.ProxyServerActor
Creates a new ProxyServerActor
ProxyServerActor(String, Strand, MailboxConfig, boolean, Object, Class<?>[]) - Constructor for class co.paralleluniverse.actors.behaviors.ProxyServerActor
Creates a new ProxyServerActor
ProxyServerActor.Invocation - Class in co.paralleluniverse.actors.behaviors
 
push(double, Stack, int) - Static method in class co.paralleluniverse.fibers.Stack
 
push(float, Stack, int) - Static method in class co.paralleluniverse.fibers.Stack
 
push(int, Stack, int) - Static method in class co.paralleluniverse.fibers.Stack
 
push(long, Stack, int) - Static method in class co.paralleluniverse.fibers.Stack
 
push(Object, Stack, int) - Static method in class co.paralleluniverse.fibers.Stack
 
pushMethod(int, int) - Method in class co.paralleluniverse.fibers.Stack
Called before a method is called.

Q

queue() - Method in class co.paralleluniverse.actors.Mailbox
 
queue() - Method in class co.paralleluniverse.strands.channels.QueueDoubleChannel
 
queue() - Method in class co.paralleluniverse.strands.channels.QueueFloatChannel
 
queue() - Method in class co.paralleluniverse.strands.channels.QueueIntChannel
 
queue() - Method in class co.paralleluniverse.strands.channels.QueueLongChannel
 
queue() - Method in class co.paralleluniverse.strands.channels.QueuePrimitiveChannel
 
queue() - Method in class co.paralleluniverse.strands.channels.SingleConsumerQueueChannel
 
QueueChannel<Message> - Class in co.paralleluniverse.strands.channels
 
QueueChannel(BasicQueue<Message>, Channels.OverflowPolicy, boolean) - Constructor for class co.paralleluniverse.strands.channels.QueueChannel
 
QueueChannel(BasicQueue<Message>, Channels.OverflowPolicy, boolean, boolean) - Constructor for class co.paralleluniverse.strands.channels.QueueChannel
 
QueueDoubleChannel - Class in co.paralleluniverse.strands.channels
 
QueueDoubleChannel(BasicSingleConsumerDoubleQueue, Channels.OverflowPolicy) - Constructor for class co.paralleluniverse.strands.channels.QueueDoubleChannel
 
QueueFloatChannel - Class in co.paralleluniverse.strands.channels
 
QueueFloatChannel(BasicSingleConsumerFloatQueue, Channels.OverflowPolicy) - Constructor for class co.paralleluniverse.strands.channels.QueueFloatChannel
 
QueueIntChannel - Class in co.paralleluniverse.strands.channels
 
QueueIntChannel(BasicSingleConsumerIntQueue, Channels.OverflowPolicy) - Constructor for class co.paralleluniverse.strands.channels.QueueIntChannel
 
QueueLongChannel - Class in co.paralleluniverse.strands.channels
 
QueueLongChannel(BasicSingleConsumerLongQueue, Channels.OverflowPolicy) - Constructor for class co.paralleluniverse.strands.channels.QueueLongChannel
 
QueueObjectChannel<Message> - Class in co.paralleluniverse.strands.channels
 
QueueObjectChannel(BasicQueue<Message>, Channels.OverflowPolicy, boolean, boolean) - Constructor for class co.paralleluniverse.strands.channels.QueueObjectChannel
 
QueuePrimitiveChannel<Message> - Class in co.paralleluniverse.strands.channels
Single consumer!
QueuePrimitiveChannel(BasicSingleConsumerQueue<Message>, Channels.OverflowPolicy) - Constructor for class co.paralleluniverse.strands.channels.QueuePrimitiveChannel
 

R

randtag() - Static method in class co.paralleluniverse.actors.ActorUtil
Generates a random identifier object (with correct equals and hashCode semantics) that is unlikely to be equal to any other object generated by this method.
ReactiveStreams - Class in co.paralleluniverse.strands.channels.reactivestreams
Converts between Quasar channels and reactive streams
ReactiveStreams() - Constructor for class co.paralleluniverse.strands.channels.reactivestreams.ReactiveStreams
 
read(Kryo, Input, Class<CustomFiberWriter>) - Method in class co.paralleluniverse.fibers.CustomFiberWriterSerializer
 
read(Kryo, Input, Class<ThreadLocal<?>>) - Method in class co.paralleluniverse.fibers.ThreadLocalSerializer
 
read(ByteBuffer) - Method in class co.paralleluniverse.fibers.io.FiberFileChannel
 
read(ByteBuffer) - Method in class co.paralleluniverse.fibers.io.FiberSocketChannel
 
read(ByteBuffer[]) - Method in class co.paralleluniverse.fibers.io.FiberFileChannel
Reads a sequence of bytes from this channel into the given buffers.
read(ByteBuffer[]) - Method in class co.paralleluniverse.fibers.io.FiberSocketChannel
 
read(ByteBuffer[], int, int) - Method in class co.paralleluniverse.fibers.io.FiberFileChannel
 
read(ByteBuffer[], int, int) - Method in class co.paralleluniverse.fibers.io.FiberSocketChannel
 
read(ByteBuffer[], int, int, long, TimeUnit) - Method in class co.paralleluniverse.fibers.io.FiberSocketChannel
Reads a sequence of bytes from this channel into a subsequence of the given buffers.
read(ByteBuffer, long) - Method in class co.paralleluniverse.fibers.io.FiberFileChannel
Reads a sequence of bytes from this channel into the given buffer, starting at the given file position.
read(ByteBuffer, long, TimeUnit) - Method in class co.paralleluniverse.fibers.io.FiberSocketChannel
Reads a sequence of bytes from this channel into the given buffer.
readLock() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock
 
readLock() - Method in class co.paralleluniverse.strands.concurrent.StampedLock
Non-exclusively acquires the lock, blocking if necessary until available.
ReadLock(ReentrantReadWriteLock) - Constructor for class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock.ReadLock
Constructor for use by subclasses
readLockInterruptibly() - Method in class co.paralleluniverse.strands.concurrent.StampedLock
Non-exclusively acquires the lock, blocking if necessary until available or the current strand is interrupted.
readResolve() - Method in class co.paralleluniverse.actors.Actor
 
readResolve() - Method in class co.paralleluniverse.actors.BasicActor
 
readResolve() - Method in class co.paralleluniverse.actors.behaviors.FiniteStateMachineActor
 
receive() - Method in class co.paralleluniverse.actors.Actor
Returns the next message from the mailbox.
receive() - Method in class co.paralleluniverse.strands.channels.DelegatingReceivePort
 
receive() - Method in class co.paralleluniverse.strands.channels.FlatMappingReceivePort
 
receive() - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
receive() - Method in interface co.paralleluniverse.strands.channels.ReceivePort
Retrieves a message from the channels, possibly blocking until one becomes available.
receive() - Method in class co.paralleluniverse.strands.channels.ReceivePortGroup
 
receive() - Method in class co.paralleluniverse.strands.channels.SingleConsumerQueueChannel
 
receive() - Method in class co.paralleluniverse.strands.channels.ThreadReceivePort
Retrieves a message from the channels, possibly blocking until one becomes available.
receive() - Method in class co.paralleluniverse.strands.channels.TickerChannelConsumer
 
receive() - Method in class co.paralleluniverse.strands.channels.TransferChannel
 
receive() - Method in class co.paralleluniverse.strands.channels.ZippingReceivePort
 
receive() - Method in class co.paralleluniverse.strands.dataflow.ValChannel
 
receive(long, TimeUnit) - Method in class co.paralleluniverse.actors.Actor
Returns the next message from the mailbox.
receive(long, TimeUnit) - Method in class co.paralleluniverse.strands.channels.DelegatingReceivePort
 
receive(long, TimeUnit) - Method in class co.paralleluniverse.strands.channels.FlatMappingReceivePort
 
receive(long, TimeUnit) - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
receive(long, TimeUnit) - Method in interface co.paralleluniverse.strands.channels.ReceivePort
Retrieves a message from the channels, possibly blocking until one becomes available, but no longer than the specified timeout.
receive(long, TimeUnit) - Method in class co.paralleluniverse.strands.channels.ReceivePortGroup
 
receive(long, TimeUnit) - Method in class co.paralleluniverse.strands.channels.SingleConsumerQueueChannel
 
receive(long, TimeUnit) - Method in class co.paralleluniverse.strands.channels.ThreadReceivePort
Retrieves a message from the channels, possibly blocking until one becomes available, but no longer than the specified timeout.
receive(long, TimeUnit) - Method in class co.paralleluniverse.strands.channels.TickerChannelConsumer
 
receive(long, TimeUnit) - Method in class co.paralleluniverse.strands.channels.TransferChannel
 
receive(long, TimeUnit) - Method in class co.paralleluniverse.strands.channels.ZippingReceivePort
 
receive(long, TimeUnit) - Method in class co.paralleluniverse.strands.dataflow.ValChannel
 
receive(long, TimeUnit, MessageProcessor<? super Message, T>) - Method in class co.paralleluniverse.actors.BasicActor
Performs a selective receive.
receive(long, TimeUnit, MessageProcessor<? super Message, T>) - Method in class co.paralleluniverse.actors.SelectiveReceiveHelper
Performs a selective receive.
receive(long, TimeUnit, MessageProcessor<Object, SuspendableCallable<SuspendableCallable>>) - Method in class co.paralleluniverse.actors.behaviors.FiniteStateMachineActor
Performs a selective receive.
receive(long, TimeUnit, Class<M>) - Method in class co.paralleluniverse.actors.BasicActor
Performs a selective receive based on type.
receive(long, TimeUnit, Class<M>) - Method in class co.paralleluniverse.actors.behaviors.FiniteStateMachineActor
Performs a selective receive based on type.
receive(long, TimeUnit, Class<M>) - Method in class co.paralleluniverse.actors.SelectiveReceiveHelper
Performs a selective receive based on type.
receive(MessageProcessor<? super Message, T>) - Method in class co.paralleluniverse.actors.BasicActor
Performs a selective receive.
receive(MessageProcessor<? super Message, T>) - Method in class co.paralleluniverse.actors.SelectiveReceiveHelper
Performs a selective receive.
receive(MessageProcessor<Object, SuspendableCallable<SuspendableCallable>>) - Method in class co.paralleluniverse.actors.behaviors.FiniteStateMachineActor
Performs a selective receive.
receive(ReceivePort<? extends Message>) - Static method in class co.paralleluniverse.strands.channels.Selector
Creates a SelectAction for a receive operation
receive(ReceivePort<? extends Message>, SelectReceiveListener<Message>) - Static method in class co.paralleluniverse.strands.channels.Selector
Creates a SelectAction for a receive operation
receive(Timeout) - Method in class co.paralleluniverse.actors.Actor
Returns the next message from the mailbox.
receive(Timeout) - Method in class co.paralleluniverse.strands.channels.DelegatingReceivePort
 
receive(Timeout) - Method in class co.paralleluniverse.strands.channels.FlatMappingReceivePort
 
receive(Timeout) - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
receive(Timeout) - Method in interface co.paralleluniverse.strands.channels.ReceivePort
Retrieves a message from the channels, possibly blocking until one becomes available, but no longer than the specified timeout.
receive(Timeout) - Method in class co.paralleluniverse.strands.channels.ReceivePortGroup
 
receive(Timeout) - Method in class co.paralleluniverse.strands.channels.TickerChannelConsumer
 
receive(Timeout) - Method in class co.paralleluniverse.strands.channels.TransferChannel
 
receive(Timeout) - Method in class co.paralleluniverse.strands.channels.ZippingReceivePort
 
receive(Timeout) - Method in class co.paralleluniverse.strands.dataflow.ValChannel
 
receive(Timeout, MessageProcessor<? super Message, T>) - Method in class co.paralleluniverse.actors.BasicActor
Performs a selective receive.
receive(Timeout, MessageProcessor<? super Message, T>) - Method in class co.paralleluniverse.actors.SelectiveReceiveHelper
Performs a selective receive.
receive(Timeout, MessageProcessor<Object, SuspendableCallable<SuspendableCallable>>) - Method in class co.paralleluniverse.actors.behaviors.FiniteStateMachineActor
Performs a selective receive.
receive(Timeout, Class<M>) - Method in class co.paralleluniverse.actors.BasicActor
Performs a selective receive based on type.
receive(Timeout, Class<M>) - Method in class co.paralleluniverse.actors.behaviors.FiniteStateMachineActor
Performs a selective receive based on type.
receive(Timeout, Class<M>) - Method in class co.paralleluniverse.actors.SelectiveReceiveHelper
Performs a selective receive based on type.
receive(Class<M>) - Method in class co.paralleluniverse.actors.BasicActor
Performs a selective receive based on type.
receive(Class<M>) - Method in class co.paralleluniverse.actors.behaviors.FiniteStateMachineActor
Performs a selective receive based on type.
receive(Class<M>) - Method in class co.paralleluniverse.actors.SelectiveReceiveHelper
Performs a selective receive based on type.
receiveDouble() - Method in interface co.paralleluniverse.strands.channels.DoubleReceivePort
Retrieves a message from the channels, possibly blocking until one becomes available.
receiveDouble() - Method in class co.paralleluniverse.strands.channels.QueueDoubleChannel
 
receiveDouble(long, TimeUnit) - Method in interface co.paralleluniverse.strands.channels.DoubleReceivePort
Retrieves a message from the channels, possibly blocking until one becomes available, but no longer than the specified timeout.
receiveDouble(long, TimeUnit) - Method in class co.paralleluniverse.strands.channels.QueueDoubleChannel
 
receiveDouble(Timeout) - Method in interface co.paralleluniverse.strands.channels.DoubleReceivePort
Retrieves a message from the channels, possibly blocking until one becomes available, but no longer than the specified timeout.
receiveDouble(Timeout) - Method in class co.paralleluniverse.strands.channels.QueueDoubleChannel
 
receiveFloat() - Method in interface co.paralleluniverse.strands.channels.FloatReceivePort
Retrieves a message from the channels, possibly blocking until one becomes available.
receiveFloat() - Method in class co.paralleluniverse.strands.channels.QueueFloatChannel
 
receiveFloat() - Method in class co.paralleluniverse.strands.channels.TickerChannelConsumer.TickerChannelFloatConsumer
 
receiveFloat(long, TimeUnit) - Method in interface co.paralleluniverse.strands.channels.FloatReceivePort
Retrieves a message from the channels, possibly blocking until one becomes available, but no longer than the specified timeout.
receiveFloat(long, TimeUnit) - Method in class co.paralleluniverse.strands.channels.QueueFloatChannel
 
receiveFloat(long, TimeUnit) - Method in class co.paralleluniverse.strands.channels.TickerChannelConsumer.TickerChannelFloatConsumer
 
receiveFloat(Timeout) - Method in interface co.paralleluniverse.strands.channels.FloatReceivePort
Retrieves a message from the channels, possibly blocking until one becomes available, but no longer than the specified timeout.
receiveFloat(Timeout) - Method in class co.paralleluniverse.strands.channels.QueueFloatChannel
 
receiveFloat(Timeout) - Method in class co.paralleluniverse.strands.channels.TickerChannelConsumer.TickerChannelFloatConsumer
 
receiveFromThread() - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
receiveFromThread(long, TimeUnit) - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
receiveInt() - Method in interface co.paralleluniverse.strands.channels.IntReceivePort
Retrieves a message from the channels, possibly blocking until one becomes available.
receiveInt() - Method in class co.paralleluniverse.strands.channels.QueueIntChannel
 
receiveInt(long, TimeUnit) - Method in interface co.paralleluniverse.strands.channels.IntReceivePort
Retrieves a message from the channels, possibly blocking until one becomes available, but no longer than the specified timeout.
receiveInt(long, TimeUnit) - Method in class co.paralleluniverse.strands.channels.QueueIntChannel
 
receiveInt(Timeout) - Method in interface co.paralleluniverse.strands.channels.IntReceivePort
Retrieves a message from the channels, possibly blocking until one becomes available, but no longer than the specified timeout.
receiveInt(Timeout) - Method in class co.paralleluniverse.strands.channels.QueueIntChannel
 
receiveInternal(long, TimeUnit) - Method in class co.paralleluniverse.strands.channels.TransferChannel
 
receiveLong() - Method in interface co.paralleluniverse.strands.channels.LongReceivePort
Retrieves a message from the channels, possibly blocking until one becomes available.
receiveLong() - Method in class co.paralleluniverse.strands.channels.QueueLongChannel
 
receiveLong(long, TimeUnit) - Method in interface co.paralleluniverse.strands.channels.LongReceivePort
Retrieves a message from the channels, possibly blocking until one becomes available, but no longer than the specified timeout.
receiveLong(long, TimeUnit) - Method in class co.paralleluniverse.strands.channels.QueueLongChannel
 
receiveLong(Timeout) - Method in interface co.paralleluniverse.strands.channels.LongReceivePort
Retrieves a message from the channels, possibly blocking until one becomes available, but no longer than the specified timeout.
receiveLong(Timeout) - Method in class co.paralleluniverse.strands.channels.QueueLongChannel
 
ReceivePort<Message> - Interface in co.paralleluniverse.strands.channels
A channel's consumer-side functional interface.
ReceivePort.EOFException - Exception in co.paralleluniverse.strands.channels
 
ReceivePortGroup<M> - Class in co.paralleluniverse.strands.channels
 
ReceivePortGroup() - Constructor for class co.paralleluniverse.strands.channels.ReceivePortGroup
 
ReceivePortGroup(boolean) - Constructor for class co.paralleluniverse.strands.channels.ReceivePortGroup
 
ReceivePortGroup(ReceivePort<? extends M>...) - Constructor for class co.paralleluniverse.strands.channels.ReceivePortGroup
 
ReceivePortGroup(Collection<? extends ReceivePort<? extends M>>) - Constructor for class co.paralleluniverse.strands.channels.ReceivePortGroup
 
ReceivePortGroup(Collection<? extends ReceivePort<? extends M>>, boolean) - Constructor for class co.paralleluniverse.strands.channels.ReceivePortGroup
 
record(int, String, String, String) - Method in class co.paralleluniverse.actors.ActorImpl
 
record(int, String, String, String) - Method in class co.paralleluniverse.fibers.Fiber
 
record(int, String, String, String, Object) - Method in class co.paralleluniverse.actors.ActorImpl
 
record(int, String, String, String, Object) - Method in class co.paralleluniverse.fibers.Fiber
 
record(int, String, String, String, Object...) - Method in class co.paralleluniverse.actors.ActorImpl
 
record(int, String, String, String, Object...) - Method in class co.paralleluniverse.fibers.Fiber
 
record(int, String, String, String, Object, Object) - Method in class co.paralleluniverse.actors.ActorImpl
 
record(int, String, String, String, Object, Object) - Method in class co.paralleluniverse.fibers.Fiber
 
record(int, String, String, String, Object, Object, Object) - Method in class co.paralleluniverse.actors.ActorImpl
 
record(int, String, String, String, Object, Object, Object) - Method in class co.paralleluniverse.fibers.Fiber
 
record(int, String, String, String, Object, Object, Object, Object) - Method in class co.paralleluniverse.actors.ActorImpl
 
record(int, String, String, String, Object, Object, Object, Object) - Method in class co.paralleluniverse.fibers.Fiber
 
record(int, String, String, String, Object, Object, Object, Object, Object) - Method in class co.paralleluniverse.actors.ActorImpl
 
record(int, String, String, String, Object, Object, Object, Object, Object) - Method in class co.paralleluniverse.fibers.Fiber
 
record(int, String, String, String, Object, Object, Object, Object, Object, Object) - Method in class co.paralleluniverse.fibers.Fiber
 
record(int, String, String, String, Object, Object, Object, Object, Object, Object, Object) - Method in class co.paralleluniverse.fibers.Fiber
 
RECORDER - Static variable in class co.paralleluniverse.strands.channels.QueueChannel
 
RECORDER - Static variable in class co.paralleluniverse.strands.ConditionSynchronizer
 
RECORDER - Static variable in class co.paralleluniverse.strands.dataflow.Var
 
reduce(Function2<T, S, T>, T) - Method in class co.paralleluniverse.strands.channels.TransformingSendPort
Returns a TransformingSendPort to which sending messages that are transformed towards a channel by a reduction function.
reduce(Function2<U, T, U>, U) - Method in class co.paralleluniverse.strands.channels.TransformingReceivePort
Returns a TransformingReceivePort from which receiving messages that are transformed from a given channel by a given reduction function.
reduce(ReceivePort<S>, Function2<T, S, T>, T) - Static method in class co.paralleluniverse.strands.channels.Channels
Returns a ReceivePort providing messages that are transformed from a given channel by a given reduction function.
reducePermits(int) - Method in class co.paralleluniverse.strands.concurrent.Semaphore
Shrinks the number of available permits by the indicated reduction.
reduceSend(SendPort<T>, Function2<T, S, T>, T) - Static method in class co.paralleluniverse.strands.channels.Channels
Returns a SendPort accepting messages that are transformed by a reduction function.
ReentrantLock - Class in co.paralleluniverse.strands.concurrent
A reentrant mutual exclusion Lock with the same basic behavior and semantics as the implicit monitor lock accessed using synchronized methods and statements, but with extended capabilities.
ReentrantLock() - Constructor for class co.paralleluniverse.strands.concurrent.ReentrantLock
Creates an instance of ReentrantLock.
ReentrantLock(boolean) - Constructor for class co.paralleluniverse.strands.concurrent.ReentrantLock
Creates an instance of ReentrantLock with the given fairness policy.
ReentrantReadWriteLock - Class in co.paralleluniverse.strands.concurrent
An implementation of ReadWriteLock supporting similar semantics to ReentrantLock.
ReentrantReadWriteLock() - Constructor for class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock
Creates a new ReentrantReadWriteLock with default (nonfair) ordering properties.
ReentrantReadWriteLock(boolean) - Constructor for class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock
Creates a new ReentrantReadWriteLock with the given fairness policy.
ReentrantReadWriteLock.ReadLock - Class in co.paralleluniverse.strands.concurrent
The lock returned by method ReentrantReadWriteLock.readLock().
ReentrantReadWriteLock.WriteLock - Class in co.paralleluniverse.strands.concurrent
The lock returned by method ReentrantReadWriteLock.writeLock().
ref - Variable in class co.paralleluniverse.actors.ActorImpl
 
ref() - Method in class co.paralleluniverse.actors.Actor
Returns the ActorRef to this actor, if it has been started.
ref() - Method in class co.paralleluniverse.actors.ActorImpl
 
ref() - Method in class co.paralleluniverse.actors.behaviors.BehaviorActor
 
ref() - Method in class co.paralleluniverse.actors.behaviors.EventSourceActor
 
ref() - Method in class co.paralleluniverse.actors.behaviors.ServerActor
 
ref() - Method in class co.paralleluniverse.actors.behaviors.SupervisorActor
 
refresh() - Method in interface co.paralleluniverse.actors.ActorMXBean
 
refresh() - Method in interface co.paralleluniverse.actors.ActorsMXBean
 
refresh() - Method in interface co.paralleluniverse.fibers.FibersMXBean
 
register() - Method in class co.paralleluniverse.actors.Actor
Registers this actor in the actor registry under its name.
register() - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
register() - Method in class co.paralleluniverse.strands.channels.Selector
 
register() - Method in class co.paralleluniverse.strands.channels.TransferChannel
 
register() - Method in class co.paralleluniverse.strands.concurrent.Phaser
Adds a new unarrived party to this phaser.
register() - Method in interface co.paralleluniverse.strands.Condition
 
register() - Method in class co.paralleluniverse.strands.ConditionSelector
 
register() - Method in class co.paralleluniverse.strands.DoneSynchronizer
 
register() - Method in class co.paralleluniverse.strands.OwnedSynchronizer
 
register() - Method in class co.paralleluniverse.strands.SimpleConditionSynchronizer
 
register() - Method in interface co.paralleluniverse.strands.Synchronization
 
register(ActorRef<?>) - Static method in class co.paralleluniverse.actors.LocalActor
 
register(ActorRef<?>, String) - Static method in class co.paralleluniverse.actors.LocalActor
 
register(SelectAction<Message>) - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
register(SelectAction<Message>) - Method in interface co.paralleluniverse.strands.channels.Selectable
 
register(SelectAction<Message>) - Method in class co.paralleluniverse.strands.channels.TickerChannelConsumer
 
register(SelectAction<Message>) - Method in class co.paralleluniverse.strands.channels.TransferChannel
 
register(SelectAction<V>) - Method in class co.paralleluniverse.strands.dataflow.ValChannel
 
register(String) - Method in class co.paralleluniverse.actors.Actor
Registers this actor in the actor registry under the given name and sets this actor's name.
RegistrationException - Exception in co.paralleluniverse.actors
 
RegistrationException() - Constructor for exception co.paralleluniverse.actors.RegistrationException
 
RegistrationException(String) - Constructor for exception co.paralleluniverse.actors.RegistrationException
 
RegistrationException(String, Throwable) - Constructor for exception co.paralleluniverse.actors.RegistrationException
 
RegistrationException(Throwable) - Constructor for exception co.paralleluniverse.actors.RegistrationException
 
reinstantiate() - Method in class co.paralleluniverse.actors.Actor
Returns a "clone" of this actor, used by a supervisor to restart this actor if it dies.
release() - Method in class co.paralleluniverse.strands.concurrent.Semaphore
Releases a permit, returning it to the semaphore.
release(int) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Releases in exclusive mode.
release(int) - Method in class co.paralleluniverse.strands.concurrent.Semaphore
Releases the given number of permits, returning them to the semaphore.
release(long) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Releases in exclusive mode.
releaseShared(int) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Releases in shared mode.
releaseShared(long) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Releases in shared mode.
reloadModule(String) - Method in class co.paralleluniverse.actors.ActorLoader
 
reloadModule(String) - Method in interface co.paralleluniverse.actors.ActorLoaderMXBean
Loads or reloads the module at the given URL
reloadModule(URL) - Method in class co.paralleluniverse.actors.ActorLoader
 
RemoteActor<Message> - Class in co.paralleluniverse.actors
This class should be extended by implementations of remote actors.
RemoteActor(ActorRef<Message>) - Constructor for class co.paralleluniverse.actors.RemoteActor
 
RemoteActor.RemoteActorAdminMessage - Class in co.paralleluniverse.actors
 
RemoteActorAdminMessage() - Constructor for class co.paralleluniverse.actors.RemoteActor.RemoteActorAdminMessage
 
remove() - Method in class co.paralleluniverse.fibers.SchedulerLocal
Removes the association between the scheduler-local value and the current scheduler.
remove(T...) - Method in interface co.paralleluniverse.strands.channels.Mix
 
remove(T...) - Method in class co.paralleluniverse.strands.channels.ReceivePortGroup
 
removeChild(ActorRef<?>, boolean) - Method in class co.paralleluniverse.actors.behaviors.Supervisor
Removes a child actor from the supervisor.
removeChild(ActorRef, boolean) - Method in class co.paralleluniverse.actors.behaviors.SupervisorActor
Removes a child actor from the supervisor.
removeChild(Object, boolean) - Method in class co.paralleluniverse.actors.behaviors.Supervisor
Removes a child actor from the supervisor.
removeChild(Object, boolean) - Method in class co.paralleluniverse.actors.behaviors.SupervisorActor
Removes a child actor from the supervisor.
removeHandler(EventHandler<Event>) - Method in class co.paralleluniverse.actors.behaviors.EventSource
Removes an EventHandler from the actor
removeHandler(EventHandler<Event>) - Method in class co.paralleluniverse.actors.behaviors.EventSourceActor
 
removeLifecycleListener(LifecycleListener) - Method in class co.paralleluniverse.actors.Actor
 
removeLifecycleListener(LifecycleListener) - Method in class co.paralleluniverse.actors.ActorImpl
 
removeLifecycleListener(LifecycleListener) - Method in class co.paralleluniverse.actors.FakeActor
 
removeLifecycleListener(LifecycleListener) - Method in class co.paralleluniverse.actors.RemoteActor
 
removeNotificationListener(NotificationListener) - Method in class co.paralleluniverse.actors.ActorLoader
 
removeNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class co.paralleluniverse.actors.ActorLoader
 
removeObserverListeners(ActorRef) - Method in class co.paralleluniverse.actors.Actor
 
removeObserverListeners(ActorRef) - Method in class co.paralleluniverse.actors.ActorImpl
 
removeObserverListeners(ActorRef) - Method in class co.paralleluniverse.actors.FakeActor
 
removeObserverListeners(ActorRef) - Method in class co.paralleluniverse.actors.RemoteActor
 
removeWatch(long) - Method in interface co.paralleluniverse.actors.ActorsMXBean
Removes an actor from the set of watched actors.
reply(ActorRef<?>, Object, V) - Method in class co.paralleluniverse.actors.behaviors.ServerActor
Replies with a result to a call request, if the handleCall method returned null.
reply(RequestMessage<V>, V) - Static method in class co.paralleluniverse.actors.behaviors.RequestReplyHelper
Replies with a result to a RequestMessage.
replyError(ActorRef<?>, Object, Throwable) - Method in class co.paralleluniverse.actors.behaviors.ServerActor
Replies with an exception to a call request, if the handleCall method returned null.
replyError(RequestMessage<?>, Throwable) - Static method in class co.paralleluniverse.actors.behaviors.RequestReplyHelper
Replies with an exception to a RequestMessage.
requestAsync() - Method in class co.paralleluniverse.fibers.FiberAsync
A user of this class must override this method to start the asynchronous operation and register the callback.
requestAsync() - Method in class co.paralleluniverse.fibers.futures.AsyncCompletionStage
 
requestAsync() - Method in class co.paralleluniverse.fibers.futures.AsyncListenableFuture
 
requester - Variable in class co.paralleluniverse.actors.ShutdownMessage
 
RequestMessage<V> - Class in co.paralleluniverse.actors.behaviors
A message that contains a sender reference (the from property} and a unique identifier (the id property) and may be used as a request by RequestReplyHelper.call().
RequestMessage() - Constructor for class co.paralleluniverse.actors.behaviors.RequestMessage
Constructs a new RequestMessage.
This constructor may only be used if the message is to be sent via RequestReplyHelper.call()
RequestMessage(ActorRef<?>) - Constructor for class co.paralleluniverse.actors.behaviors.RequestMessage
Constructs a new RequestMessage.
This constructor may only be used if the message is to be sent via RequestReplyHelper.call()
RequestMessage(ActorRef<?>, Object) - Constructor for class co.paralleluniverse.actors.behaviors.RequestMessage
Constructs a new RequestMessage.
RequestMessage(Object) - Constructor for class co.paralleluniverse.actors.behaviors.RequestMessage
Constructs a new RequestMessage.
This constructor may only be used if the message is to be sent via RequestReplyHelper.call()
RequestReplyHelper - Class in co.paralleluniverse.actors.behaviors
This class contains static methods that implement a request-reply pattern with actors.
requestSync() - Method in class co.paralleluniverse.fibers.FiberAsync
Called if FiberAsync.run() is not being executed in a fiber.
requestSync() - Method in class co.paralleluniverse.fibers.futures.AsyncCompletionStage
 
requestSync() - Method in class co.paralleluniverse.fibers.futures.AsyncListenableFuture
 
requestSync(long, TimeUnit) - Method in class co.paralleluniverse.fibers.FiberAsync
Called if FiberAsync.run(long, TimeUnit) is not being executed in a fiber.
reset() - Method in class co.paralleluniverse.strands.concurrent.CyclicBarrier
Resets the barrier to its initial state.
ResponseMessage - Class in co.paralleluniverse.actors.behaviors
A message type used as a superclass by responses to RequestMessage.
ResponseMessage(Object) - Constructor for class co.paralleluniverse.actors.behaviors.ResponseMessage
Constructs a ResponseMessage.
REST_FOR_ONE - co.paralleluniverse.actors.behaviors.SupervisorActor.RestartStrategy
Kill all children that were added to the supervisor after the addition of the dead actor, and restart them all (including the actor whose death triggered the strategy).
run() - Method in class co.paralleluniverse.actors.Actor
 
run() - Method in class co.paralleluniverse.fibers.Fiber
 
run() - Method in class co.paralleluniverse.fibers.FiberAsync
Runs the asynchronous operation, blocks until it completes and returns its result.
run() - Method in class co.paralleluniverse.strands.channels.transfer.Pipeline
 
run() - Method in interface co.paralleluniverse.strands.SuspendableCallable
 
run() - Method in interface co.paralleluniverse.strands.SuspendableRunnable
 
run() - Method in class co.paralleluniverse.strands.SuspendableUtils.VoidSuspendableCallable
 
run(long, TimeUnit) - Method in class co.paralleluniverse.fibers.FiberAsync
Runs the asynchronous operation, blocks until it completes (but only up to the given timeout duration) and returns its result.
run(Timeout) - Method in class co.paralleluniverse.fibers.FiberAsync
Runs the asynchronous operation, blocks until it completes (but only up to the given timeout duration) and returns its result.
runBlocking(ExecutorService, long, TimeUnit, CheckedCallable<V, E>) - Static method in class co.paralleluniverse.fibers.FiberAsync
Runs a thread-blocking operation on a given thread pool, blocks (the fiber) until the operation completes (but no longer than the specified timeout) and returns its result.
runBlocking(ExecutorService, CheckedCallable<V, E>) - Static method in class co.paralleluniverse.fibers.FiberAsync
Runs a thread-blocking operation on a given thread pool, blocks (the fiber) until the operation completes and returns its result.
runBlocking(ExecutorService, Timeout, CheckedCallable<V, E>) - Static method in class co.paralleluniverse.fibers.FiberAsync
Runs a thread-blocking operation on a given thread pool, blocks (the fiber) until the operation completes (but no longer than the specified timeout) and returns its result.
runInFiber(FiberScheduler, SuspendableCallable<V>) - Static method in class co.paralleluniverse.fibers.FiberUtil
Runs an action in a new fiber, awaits the fiber's termination, and returns its result.
runInFiber(FiberScheduler, SuspendableRunnable) - Static method in class co.paralleluniverse.fibers.FiberUtil
Runs an action in a new fiber and awaits the fiber's termination.
runInFiber(SuspendableCallable<V>) - Static method in class co.paralleluniverse.fibers.FiberUtil
Runs an action in a new fiber, awaits the fiber's termination, and returns its result.
runInFiber(SuspendableRunnable) - Static method in class co.paralleluniverse.fibers.FiberUtil
Runs an action in a new fiber and awaits the fiber's termination.
runInFiberChecked(FiberScheduler, SuspendableCallable<V>, Class<X>) - Static method in class co.paralleluniverse.fibers.FiberUtil
Runs an action in a new fiber, awaits the fiber's termination, and returns its result.
runInFiberChecked(FiberScheduler, SuspendableRunnable, Class<X>) - Static method in class co.paralleluniverse.fibers.FiberUtil
Runs an action in a new fiber and awaits the fiber's termination.
runInFiberChecked(SuspendableCallable<V>, Class<X>) - Static method in class co.paralleluniverse.fibers.FiberUtil
Runs an action in a new fiber, awaits the fiber's termination, and returns its result.
runInFiberChecked(SuspendableRunnable, Class<X>) - Static method in class co.paralleluniverse.fibers.FiberUtil
Runs an action in a new fiber and awaits the fiber's termination.
runInFiberRuntime(FiberScheduler, SuspendableCallable<V>) - Static method in class co.paralleluniverse.fibers.FiberUtil
Runs an action in a new fiber, awaits the fiber's termination, and returns its result.
runInFiberRuntime(FiberScheduler, SuspendableRunnable) - Static method in class co.paralleluniverse.fibers.FiberUtil
Runs an action in a new fiber and awaits the fiber's termination.
runInFiberRuntime(SuspendableCallable<V>) - Static method in class co.paralleluniverse.fibers.FiberUtil
Runs an action in a new fiber, awaits the fiber's termination, and returns its result.
runInFiberRuntime(SuspendableRunnable) - Static method in class co.paralleluniverse.fibers.FiberUtil
Runs an action in a new fiber and awaits the fiber's termination.
runnableToCallable(SuspendableRunnable) - Static method in class co.paralleluniverse.strands.SuspendableUtils
 
RUNNING - co.paralleluniverse.strands.Strand.State
Strand is running.
RuntimeExecutionException - Exception in co.paralleluniverse.fibers
Similar to ExecutionException only as an unchecked, rather than a checked, exception.
RuntimeExecutionException(Throwable) - Constructor for exception co.paralleluniverse.fibers.RuntimeExecutionException
 
RuntimeSuspendExecution - Exception in co.paralleluniverse.fibers
 

S

SchedulerLocal<T> - Class in co.paralleluniverse.fibers
Associates a value with the current FiberScheduler
SchedulerLocal() - Constructor for class co.paralleluniverse.fibers.SchedulerLocal
 
select() - Static method in class co.paralleluniverse.actors.behaviors.MessageSelector
Creates a new MessageSelector.
select(boolean, long, TimeUnit, SelectAction<Message>...) - Static method in class co.paralleluniverse.strands.channels.Selector
Performs exactly one channel operation of a given set, blocking until any of the actions completes, but no longer than the given timeout.
select(boolean, long, TimeUnit, List<? extends SelectAction<Message>>) - Static method in class co.paralleluniverse.strands.channels.Selector
Performs exactly one channel operation of a given set, blocking until any of the actions completes, but no longer than the specified timeout.
select(boolean, SelectAction<Message>...) - Static method in class co.paralleluniverse.strands.channels.Selector
Performs exactly one channel operation of a given set, blocking until any of the actions completes.
select(boolean, Timeout, SelectAction<Message>...) - Static method in class co.paralleluniverse.strands.channels.Selector
Performs exactly one channel operation of a given set, blocking until any of the actions completes, but no longer than the given timeout.
select(boolean, Timeout, List<? extends SelectAction<Message>>) - Static method in class co.paralleluniverse.strands.channels.Selector
Performs exactly one channel operation of a given set, blocking until any of the actions completes, but no longer than the specified timeout.
select(boolean, List<? extends SelectAction<Message>>) - Static method in class co.paralleluniverse.strands.channels.Selector
Performs exactly one channel operation of a given set, blocking until any of the actions completes.
select(long, TimeUnit, SelectAction<Message>...) - Static method in class co.paralleluniverse.strands.channels.Selector
Performs exactly one channel operation of a given set, blocking until any of the actions completes, but no longer than the given timeout.
select(long, TimeUnit, List<? extends SelectAction<Message>>) - Static method in class co.paralleluniverse.strands.channels.Selector
Performs exactly one channel operation of a given set, blocking until any of the actions completes, but no longer than the given timeout.
select(SelectAction<Message>...) - Static method in class co.paralleluniverse.strands.channels.Selector
Performs exactly one channel operation of a given set, blocking until any of the actions completes.
select(Timeout, SelectAction<Message>...) - Static method in class co.paralleluniverse.strands.channels.Selector
Performs exactly one channel operation of a given set, blocking until any of the actions completes, but no longer than the given timeout.
select(Timeout, List<? extends SelectAction<Message>>) - Static method in class co.paralleluniverse.strands.channels.Selector
Performs exactly one channel operation of a given set, blocking until any of the actions completes, but no longer than the given timeout.
select(List<? extends SelectAction<Message>>) - Static method in class co.paralleluniverse.strands.channels.Selector
Performs exactly one channel operation of a given set, blocking until any of the actions completes.
select(Message) - Method in class co.paralleluniverse.strands.channels.SplitSendPort
Subclasses will implement this method to select the target SendPort.
Selectable<Message> - Interface in co.paralleluniverse.strands.channels
A channel port that can be used by a Selector.
SelectAction<Message> - Class in co.paralleluniverse.strands.channels
A channel operation that is selected by a Selector.
SelectiveReceiveHelper<Message> - Class in co.paralleluniverse.actors
Performs selective receive on behalf of an actor.
SelectiveReceiveHelper(Actor<Message, ?>) - Constructor for class co.paralleluniverse.actors.SelectiveReceiveHelper
Creates a SelectiveReceiveHelper to add selective receive to an actor
Selector<Message> - Class in co.paralleluniverse.strands.channels
Attempts to perform at most one channel operation (send or receive) of a given set.
SelectReceiveListener<Message> - Interface in co.paralleluniverse.strands.channels
A listener associated with a receive SelectAction, which is called if an only if the associated action has succeeded.
SelectSendListener<Message> - Interface in co.paralleluniverse.strands.channels
A listener associated with a send SelectAction, which is called if an only if the associated action has succeeded.
self() - Method in class co.paralleluniverse.actors.Actor
Returns the ActorRef to this actor, if it has been started.
self() - Method in class co.paralleluniverse.actors.behaviors.BehaviorActor
 
self() - Method in class co.paralleluniverse.actors.behaviors.EventSourceActor
 
self() - Method in class co.paralleluniverse.actors.behaviors.ServerActor
 
self() - Method in class co.paralleluniverse.actors.behaviors.SupervisorActor
 
self() - Static method in class co.paralleluniverse.actors.LocalActor
Returns the ActorRef of the actor currently running in the current strand.
Semaphore - Class in co.paralleluniverse.strands.concurrent
A counting semaphore.
Semaphore(int) - Constructor for class co.paralleluniverse.strands.concurrent.Semaphore
Creates a Semaphore with the given number of permits and nonfair fairness setting.
Semaphore(int, boolean) - Constructor for class co.paralleluniverse.strands.concurrent.Semaphore
Creates a Semaphore with the given number of permits and the given fairness setting.
send(double) - Method in interface co.paralleluniverse.strands.channels.DoubleSendPort
Sends a message to the channel, possibly blocking until there's room available in the channel.
send(double) - Method in class co.paralleluniverse.strands.channels.QueueDoubleChannel
 
send(double, long, TimeUnit) - Method in interface co.paralleluniverse.strands.channels.DoubleSendPort
Sends a message to the channel, possibly blocking until there's room available in the channel, but never longer than the specified timeout.
send(double, long, TimeUnit) - Method in class co.paralleluniverse.strands.channels.QueueDoubleChannel
 
send(double, Timeout) - Method in interface co.paralleluniverse.strands.channels.DoubleSendPort
Sends a message to the channel, possibly blocking until there's room available in the channel, but never longer than the specified timeout.
send(double, Timeout) - Method in class co.paralleluniverse.strands.channels.QueueDoubleChannel
 
send(float) - Method in interface co.paralleluniverse.strands.channels.FloatSendPort
Sends a message to the channel, possibly blocking until there's room available in the channel.
send(float) - Method in class co.paralleluniverse.strands.channels.QueueFloatChannel
 
send(float, long, TimeUnit) - Method in interface co.paralleluniverse.strands.channels.FloatSendPort
Sends a message to the channel, possibly blocking until there's room available in the channel, but never longer than the specified timeout.
send(float, long, TimeUnit) - Method in class co.paralleluniverse.strands.channels.QueueFloatChannel
 
send(float, Timeout) - Method in interface co.paralleluniverse.strands.channels.FloatSendPort
Sends a message to the channel, possibly blocking until there's room available in the channel, but never longer than the specified timeout.
send(float, Timeout) - Method in class co.paralleluniverse.strands.channels.QueueFloatChannel
 
send(int) - Method in interface co.paralleluniverse.strands.channels.IntSendPort
Sends a message to the channel, possibly blocking until there's room available in the channel.
send(int) - Method in class co.paralleluniverse.strands.channels.QueueIntChannel
 
send(int, long, TimeUnit) - Method in interface co.paralleluniverse.strands.channels.IntSendPort
Sends a message to the channel, possibly blocking until there's room available in the channel, but never longer than the specified timeout.
send(int, long, TimeUnit) - Method in class co.paralleluniverse.strands.channels.QueueIntChannel
 
send(int, Timeout) - Method in interface co.paralleluniverse.strands.channels.IntSendPort
Sends a message to the channel, possibly blocking until there's room available in the channel, but never longer than the specified timeout.
send(int, Timeout) - Method in class co.paralleluniverse.strands.channels.QueueIntChannel
 
send(long) - Method in interface co.paralleluniverse.strands.channels.LongSendPort
Sends a message to the channel, possibly blocking until there's room available in the channel.
send(long) - Method in class co.paralleluniverse.strands.channels.QueueLongChannel
 
send(long, long, TimeUnit) - Method in interface co.paralleluniverse.strands.channels.LongSendPort
Sends a message to the channel, possibly blocking until there's room available in the channel, but never longer than the specified timeout.
send(long, long, TimeUnit) - Method in class co.paralleluniverse.strands.channels.QueueLongChannel
 
send(long, Timeout) - Method in interface co.paralleluniverse.strands.channels.LongSendPort
Sends a message to the channel, possibly blocking until there's room available in the channel, but never longer than the specified timeout.
send(long, Timeout) - Method in class co.paralleluniverse.strands.channels.QueueLongChannel
 
send(SendPort<? super Message>, Message) - Static method in class co.paralleluniverse.strands.channels.Selector
Creates a SelectAction for a send operation
send(SendPort<? super Message>, Message, SelectSendListener<Message>) - Static method in class co.paralleluniverse.strands.channels.Selector
Creates a SelectAction for a send operation
send(Message) - Method in class co.paralleluniverse.actors.ActorRef
Sends a message to the actor, possibly blocking until there's room available in the mailbox.
send(Message) - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
send(Message) - Method in interface co.paralleluniverse.strands.channels.SendPort
Sends a message to the channel, possibly blocking until there's room available in the channel.
send(Message) - Method in class co.paralleluniverse.strands.channels.SplitSendPort
 
send(Message) - Method in class co.paralleluniverse.strands.channels.ThreadSendPort
Sends a message to the channel, possibly blocking until there's room available in the channel.
send(Message) - Method in class co.paralleluniverse.strands.channels.Topic
 
send(Message) - Method in class co.paralleluniverse.strands.channels.TransferChannel
 
send(Message, long, TimeUnit) - Method in class co.paralleluniverse.actors.ActorRef
Sends a message to the actor, possibly blocking until there's room available in the mailbox, but never longer than the specified timeout.
send(Message, long, TimeUnit) - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
send(Message, long, TimeUnit) - Method in interface co.paralleluniverse.strands.channels.SendPort
Sends a message to the channel, possibly blocking until there's room available in the channel, but never longer than the specified timeout.
send(Message, long, TimeUnit) - Method in class co.paralleluniverse.strands.channels.SplitSendPort
 
send(Message, long, TimeUnit) - Method in class co.paralleluniverse.strands.channels.ThreadSendPort
Sends a message to the channel, possibly blocking until there's room available in the channel, but never longer than the specified timeout.
send(Message, long, TimeUnit) - Method in class co.paralleluniverse.strands.channels.Topic
 
send(Message, long, TimeUnit) - Method in class co.paralleluniverse.strands.channels.TransferChannel
 
send(Message, Timeout) - Method in class co.paralleluniverse.actors.ActorRef
Sends a message to the actor, possibly blocking until there's room available in the mailbox, but never longer than the specified timeout.
send(Message, Timeout) - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
send(Message, Timeout) - Method in interface co.paralleluniverse.strands.channels.SendPort
Sends a message to the channel, possibly blocking until there's room available in the channel, but never longer than the specified timeout.
send(Message, Timeout) - Method in class co.paralleluniverse.strands.channels.SplitSendPort
 
send(Message, Timeout) - Method in class co.paralleluniverse.strands.channels.Topic
 
send(Message, Timeout) - Method in class co.paralleluniverse.strands.channels.TransferChannel
 
send(T) - Method in class co.paralleluniverse.strands.channels.DelegatingSendPort
 
send(T, long, TimeUnit) - Method in class co.paralleluniverse.strands.channels.DelegatingSendPort
 
send(T, Timeout) - Method in class co.paralleluniverse.strands.channels.DelegatingSendPort
 
send0(Message, boolean, boolean, long) - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
sendClosed - Variable in class co.paralleluniverse.strands.channels.Topic
 
sendNonSuspendable(Message) - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
sendOrInterrupt(ActorRef<?>, Object) - Static method in class co.paralleluniverse.actors.ActorUtil
Attempts to send a message to an actor, and if the message cannot be sent due to a full mailbox - interrupt the actor.
sendOrInterrupt(Object) - Method in class co.paralleluniverse.actors.ActorImpl
 
SendPort<Message> - Interface in co.paralleluniverse.strands.channels
A channel's producer-side functional interface.
sendSync(Message) - Method in class co.paralleluniverse.actors.Actor
 
sendSync(Message) - Method in class co.paralleluniverse.actors.ActorImpl
 
sendSync(Message) - Method in class co.paralleluniverse.actors.ActorRef
Sends a message to the actor, and attempts to schedule the actor's strand for immediate execution.
sendSync(Message) - Method in class co.paralleluniverse.actors.Mailbox
 
sendSync(Message) - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
server() - Method in class co.paralleluniverse.actors.behaviors.ServerActor
The ServerHandler passed at construction, or null if none was set.
Server<CallMessage,​V,​CastMessage> - Class in co.paralleluniverse.actors.behaviors
An interface to a ServerActor.
Server(ActorRef<Object>) - Constructor for class co.paralleluniverse.actors.behaviors.Server
If actor is known to be a ServerActor, creates a new Server interface to it.
ServerActor<CallMessage,​V,​CastMessage> - Class in co.paralleluniverse.actors.behaviors
A behavior implementing a server that responds to request messages.
ServerActor() - Constructor for class co.paralleluniverse.actors.behaviors.ServerActor
Creates a new server actor
ServerActor(ServerHandler<CallMessage, V, CastMessage>) - Constructor for class co.paralleluniverse.actors.behaviors.ServerActor
Creates a new server actor
ServerActor(ServerHandler<CallMessage, V, CastMessage>, MailboxConfig) - Constructor for class co.paralleluniverse.actors.behaviors.ServerActor
Creates a new server actor
ServerActor(MailboxConfig) - Constructor for class co.paralleluniverse.actors.behaviors.ServerActor
Creates a new server actor
ServerActor(String) - Constructor for class co.paralleluniverse.actors.behaviors.ServerActor
Creates a new server actor
ServerActor(String, ServerHandler<CallMessage, V, CastMessage>) - Constructor for class co.paralleluniverse.actors.behaviors.ServerActor
Creates a new server actor
ServerActor(String, ServerHandler<CallMessage, V, CastMessage>, long, TimeUnit, Strand, MailboxConfig) - Constructor for class co.paralleluniverse.actors.behaviors.ServerActor
Creates a new server actor
ServerActor(String, ServerHandler<CallMessage, V, CastMessage>, MailboxConfig) - Constructor for class co.paralleluniverse.actors.behaviors.ServerActor
Creates a new server actor
ServerActor(String, MailboxConfig) - Constructor for class co.paralleluniverse.actors.behaviors.ServerActor
Creates a new server actor
ServerHandler<CallMessage,​V,​CastMessage> - Interface in co.paralleluniverse.actors.behaviors
A delegate object that can be used instead of subclassing ServerActor and overriding its methods.
set(T) - Method in class co.paralleluniverse.fibers.SchedulerLocal
Sets the scheduler-local value of this SchedulerLocal.
set(T) - Method in class co.paralleluniverse.fibers.TrueThreadLocal
 
set(T) - Method in class co.paralleluniverse.strands.dataflow.Var
Sets a new value for this Var.
set(V) - Method in class co.paralleluniverse.strands.AbstractFuture
 
set(V) - Method in class co.paralleluniverse.strands.dataflow.Val
Sets the value.
set(V) - Method in class co.paralleluniverse.strands.SettableFuture
 
setActor(Actor<Message, ?>) - Method in class co.paralleluniverse.actors.SelectiveReceiveHelper
used only during deserialization
setDefaultTimeout(long, TimeUnit) - Static method in class co.paralleluniverse.actors.behaviors.RequestReplyHelper
Sets a default timeout for non-timed calls on this strand.
setDefaultTimeout(long, TimeUnit) - Method in class co.paralleluniverse.actors.behaviors.Server
Sets a default timeout for non-timed calls on this server reference.
setDefaultUncaughtExceptionHandler(Strand.UncaughtExceptionHandler) - Static method in class co.paralleluniverse.fibers.Fiber
Set the default handler invoked when a fiber abruptly terminates due to an uncaught exception, and no other handler has been defined for that fiber.
setException(Throwable) - Method in class co.paralleluniverse.strands.AbstractFuture
 
setException(Throwable) - Method in class co.paralleluniverse.strands.dataflow.Val
Sets an exception that will be thrown by get, wrapped by RuntimeExecutionException.
setException(Throwable) - Method in class co.paralleluniverse.strands.SettableFuture
 
setExclusiveOwnerStrand(Strand) - Method in class co.paralleluniverse.strands.concurrent.AbstractOwnableSynchronizer
Sets the strand that currently owns exclusive access.
setFiber(FiberScheduler) - Method in class co.paralleluniverse.strands.StrandFactoryBuilder
Makes the resulting StrandFactory produce fibers.
setForwardWatch(boolean) - Method in class co.paralleluniverse.actors.Actor
Deprecated.
setMonitor(ActorMonitor) - Method in class co.paralleluniverse.actors.Actor
Sets the actor's monitor
setName(String) - Method in class co.paralleluniverse.actors.Actor
Sets this actor's name.
setName(String) - Method in class co.paralleluniverse.actors.ActorImpl
 
setName(String) - Method in class co.paralleluniverse.fibers.Fiber
 
setName(String) - Method in class co.paralleluniverse.strands.Strand
Sets this strand's name.
setNameFormat(String) - Method in class co.paralleluniverse.strands.StrandFactoryBuilder
Sets the naming format to use when naming strands (Strand.setName(java.lang.String)) which are created with this StrandFactory.
setNoLocals(boolean) - Method in class co.paralleluniverse.fibers.Fiber
Deprecated.
setOption(SocketOption<T>, T) - Method in class co.paralleluniverse.fibers.io.FiberServerSocketChannel
 
setOption(SocketOption<T>, T) - Method in class co.paralleluniverse.fibers.io.FiberSocketChannel
 
setPriority(int) - Method in class co.paralleluniverse.fibers.Fiber
Sets the priority of this fiber.
setPriority(int) - Method in class co.paralleluniverse.strands.Strand
Attempts to change the priority of this strand.
setPriority(int) - Method in class co.paralleluniverse.strands.StrandFactoryBuilder
Sets the priority for strands created by the StrandFactory.
setSeed(long) - Method in class co.paralleluniverse.strands.StrandLocalRandom
Throws UnsupportedOperationException.
setSoloEffect(Mix.SoloEffect) - Method in interface co.paralleluniverse.strands.channels.Mix
 
setSoloEffect(Mix.SoloEffect) - Method in class co.paralleluniverse.strands.channels.ReceivePortGroup
 
setStackSize(int) - Method in class co.paralleluniverse.strands.StrandFactoryBuilder
Suggests a stack size of strands created by the resulting StrandFactory.
setState(int) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Sets the value of synchronization state.
setState(long) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Sets the value of synchronization state.
setState(Mix.State, T...) - Method in interface co.paralleluniverse.strands.channels.Mix
 
setState(Mix.State, T...) - Method in class co.paralleluniverse.strands.channels.ReceivePortGroup
 
setState(Map<T, Mix.State>) - Method in interface co.paralleluniverse.strands.channels.Mix
 
setState(Map<T, Mix.State>) - Method in class co.paralleluniverse.strands.channels.ReceivePortGroup
 
setStrand(Strand) - Method in class co.paralleluniverse.actors.Actor
 
setStrand(Strand) - Method in class co.paralleluniverse.strands.channels.QueuePrimitiveChannel
 
setStrand(Strand) - Method in class co.paralleluniverse.strands.channels.SingleConsumerQueueChannel
 
setStrand(Strand) - Method in interface co.paralleluniverse.strands.Stranded
 
SettableFuture<V> - Class in co.paralleluniverse.strands
 
SettableFuture() - Constructor for class co.paralleluniverse.strands.SettableFuture
 
setThread(boolean) - Method in class co.paralleluniverse.strands.StrandFactoryBuilder
Makes the resulting StrandFactory produce threads.
setTimeout(long, TimeUnit) - Method in class co.paralleluniverse.actors.behaviors.ServerActor
Sets a duration after which, if a request has not been received, the ServerActor.handleTimeout() method will be called.
setUncaughtExceptionHandler(Strand.UncaughtExceptionHandler) - Method in class co.paralleluniverse.fibers.Fiber
Set the handler invoked when this fiber abruptly terminates due to an uncaught exception.
setUncaughtExceptionHandler(Strand.UncaughtExceptionHandler) - Method in class co.paralleluniverse.strands.Strand
Set the handler invoked when this strand abruptly terminates due to an uncaught exception.
setUncaughtExceptionHandler(Strand.UncaughtExceptionHandler) - Method in class co.paralleluniverse.strands.StrandFactoryBuilder
Sets the Strand.UncaughtExceptionHandler for new threads created with this ThreadFactory.
shouldPreempt(int) - Method in class co.paralleluniverse.fibers.Fiber
 
shutdown() - Static method in class co.paralleluniverse.actors.ActorRegistry
Shuts down the registry.
shutdown() - Method in class co.paralleluniverse.actors.behaviors.Behavior
Asks this actor to shut down.
shutdown() - Method in class co.paralleluniverse.actors.behaviors.BehaviorActor
Causes this actor to shut down.
shutdown() - Method in class co.paralleluniverse.actors.behaviors.ServerActor
 
shutdown() - Method in class co.paralleluniverse.fibers.FiberExecutorScheduler
 
shutdown() - Method in class co.paralleluniverse.fibers.FiberForkJoinScheduler
 
shutdown() - Method in class co.paralleluniverse.fibers.FiberScheduler
 
shutdown() - Method in class co.paralleluniverse.fibers.io.ChannelGroup
Shutdown the channel group.
shutdownInput() - Method in class co.paralleluniverse.fibers.io.FiberSocketChannel
Shutdown the connection for reading without closing the channel.
ShutdownMessage - Class in co.paralleluniverse.actors
A message requesting the receiving actor to shut itself down.
ShutdownMessage(ActorRef) - Constructor for class co.paralleluniverse.actors.ShutdownMessage
 
shutdownOutput() - Method in class co.paralleluniverse.fibers.io.FiberSocketChannel
Shutdown the connection for writing without closing the channel.
signal() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer.ConditionObject
Moves the longest-waiting strand, if one exists, from the wait queue for this condition to the wait queue for the owning lock.
signal() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer.ConditionObject
Moves the longest-waiting strand, if one exists, from the wait queue for this condition to the wait queue for the owning lock.
signal() - Method in interface co.paralleluniverse.strands.Condition
 
signal() - Method in class co.paralleluniverse.strands.ConditionSelector
 
signal() - Method in class co.paralleluniverse.strands.DoneSynchronizer
 
signal() - Method in class co.paralleluniverse.strands.OwnedSynchronizer
 
signal() - Method in class co.paralleluniverse.strands.SimpleConditionSynchronizer
 
signalAll() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer.ConditionObject
Moves all strands from the wait queue for this condition to the wait queue for the owning lock.
signalAll() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer.ConditionObject
Moves all strands from the wait queue for this condition to the wait queue for the owning lock.
signalAll() - Method in interface co.paralleluniverse.strands.Condition
 
signalAll() - Method in class co.paralleluniverse.strands.ConditionSelector
 
signalAll() - Method in class co.paralleluniverse.strands.DoneSynchronizer
 
signalAll() - Method in class co.paralleluniverse.strands.OwnedSynchronizer
 
signalAll() - Method in class co.paralleluniverse.strands.SimpleConditionSynchronizer
 
signalAndWait() - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
signalAndWait() - Method in class co.paralleluniverse.strands.OwnedSynchronizer
 
signalReceivers() - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
SimpleConditionSynchronizer - Class in co.paralleluniverse.strands
 
SimpleConditionSynchronizer(Object) - Constructor for class co.paralleluniverse.strands.SimpleConditionSynchronizer
 
SingleConsumerQueueChannel<Message> - Class in co.paralleluniverse.strands.channels
 
SingleConsumerQueueChannel(SingleConsumerQueue<Message>, Channels.OverflowPolicy) - Constructor for class co.paralleluniverse.strands.channels.SingleConsumerQueueChannel
 
singletonReceivePort(T) - Static method in class co.paralleluniverse.strands.channels.Channels
Returns a newly created ReceivePort that receives a single message: the object given to the function.
size() - Method in class co.paralleluniverse.fibers.io.FiberFileChannel
 
sleep(long) - Static method in class co.paralleluniverse.fibers.Fiber
 
sleep(long) - Static method in class co.paralleluniverse.strands.Strand
Causes the currently executing strand to sleep (temporarily cease execution) for the specified number of milliseconds, subject to the precision and accuracy of system timers and schedulers.
sleep(long, int) - Static method in class co.paralleluniverse.fibers.Fiber
 
sleep(long, int) - Static method in class co.paralleluniverse.strands.Strand
Causes the currently executing strand to sleep (temporarily cease execution) for the specified number of milliseconds plus the specified number of nanoseconds, subject to the precision and accuracy of system timers and schedulers.
sleep(long, TimeUnit) - Static method in class co.paralleluniverse.fibers.Fiber
 
sleep(long, TimeUnit) - Static method in class co.paralleluniverse.strands.Strand
Causes the currently executing strand to sleep (temporarily cease execution) for the specified duration, subject to the precision and accuracy of system timers and schedulers.
solo - Variable in class co.paralleluniverse.strands.channels.Mix.State
 
spawn() - Method in class co.paralleluniverse.actors.Actor
Starts a new fiber and runs the actor in it.
spawn() - Method in class co.paralleluniverse.actors.behaviors.BehaviorActor
 
spawn() - Method in class co.paralleluniverse.actors.behaviors.EventSourceActor
 
spawn() - Method in class co.paralleluniverse.actors.behaviors.ServerActor
 
spawn() - Method in class co.paralleluniverse.actors.behaviors.SupervisorActor
 
spawn(FiberFactory) - Method in class co.paralleluniverse.actors.Actor
Starts a new fiber using the given scheduler and runs the actor in it.
spawn(FiberFactory) - Method in class co.paralleluniverse.actors.behaviors.BehaviorActor
 
spawn(FiberFactory) - Method in class co.paralleluniverse.actors.behaviors.EventSourceActor
 
spawn(FiberFactory) - Method in class co.paralleluniverse.actors.behaviors.ServerActor
 
spawn(FiberFactory) - Method in class co.paralleluniverse.actors.behaviors.SupervisorActor
 
spawn(StrandFactory) - Method in class co.paralleluniverse.actors.Actor
Starts a new fiber using the given scheduler and runs the actor in it.
spawn(StrandFactory) - Method in class co.paralleluniverse.actors.behaviors.BehaviorActor
 
spawn(StrandFactory) - Method in class co.paralleluniverse.actors.behaviors.EventSourceActor
 
spawn(StrandFactory) - Method in class co.paralleluniverse.actors.behaviors.ServerActor
 
spawn(StrandFactory) - Method in class co.paralleluniverse.actors.behaviors.SupervisorActor
 
spawnThread() - Method in class co.paralleluniverse.actors.Actor
Starts a new thread and runs the actor in it.
spawnThread() - Method in class co.paralleluniverse.actors.behaviors.BehaviorActor
 
spawnThread() - Method in class co.paralleluniverse.actors.behaviors.EventSourceActor
 
spawnThread() - Method in class co.paralleluniverse.actors.behaviors.ServerActor
 
spawnThread() - Method in class co.paralleluniverse.actors.behaviors.SupervisorActor
 
SplitSendPort<Message> - Class in co.paralleluniverse.strands.channels
SendPort that will send messages it receives to a target SendPort.
SplitSendPort() - Constructor for class co.paralleluniverse.strands.channels.SplitSendPort
 
Stack - Class in co.paralleluniverse.fibers
Internal Class - DO NOT USE! (Public so that instrumented code can access it) ANY CHANGE IN THIS CLASS NEEDS TO BE SYNCHRONIZED WITH InstrumentMethod
stackTrace() - Method in interface co.paralleluniverse.actors.ActorMXBean
The actor's current call-stack
StampedLock - Class in co.paralleluniverse.strands.concurrent
A capability-based lock with three modes for controlling read/write access.
StampedLock() - Constructor for class co.paralleluniverse.strands.concurrent.StampedLock
Creates a new lock, initially in unlocked state.
StandardChannel<Message> - Interface in co.paralleluniverse.strands.channels
A common interface for standard channel implementations
start() - Method in class co.paralleluniverse.actors.Actor
 
start() - Method in class co.paralleluniverse.fibers.Fiber
 
start() - Method in class co.paralleluniverse.strands.Strand
Starts the strand.
STARTED - co.paralleluniverse.strands.Strand.State
Strand started but not yet running.
State(boolean) - Constructor for class co.paralleluniverse.strands.channels.Mix.State
 
State(Mix.Mode) - Constructor for class co.paralleluniverse.strands.channels.Mix.State
 
State(Mix.Mode, Boolean) - Constructor for class co.paralleluniverse.strands.channels.Mix.State
 
stopMonitor() - Method in class co.paralleluniverse.actors.Actor
Shuts down the actor's monitor.
stopMonitor(ActorRef<?>) - Static method in class co.paralleluniverse.actors.LocalActor
 
Strand - Class in co.paralleluniverse.strands
A Strand is either a Thread or a Fiber
Strand() - Constructor for class co.paralleluniverse.strands.Strand
 
Strand.State - Enum in co.paralleluniverse.strands
A strand's running state
Strand.UncaughtExceptionHandler - Interface in co.paralleluniverse.strands
Interface for handlers invoked when a Strand abruptly terminates due to an uncaught exception.
Stranded - Interface in co.paralleluniverse.strands
 
StrandFactory - Interface in co.paralleluniverse.strands
Creates new strands on demand.
StrandFactoryBuilder - Class in co.paralleluniverse.strands
Easily creates StrandFactorys.
StrandFactoryBuilder() - Constructor for class co.paralleluniverse.strands.StrandFactoryBuilder
 
StrandLocalRandom - Class in co.paralleluniverse.strands
A random number generator isolated to the current thread.
subscribe(int, Channels.OverflowPolicy, Publisher<T>) - Static method in class co.paralleluniverse.strands.channels.reactivestreams.ReactiveStreams
Subscribes to a given Publisher and return a ReceivePort to the subscription.
subscribe(T) - Method in class co.paralleluniverse.strands.channels.Topic
 
Supervisor - Class in co.paralleluniverse.actors.behaviors
An interface to a SupervisorActor.
Supervisor(ActorRef<Object>) - Constructor for class co.paralleluniverse.actors.behaviors.Supervisor
If actor is known to be a ServerActor, creates a new Server interface to it.
Supervisor.ChildMode - Enum in co.paralleluniverse.actors.behaviors
Determines whether a child (supervised) actor should be restarted if the supervisor's restart strategy states that it should be restarted.
Supervisor.ChildSpec - Class in co.paralleluniverse.actors.behaviors
Describes a child actor's configuration in a supervisor
SupervisorActor - Class in co.paralleluniverse.actors.behaviors
An actor that supervises, and if necessary, restarts other actors.
SupervisorActor(SupervisorActor.RestartStrategy) - Constructor for class co.paralleluniverse.actors.behaviors.SupervisorActor
Constructs a new supervisor with no children.
SupervisorActor(SupervisorActor.RestartStrategy, Supervisor.ChildSpec...) - Constructor for class co.paralleluniverse.actors.behaviors.SupervisorActor
Constructs a new supervisor with a given list of children.
SupervisorActor(SupervisorActor.RestartStrategy, List<Supervisor.ChildSpec>) - Constructor for class co.paralleluniverse.actors.behaviors.SupervisorActor
Constructs a new supervisor with a given list of children.
SupervisorActor(Strand, String, MailboxConfig, SupervisorActor.RestartStrategy) - Constructor for class co.paralleluniverse.actors.behaviors.SupervisorActor
Constructs a new supervisor with no children.
SupervisorActor(Strand, String, MailboxConfig, SupervisorActor.RestartStrategy, Initializer) - Constructor for class co.paralleluniverse.actors.behaviors.SupervisorActor
Constructs a new supervisor with no children.
SupervisorActor(Strand, String, MailboxConfig, SupervisorActor.RestartStrategy, Supervisor.ChildSpec...) - Constructor for class co.paralleluniverse.actors.behaviors.SupervisorActor
Constructs a new supervisor with a given list of children.
SupervisorActor(Strand, String, MailboxConfig, SupervisorActor.RestartStrategy, List<Supervisor.ChildSpec>) - Constructor for class co.paralleluniverse.actors.behaviors.SupervisorActor
Constructs a new supervisor with a given list of children.
SupervisorActor(String, SupervisorActor.RestartStrategy) - Constructor for class co.paralleluniverse.actors.behaviors.SupervisorActor
Constructs a new supervisor with no children.
SupervisorActor(String, SupervisorActor.RestartStrategy, Initializer) - Constructor for class co.paralleluniverse.actors.behaviors.SupervisorActor
Constructs a new supervisor with no children.
SupervisorActor(String, SupervisorActor.RestartStrategy, Supervisor.ChildSpec...) - Constructor for class co.paralleluniverse.actors.behaviors.SupervisorActor
Constructs a new supervisor with a given list of children.
SupervisorActor(String, SupervisorActor.RestartStrategy, List<Supervisor.ChildSpec>) - Constructor for class co.paralleluniverse.actors.behaviors.SupervisorActor
Constructs a new supervisor with a given list of children.
SupervisorActor(String, MailboxConfig, SupervisorActor.RestartStrategy) - Constructor for class co.paralleluniverse.actors.behaviors.SupervisorActor
Constructs a new supervisor with no children.
SupervisorActor(String, MailboxConfig, SupervisorActor.RestartStrategy, Initializer) - Constructor for class co.paralleluniverse.actors.behaviors.SupervisorActor
Constructs a new supervisor with no children.
SupervisorActor(String, MailboxConfig, SupervisorActor.RestartStrategy, Supervisor.ChildSpec...) - Constructor for class co.paralleluniverse.actors.behaviors.SupervisorActor
Constructs a new supervisor with a given list of children.
SupervisorActor(String, MailboxConfig, SupervisorActor.RestartStrategy, List<Supervisor.ChildSpec>) - Constructor for class co.paralleluniverse.actors.behaviors.SupervisorActor
Constructs a new supervisor with a given list of children.
SupervisorActor.RestartStrategy - Enum in co.paralleluniverse.actors.behaviors
Specifies a supervisor's strategy in the event a child dies.
SupervisorException - Exception in co.paralleluniverse.actors.behaviors
 
SupervisorException() - Constructor for exception co.paralleluniverse.actors.behaviors.SupervisorException
 
SupervisorException(String) - Constructor for exception co.paralleluniverse.actors.behaviors.SupervisorException
 
SupervisorException(String, Throwable) - Constructor for exception co.paralleluniverse.actors.behaviors.SupervisorException
 
SupervisorException(Throwable) - Constructor for exception co.paralleluniverse.actors.behaviors.SupervisorException
 
supportedOptions() - Method in class co.paralleluniverse.fibers.io.FiberServerSocketChannel
 
supportedOptions() - Method in class co.paralleluniverse.fibers.io.FiberSocketChannel
 
Suspendable - Annotation Type in co.paralleluniverse.fibers
Marks a method as suspendable.
SuspendableAction1<S> - Interface in co.paralleluniverse.strands
 
SuspendableAction2<S1,​S2> - Interface in co.paralleluniverse.strands
 
SuspendableCallable<V> - Interface in co.paralleluniverse.strands
This interface can represent any operation that may suspend the currently executing Strand (i.e.
SuspendableRunnable - Interface in co.paralleluniverse.strands
This interface can represent any operation that may suspend the currently executing Strand (i.e.
SuspendableUtils - Class in co.paralleluniverse.strands
 
SuspendableUtils() - Constructor for class co.paralleluniverse.strands.SuspendableUtils
 
SuspendableUtils.VoidSuspendableCallable - Class in co.paralleluniverse.strands
 
SuspendExecution - Exception in co.paralleluniverse.fibers
An exception used to initiate the control transfer.
SuspendExecution() - Constructor for exception co.paralleluniverse.fibers.SuspendExecution
 
sync() - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
Synchronization - Interface in co.paralleluniverse.strands
 

T

take(long) - Method in class co.paralleluniverse.strands.channels.TransformingReceivePort
Returns a TakeReceivePort that can provide at most count messages from the underlying channel.
take(ReceivePort<T>, long) - Static method in class co.paralleluniverse.strands.channels.Channels
Returns a ReceivePort that can provide at most count messages from channel.
target - Variable in class co.paralleluniverse.strands.channels.DelegatingReceivePort
 
target - Variable in class co.paralleluniverse.strands.channels.DelegatingSendPort
 
TEMPORARY - co.paralleluniverse.actors.behaviors.Supervisor.ChildMode
The child actor should never be restarted.
terminate(Throwable) - Method in class co.paralleluniverse.actors.behaviors.AbstractServerHandler
terminate(Throwable) - Method in class co.paralleluniverse.actors.behaviors.BehaviorActor
Called by onTerminate to terminate the actor.
terminate(Throwable) - Method in interface co.paralleluniverse.actors.behaviors.Initializer
 
TERMINATE - Static variable in class co.paralleluniverse.actors.behaviors.FiniteStateMachineActor
The termination state for the FSM
TERMINATED - co.paralleluniverse.strands.Strand.State
Strand has terminated.
ThreadLocalSerializer - Class in co.paralleluniverse.fibers
 
ThreadLocalSerializer() - Constructor for class co.paralleluniverse.fibers.ThreadLocalSerializer
 
ThreadReceivePort<Message> - Class in co.paralleluniverse.strands.channels
This class is a simple convenience wrapper around ReceivePort that can be used by threads (as opposed to fibers).
ThreadReceivePort(ReceivePort<Message>) - Constructor for class co.paralleluniverse.strands.channels.ThreadReceivePort
Creates a new convenience wrapper for using a ReceivePort in a thread.
ThreadSendPort<Message> - Class in co.paralleluniverse.strands.channels
This class is a simple convenience wrapper around SendPort that can be used by threads (as opposed to fibers).
ThreadSendPort(SendPort<Message>) - Constructor for class co.paralleluniverse.strands.channels.ThreadSendPort
Creates a new convenience wrapper for using a SendPort in a thread.
THROW - co.paralleluniverse.strands.channels.Channels.OverflowPolicy
The sender will get an exception (except if the channel is an actor's mailbox)
throwIn(RuntimeException) - Method in class co.paralleluniverse.actors.Actor
 
throwIn(RuntimeException) - Method in class co.paralleluniverse.actors.ActorImpl
 
throwIn(RuntimeException) - Method in class co.paralleluniverse.actors.RemoteActor
 
TickerChannelConsumer<Message> - Class in co.paralleluniverse.strands.channels
A ReceivePort which is a view of a ticker channel.
TickerChannelConsumer.TickerChannelFloatConsumer - Class in co.paralleluniverse.strands.channels
 
TickerChannelFloatConsumer(QueueFloatChannel) - Constructor for class co.paralleluniverse.strands.channels.TickerChannelConsumer.TickerChannelFloatConsumer
 
TIMED_WAITING - co.paralleluniverse.strands.Strand.State
Strand is blocked with a timeout
timeLeft(TimeUnit) - Method in class co.paralleluniverse.strands.Timeout
Returns how long is left before the timeout expires in the given time unit.
timeout(long, TimeUnit) - Static method in class co.paralleluniverse.strands.channels.TimeoutChannel
 
Timeout - Class in co.paralleluniverse.strands
Represents a timeout that can span several operations.
Timeout(long, TimeUnit) - Constructor for class co.paralleluniverse.strands.Timeout
Starts a new Timeout that begins now and expires within the given timeout from the instant this constructor has been called.
TimeoutChannel<Message> - Class in co.paralleluniverse.strands.channels
 
toActorBuilder(ActorRef<M>) - Static method in class co.paralleluniverse.actors.LocalActor
 
toFuture(Fiber<V>) - Static method in class co.paralleluniverse.fibers.FiberUtil
Turns a fiber into a Future.
Topic<Message> - Class in co.paralleluniverse.strands.channels
A channel that forwards all messages to subscriber channels.
Topic() - Constructor for class co.paralleluniverse.strands.channels.Topic
 
toProcessor(int, Channels.OverflowPolicy, SuspendableAction2<? extends ReceivePort<? super T>, ? extends SendPort<? extends R>>) - Static method in class co.paralleluniverse.strands.channels.reactivestreams.ReactiveStreams
Turns a transformer into a Publisher.
toProcessor(FiberFactory, int, Channels.OverflowPolicy, SuspendableAction2<? extends ReceivePort<? super T>, ? extends SendPort<? extends R>>) - Static method in class co.paralleluniverse.strands.channels.reactivestreams.ReactiveStreams
Turns a transformer into a Publisher.
toPublisher(ReceivePort<T>) - Static method in class co.paralleluniverse.strands.channels.reactivestreams.ReactiveStreams
Turns a channel to a Publisher.
toPublisher(ReceivePort<T>, FiberFactory) - Static method in class co.paralleluniverse.strands.channels.reactivestreams.ReactiveStreams
Turns a channel to a Publisher.
toPublisher(Topic<T>) - Static method in class co.paralleluniverse.strands.channels.reactivestreams.ReactiveStreams
Turns a topic to a Publisher.
toPublisher(Topic<T>, FiberFactory) - Static method in class co.paralleluniverse.strands.channels.reactivestreams.ReactiveStreams
Turns a topic to a Publisher.
toReceivePort(Iterable<T>) - Static method in class co.paralleluniverse.strands.channels.Channels
Returns a newly created ReceivePort that receives all the elements iterated by the iterable.
toReceivePort(Iterator<T>) - Static method in class co.paralleluniverse.strands.channels.Channels
Returns a newly created ReceivePort that receives all the elements iterated by the iterator.
toRunnable(SuspendableCallable<?>) - Static method in class co.paralleluniverse.strands.Strand
A utility method that converts a SuspendableCallable to a Runnable so that it could run as the target of a thread.
toRunnable(SuspendableRunnable) - Static method in class co.paralleluniverse.strands.Strand
A utility method that converts a SuspendableRunnable to a Runnable so that it could run as the target of a thread.
toString() - Method in class co.paralleluniverse.actors.Actor
 
toString() - Method in class co.paralleluniverse.actors.ActorImpl.ActorLifecycleListener
 
toString() - Method in class co.paralleluniverse.actors.ActorImpl
 
toString() - Method in class co.paralleluniverse.actors.ActorRef
 
toString() - Method in class co.paralleluniverse.actors.ActorSpec
 
toString() - Method in class co.paralleluniverse.actors.behaviors.ActorMessage
 
toString() - Method in class co.paralleluniverse.actors.behaviors.EventSource
 
toString() - Method in class co.paralleluniverse.actors.behaviors.ProxyServerActor.Invocation
 
toString() - Method in class co.paralleluniverse.actors.behaviors.Server
 
toString() - Method in class co.paralleluniverse.actors.behaviors.Supervisor.ChildSpec
 
toString() - Method in class co.paralleluniverse.actors.behaviors.Supervisor
 
toString() - Method in class co.paralleluniverse.actors.ExitMessage
 
toString() - Method in exception co.paralleluniverse.actors.LifecycleException
 
toString() - Method in class co.paralleluniverse.actors.MailboxConfig
 
toString() - Method in class co.paralleluniverse.actors.ShutdownMessage
 
toString() - Method in class co.paralleluniverse.fibers.Fiber
 
toString() - Method in class co.paralleluniverse.strands.channels.DelegatingReceivePort
 
toString() - Method in class co.paralleluniverse.strands.channels.DelegatingSendPort
 
toString() - Method in class co.paralleluniverse.strands.channels.Mix.State
 
toString() - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
toString() - Method in class co.paralleluniverse.strands.channels.Selector
 
toString() - Method in class co.paralleluniverse.strands.channels.SingleConsumerQueueChannel
 
toString() - Method in class co.paralleluniverse.strands.channels.ThreadReceivePort
 
toString() - Method in class co.paralleluniverse.strands.channels.ThreadSendPort
 
toString() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Returns a string identifying this synchronizer, as well as its state.
toString() - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Returns a string identifying this synchronizer, as well as its state.
toString() - Method in class co.paralleluniverse.strands.concurrent.CountDownLatch
Returns a string identifying this latch, as well as its state.
toString() - Method in class co.paralleluniverse.strands.concurrent.Phaser
Returns a string identifying this phaser, as well as its state.
toString() - Method in class co.paralleluniverse.strands.concurrent.ReentrantLock
Returns a string identifying this lock, as well as its lock state.
toString() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock.ReadLock
Returns a string identifying this lock, as well as its lock state.
toString() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock
Returns a string identifying this lock, as well as its lock state.
toString() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock.WriteLock
Returns a string identifying this lock, as well as its lock state.
toString() - Method in class co.paralleluniverse.strands.concurrent.Semaphore
Returns a string identifying this semaphore, as well as its state.
toString(StackTraceElement[]) - Static method in class co.paralleluniverse.strands.Strand
This utility method turns a stack-trace into a human readable, multi-line string.
TransferChannel<Message> - Class in co.paralleluniverse.strands.channels
 
TransferChannel() - Constructor for class co.paralleluniverse.strands.channels.TransferChannel
 
transferFrom(ReadableByteChannel, long, long) - Method in class co.paralleluniverse.fibers.io.FiberFileChannel
 
transferTo(long, long, WritableByteChannel) - Method in class co.paralleluniverse.fibers.io.FiberFileChannel
 
transform(ReceivePort<M>) - Static method in class co.paralleluniverse.strands.channels.Channels
Returns a TransformingReceivePort wrapping the given channel, which may be used for functional transformations.
transform(Object[]) - Method in class co.paralleluniverse.strands.channels.ZippingReceivePort
 
TransformingReceivePort<T> - Class in co.paralleluniverse.strands.channels
A ReceivePort with additional functional-transform operations, usually wrapping a plain ReceivePort.
TransformingSendPort<T> - Class in co.paralleluniverse.strands.channels
A SendPort with additional functional-transform operations, usually wrapping a plain SendPort.
transformSend(SendPort<M>) - Static method in class co.paralleluniverse.strands.channels.Channels
Returns a TransformingSendPort wrapping the given channel, which may be used for functional transformations.
TRANSIENT - co.paralleluniverse.actors.behaviors.Supervisor.ChildMode
The child actor should be restarted if it dies of unnatural causes (an exception) if the supervisor's restart strategy states that it should be restarted.
TrueThreadLocal<T> - Class in co.paralleluniverse.fibers
A ThreadLocal that is local to the current thread, rather than Strand.
TrueThreadLocal() - Constructor for class co.paralleluniverse.fibers.TrueThreadLocal
 
truncate(long) - Method in class co.paralleluniverse.fibers.io.FiberFileChannel
 
tryAcquire() - Method in class co.paralleluniverse.strands.concurrent.Semaphore
Acquires a permit from this semaphore, only if one is available at the time of invocation.
tryAcquire(int) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Attempts to acquire in exclusive mode.
tryAcquire(int) - Method in class co.paralleluniverse.strands.concurrent.Semaphore
Acquires the given number of permits from this semaphore, only if all are available at the time of invocation.
tryAcquire(int, long, TimeUnit) - Method in class co.paralleluniverse.strands.concurrent.Semaphore
Acquires the given number of permits from this semaphore, if all become available within the given waiting time and the current thread has not been interrupted.
tryAcquire(long) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Attempts to acquire in exclusive mode.
tryAcquire(long, TimeUnit) - Method in class co.paralleluniverse.strands.concurrent.Semaphore
Acquires a permit from this semaphore, if one becomes available within the given waiting time and the current thread has not been interrupted.
tryAcquireNanos(int, long) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Attempts to acquire in exclusive mode, aborting if interrupted, and failing if the given timeout elapses.
tryAcquireNanos(long, long) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Attempts to acquire in exclusive mode, aborting if interrupted, and failing if the given timeout elapses.
tryAcquireShared(int) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Attempts to acquire in shared mode.
tryAcquireShared(long) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Attempts to acquire in shared mode.
tryAcquireSharedNanos(int, long) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Attempts to acquire in shared mode, aborting if interrupted, and failing if the given timeout elapses.
tryAcquireSharedNanos(long, long) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Attempts to acquire in shared mode, aborting if interrupted, and failing if the given timeout elapses.
tryConvertToOptimisticRead(long) - Method in class co.paralleluniverse.strands.concurrent.StampedLock
If the lock state matches the given stamp then, if the stamp represents holding a lock, releases it and returns an observation stamp.
tryConvertToReadLock(long) - Method in class co.paralleluniverse.strands.concurrent.StampedLock
If the lock state matches the given stamp, performs one of the following actions.
tryConvertToWriteLock(long) - Method in class co.paralleluniverse.strands.concurrent.StampedLock
If the lock state matches the given stamp, performs one of the following actions.
tryGetActor(String) - Static method in class co.paralleluniverse.actors.ActorRegistry
Locates a registered actor by name.
tryLock() - Method in class co.paralleluniverse.strands.concurrent.ReentrantLock
Acquires the lock only if it is not held by another strand at the time of invocation.
tryLock() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock.ReadLock
Acquires the read lock only if the write lock is not held by another strand at the time of invocation.
tryLock() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock.WriteLock
Acquires the write lock only if it is not held by another strand at the time of invocation.
tryLock(long, long, boolean) - Method in class co.paralleluniverse.fibers.io.FiberFileChannel
 
tryLock(long, TimeUnit) - Method in class co.paralleluniverse.strands.concurrent.ReentrantLock
Acquires the lock if it is not held by another strand within the given waiting time and the current strand has not been interrupted.
tryLock(long, TimeUnit) - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock.ReadLock
Acquires the read lock if the write lock is not held by another strand within the given waiting time and the current strand has not been interrupted.
tryLock(long, TimeUnit) - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock.WriteLock
Acquires the write lock if it is not held by another strand within the given waiting time and the current strand has not been interrupted.
tryNow(Object) - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
tryNow(Object) - Method in interface co.paralleluniverse.strands.channels.Selectable
 
tryNow(Object) - Method in class co.paralleluniverse.strands.channels.TickerChannelConsumer
 
tryNow(Object) - Method in class co.paralleluniverse.strands.channels.TransferChannel
 
tryNow(Object) - Method in class co.paralleluniverse.strands.dataflow.ValChannel
 
tryOptimisticRead() - Method in class co.paralleluniverse.strands.concurrent.StampedLock
Returns a stamp that can later be validated, or zero if exclusively locked.
tryReadLock() - Method in class co.paralleluniverse.strands.concurrent.StampedLock
Non-exclusively acquires the lock if it is immediately available.
tryReadLock(long, TimeUnit) - Method in class co.paralleluniverse.strands.concurrent.StampedLock
Non-exclusively acquires the lock if it is available within the given time and the current strand has not been interrupted.
tryReceive() - Method in class co.paralleluniverse.actors.Actor
Retrieves a message from the mailbox if one is available.
tryReceive() - Method in class co.paralleluniverse.strands.channels.DelegatingReceivePort
 
tryReceive() - Method in class co.paralleluniverse.strands.channels.FlatMappingReceivePort
 
tryReceive() - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
tryReceive() - Method in interface co.paralleluniverse.strands.channels.ReceivePort
Retrieves a message from the channel if one is available.
tryReceive() - Method in class co.paralleluniverse.strands.channels.ReceivePortGroup
 
tryReceive() - Method in class co.paralleluniverse.strands.channels.SingleConsumerQueueChannel
 
tryReceive() - Method in class co.paralleluniverse.strands.channels.ThreadReceivePort
Retrieves a message from the channel if one is available.
tryReceive() - Method in class co.paralleluniverse.strands.channels.TickerChannelConsumer
 
tryReceive() - Method in class co.paralleluniverse.strands.channels.TransferChannel
 
tryReceive() - Method in class co.paralleluniverse.strands.channels.ZippingReceivePort
 
tryReceive() - Method in class co.paralleluniverse.strands.dataflow.ValChannel
 
tryReceive(MessageProcessor<? super Message, T>) - Method in class co.paralleluniverse.actors.BasicActor
Tries to perform a selective receive.
tryReceive(MessageProcessor<? super Message, T>) - Method in class co.paralleluniverse.actors.SelectiveReceiveHelper
Tries to perform a selective receive.
tryReceive(MessageProcessor<Object, SuspendableCallable<SuspendableCallable>>) - Method in class co.paralleluniverse.actors.behaviors.FiniteStateMachineActor
Tries to perform a selective receive.
tryReceive(Class<M>) - Method in class co.paralleluniverse.actors.BasicActor
Tries to performs a selective receive based on type.
tryReceive(Class<M>) - Method in class co.paralleluniverse.actors.behaviors.FiniteStateMachineActor
Tries to performs a selective receive based on type.
tryReceive(Class<M>) - Method in class co.paralleluniverse.actors.SelectiveReceiveHelper
Tries to performs a selective receive based on type.
tryRelease(int) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Attempts to set the state to reflect a release in exclusive mode.
tryRelease(long) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Attempts to set the state to reflect a release in exclusive mode.
tryReleaseShared(int) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedSynchronizer
Attempts to set the state to reflect a release in shared mode.
tryReleaseShared(long) - Method in class co.paralleluniverse.strands.concurrent.AbstractQueuedLongSynchronizer
Attempts to set the state to reflect a release in shared mode.
trySelect() - Method in class co.paralleluniverse.strands.channels.Selector
 
trySelect(boolean, SelectAction<Message>...) - Static method in class co.paralleluniverse.strands.channels.Selector
Attempts to performs exactly one channel operation of a given set if one can be completed without blocking.
trySelect(boolean, List<? extends SelectAction<Message>>) - Static method in class co.paralleluniverse.strands.channels.Selector
Attempts to performs exactly one channel operation of a given set if one can be completed without blocking.
trySelect(SelectAction<Message>...) - Static method in class co.paralleluniverse.strands.channels.Selector
Attempts to performs exactly one channel operation of a given set if one can be completed without blocking.
trySelect(List<? extends SelectAction<Message>>) - Static method in class co.paralleluniverse.strands.channels.Selector
Attempts to performs exactly one channel operation of a given set if one can be completed without blocking.
trySend(double) - Method in interface co.paralleluniverse.strands.channels.DoubleSendPort
Sends a message to the channel if the channel has room available.
trySend(double) - Method in class co.paralleluniverse.strands.channels.QueueDoubleChannel
 
trySend(float) - Method in interface co.paralleluniverse.strands.channels.FloatSendPort
Sends a message to the channel if the channel has room available.
trySend(float) - Method in class co.paralleluniverse.strands.channels.QueueFloatChannel
 
trySend(int) - Method in interface co.paralleluniverse.strands.channels.IntSendPort
Sends a message to the channel if the channel has room available.
trySend(int) - Method in class co.paralleluniverse.strands.channels.QueueIntChannel
 
trySend(long) - Method in interface co.paralleluniverse.strands.channels.LongSendPort
Sends a message to the channel if the channel has room available.
trySend(long) - Method in class co.paralleluniverse.strands.channels.QueueLongChannel
 
trySend(Message) - Method in class co.paralleluniverse.actors.Actor
 
trySend(Message) - Method in class co.paralleluniverse.actors.ActorImpl
 
trySend(Message) - Method in class co.paralleluniverse.actors.ActorRef
Sends a message to the actor if the channel has mailbox available.
trySend(Message) - Method in class co.paralleluniverse.actors.FakeActor
 
trySend(Message) - Method in class co.paralleluniverse.actors.RemoteActor
 
trySend(Message) - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
trySend(Message) - Method in interface co.paralleluniverse.strands.channels.SendPort
Sends a message to the channel if the channel has room available.
trySend(Message) - Method in class co.paralleluniverse.strands.channels.SplitSendPort
 
trySend(Message) - Method in class co.paralleluniverse.strands.channels.ThreadSendPort
Sends a message to the channel if the channel has room available.
trySend(Message) - Method in class co.paralleluniverse.strands.channels.Topic
 
trySend(Message) - Method in class co.paralleluniverse.strands.channels.TransferChannel
 
trySend(T) - Method in class co.paralleluniverse.strands.channels.DelegatingSendPort
 
tryUnlockRead() - Method in class co.paralleluniverse.strands.concurrent.StampedLock
Releases one hold of the read lock if it is held, without requiring a stamp value.
tryUnlockWrite() - Method in class co.paralleluniverse.strands.concurrent.StampedLock
Releases the write lock if it is held, without requiring a stamp value.
tryWriteLock() - Method in class co.paralleluniverse.strands.concurrent.StampedLock
Exclusively acquires the lock if it is immediately available.
tryWriteLock(long, TimeUnit) - Method in class co.paralleluniverse.strands.concurrent.StampedLock
Exclusively acquires the lock if it is available within the given time and the current strand has not been interrupted.

U

uncaughtException(Strand, Throwable) - Method in interface co.paralleluniverse.strands.Strand.UncaughtExceptionHandler
Method invoked when the given fiber terminates due to the given uncaught exception.
unlink(ActorRef) - Method in class co.paralleluniverse.actors.Actor
Un-links this actor from another.
unlink(ActorRef<?>, ActorRef<?>) - Static method in class co.paralleluniverse.actors.LocalActor
 
unlinked(ActorRef) - Method in class co.paralleluniverse.actors.Actor
 
unlinked(ActorRef) - Method in class co.paralleluniverse.actors.ActorImpl
 
unlinked(ActorRef) - Method in class co.paralleluniverse.actors.RemoteActor
 
unloadModule(String) - Method in class co.paralleluniverse.actors.ActorLoader
 
unloadModule(String) - Method in interface co.paralleluniverse.actors.ActorLoaderMXBean
Unloads the module at the given URL
unloadModule(URL) - Method in class co.paralleluniverse.actors.ActorLoader
 
unlock() - Method in class co.paralleluniverse.actors.Mailbox
 
unlock() - Method in class co.paralleluniverse.strands.concurrent.ReentrantLock
Attempts to release this lock.
unlock() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock.ReadLock
Attempts to release this lock.
unlock() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock.WriteLock
Attempts to release this lock.
unlock(long) - Method in class co.paralleluniverse.strands.concurrent.StampedLock
If the lock state matches the given stamp, releases the corresponding mode of the lock.
unlockRead(long) - Method in class co.paralleluniverse.strands.concurrent.StampedLock
If the lock state matches the given stamp, releases the non-exclusive lock.
unlockWrite(long) - Method in class co.paralleluniverse.strands.concurrent.StampedLock
If the lock state matches the given stamp, releases the exclusive lock.
unpark() - Method in class co.paralleluniverse.fibers.Fiber
Makes available the permit for this fiber, if it was not already available.
unpark() - Method in class co.paralleluniverse.strands.Strand
Makes available the permit for this strand, if it was not already available.
unpark(Fiber, Object) - Static method in class co.paralleluniverse.fibers.FiberControl
 
unpark(Strand) - Static method in class co.paralleluniverse.strands.Strand
Makes available the permit for the given strand, if it was not already available.
unpark(Strand, Object) - Static method in class co.paralleluniverse.strands.Strand
Makes available the permit for the given strand, if it was not already available.
unpark(Object) - Method in class co.paralleluniverse.fibers.Fiber
 
unpark(Object) - Method in class co.paralleluniverse.strands.Strand
Makes available the permit for this strand, if it was not already available.
unpark(Thread) - Static method in class co.paralleluniverse.strands.Strand
Makes available the permit for the given strand, if it was not already available.
unparkDeserialized(Fiber<V>, FiberScheduler) - Static method in class co.paralleluniverse.fibers.Fiber
Unparks a fiber that's been deserialized (with the help of Fiber.getFiberSerializer()
unparkSerialized(byte[], FiberScheduler) - Static method in class co.paralleluniverse.fibers.Fiber
Deserializes a fiber from the given byte array and unparks it.
unregister() - Method in class co.paralleluniverse.actors.Actor
Unregisters this actor from the actor registry.
unregister(ActorRef<?>) - Static method in class co.paralleluniverse.actors.LocalActor
 
unregister(Object) - Method in class co.paralleluniverse.strands.channels.QueueChannel
 
unregister(Object) - Method in interface co.paralleluniverse.strands.channels.Selectable
 
unregister(Object) - Method in class co.paralleluniverse.strands.channels.Selector
 
unregister(Object) - Method in class co.paralleluniverse.strands.channels.TickerChannelConsumer
 
unregister(Object) - Method in class co.paralleluniverse.strands.channels.TransferChannel
 
unregister(Object) - Method in interface co.paralleluniverse.strands.Condition
 
unregister(Object) - Method in class co.paralleluniverse.strands.ConditionSelector
 
unregister(Object) - Method in class co.paralleluniverse.strands.dataflow.ValChannel
 
unregister(Object) - Method in class co.paralleluniverse.strands.DoneSynchronizer
 
unregister(Object) - Method in class co.paralleluniverse.strands.OwnedSynchronizer
 
unregister(Object) - Method in class co.paralleluniverse.strands.SimpleConditionSynchronizer
 
unregister(Object) - Method in interface co.paralleluniverse.strands.Synchronization
 
unsubscribe(SendPort<? super Message>) - Method in class co.paralleluniverse.strands.channels.Topic
 
unsubscribeAll() - Method in class co.paralleluniverse.strands.channels.Topic
 
unwatch(ActorRef, Object) - Method in class co.paralleluniverse.actors.Actor
Un-watches another actor.
unwatch(ActorRef, Object) - Method in class co.paralleluniverse.actors.FakeActor
Un-watches another actor.
unwrapSuspendable(Runnable) - Static method in class co.paralleluniverse.strands.Strand
Returns the SuspendableCallable or SuspendableRunnable, wrapped by the given Runnable by toRunnable.
Upgrade - Annotation Type in co.paralleluniverse.actors
Marks an actor class as a code upgrade.

V

Val<V> - Class in co.paralleluniverse.strands.dataflow
A dataflow constant.
Val() - Constructor for class co.paralleluniverse.strands.dataflow.Val
 
Val(FiberScheduler, SuspendableCallable<V>) - Constructor for class co.paralleluniverse.strands.dataflow.Val
Creates a Val whose value will be the one returned by the given SuspendableCallable, which will be spawned into a new fiber, scheduled by the given FiberScheduler.
Val(SuspendableCallable<V>) - Constructor for class co.paralleluniverse.strands.dataflow.Val
Creates a Val whose value will be the one returned by the given SuspendableCallable, which will be spawned into a new fiber.
ValChannel<V> - Class in co.paralleluniverse.strands.dataflow
An adapter that turns a DelayedVal into a ReceivePort that receives the DelayedVal's value and then closes.
ValChannel(Val<V>) - Constructor for class co.paralleluniverse.strands.dataflow.ValChannel
 
validate(long) - Method in class co.paralleluniverse.strands.concurrent.StampedLock
Returns true if the lock has not been exclusively acquired since issuance of the given stamp.
valueOf(String) - Static method in enum co.paralleluniverse.actors.behaviors.Supervisor.ChildMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum co.paralleluniverse.actors.behaviors.SupervisorActor.RestartStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum co.paralleluniverse.strands.channels.Channels.OverflowPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum co.paralleluniverse.strands.channels.Mix.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum co.paralleluniverse.strands.channels.Mix.SoloEffect
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum co.paralleluniverse.strands.Strand.State
Returns the enum constant of this type with the specified name.
ValueResponseMessage<V> - Class in co.paralleluniverse.actors.behaviors
A simple subclass of ResponseMessage that encapsulates a single response value.
ValueResponseMessage(Object, V) - Constructor for class co.paralleluniverse.actors.behaviors.ValueResponseMessage
Constructs a ValueResponseMessage.
values() - Static method in enum co.paralleluniverse.actors.behaviors.Supervisor.ChildMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum co.paralleluniverse.actors.behaviors.SupervisorActor.RestartStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum co.paralleluniverse.strands.channels.Channels.OverflowPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum co.paralleluniverse.strands.channels.Mix.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum co.paralleluniverse.strands.channels.Mix.SoloEffect
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum co.paralleluniverse.strands.Strand.State
Returns an array containing the constants of this enum type, in the order they are declared.
Var<T> - Class in co.paralleluniverse.strands.dataflow
A dataflow variable.
Var() - Constructor for class co.paralleluniverse.strands.dataflow.Var
Creates a new Var with no history.
Var(int) - Constructor for class co.paralleluniverse.strands.dataflow.Var
Creates a new Var.
Var(int, FiberScheduler, SuspendableCallable<T>) - Constructor for class co.paralleluniverse.strands.dataflow.Var
Creates a new Var, whose value is set to the value returned by the given function f; the function will be re-applied, and the Var's value re-set, whenever any of the Vars referenced by f change value.
Var(int, SuspendableCallable<T>) - Constructor for class co.paralleluniverse.strands.dataflow.Var
Creates a new Var, whose value is set to the value returned by the given function f; the function will be re-applied, and the Var's value re-set, whenever any of the Vars referenced by f change value.
Var(FiberScheduler, SuspendableCallable<T>) - Constructor for class co.paralleluniverse.strands.dataflow.Var
Creates a new Var with no history, whose value is set to the value returned by the given function f; the function will be re-applied, and the Var's value re-set, whenever any of the Vars referenced by f change value.
Var(SuspendableCallable<T>) - Constructor for class co.paralleluniverse.strands.dataflow.Var
Creates a new Var with no history, whose value is set to the value returned by the given function f; the function will be re-applied, and the Var's value re-set, whenever any of the Vars referenced by f change value.
verifyInActor() - Method in class co.paralleluniverse.actors.Actor
Tests whether this code is executing in this actor's strand, and throws a ConcurrencyException if not.
VerifyInstrumentationException - Exception in co.paralleluniverse.fibers
 
VerifyInstrumentationException(String) - Constructor for exception co.paralleluniverse.fibers.VerifyInstrumentationException
 
verifyOnActorStrand() - Method in class co.paralleluniverse.actors.Actor
 
VoidSuspendableCallable(SuspendableRunnable) - Constructor for class co.paralleluniverse.strands.SuspendableUtils.VoidSuspendableCallable
 

W

waitForRegistration() - Method in class co.paralleluniverse.fibers.FiberAsync
Spins until requestAsync returns.
WAITING - co.paralleluniverse.strands.Strand.State
Strand is blocked.
watch - Variable in class co.paralleluniverse.actors.ExitMessage
 
watch(ActorRef) - Method in class co.paralleluniverse.actors.Actor
Makes this actor watch another actor.
watch(ActorRef) - Method in class co.paralleluniverse.actors.FakeActor
Makes this fake actor watch another actor.
withFixedThreadPool(int, ThreadFactory) - Static method in class co.paralleluniverse.fibers.io.ChannelGroup
Creates a channel group with a fixed thread pool.
withId(Object) - Method in class co.paralleluniverse.actors.behaviors.MessageSelector
Returns a MessageSelector that selects IdMessages with the given id.
withThreadPool(ExecutorService) - Static method in class co.paralleluniverse.fibers.io.ChannelGroup
Creates a channel group with a given thread pool.
wrapException(Throwable) - Method in class co.paralleluniverse.fibers.FiberAsync
Takes the exception generated by the async operation and possibly wraps it in an exception that will be thrown by the run method.
wrapException(Throwable) - Method in class co.paralleluniverse.fibers.futures.AsyncCompletionStage
 
write(Fiber) - Method in interface co.paralleluniverse.fibers.CustomFiberWriter
 
write(Fiber, ByteArraySerializer) - Method in interface co.paralleluniverse.fibers.FiberWriter
 
write(Kryo, Output, CustomFiberWriter) - Method in class co.paralleluniverse.fibers.CustomFiberWriterSerializer
 
write(Kryo, Output, ThreadLocal<?>) - Method in class co.paralleluniverse.fibers.ThreadLocalSerializer
 
write(ByteBuffer) - Method in class co.paralleluniverse.fibers.io.FiberFileChannel
 
write(ByteBuffer) - Method in class co.paralleluniverse.fibers.io.FiberSocketChannel
 
write(ByteBuffer[]) - Method in class co.paralleluniverse.fibers.io.FiberFileChannel
 
write(ByteBuffer[]) - Method in class co.paralleluniverse.fibers.io.FiberSocketChannel
 
write(ByteBuffer[], int, int) - Method in class co.paralleluniverse.fibers.io.FiberFileChannel
 
write(ByteBuffer[], int, int) - Method in class co.paralleluniverse.fibers.io.FiberSocketChannel
 
write(ByteBuffer[], int, int, long, TimeUnit) - Method in class co.paralleluniverse.fibers.io.FiberSocketChannel
Writes a sequence of bytes to this channel from a subsequence of the given buffers.
write(ByteBuffer, long) - Method in class co.paralleluniverse.fibers.io.FiberFileChannel
Writes a sequence of bytes to this channel from the given buffer, starting at the given file position.
write(ByteBuffer, long, TimeUnit) - Method in class co.paralleluniverse.fibers.io.FiberSocketChannel
Writes a sequence of bytes to this channel from the given buffer.
writeLock() - Method in class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock
 
writeLock() - Method in class co.paralleluniverse.strands.concurrent.StampedLock
Exclusively acquires the lock, blocking if necessary until available.
WriteLock(ReentrantReadWriteLock) - Constructor for class co.paralleluniverse.strands.concurrent.ReentrantReadWriteLock.WriteLock
Constructor for use by subclasses
writeLockInterruptibly() - Method in class co.paralleluniverse.strands.concurrent.StampedLock
Exclusively acquires the lock, blocking if necessary until available or the current strand is interrupted.
writeReplace() - Method in class co.paralleluniverse.actors.Actor
 
writeReplace() - Method in class co.paralleluniverse.actors.FakeActor
 
writeReplace() - Method in class co.paralleluniverse.actors.Mailbox
 
writeReplace() - Method in class co.paralleluniverse.strands.channels.QueueChannel
 

Y

yield() - Static method in class co.paralleluniverse.fibers.Fiber
 
yield() - Static method in class co.paralleluniverse.strands.Strand
A hint to the scheduler that the current strand is willing to yield its current use of a processor.
yieldAndUnpark(Fiber) - Static method in class co.paralleluniverse.fibers.Fiber
 
yieldAndUnpark(Fiber, Object) - Static method in class co.paralleluniverse.fibers.Fiber
 
yieldAndUnpark(Strand) - Static method in class co.paralleluniverse.strands.Strand
 
yieldAndUnpark(Strand, Object) - Static method in class co.paralleluniverse.strands.Strand
 

Z

zip(ReceivePort<S1>, ReceivePort<S2>, Function2<S1, S2, M>) - Static method in class co.paralleluniverse.strands.channels.Channels
Returns a ReceivePort that combines each vector of messages from a vector of channels into a single combined message.
zip(ReceivePort<S1>, ReceivePort<S2>, ReceivePort<S3>, Function3<S1, S2, S3, M>) - Static method in class co.paralleluniverse.strands.channels.Channels
Returns a ReceivePort that combines each vector of messages from a vector of channels into a single combined message.
zip(ReceivePort<S1>, ReceivePort<S2>, ReceivePort<S3>, ReceivePort<S4>, Function4<S1, S2, S3, S4, M>) - Static method in class co.paralleluniverse.strands.channels.Channels
Returns a ReceivePort that combines each vector of messages from a vector of channels into a single combined message.
zip(ReceivePort<S1>, ReceivePort<S2>, ReceivePort<S3>, ReceivePort<S4>, ReceivePort<S5>, Function5<S1, S2, S3, S4, S5, M>) - Static method in class co.paralleluniverse.strands.channels.Channels
Returns a ReceivePort that combines each vector of messages from a vector of channels into a single combined message.
zip(List<? extends ReceivePort<?>>, Function<Object[], M>) - Static method in class co.paralleluniverse.strands.channels.Channels
Returns a ReceivePort that combines each vector of messages from a list of channels into a single combined message.
ZippingReceivePort<Message> - Class in co.paralleluniverse.strands.channels
Single consumer
ZippingReceivePort(ReceivePort<?>...) - Constructor for class co.paralleluniverse.strands.channels.ZippingReceivePort
 
ZippingReceivePort(Function<Object[], Message>, ReceivePort<?>...) - Constructor for class co.paralleluniverse.strands.channels.ZippingReceivePort
 
ZippingReceivePort(Function<Object[], Message>, List<? extends ReceivePort<?>>) - Constructor for class co.paralleluniverse.strands.channels.ZippingReceivePort
 
ZippingReceivePort(List<? extends ReceivePort<?>>) - Constructor for class co.paralleluniverse.strands.channels.ZippingReceivePort
 
A B C D E F G H I J L M N O P Q R S T U V W Y Z 
All Classes All Packages