module Uq_engines:sig..end
Unixqueue.event_system, and do their task by
 generating events for resources of the operating system, and 
 by handling such events. Engines are in one of four states: They
 may be still working, they may be done, they may be
 aborted, or they may be in an error state. The three latter
 states a called final states, because they indicate that the
 engine has stopped operation.
It is possible to ask an engine to notify another object when it changes its state. For simplicity, notification is done by invoking a callback function, and not by issuing notification events.
 Effectively, engines provide a calculus for cooperative microthreading.
 This calculus includes combinators for sequential execution and
 synchronization. Moreover, it is easy to connect it with callback-style
 microthreading - one can arrange callbacks when an engine is done, and
 one can catch callbacks and turn them into engines.
exception Closed_channel
 This exception should be regarded as equivalent to
 Netchannels.Closed_channel, but need not be the same exception.
exception Broken_communication
 This exception is not raised, but used as argument of the `Error
 state.
exception Watchdog_timeout
 This exception is not raised, but used as argument of the `Error
 state.
exception Timeout
input_engine and output_engine to indicate timeoutsexception Addressing_method_not_supported
client_endpoint_connector and server_endpoint_acceptor to
 indicate that the passed address is not supported by the class.exception Cancelled
multiplex_controller is invoked with this
 exception if the operation is cancelled.type'tengine_state =[ `Aborted | `Done of 't | `Error of exn | `Working of int ]
't:`Working n: The engine is working. The number n counts the number
   of events that have been processed.`Done arg: The engine has completed its task without errors. 
   The argument arg is the result value of the engine`Error exn: The engine has aborted because of an error. The
   argument exn describes the error as an exception.`Aborted: The engine has aborted because the abort method
   was calledtype'tfinal_state =[ `Aborted | `Done of 't | `Error of exn ]
