|
|||||||||
PREV NEXT | FRAMES NO FRAMES |
Actor
.
Actor
.
Actor
.
Actor
.
Props
to determine the type of actor which will
be created.
ActorClassification
An EventBus where the Subscribers are ActorRefs and the Classifier is ActorRef
Means that ActorRefs "listen" to other ActorRefs
E is the Event typeActorSystem
.
".."
signifies the parent of an actor.
".."
signifies the parent of an actor.
Identify
.Kill
messageActorSelection.resolveOne(akka.util.Timeout)
can't identify the actor the
Future
is completed with this failure.ActorSystem
.Routee
that sends the messages to an ActorRef
.ActorSelection
from the given path, which is
parsed for wildcards (these are replaced by regular expressions
internally).
ActorSelection
from the given path, which is
parsed for wildcards (these are replaced by regular expressions
internally).
Routee
that sends the messages to an ActorSelection
.RoutingLogic
.
ActorRefRoutee
for the
specified ActorRef
and the same RoutingLogic
.
ActorSelectionRoutee
for the
specified ActorSelection
and the same RoutingLogic
.
Router
.
Pool
.Future
that will be completed with the success or failure of the provided value
after the specified duration.
Future
that will be completed with the success or failure of the provided Callable
after the specified duration.
Future
that will be completed with the success or failure of the provided value
after the specified duration.
Future
that will be completed with the success or failure of the provided Callable
after the specified duration.
Future
that will be completed with the success or failure of the provided value
after the specified duration.
Directive
(Resume, Restart, Stop) specified in the Decider
to all children when one fails, as opposed to OneForOneStrategy
that applies
it only to the child actor that failed.ActorPath
of the anchor actor.
WriteCommand
to form a CompoundWrite
.
LogSource
, generate the
string representation and originating class.
LogSource
and
ActorSystem
, generate the string representation and
originating class.
Tcp
or Udp
.
Tcp
or Udp
.
WriteCommand
.
postRestart
.
postStop
.
preRestart
.
preStart
.
?
and ask
methods on
ActorRef
, which will defer to the
ask(actorRef, message)(timeout)
method defined here.
Future
holding the eventual reply message; this means that the target actor
needs to send the result to the sender
reference provided.
?
and ask
methods on
ActorSelection
, which will defer to the
ask(actorSelection, message)(timeout)
method defined here.
Future
holding the eventual reply message; this means that the target actor
needs to send the result to the sender
reference provided.
akka.pattern.ask
:
Sends a message asynchronously and returns a Future
holding the eventual reply message; this means that the target actor
needs to send the result to the sender
reference provided.
akka.pattern.ask
:
Sends a message asynchronously and returns a Future
holding the eventual reply message; this means that the target actor
needs to send the result to the sender
reference provided.
akka.pattern.ask
:
Sends a message asynchronously and returns a Future
holding the eventual reply message; this means that the target ActorSelection
needs to send the result to the sender
reference provided.
akka.pattern.ask
:
Sends a message asynchronously and returns a Future
holding the eventual reply message; this means that the target ActorSelection
needs to send the result to the sender
reference provided.
akka.pattern.ask
:
Sends a message asynchronously and returns a Future
holding the eventual reply message; this means that the target actor
needs to send the result to the sender
reference provided.
akka.pattern.ask
:
Sends a message asynchronously and returns a Future
holding the eventual reply message; this means that the target actor
needs to send the result to the sender
reference provided.
akka.pattern.ask
:
Sends a message asynchronously and returns a Future
holding the eventual reply message; this means that the target ActorSelection
needs to send the result to the sender
reference provided.
akka.pattern.ask
:
Sends a message asynchronously and returns a Future
holding the eventual reply message; this means that the target ActorSelection
needs to send the result to the sender
reference provided.
backoffThreshold
and backoffRate
BalancingDispatcher
.Runnable.run()
calls
into a single Runnable passed to the original
Executor.TcpExt.getManager()
in order to bind to a listening socket.
TcpExt.getManager()
in order to bind to a listening socket.
UdpExt.manager()
in order to bind to the given
local port (or an automatically assigned one if the port number is zero).
UdpExt.manager()
in order to bind to the given
local port (or an automatically assigned one if the port number is zero).
Inet.SocketOption
to set the SO_BROADCAST option
Inet.SocketOption
to set the SO_BROADCAST option
PartialFunction
from this builder.
PartialFunction
from this builder.
PartialFunction
from this builder.
LoggingAdapter
that publishes Logging.LogEvent
to event stream.ByteString
.CircuitBreaker.withCircuitBreaker(scala.Function0>)
CircuitBreaker.withSyncCircuitBreaker(scala.Function0)
register
on the ChannelRegistry
.TcpExt.getManager()
.
remoteAddress
without binding to a local address and without
specifying options.
TcpExt.getManager()
.
remoteAddress
without binding to a local address and without
specifying options.
UdpExt.manager()
in order to bind to a local
port (optionally with the chosen localAddress
) and create a UDP socket
which is restricted to sending to and receiving from the given remoteAddress
.
localAddress
.
localAddress
or options
.
UdpExt.manager()
in order to bind to a local
port (optionally with the chosen localAddress
) and create a UDP socket
which is restricted to sending to and receiving from the given remoteAddress
.
localAddress
.
localAddress
or options
.
hashMapping
when
constructing the ConsistentHashingRouter
the messages need to implement this interface to define what
data to use for the consistent hash key.hashMapping
when
constructing the ConsistentHashingRouter
and messages can't implement ConsistentHashingRouter.ConsistentHashable
themselves they can we wrapped by this envelope instead.Creator
.
Creator
with the type set to the given actorClass.
Creator
.
Creator
with the type set to the given actorClass.
WriteCommand
.
Match
from the builder.
UnitMatch
from the builder.
Class[_]
object and a constructor description
will create a new instance of that class.
args
argument.
RouterConfig
Actor
with Stash
,
since just using actor()(new Act with Stash{})
will not be able to see the
Stash component due to type erasure.Group
nor
a Pool
it may extend this base class.DeadLetter
.Actor.supervisorStrategy()
.Decider
is used by default in the supervisor strategy.
Decider
is used by default in the supervisor strategy.
UdpConnected.Connected
message) in order to close the socket.
UdpConnected.Connected
message) in order to close the socket.
Deploy
instance.
Dispatcher
binds a set of Actors to a thread pool backed up by a
BlockingQueue
.Dispatcher
.Logging.LogEvent
when the string representation was supplied
directly.ReflectiveDynamicAccess
is the default implementation).envelope
at the first position in the mailbox.
EventBus
E is the Event type
S is the Subscriber type
C is the Classifier typeExtension
).Class
’s simple name.
Class
’s simple name.
FSM.SubscribeTransitionCallBack
before sending any
FSM.Transition
messages.FSM
will be wrapped inside an
Event
, which allows pattern matching to extract both state and data.FSM
is shutting itself down because of
an error, e.g.LoggingFSM
, can be obtained by calling getLog
.stop()
.whenUnhandled
and onTermination
handlers.FSM
is shutting down.system.stop(fsm)
from outside;
also applies to Stop
supervision directive.FSM
: the state
name, the state data, possibly custom timeout, stop reason and replies
accumulated while processing the last message.FSM
whithin the
onTermination
block.FSM
to request first the FSM.CurrentState
and then a series of FSM.Transition
updates.FSM.SubscribeTransitionCallBack
).FSM.Transition
notifications which was
effected by sending the corresponding FSM.SubscribeTransitionCallBack
.FSM.whenUnhandled(scala.PartialFunction, akka.actor.FSM.State>)
.FSM.onTermination(scala.PartialFunction, scala.runtime.BoxedUnit>)
.FSM.onTransition(scala.PartialFunction, scala.runtime.BoxedUnit>)
.Future
object with the result of that computation.
Future
object with the result of that computation.
Class[_]
object for the code
executing in that stack frame.
Class[_]
object for the code
executing in that stack frame.
Class[_]
object loaded with the right class loader (i.e.
isErrorClosed
returns true, then the error condition can be
retrieved by this method.
n
bytes were encoded.
akka.event.slf4j.Slf4jLogger
is configured.
a
if this is some(a)
or defaultValue
if
this is none
.
ActorRef
of the actor replying to the request or
null if no actor matched the request.
ActorRef
.
Future
that will be completed with success (value true
) when
existing messages of the target actor has been processed and the actor has been
terminated.
Future
that will be completed with success (value true
) when
existing messages of the target actor has been processed and the actor has been
terminated.
Future
that will be completed with success (value true
) when
existing messages of the target actor has been processed and the actor has been
terminated.
Future
that will be completed with success (value true
) when
existing messages of the target actor has been processed and the actor has been
terminated.
Future
that will be completed with success (value true
) when
existing messages of the target actor has been processed and the actor has been
terminated.
RouterConfig
for router actor with routee actors that are created external to the
router and the router sends messages to the specified path using actor selection,
without watching for termination.Group
true
), or it returns false
to escalate the
failure, which will lead to this actor re-throwing the exception which
caused the failure.
hashCode
.hashCode
.requiring
methods.ActorIdentity
containing the ActorRef
.System.identityHashCode
,
unless that happens to be the same for two non-equals objects, in which
case the supplied “real” comparator is used; the comparator must be
consistent with equals, otherwise it would not be an enhancement over
the identityHashCode.
System.identityHashCode
,
unless that happens to be the same for two non-equals objects, in which
case the supplied “real” comparator is used; the comparator must be
consistent with equals, otherwise it would not be an enhancement over
the identityHashCode.
Iterable
into an immutable Scala IndexedSeq (by copying it).
Iterable
into an immutable Scala IndexedSeq (by copying it).
Iterable
into an immutable Scala sequence (by copying it).
Iterable
into an immutable Scala sequence (by copying it).
akka.actor.dsl.Inbox!.Inbox!.receive
and akka.actor.dsl.Inbox!.Inbox!.select
methods.
Actor
subclass.Inet.SocketOption
to set the SO_RCVBUF optionInet.SocketOption
to enable or disable SO_REUSEADDRInet.SocketOption
to set the SO_SNDBUF option.Inet.SocketOption
to set the traffic class or
type-of-service octet in the IP header for packets sent from this
socket.null
is an invalid message.true
iff the connection has been closed in response to an Abort
command.
true
iff the connection has been fully closed in response to a
ConfirmedClose
command.
true
iff the connection has been closed due to an IO error.
RouterConfig.routingLogicController(akka.routing.RoutingLogic)
actor.
true
iff the connection has been closed by the peer; in case
keepOpenOnPeerClosed
is in effect as per the Tcp.Register
command,
this connection’s reading half is now closed.
isCheck == true
and the latter to isCheck == false
for those cases where
this is important to know.ExtendedActorSystem
, because
that is the preferred constructor which will be invoked when reflectively instantiating
the JSerializer (also possible with empty constructor).Inet.SocketOption
to enable or disable SO_KEEPALIVE
Inet.SocketOption
to enable or disable SO_KEEPALIVE
ActorSystem.eventStream
.
SupervisorStrategy.loggingEnabled()
is true
.
true
.
FSM
which adds a rolling event log and
debug logging capabilities (analogous to LoggingReceive
).Logging
’s apply
/create
method.FSM.Failure
is logged at error level and other reason
types are not logged.
LookupClassification
E is the Event type
S is the Subscriber type
C is the Classifier typeDeploy
instance.
ActorSystem
with one
top level application supervisor actor.ActorSystem
with one
top level application supervisor actor.PFBuilder
with a case statement added.
PFBuilder
with a case statement added.
PartialFunction
that can be built during
runtime from Java.PFBuilder
with the first
case statement added.
PFBuilder
with the first
case statement added.
UnitPFBuilder
with a case statement added.
UnitPFBuilder
with a case statement added.
UnitPFBuilder
with the first
case statement added.
UnitPFBuilder
with the first
case statement added.
PFBuilder
with a case statement added.
PFBuilder
with the first
case statement added.
UnitPFBuilder
with a case statement added.
UnitPFBuilder
with the first
case statement added.
FSMStateFunctionBuilder
with the first case statement set.
UnitPFBuilder
with the first case statement set.
UnitPFBuilder
with the first case statement set.
PFBuilder
with the first
case statement added.
UnitPFBuilder
with a case statement added.
UnitPFBuilder
with a case statement added.
UnitPFBuilder
with the first
case statement added.
UnitPFBuilder
with the first
case statement added.
FSMStateFunctionBuilder
with the first case statement set.
FSMStateFunctionBuilder
with the first case statement set.
FSMStateFunctionBuilder
with the first case statement set.
FSMStateFunctionBuilder
with the first case statement set.
FSMStateFunctionBuilder
with the first case statement set.
FSMStateFunctionBuilder
with the first case statement set.
FSMStateFunctionBuilder
with the first case statement set.
FSMStateFunctionBuilder
with the first case statement set.
FSMStateFunctionBuilder
with the first case statement set.
FSMTransitionHandlerBuilder
with the first case statement set.
FSMTransitionHandlerBuilder
with the first case statement set.
FSMStopBuilder
with the first case statement set.
FSMStopBuilder
with the first case statement set.
FSMStopBuilder
with the first case statement set.
akka.event.slf4j.Slf4jLogger
is configured.
Tcp.WriteCommand
can optionally request a positive acknowledgment to be sent
to the commanding actor.
Tcp.NoAck
instance which is used when no acknowledgment information is
explicitly provided.
Tcp.WriteCommand
can optionally request a positive acknowledgment to be sent
to the commanding actor.
Tcp.NoAck
instance which is used when no acknowledgment information is
explicitly provided.
UdpConnected.Send
can optionally request a positive acknowledgment to be sent
to the commanding actor.
UdpConnected.NoAck
instance which is used when no acknowledgment information is
explicitly provided.
UdpConnected.Send
can optionally request a positive acknowledgment to be sent
to the commanding actor.
UdpConnected.NoAck
instance which is used when no acknowledgment information is
explicitly provided.
Udp.Send
can optionally request a positive acknowledgment to be sent
to the commanding actor.
Udp.NoAck
instance which is used when no acknowledgment information is
explicitly provided.
Udp.Send
can optionally request a positive acknowledgment to be sent
to the commanding actor.
Udp.NoAck
instance which is used when no acknowledgment information is
explicitly provided.
Option
factory that creates None
Option
factory that creates None
stop()
.
Routee
that doesn't send the message to any routee.Routee
that doesn't send the message to any routee.ActorRef.tell(java.lang.Object, akka.actor.ActorRef)
if there is not actor to
reply to (e.g.
ActorRef.tell(java.lang.Object, akka.actor.ActorRef)
if there is not actor to
reply to (e.g.
whenUnhandled
and onTermination
handlers.
whenUnhandled
and onTermination
handlers.
Directive
(Resume, Restart, Stop) specified in the Decider
to the child actor that failed, as opposed to AllForOneStrategy
that applies
it to all children.Inet.SocketOption
to enable or disable OOBINLINE (receipt
of TCP urgent data) By default, this option is disabled and TCP urgent
data is silently discarded.
Inet.SocketOption
to enable or disable OOBINLINE (receipt
of TCP urgent data) By default, this option is disabled and TCP urgent
data is silently discarded.
Option
factory that creates None
if
v
is null
, Some(v)
otherwise.
Option
factory that creates None
if
v
is null
, Some(v)
otherwise.
Some[A]
represents existing values of type
A
.PartialFunction
.PinnedDispatcher
.Future
to send
the result to the given ActorRef
or ActorSelection
.
Future
to send
the result to the given ActorRef
or ActorSelection
.
pipeTo
method on Future
:
RouterConfig
for router actor that creates routees as child actors and removes
them from the router if they terminate.Pool
preStart()
.
preStart()
.
preStart()
.
others
to this stash.
Write
or WriteFile
to form
a CompoundWrite
.
postStop()
.'''
postStop()
.'''
postStop()
.'''
router
is initalized but before super.start()
to
be able to do extra initialization in subclass.
Props
for a group router based on the settings defined by
this instance.
Props
for a group router based on the settings defined by
this instance.
Props
for a pool router based on the settings defined by
this instance and the supplied Props
for the routees created by the
router.
n
least significant bytes of the given Long to this builder.
rampupRate
.
become
to change this.
receiver
actor.
Inet.SocketOption
to set the SO_RCVBUF option
Inet.SocketOption
to set the SO_RCVBUF option
Actor.receive()
.DynamicAccess
implementation used by ExtendedActorSystem
unless overridden.register
Tcp.Connected
message.
register(handler, false, false)
.
Tcp.Connected
message.
register(handler, false, false)
.
MessageDispatcherConfigurator
that will be
used by Dispatchers.lookup(java.lang.String)
and Dispatchers.hasDispatcher(java.lang.String)
instead of looking
up the configurator from the system configuration.
ActorRefRoutee
for the specified
ActorRef
.
ActorSelectionRoutee
for the specified
ActorSelection
.
Router
.
value
.
Resizer
to use.
Pool
routers with dynamically resizable number of routees are implemented by providing a Resizer
implementation in the Pool
configuration.ActorRef
matching this selection.
ActorRef
matching this selection.
suspend
is called,
if it isn't currently suspended, it is a no-op.
Tcp.SuspendReading
command in order to resume reading from the socket.
Tcp.SuspendReading
command in order to resume reading from the socket.
UdpConnected.SuspendReading
command.
UdpConnected.SuspendReading
command.
Udp.SuspendReading
command.
Udp.SuspendReading
command.
useResumeWriting
is in effect as was indicated in the Tcp.Register
message
then this command needs to be sent to the connection actor in order to re-enable
writing after a Tcp.CommandFailed
event.
useResumeWriting
is in effect as was indicated in the Tcp.Register
message
then this command needs to be sent to the connection actor in order to re-enable
writing after a Tcp.CommandFailed
event.
Inet.SocketOption
to enable or disable SO_REUSEADDR
Inet.SocketOption
to enable or disable SO_REUSEADDR
Routee
selected by the RoutingLogic
.
Router
.Router.route(java.lang.Object, akka.actor.ActorRef)
method the
RoutingLogic
decides to which Routee
to send the message.Deploy
instance.
Router
to select
destination routed messages.ScanningClassification
E is the Event type
S is the Subscriber type
C is the Classifier typeDeploy
serves two purposes: as a marker for
pattern matching the “scope” (i.e.receiver
actor.
Udp.SimpleSender
query to the UdpExt.manager()
as well as by
the listener actors which are created in response to Udp.Bind
.
send(payload, target, noAck())
.
Udp.SimpleSender
query to the UdpExt.manager()
as well as by
the listener actors which are created in response to Udp.Bind
.
send(payload, target, noAck())
.
Inet.SocketOption
to set the SO_SNDBUF option.
Inet.SocketOption
to set the SO_SNDBUF option.
Seq
of Cause-Directive pairs to a Decider
.
Seq
of Throwables to a Decider
.
Seq
of Throwables to a Decider
.
Futures$.traverse(java.lang.Iterable, akka.japi.Function>, scala.concurrent.ExecutionContext)
.
Futures.traverse(java.lang.Iterable, akka.japi.Function>, scala.concurrent.ExecutionContext)
.
ExecutionContext
allows to wrap an underlying ExecutionContext
and provide guaranteed serial execution
of tasks submitted to it.DynamicAccess
.
ReceiveTimeout
message is triggered.
Routee
that sends each message to all routees
.system.stop(fsm)
from outside;
also applies to Stop
supervision directive.
Option
factory that creates Some
Option
factory that creates Some
Stash
trait enables an actor to temporarily stash away messages that can not or
should not be handled using the actor's current behavior.ActorRef
; this is
an asynchronous operation, i.e.
FSM.Reason
.
SubchannelClassification
E is the Event type
S is the Subscriber type
C is the Classifier type/user
).DeadLetter
with the slight twist of NOT being logged by the default dead letters listener.resume
is called,
this operation is idempotent.
Udp.Bound
message) to
have it stop reading datagrams from the network.
Udp.Bound
message) to
have it stop reading datagrams from the network.
Udp.Bound
message) to
have it stop reading datagrams from the network.
Udp.Bound
message) to
have it stop reading datagrams from the network.
akka.actor.Guardian.TerminationHook
before systemGuardian is stopped.interval
and then send to a second, random picked, and so on till one full cycle..interval
and then send to a second, random picked, and so on till one full cycle..interval
and then send to a second, random picked, and so on till one full cycle.Abort
command.TcpExt.manager()
in order to bind to a listening socket.Tcp.Bind
command will—in case of success—receive confirmation
in this form.Close
command.ConfirmedClose
command.TcpExt.manager()
.Tcp.Connect
command (for outbound) or to the handler for incoming connections designated
in the Tcp.Bind
message.Tcp.WriteCommand
and Tcp.Event
.Tcp.WriteCommand
can optionally request a positive acknowledgment to be sent
to the commanding actor.Tcp.NoAck
instance which is used when no acknowledgment information is
explicitly provided.Tcp.Register
message.Tcp.Connected
message.SuspendReading
command in order to resume reading from the socket.useResumeWriting
is in effect as was indicated in the Tcp.Register
message
then this command needs to be sent to the connection actor in order to re-enable
writing after a Tcp.CommandFailed
event.Tcp.Write
and Tcp.WriteFile
.Inet.SocketOption
to enable or disable SO_KEEPALIVEInet.SocketOption
to enable or disable OOBINLINE (receipt
of TCP urgent data) By default, this option is disabled and TCP urgent
data is silently discarded.Inet.SocketOption
to enable or disable TCP_NODELAY
(disable or enable Nagle's algorithm)Tcp.Bound
message).Unbind
command will receive confirmation through this
message once the listening socket has been closed.Tcp.Write
, Tcp.WriteFile
and Tcp.CompoundWrite
.count
bytes starting at position
from file at filePath
to the connection.useResumeWriting
is in effect as indicated in the Tcp.Register
message,
the ResumeWriting
command will be acknowledged by this message type, upon
which it is safe to send at least one write.Inet.SocketOption
to enable or disable TCP_NODELAY
(disable or enable Nagle's algorithm)
Inet.SocketOption
to enable or disable TCP_NODELAY
(disable or enable Nagle's algorithm)
Inet.SocketOption
to set the traffic class or
type-of-service octet in the IP header for packets sent from this
socket.
Inet.SocketOption
to set the traffic class or
type-of-service octet in the IP header for packets sent from this
socket.
TypedActor.MethodCall
to the provided ActorRef.
UdpExt.manager()
in order to bind to the given
local port (or an automatically assigned one if the port number is zero).Udp.Bind
command.Udp.Command
and Udp.Event
.Udp.Send
can optionally request a positive acknowledgment to be sent
to the commanding actor.Udp.NoAck
instance which is used when no acknowledgment information is
explicitly provided.Udp.Bind
message using this message type.SuspendReading
command.Udp.SimpleSender
query to the UdpExt.manager()
as well as by
the listener actors which are created in response to Udp.Bind
.Udp.SimpleSender
query.Inet.SocketOption
to set the SO_BROADCAST optionUdp.Bound
message) to
have it stop reading datagrams from the network.Udp.Bound
message in order to close the listening socket.Unbind
command
after the socket has been closed.UdpExt.manager()
in order to bind to a local
port (optionally with the chosen localAddress
) and create a UDP socket
which is restricted to sending to and receiving from the given remoteAddress
.UdpConnected.Connect
message when the UDP socket has been bound to the local and
remote addresses given.UdpConnected.Connected
message) in order to close the socket.Disconnect
message when the UDP socket has been closed.UdpConnected.Command
and UdpConnected.Event
.UdpConnected.Send
can optionally request a positive acknowledgment to be sent
to the commanding actor.UdpConnected.NoAck
instance which is used when no acknowledgment information is
explicitly provided.Udp.Bind
message using this message type.SuspendReading
command.Udp.Bound
message) to
have it stop reading datagrams from the network.Tcp.Bound
message).
Tcp.Bound
message).
Udp.Bound
message in order to close the listening socket.
Udp.Bound
message in order to close the listening socket.
UnboundedStash
trait is a version of Stash
that enforces an unbounded stash for you actor.UntypedActor.onReceive(java.lang.Object)
(e.g.
PartialFunction
that can be built during
runtime from Java.PartialFunction
.Stash
that does not enforce any mailbox type.Stash
that enforces an unbounded deque for the actor.Stash
that does not enforce any mailbox type.Tcp.SimpleWriteCommand.ack()
token not being a of type Tcp.NoAck
.
Terminated
message
it will be propagated to user's receive.
preRestart
action with the supplied function.
postRestart
action with the supplied function.
preStart
action with the supplied thunk.
postStop
action with the supplied thunk.
Deploy
instances using
withFallback()
on
the left one, this is propagated to “merging” scopes in the same way.
this
(i.e.
" in state " + label
to each message it logs.
" in state " + label
to each message it logs.
RoutingLogic
.
uid
.
ConsistentHash
write(data, noAck())
.
write(data, noAck())
.
count
bytes starting at position
from file at filePath
to the connection.
count
bytes starting at position
from file at filePath
to the connection.
|
|||||||||
PREV NEXT | FRAMES NO FRAMES |