engine_state without `Working. These are only the final
	states.val string_of_state : 'a engine_state -> stringclass type['t]engine =object..end
class['t]delegate_engine :'t #engine ->['t]engine
val when_state : ?is_done:('a -> unit) ->
       ?is_error:(exn -> unit) ->
       ?is_aborted:(unit -> unit) ->
       ?is_progressing:(int -> unit) -> 'a #engine -> unitwhen_state only observes future state changes.
 If one of the functions raises an exception, this exception is
 propagated to the caller of Unixqueue.run.
is_done : The state transitions to `Done. The argument of
   is_done is the argument of the `Done state.is_error : The state transitions to `Error. The argument of
   is_error is the argument of the `Error state.is_aborted : The state transitions to `Aborted.is_progressing : This function is called when the `Working
   state changes. The int argument is the new `Working arg.class['a]signal_engine :Unixqueue.event_system ->object..end
let se = new signal_engine esys: The engine se remains in
      `Working 0 until the method se # signal x is called.
val signal_engine : Unixqueue.event_system ->
       'a engine * ('a final_state -> unit)let (se, signal) = signal_engine esys: Same as functionclass[['a, 'b]]map_engine :map_done:('a -> 'b engine_state) -> ?map_error:exn -> 'b engine_state -> ?map_aborted:unit -> 'b engine_state -> ?propagate_working:bool -> 'a #engine ->['b]engine
map_engine observes the argument engine, and when the
 state changes to `Done, `Error, or `Aborted, the corresponding
 mapping function is called, and the resulting state becomes the state
 of the mapped engine.
val map_engine : map_done:('a -> 'b engine_state) ->
       ?map_error:(exn -> 'b engine_state) ->
       ?map_aborted:(unit -> 'b engine_state) ->
       ?propagate_working:bool -> 'a #engine -> 'b engineclass[['a, 'b]]fmap_engine :'a #engine -> ('a final_state -> 'b final_state) ->['b]engine
map_engine but different calling conventions: The
      mapping function is called when the argument engine reaches a
      final state, and this state can be mapped to another final state.
val fmap_engine : 'a #engine ->
       ('a final_state -> 'b final_state) ->
       'b engine
      After opening Uq_engines.Operators, this is also available
      as operator >>, e.g.
 
         e >>
           (function
             | `Done r -> ...
             | `Error error -> ...
             | `Aborted -> ...
           )
       class['a]meta_engine :'a #engine ->['a final_state]engine
s to `Done s
val meta_engine : 'a #engine -> 'a final_state engineclass['t]epsilon_engine :'t engine_state -> Unixqueue.event_system ->['t]engine
`Working 0 in one
 step ("epsilon time") to the passed constant state.
val epsilon_engine : 't engine_state -> Unixqueue.event_system -> 't engineclass[['a, 'b]]seq_engine :'a #engine -> ('a -> 'b #engine) ->['b]engine
val seq_engine : 'a #engine ->
       ('a -> 'b #engine) -> 'b engine
 After opening Uq_engines.Operators, this is also available
 as operator ++, e.g.
 
 e1 ++ (fun r1 -> e2) e1 and e2 are engines, and r1 is the result of e1).class[['a, 'b]]qseq_engine :'a #engine -> ('a -> 'b #engine) ->['b]engine
val qseq_engine : 'a #engine ->
       ('a -> 'b #engine) -> 'b engineseq_engine, but this version does not
      propagate working state (i.e. no progress reporting).
      qseq_engine should be preferred for recursive chains of engines.
class['a]stream_seq_engine :'a -> ('a -> 'a #engine) Stream.t -> Unixqueue.event_system ->['a]engine
let se = new stream_seq_engine x0 s esys: The constructed engine se
 fetches functions f : 'a -> 'a #engine from the stream s, and
 runs the engines obtained by calling these functions e = f x one
 after the other.
val stream_seq_engine : 'a ->
       ('a -> 'a #engine) Stream.t ->
       Unixqueue.event_system -> 'a engineclass[['a, 'b]]sync_engine :'a #engine -> 'b #engine ->[('a * 'b)]engine
`Done (synchronization).
val sync_engine : 'a #engine -> 'b #engine -> ('a * 'b) engineclass[['a, 'b]]msync_engine :'a #engine list -> ('a -> 'b -> 'b) -> 'b -> Unixqueue.event_system ->['b]engine
let me = new msync_engine el f x0 esys - Runs the engines in el in
      parallel, and waits until all are `Done.
val msync_engine : 'a #engine list ->
       ('a -> 'b -> 'b) -> 'b -> Unixqueue.event_system -> 'b engineclass['a]delay_engine :float -> (unit -> 'a #engine) -> Unixqueue.event_system ->['a]engine
let de = delay_engine d f esys: The engine e = f() is created
      after d seconds, and the result of e becomes the result of de.
val delay_engine : float ->
       (unit -> 'a #engine) ->
       Unixqueue.event_system -> 'a engineclass['a]timeout_engine :float -> exn -> 'a engine ->['a]engine
timeout_engine d x e: If the engine e finishes within d
      seconds, the result remains unchanged.
val timeout_engine : float -> exn -> 'a engine -> 'a engineclass watchdog :float -> 'a #engine ->[unit]engine
`Error Watchdog_timeout.
val watchdog : float -> 'a #engine -> unit engineclass type['a]serializer_t =object..end
class['a]serializer :Unixqueue.event_system ->['a]serializer_t
val serializer : Unixqueue.event_system -> 'a serializer_tclass type['a]prioritizer_t =object..end
p can be executed.
class['a]prioritizer :Unixqueue.event_system ->['a]prioritizer_t
val prioritizer : Unixqueue.event_system -> 'a prioritizer_tclass type['a]cache_t =object..end
class['a]cache :(Unixqueue.event_system -> 'a engine) -> Unixqueue.event_system ->['a]cache_t
new cache f esys: A cache that runs f esys to obtain values
val cache : (Unixqueue.event_system -> 'a engine) ->
       Unixqueue.event_system -> 'a cache_tclass['t]engine_mixin :'t engine_state -> Unixqueue.event_system ->object..end
state and 
 request_notification.
module Operators:sig..end
++, >>, and eps_e
class poll_engine :?extra_match:exn -> bool -> (Unixqueue.operation * float) list -> Unixqueue.event_system ->object..end
class['a]input_engine :(Unix.file_descr -> 'a) -> Unix.file_descr -> float -> Unixqueue.event_system ->['a]engine
let e = new input_engine f fd tmo - Waits until the file descriptor
      becomes readable, and calls then let x = f fd to read from the
      descriptor.
class['a]output_engine :(Unix.file_descr -> 'a) -> Unix.file_descr -> float -> Unixqueue.event_system ->['a]engine
let e = new output_engine f fd tmo - Waits until the file descriptor
      becomes writable, and calls then let x = f fd to write to the
      descriptor.
class poll_process_engine :?period:float -> pid:int -> Unixqueue.event_system ->[Unix.process_status]engine
Shell_uq instead.
    The module Uq_io provides a bunch of functions to read and write
    data via various "devices". All these functions return engines, and
    are easy to use. Devices can be file descriptors, but also other
    data structures. In particular, there is also support for buffered I/O
    and for reading line-by-line from an input device.
      open Uq_engines.Operators  (* for ">>" and "++" *)
      let fd = 
        Unix.openfile filename [Unix.O_RDONLY] 0 in
      let d = 
        `Buffer_in(Uq_io.create_in_buffer(`Polldescr(`Read_write,fd,esys))) in
      let rec read_lines acc =
        Uq_io.input_line_e d >>
          (function                       (* catch exception End_of_file *)
            | `Done line -> `Done(Some line)
            | `Error End_of_file -> `Done None
            | `Error error -> `Error error
            | `Aborted -> `Aborted
          ) ++
          (function
            | Some line ->
                read_lines (line :: acc)
            | None ->
                eps_e (`Done (List.rev acc)) esys
          ) in
      let e = read_lines []
    There is generally the question whether this style leads to stack overflows. This depends on the mechanisms that come into play:
Also note another difference: The event queue mechanism allows that other asynchronous code attached to the same event queue may run (control maybe yielded to unrelated execution contexts). The pure engine mechanism does not allow that. This may be handy when exclusive access to variables is needed. (But be careful here - this is very sensitive to minimal changes of the implementation.)
    Certain engines enforce using the event queue mechanisms although they
    are unrelated to I/O. Especially Uq_engines.delay_engine is
    useful here: A "delay" of 0 seconds is already sufficient to
    go back to the event queue. If recursions sometimes lead to
    stack overflows the solution is to include such a zero delay
    before doing the self call.
Uq_clientUq_serverUq_multiplexUq_transferUq_datagramUq_ioRpc_proxy.ManagedClient.rpc_engine allows
    to call an RPC via an engine. When the call is done, the engine transitions
    to `Done r, and r is the result of the remote call.Shell_uq.call_engine allows to start an
    external program, and to monitor it via an engine.Uq_engines_compat.class type async_out_channel =object..end
Uq_transfer.async_out_channel
class type async_in_channel =object..end
Uq_transfer.async_in_channel
class type async_out_channel_engine =object..end
Uq_transfer.async_out_channel_engine
typecopy_task =[ `Bidirectional of Unix.file_descr * Unix.file_descr
| `Tridirectional of Unix.file_descr * Unix.file_descr * Unix.file_descr
| `Uni_socket of Unix.file_descr * Unix.file_descr
| `Unidirectional of Unix.file_descr * Unix.file_descr ]
Uq_transfer.copy_taskclass type async_in_channel_engine =object..end
Uq_transfer.async_in_channel_engine
class type multiplex_controller =object..end
Uq_multiplex.multiplex_controller
exception Mem_not_supported
Uq_multiplex.Mem_not_supportedclass type datagram_multiplex_controller =object..end
typeonshutdown_out_spec =[ `Action of
async_out_channel_engine ->
multiplex_controller -> unit engine_state -> unit
| `Ignore
| `Initiate_shutdown ]
Uq_transfer.onshutdown_out_spectypeonshutdown_in_spec =[ `Action of
async_in_channel_engine ->
multiplex_controller -> unit engine_state -> unit
| `Ignore
| `Initiate_shutdown ]
Uq_transfer.onshutdown_in_spectypeinetspec =[ `Sock_inet of Unix.socket_type * Unix.inet_addr * int
| `Sock_inet_byname of Unix.socket_type * string * int ]
Uq_client.inetspectypesockspec =[ `Sock_inet of Unix.socket_type * Unix.inet_addr * int
| `Sock_inet_byname of Unix.socket_type * string * int
| `Sock_unix of Unix.socket_type * string ]
Uq_client.sockspectypeconnect_address =[ `Command of string * (int -> Unixqueue.event_system -> unit)
| `Socket of sockspec * connect_options
| `W32_pipe of Netsys_win32.pipe_mode * string ]
Uq_client.connect_addresstype |    | conn_bind :  | (* | Bind the connecting socket to this address (same family as the
 connected socket required). None: Use an anonymous port. | *) | 
typeconnect_status =[ `Command of Unix.file_descr * int
| `Socket of Unix.file_descr * sockspec
| `W32_pipe of Unix.file_descr ]
Uq_client.connect_statusclass type client_endpoint_connector =object..end
Uq_client.client_endpoint_connector
typelisten_address =[ `Socket of sockspec * listen_options
| `W32_pipe of Netsys_win32.pipe_mode * string * listen_options ]
Uq_server.listen_addresstype |    | lstn_backlog :  | 
|    | lstn_reuseaddr :  | 
class type server_endpoint_acceptor =object..end
Uq_server.server_endpoint_acceptor
class type server_endpoint_listener =object..end
Uq_server.server_endpoint_listener
typedatagram_type =[ `Inet6_udp | `Inet_udp | `Unix_dgram ]
Uq_datagram.datagram_typeclass type wrapped_datagram_socket =object..end
Uq_datagram.datagram_type
class type datagram_socket_provider =object..end
Uq_datagram.datagram_type
module Debug:sig..end