| 123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785786787788789790791792793794795796797798799800801802803804805806807808809810811812813814815816817818819820821822823824825826827828829830831832833834835836837838839840841842843844845846847848849850851852853854855856857858859860861862863864865866867868869870871872873874875876877878879880881882883884885886887888889890891892893894895896897898899900901902903904905906907908909910911912913914915916917918919920921922923924925926927928929930931932933934935936937938939940941942943944945946947948949950951952953954955956957958959960961962963964965966967968969970971972973974975976977978979980981982983984985986987988989990991992993994995996997998999100010011002100310041005100610071008100910101011101210131014101510161017101810191020102110221023102410251026102710281029103010311032103310341035103610371038103910401041104210431044104510461047104810491050105110521053105410551056105710581059106010611062106310641065106610671068106910701071107210731074107510761077107810791080108110821083108410851086108710881089109010911092109310941095109610971098109911001101110211031104110511061107110811091110111111121113111411151116111711181119112011211122112311241125112611271128112911301131113211331134113511361137113811391140114111421143114411451146114711481149115011511152115311541155115611571158115911601161116211631164116511661167116811691170117111721173117411751176117711781179118011811182118311841185118611871188118911901191119211931194119511961197119811991200120112021203120412051206120712081209121012111212121312141215121612171218121912201221122212231224122512261227122812291230123112321233123412351236123712381239124012411242124312441245124612471248124912501251125212531254125512561257125812591260126112621263126412651266126712681269127012711272127312741275127612771278127912801281128212831284128512861287128812891290129112921293129412951296129712981299130013011302130313041305130613071308130913101311131213131314131513161317131813191320132113221323132413251326132713281329133013311332133313341335133613371338133913401341134213431344134513461347134813491350135113521353135413551356135713581359136013611362136313641365136613671368136913701371137213731374137513761377137813791380138113821383138413851386138713881389139013911392139313941395139613971398139914001401140214031404140514061407140814091410141114121413141414151416141714181419142014211422142314241425142614271428142914301431143214331434143514361437143814391440144114421443144414451446144714481449145014511452145314541455145614571458145914601461146214631464146514661467146814691470147114721473147414751476147714781479148014811482148314841485148614871488148914901491149214931494149514961497149814991500150115021503150415051506150715081509151015111512151315141515151615171518151915201521152215231524152515261527152815291530153115321533153415351536153715381539154015411542154315441545154615471548154915501551155215531554155515561557155815591560156115621563156415651566156715681569157015711572157315741575157615771578157915801581158215831584158515861587158815891590159115921593159415951596159715981599160016011602160316041605160616071608160916101611161216131614161516161617161816191620162116221623162416251626162716281629163016311632163316341635163616371638163916401641164216431644164516461647164816491650165116521653165416551656165716581659166016611662166316641665166616671668166916701671167216731674167516761677167816791680168116821683168416851686168716881689169016911692169316941695169616971698169917001701170217031704170517061707170817091710171117121713171417151716171717181719172017211722172317241725172617271728172917301731173217331734173517361737173817391740174117421743174417451746174717481749175017511752175317541755175617571758175917601761176217631764176517661767176817691770177117721773177417751776177717781779178017811782178317841785178617871788178917901791179217931794179517961797179817991800180118021803180418051806180718081809181018111812181318141815181618171818181918201821182218231824182518261827182818291830183118321833183418351836183718381839184018411842184318441845184618471848184918501851185218531854185518561857185818591860186118621863186418651866186718681869187018711872187318741875187618771878187918801881188218831884188518861887188818891890189118921893189418951896189718981899190019011902190319041905190619071908190919101911191219131914191519161917191819191920192119221923192419251926192719281929193019311932193319341935193619371938193919401941194219431944194519461947194819491950195119521953195419551956195719581959196019611962196319641965196619671968196919701971197219731974197519761977197819791980198119821983198419851986198719881989199019911992199319941995199619971998199920002001200220032004200520062007200820092010201120122013201420152016201720182019202020212022202320242025202620272028202920302031203220332034203520362037203820392040204120422043204420452046204720482049205020512052205320542055205620572058205920602061206220632064206520662067206820692070207120722073207420752076207720782079208020812082208320842085208620872088208920902091209220932094209520962097209820992100210121022103210421052106210721082109211021112112211321142115211621172118211921202121212221232124212521262127212821292130213121322133213421352136213721382139214021412142214321442145214621472148214921502151215221532154215521562157215821592160216121622163216421652166216721682169217021712172217321742175217621772178217921802181218221832184218521862187218821892190219121922193219421952196219721982199220022012202220322042205220622072208220922102211221222132214221522162217221822192220222122222223222422252226222722282229223022312232223322342235223622372238223922402241224222432244224522462247224822492250225122522253225422552256225722582259226022612262226322642265226622672268226922702271227222732274227522762277227822792280228122822283228422852286228722882289229022912292229322942295229622972298229923002301230223032304230523062307230823092310231123122313231423152316231723182319232023212322232323242325232623272328232923302331233223332334233523362337233823392340234123422343234423452346234723482349235023512352235323542355235623572358235923602361236223632364236523662367236823692370237123722373237423752376237723782379238023812382238323842385238623872388238923902391239223932394239523962397239823992400240124022403240424052406240724082409241024112412241324142415241624172418241924202421242224232424242524262427242824292430243124322433243424352436243724382439244024412442244324442445244624472448244924502451245224532454245524562457245824592460246124622463246424652466246724682469247024712472247324742475247624772478247924802481248224832484248524862487248824892490249124922493249424952496249724982499250025012502250325042505250625072508250925102511251225132514251525162517251825192520252125222523252425252526252725282529253025312532253325342535253625372538253925402541254225432544254525462547254825492550255125522553255425552556255725582559256025612562256325642565256625672568256925702571257225732574257525762577257825792580258125822583258425852586258725882589259025912592259325942595259625972598259926002601260226032604260526062607260826092610261126122613261426152616261726182619262026212622262326242625262626272628262926302631263226332634263526362637263826392640264126422643264426452646264726482649265026512652265326542655265626572658265926602661266226632664266526662667266826692670267126722673267426752676267726782679268026812682268326842685268626872688268926902691269226932694269526962697269826992700270127022703270427052706270727082709271027112712271327142715271627172718271927202721272227232724272527262727272827292730273127322733273427352736273727382739274027412742274327442745274627472748274927502751275227532754275527562757275827592760276127622763276427652766276727682769277027712772277327742775277627772778277927802781278227832784278527862787278827892790279127922793279427952796279727982799280028012802280328042805280628072808280928102811281228132814281528162817281828192820282128222823282428252826282728282829283028312832283328342835283628372838283928402841284228432844284528462847284828492850285128522853285428552856285728582859286028612862286328642865286628672868286928702871287228732874287528762877287828792880288128822883288428852886288728882889289028912892289328942895289628972898289929002901290229032904290529062907290829092910291129122913291429152916291729182919292029212922292329242925 | //// Copyright (c) 2016-2019 Vinnie Falco (vinnie dot falco at gmail dot com)//// Distributed under the Boost Software License, Version 1.0. (See accompanying// file LICENSE_1_0.txt or copy at http://www.boost.org/LICENSE_1_0.txt)//// Official repository: https://github.com/boostorg/beast//#ifndef BOOST_BEAST_WEBSOCKET_STREAM_HPP#define BOOST_BEAST_WEBSOCKET_STREAM_HPP#include <boost/beast/core/detail/config.hpp>#include <boost/beast/websocket/error.hpp>#include <boost/beast/websocket/option.hpp>#include <boost/beast/websocket/rfc6455.hpp>#include <boost/beast/websocket/stream_base.hpp>#include <boost/beast/websocket/stream_fwd.hpp>#include <boost/beast/websocket/detail/hybi13.hpp>#include <boost/beast/websocket/detail/impl_base.hpp>#include <boost/beast/websocket/detail/pmd_extension.hpp>#include <boost/beast/websocket/detail/prng.hpp>#include <boost/beast/core/role.hpp>#include <boost/beast/core/stream_traits.hpp>#include <boost/beast/core/string.hpp>#include <boost/beast/http/detail/type_traits.hpp>#include <boost/asio/async_result.hpp>#include <boost/asio/error.hpp>#include <boost/shared_ptr.hpp>#include <algorithm>#include <cstdint>#include <functional>#include <limits>#include <memory>#include <type_traits>#include <random>namespace boost {namespace beast {namespace websocket {/** The type of received control frame.    Values of this type are passed to the control frame    callback set using @ref stream::control_callback.*/enum class frame_type{    /// A close frame was received    close,    /// A ping frame was received    ping,    /// A pong frame was received    pong};namespace detail {class frame_test;} // detail//--------------------------------------------------------------------/** Provides message-oriented functionality using WebSocket.    The @ref stream class template provides asynchronous and blocking    message-oriented functionality necessary for clients and servers    to utilize the WebSocket protocol.    For asynchronous operations, the application must ensure    that they are are all performed within the same implicit    or explicit strand.    @par Thread Safety    @e Distinct @e objects: Safe.@n    @e Shared @e objects: Unsafe.    The application must also ensure that all asynchronous    operations are performed within the same implicit or explicit strand.    @par Example    To declare the @ref stream object with a @ref tcp_stream in a    multi-threaded asynchronous program using a strand, you may write:    @code    websocket::stream<tcp_stream> ws{net::make_strand(ioc)};    @endcode    Alternatively, for a single-threaded or synchronous application    you may write:    @code    websocket::stream<tcp_stream> ws(ioc);    @endcode    @tparam NextLayer The type representing the next layer, to which    data will be read and written during operations. For synchronous    operations, the type must support the <em>SyncStream</em> concept.    For asynchronous operations, the type must support the    <em>AsyncStream</em> concept.    @tparam deflateSupported A `bool` indicating whether or not the    stream will be capable of negotiating the permessage-deflate websocket    extension. Note that even if this is set to `true`, the permessage    deflate options (set by the caller at runtime) must still have the    feature enabled for a successful negotiation to occur.    @note A stream object must not be moved or destroyed while there    are pending asynchronous operations associated with it.    @par Concepts        @li <em>AsyncStream</em>        @li <em>DynamicBuffer</em>        @li <em>SyncStream</em>    @see        @li <a href="https://tools.ietf.org/html/rfc6455#section-4.1">Websocket Opening Handshake Client Requirements (RFC6455)</a>        @li <a href="https://tools.ietf.org/html/rfc6455#section-4.2">Websocket Opening Handshake Server Requirements (RFC6455)</a>        @li <a href="https://tools.ietf.org/html/rfc6455#section-7.1.2">Websocket Closing Handshake (RFC6455)</a>        @li <a href="https://tools.ietf.org/html/rfc6455#section-5.5.1">Websocket Close (RFC6455)</a>        @li <a href="https://tools.ietf.org/html/rfc6455#section-5.5.2">WebSocket Ping (RFC6455)</a>        @li <a href="https://tools.ietf.org/html/rfc6455#section-5.5.3">WebSocket Pong (RFC6455)</a>        @li <a href="https://tools.ietf.org/html/rfc7230#section-5.4">Host field (RFC7230)</a>        @li <a href="https://tools.ietf.org/html/rfc7230#section-3.1.1">request-target (RFC7230)</a>        @li <a href="https://tools.ietf.org/html/rfc7230#section-5.3.1">origin-form (RFC7230)</a>*/template<    class NextLayer,    bool deflateSupported>class stream#if ! BOOST_BEAST_DOXYGEN    : private stream_base#endif{    struct impl_type;    boost::shared_ptr<impl_type> impl_;    using time_point = typename        std::chrono::steady_clock::time_point;    using control_cb_type =        std::function<void(frame_type, string_view)>;#ifndef BOOST_BEAST_DOXYGEN    friend class close_test;    friend class frame_test;    friend class ping_test;    friend class read2_test;    friend class read3_test;    friend class stream_test;    friend class write_test;    /*  The read buffer has to be at least as large        as the largest possible control frame including        the frame header.    */    static std::size_t constexpr max_control_frame_size = 2 + 8 + 4 + 125;    static std::size_t constexpr tcp_frame_size = 1536;#endif    static time_point never() noexcept    {        return (time_point::max)();    }public:    /// Indicates if the permessage-deflate extension is supported    using is_deflate_supported =        std::integral_constant<bool, deflateSupported>;    /// The type of the next layer.    using next_layer_type =        typename std::remove_reference<NextLayer>::type;    /// The type of the executor associated with the object.    using executor_type =        beast::executor_type<next_layer_type>;    /// Rebinds the stream type to another executor.    template<class Executor1>    struct rebind_executor    {        /// The stream type when rebound to the specified executor.        using other = stream<                typename next_layer_type::template rebind_executor<Executor1>::other,                deflateSupported>;    };    /** Destructor        Destroys the stream and all associated resources.        @note A stream object must not be destroyed while there        are pending asynchronous operations associated with it.    */    ~stream();    /** Constructor        If `NextLayer` is move constructible, this function        will move-construct a new stream from the existing stream.        After the move, the only valid operation on the moved-from        object is destruction.    */    stream(stream&&) = default;    /// Move assignment (deleted)    stream& operator=(stream&&) = delete;    /** Constructor        This constructor creates a websocket stream and initializes        the next layer object.        @throws Any exceptions thrown by the NextLayer constructor.        @param args The arguments to be passed to initialize the        next layer object. The arguments are forwarded to the next        layer's constructor.    */    template<class... Args>    explicit    stream(Args&&... args);    /** Rebinding constructor     *     *  This constructor creates a the websocket stream from a     *  websocket stream with a different executor.     *     *  @throw Any exception thrown by the NextLayer rebind constructor.     *     *  @param other The other websocket stream to construct from.     */    template<class Other>    explicit    stream(stream<Other> && other);    //--------------------------------------------------------------------------    /** Get the executor associated with the object.        This function may be used to obtain the executor object that the        stream uses to dispatch handlers for asynchronous operations.        @return A copy of the executor that stream will use to dispatch handlers.    */    executor_type    get_executor() noexcept;    /** Get a reference to the next layer        This function returns a reference to the next layer        in a stack of stream layers.        @return A reference to the next layer in the stack of        stream layers.    */    next_layer_type&    next_layer() noexcept;    /** Get a reference to the next layer        This function returns a reference to the next layer in a        stack of stream layers.        @return A reference to the next layer in the stack of        stream layers.    */    next_layer_type const&    next_layer() const noexcept;    //--------------------------------------------------------------------------    //    // Observers    //    //--------------------------------------------------------------------------    /** Returns `true` if the stream is open.        The stream is open after a successful handshake, and when        no error has occurred.    */    bool    is_open() const noexcept;    /** Returns `true` if the latest message data indicates binary.        This function informs the caller of whether the last        received message frame represents a message with the        binary opcode.        If there is no last message frame, the return value is        undefined.    */    bool    got_binary() const noexcept;    /** Returns `true` if the latest message data indicates text.        This function informs the caller of whether the last        received message frame represents a message with the        text opcode.        If there is no last message frame, the return value is        undefined.    */    bool    got_text() const    {        return ! got_binary();    }    /// Returns `true` if the last completed read finished the current message.    bool    is_message_done() const noexcept;    /** Returns the close reason received from the remote peer.        This is only valid after a read completes with error::closed.    */    close_reason const&    reason() const noexcept;    /** Returns a suggested maximum buffer size for the next call to read.        This function returns a reasonable upper limit on the number        of bytes for the size of the buffer passed in the next call        to read. The number is determined by the state of the current        frame and whether or not the permessage-deflate extension is        enabled.        @param initial_size A non-zero size representing the caller's        desired buffer size for when there is no information which may        be used to calculate a more specific value. For example, when        reading the first frame header of a message.    */    std::size_t    read_size_hint(        std::size_t initial_size = +tcp_frame_size) const;    /** Returns a suggested maximum buffer size for the next call to read.        This function returns a reasonable upper limit on the number        of bytes for the size of the buffer passed in the next call        to read. The number is determined by the state of the current        frame and whether or not the permessage-deflate extension is        enabled.        @param buffer The buffer which will be used for reading. The        implementation will query the buffer to obtain the optimum        size of a subsequent call to `buffer.prepare` based on the        state of the current frame, if any.    */    template<class DynamicBuffer#if ! BOOST_BEAST_DOXYGEN        , class = typename std::enable_if<            ! std::is_integral<DynamicBuffer>::value>::type#endif    >    std::size_t    read_size_hint(        DynamicBuffer& buffer) const;    //--------------------------------------------------------------------------    //    // Settings    //    //--------------------------------------------------------------------------#if BOOST_BEAST_DOXYGEN    /// Get the option value    template<class Option>    void    get_option(Option& opt);    /// Set the option value    template<class Option>    void    set_option(Option opt);#else    void set_option(decorator opt);#endif    /** Set the timeout option        @throws system_error on failure to reset the        timer.    */    void    set_option(timeout const& opt);    /// Get the timeout option    void    get_option(timeout& opt);    /** Set the permessage-deflate extension options        @throws invalid_argument if `deflateSupported == false`, and either        `client_enable` or `server_enable` is `true`.        @note        These settings should be configured before performing the WebSocket        handshake.    */    void    set_option(permessage_deflate const& o);    /// Get the permessage-deflate extension options    void    get_option(permessage_deflate& o);    /** Set the automatic fragmentation option.        Determines if outgoing message payloads are broken up into        multiple pieces.        When the automatic fragmentation size is turned on, outgoing        message payloads are broken up into multiple frames no larger        than the write buffer size.        The default setting is to fragment messages.        @param value A `bool` indicating if auto fragmentation should be on.        @par Example        Setting the automatic fragmentation option:        @code            ws.auto_fragment(true);        @endcode    */    void    auto_fragment(bool value);    /// Returns `true` if the automatic fragmentation option is set.    bool    auto_fragment() const;    /** Set the binary message write option.        This controls whether or not outgoing message opcodes        are set to binary or text. The setting is only applied        at the start when a caller begins a new message. Changing        the opcode after a message is started will only take effect        after the current message being sent is complete.        The default setting is to send text messages.        @param value `true` if outgoing messages should indicate        binary, or `false` if they should indicate text.        @par Example        Setting the message type to binary.        @code            ws.binary(true);        @endcode        */    void    binary(bool value);    /// Returns `true` if the binary message write option is set.    bool    binary() const;    /** Set a callback to be invoked on each incoming control frame.        Sets the callback to be invoked whenever a ping, pong,        or close control frame is received during a call to one        of the following functions:        @li @ref beast::websocket::stream::read        @li @ref beast::websocket::stream::read_some        @li @ref beast::websocket::stream::async_read        @li @ref beast::websocket::stream::async_read_some        Unlike completion handlers, the callback will be invoked        for each control frame during a call to any synchronous        or asynchronous read function. The operation is passive,        with no associated error code, and triggered by reads.        For close frames, the close reason code may be obtained by        calling the function @ref reason.        @param cb The function object to call, which must be        invocable with this equivalent signature:        @code        void        callback(            frame_type kind,       // The type of frame            string_view payload    // The payload in the frame        );        @endcode        The implementation type-erases the callback which may require        a dynamic allocation. To prevent the possibility of a dynamic        allocation, use `std::ref` to wrap the callback.        If the read operation which receives the control frame is        an asynchronous operation, the callback will be invoked using        the same method as that used to invoke the final handler.        @note Incoming ping and close frames are automatically        handled. Pings are responded to with pongs, and a close frame        is responded to with a close frame leading to the closure of        the stream. It is not necessary to manually send pings, pongs,        or close frames from inside the control callback.        Attempting to manually send a close frame from inside the        control callback after receiving a close frame will result        in undefined behavior.    */    void    control_callback(std::function<void(frame_type, string_view)> cb);    /** Reset the control frame callback.        This function removes any previously set control frame callback.    */    void    control_callback();    /** Set the maximum incoming message size option.        Sets the largest permissible incoming message size. Message        frame fields indicating a size that would bring the total        message size over this limit will cause a protocol failure.        The default setting is 16 megabytes. A value of zero indicates        a limit of the maximum value of a `std::uint64_t`.        @par Example        Setting the maximum read message size.        @code            ws.read_message_max(65536);        @endcode        @param amount The limit on the size of incoming messages.    */    void    read_message_max(std::size_t amount);    /// Returns the maximum incoming message size setting.    std::size_t    read_message_max() const;    /** Set whether the PRNG is cryptographically secure        This controls whether or not the source of pseudo-random        numbers used to produce the masks required by the WebSocket        protocol are of cryptographic quality. When the setting is        `true`, a strong algorithm is used which cannot be guessed        by observing outputs. When the setting is `false`, a much        faster algorithm is used.        Masking is only performed by streams operating in the client        mode. For streams operating in the server mode, this setting        has no effect.        By default, newly constructed streams use a secure PRNG.        If the WebSocket stream is used with an encrypted SSL or TLS        next layer, if it is known to the application that intermediate        proxies are not vulnerable to cache poisoning, or if the        application is designed such that an attacker cannot send        arbitrary inputs to the stream interface, then the faster        algorithm may be used.        For more information please consult the WebSocket protocol RFC.        @param value `true` if the PRNG algorithm should be        cryptographically secure.    */    void    secure_prng(bool value);    /** Set the write buffer size option.        Sets the size of the write buffer used by the implementation to        send frames. The write buffer is needed when masking payload data        in the client role, compressing frames, or auto-fragmenting message        data.        Lowering the size of the buffer can decrease the memory requirements        for each connection, while increasing the size of the buffer can reduce        the number of calls made to the next layer to write data.        The default setting is 4096. The minimum value is 8.        The write buffer size can only be changed when the stream is not        open. Undefined behavior results if the option is modified after a        successful WebSocket handshake.        @par Example        Setting the write buffer size.        @code            ws.write_buffer_bytes(8192);        @endcode        @param amount The size of the write buffer in bytes.    */    void    write_buffer_bytes(std::size_t amount);    /// Returns the size of the write buffer.    std::size_t    write_buffer_bytes() const;    /** Set the text message write option.        This controls whether or not outgoing message opcodes        are set to binary or text. The setting is only applied        at the start when a caller begins a new message. Changing        the opcode after a message is started will only take effect        after the current message being sent is complete.        The default setting is to send text messages.        @param value `true` if outgoing messages should indicate        text, or `false` if they should indicate binary.        @par Example        Setting the message type to text.        @code            ws.text(true);        @endcode    */    void    text(bool value);    /// Returns `true` if the text message write option is set.    bool    text() const;    /** Set the compress message write option.        This controls whether or not outgoing messages should be        compressed. The setting is only applied when        @li The template parameter `deflateSupported` is true        @li Compression is enable. This is controlled with `stream::set_option`        @li Client and server have negotiated permessage-deflate settings        @li The message is larger than `permessage_deflate::msg_size_threshold`        This function permits adjusting per-message compression.        Changing the opcode after a message is started will only take effect        after the current message being sent is complete.        The default setting is to compress messages whenever the conditions        above are true.        @param value `true` if outgoing messages should be compressed        @par Example        Disabling compression for a single message.        @code            ws.compress(false);            ws.write(net::buffer(s), ec);            ws.compress(true);        @endcode    */    void    compress(bool value);    /// Returns `true` if the compress message write option is set.    bool    compress() const;    /*        timer settings        * Timer is disabled        * Close on timeout            - no complete frame received, OR            - no complete frame sent        * Ping on timeout            - ping on no complete frame received                * if can't ping?    */    //--------------------------------------------------------------------------    //    // Handshaking (Client)    //    //--------------------------------------------------------------------------    /** Perform the WebSocket handshake in the client role.        This function is used to perform the        <a href="https://en.wikipedia.org/wiki/WebSocket#Protocol_handshake">WebSocket handshake</a>,        required before messages can be sent and received. During the handshake,        the client sends the Websocket Upgrade HTTP request, and the server        replies with an HTTP response indicating the result of the handshake.        The call blocks until one of the following conditions is true:        @li The request is sent and the response is received.        @li An error occurs.        The algorithm, known as a <em>composed operation</em>, is implemented        in terms of calls to the next layer's `read_some` and `write_some`        functions.        The handshake is successful if the received HTTP response        indicates the upgrade was accepted by the server, represented by a        <a href="https://tools.ietf.org/html/rfc7230#section-3.1.2">status-code</a>        of @ref beast::http::status::switching_protocols.        @param host The name of the remote host. This is required by        the HTTP protocol to set the "Host" header field.        @param target The request-target, in origin-form. The server may use the        target to distinguish different services on the same listening port.        @throws system_error Thrown on failure.        @par Example        @code        ws.handshake("localhost", "/");        @endcode        @see        @li <a href="https://tools.ietf.org/html/rfc6455#section-4.1">Websocket Opening Handshake Client Requirements (RFC6455)</a>        @li <a href="https://tools.ietf.org/html/rfc7230#section-5.4">Host field (RFC7230)</a>        @li <a href="https://tools.ietf.org/html/rfc7230#section-3.1.1">request-target (RFC7230)</a>        @li <a href="https://tools.ietf.org/html/rfc7230#section-5.3.1">origin-form (RFC7230)</a>    */    void    handshake(        string_view host,        string_view target);    /** Perform the WebSocket handshake in the client role.        This function is used to perform the        <a href="https://en.wikipedia.org/wiki/WebSocket#Protocol_handshake">WebSocket handshake</a>,        required before messages can be sent and received. During the handshake,        the client sends the Websocket Upgrade HTTP request, and the server        replies with an HTTP response indicating the result of the handshake.        The call blocks until one of the following conditions is true:        @li The request is sent and the response is received.        @li An error occurs.        The algorithm, known as a <em>composed operation</em>, is implemented        in terms of calls to the next layer's `read_some` and `write_some`        functions.        The handshake is successful if the received HTTP response        indicates the upgrade was accepted by the server, represented by a        <a href="https://tools.ietf.org/html/rfc7230#section-3.1.2">status-code</a>        of @ref beast::http::status::switching_protocols.        @param res The HTTP Upgrade response returned by the remote        endpoint. The caller may use the response to access any        additional information sent by the server. Note that the response object        referenced by this parameter will be updated as long as the stream has        received a valid HTTP response. If not (for example because of a communications        error), the response contents will be undefined except for the result() which        will bet set to 500, Internal Server Error.        @param host The name of the remote host. This is required by        the HTTP protocol to set the "Host" header field.        @param target The request-target, in origin-form. The server may use the        target to distinguish different services on the same listening port.        @throws system_error Thrown on failure.        @par Example        @code        response_type res;        ws.handshake(res, "localhost", "/");        std::cout << res;        @endcode        @see        @li <a href="https://tools.ietf.org/html/rfc6455#section-4.1">Websocket Opening Handshake Client Requirements (RFC6455)</a>        @li <a href="https://tools.ietf.org/html/rfc7230#section-5.4">Host field (RFC7230)</a>        @li <a href="https://tools.ietf.org/html/rfc7230#section-3.1.1">request-target (RFC7230)</a>        @li <a href="https://tools.ietf.org/html/rfc7230#section-5.3.1">origin-form (RFC7230)</a>    */    void    handshake(        response_type& res,        string_view host,        string_view target);    /** Perform the WebSocket handshake in the client role.        This function is used to perform the        <a href="https://en.wikipedia.org/wiki/WebSocket#Protocol_handshake">WebSocket handshake</a>,        required before messages can be sent and received. During the handshake,        the client sends the Websocket Upgrade HTTP request, and the server        replies with an HTTP response indicating the result of the handshake.        The call blocks until one of the following conditions is true:        @li The request is sent and the response is received.        @li An error occurs.        The algorithm, known as a <em>composed operation</em>, is implemented        in terms of calls to the next layer's `read_some` and `write_some`        functions.        The handshake is successful if the received HTTP response        indicates the upgrade was accepted by the server, represented by a        <a href="https://tools.ietf.org/html/rfc7230#section-3.1.2">status-code</a>        of @ref beast::http::status::switching_protocols.        @param host The name of the remote host. This is required by        the HTTP protocol to set the "Host" header field.        @param target The request-target, in origin-form. The server may use the        target to distinguish different services on the same listening port.        @param ec Set to indicate what error occurred, if any.        @par Example        @code        error_code ec;        ws.handshake("localhost", "/", ec);        @endcode        @see        @li <a href="https://tools.ietf.org/html/rfc6455#section-4.1">Websocket Opening Handshake Client Requirements (RFC6455)</a>        @li <a href="https://tools.ietf.org/html/rfc7230#section-5.4">Host field (RFC7230)</a>        @li <a href="https://tools.ietf.org/html/rfc7230#section-3.1.1">request-target (RFC7230)</a>        @li <a href="https://tools.ietf.org/html/rfc7230#section-5.3.1">origin-form (RFC7230)</a>    */    void    handshake(        string_view host,        string_view target,        error_code& ec);    /** Perform the WebSocket handshake in the client role.        This function is used to perform the        <a href="https://en.wikipedia.org/wiki/WebSocket#Protocol_handshake">WebSocket handshake</a>,        required before messages can be sent and received. During the handshake,        the client sends the Websocket Upgrade HTTP request, and the server        replies with an HTTP response indicating the result of the handshake.        The call blocks until one of the following conditions is true:        @li The request is sent and the response is received.        @li An error occurs.        The algorithm, known as a <em>composed operation</em>, is implemented        in terms of calls to the next layer's `read_some` and `write_some`        functions.        The handshake is successful if the received HTTP response        indicates the upgrade was accepted by the server, represented by a        <a href="https://tools.ietf.org/html/rfc7230#section-3.1.2">status-code</a>        of @ref beast::http::status::switching_protocols.        @param res The HTTP Upgrade response returned by the remote        endpoint. The caller may use the response to access any        additional information sent by the server.        @param host The name of the remote host. This is required by        the HTTP protocol to set the "Host" header field.        @param target The request-target, in origin-form. The server may use the        target to distinguish different services on the same listening port.        @param ec Set to indicate what error occurred, if any.        @par Example        @code        error_code ec;        response_type res;        ws.handshake(res, "localhost", "/", ec);        if(! ec)            std::cout << res;        @endcode        @see        @li <a href="https://tools.ietf.org/html/rfc6455#section-4.1">Websocket Opening Handshake Client Requirements (RFC6455)</a>        @li <a href="https://tools.ietf.org/html/rfc7230#section-5.4">Host field (RFC7230)</a>        @li <a href="https://tools.ietf.org/html/rfc7230#section-3.1.1">request-target (RFC7230)</a>        @li <a href="https://tools.ietf.org/html/rfc7230#section-5.3.1">origin-form (RFC7230)</a>    */    void    handshake(        response_type& res,        string_view host,        string_view target,        error_code& ec);    /** Perform the WebSocket handshake asynchronously in the client role.        This initiating function is used to asynchronously begin performing the        <a href="https://en.wikipedia.org/wiki/WebSocket#Protocol_handshake">WebSocket handshake</a>,        required before messages can be sent and received. During the handshake,        the client sends the Websocket Upgrade HTTP request, and the server        replies with an HTTP response indicating the result of the handshake.        This call always returns immediately. The asynchronous operation        will continue until one of the following conditions is true:        @li The request is sent and the response is received.        @li An error occurs.        The algorithm, known as a <em>composed asynchronous operation</em>,        is implemented in terms of calls to the next layer's `async_read_some`        and `async_write_some` functions. No other operation may be performed        on the stream until this operation completes.        The handshake is successful if the received HTTP response        indicates the upgrade was accepted by the server, represented by a        <a href="https://tools.ietf.org/html/rfc7230#section-3.1.2">status-code</a>        of @ref beast::http::status::switching_protocols.        @param host The name of the remote host. This is required by        the HTTP protocol to set the "Host" header field.        The implementation will not access the string data after the        initiating function returns.        @param target The request-target, in origin-form. The server may use the        target to distinguish different services on the same listening port.        The implementation will not access the string data after the        initiating function returns.        @param handler The completion handler to invoke when the operation        completes. The implementation takes ownership of the handler by        performing a decay-copy. The equivalent function signature of        the handler must be:        @code        void handler(            error_code const& ec    // Result of operation        );        @endcode        If the handler has an associated immediate executor,        an immediate completion will be dispatched to it.        Otherwise, the handler will not be invoked from within        this function. Invocation of the handler will be performed        by dispatching to the immediate executor. If no        immediate executor is specified, this is equivalent        to using `net::post`.        @par Example        @code        ws.async_handshake("localhost", "/",            [](error_code ec)            {                if(ec)                    std::cerr << "Error: " << ec.message() << "\n";            });        @endcode        @see        @li <a href="https://tools.ietf.org/html/rfc6455#section-4.1">Websocket Opening Handshake Client Requirements (RFC6455)</a>        @li <a href="https://tools.ietf.org/html/rfc7230#section-5.4">Host field (RFC7230)</a>        @li <a href="https://tools.ietf.org/html/rfc7230#section-3.1.1">request-target (RFC7230)</a>        @li <a href="https://tools.ietf.org/html/rfc7230#section-5.3.1">origin-form (RFC7230)</a>    */    template<        BOOST_BEAST_ASYNC_TPARAM1 HandshakeHandler =            net::default_completion_token_t<executor_type>    >    BOOST_BEAST_ASYNC_RESULT1(HandshakeHandler)    async_handshake(        string_view host,        string_view target,        HandshakeHandler&& handler =            net::default_completion_token_t<                executor_type>{});    /** Perform the WebSocket handshake asynchronously in the client role.        This initiating function is used to asynchronously begin performing the        <a href="https://en.wikipedia.org/wiki/WebSocket#Protocol_handshake">WebSocket handshake</a>,        required before messages can be sent and received. During the handshake,        the client sends the Websocket Upgrade HTTP request, and the server        replies with an HTTP response indicating the result of the handshake.        This call always returns immediately. The asynchronous operation        will continue until one of the following conditions is true:        @li The request is sent and the response is received.        @li An error occurs.        The algorithm, known as a <em>composed asynchronous operation</em>,        is implemented in terms of calls to the next layer's `async_read_some`        and `async_write_some` functions. No other operation may be performed        on the stream until this operation completes.        The handshake is successful if the received HTTP response        indicates the upgrade was accepted by the server, represented by a        <a href="https://tools.ietf.org/html/rfc7230#section-3.1.2">status-code</a>        of @ref beast::http::status::switching_protocols.        @param res The HTTP Upgrade response returned by the remote        endpoint. The caller may use the response to access any        additional information sent by the server. This object will        be assigned before the completion handler is invoked.        @param host The name of the remote host. This is required by        the HTTP protocol to set the "Host" header field.        The implementation will not access the string data after the        initiating function returns.        @param target The request-target, in origin-form. The server may use the        target to distinguish different services on the same listening port.        The implementation will not access the string data after the        initiating function returns.        @param handler The completion handler to invoke when the operation        completes. The implementation takes ownership of the handler by        performing a decay-copy. The equivalent function signature of        the handler must be:        @code        void handler(            error_code const& ec    // Result of operation        );        @endcode        If the handler has an associated immediate executor,        an immediate completion will be dispatched to it.        Otherwise, the handler will not be invoked from within        this function. Invocation of the handler will be performed        by dispatching to the immediate executor. If no        immediate executor is specified, this is equivalent        to using `net::post`.        @par Example        @code        response_type res;        ws.async_handshake(res, "localhost", "/",            [&res](error_code ec)            {                if(ec)                    std::cerr << "Error: " << ec.message() << "\n";                else                    std::cout << res;            });        @endcode        @see        @li <a href="https://tools.ietf.org/html/rfc6455#section-4.1">Websocket Opening Handshake Client Requirements (RFC6455)</a>        @li <a href="https://tools.ietf.org/html/rfc7230#section-5.4">Host field (RFC7230)</a>        @li <a href="https://tools.ietf.org/html/rfc7230#section-3.1.1">request-target (RFC7230)</a>        @li <a href="https://tools.ietf.org/html/rfc7230#section-5.3.1">origin-form (RFC7230)</a>    */    template<        BOOST_BEAST_ASYNC_TPARAM1 HandshakeHandler =            net::default_completion_token_t<executor_type>    >    BOOST_BEAST_ASYNC_RESULT1(HandshakeHandler)    async_handshake(        response_type& res,        string_view host,        string_view target,        HandshakeHandler&& handler =            net::default_completion_token_t<                executor_type>{});    //--------------------------------------------------------------------------    //    // Handshaking (Server)    //    //--------------------------------------------------------------------------    /** Perform the WebSocket handshake in the server role.        This function is used to perform the        <a href="https://en.wikipedia.org/wiki/WebSocket#Protocol_handshake">WebSocket handshake</a>,        required before messages can be sent and received. During the handshake,        the client sends the Websocket Upgrade HTTP request, and the server        replies with an HTTP response indicating the result of the handshake.        The call blocks until one of the following conditions is true:        @li The request is received and the response is sent.        @li An error occurs.        The algorithm, known as a <em>composed operation</em>, is implemented        in terms of calls to the next layer's `read_some` and `write_some`        functions.        If a valid upgrade request is received, an HTTP response with a        <a href="https://tools.ietf.org/html/rfc7230#section-3.1.2">status-code</a>        of @ref beast::http::status::switching_protocols is sent to        the peer, otherwise a non-successful error is associated with        the operation.        If the request size exceeds the capacity of the stream's        internal buffer, the error @ref error::buffer_overflow will be        indicated. To handle larger requests, an application should        read the HTTP request directly using @ref http::read and then        pass the request to the appropriate overload of @ref accept or        @ref async_accept        @throws system_error Thrown on failure.        @see        @li <a href="https://tools.ietf.org/html/rfc6455#section-4.2">Websocket Opening Handshake Server Requirements (RFC6455)</a>    */    void    accept();    /** Read and respond to a WebSocket HTTP Upgrade request.        This function is used to perform the        <a href="https://en.wikipedia.org/wiki/WebSocket#Protocol_handshake">WebSocket handshake</a>,        required before messages can be sent and received. During the handshake,        the client sends the Websocket Upgrade HTTP request, and the server        replies with an HTTP response indicating the result of the handshake.        The call blocks until one of the following conditions is true:        @li The request is received and the response is sent.        @li An error occurs.        The algorithm, known as a <em>composed operation</em>, is implemented        in terms of calls to the next layer's `read_some` and `write_some`        functions.        If a valid upgrade request is received, an HTTP response with a        <a href="https://tools.ietf.org/html/rfc7230#section-3.1.2">status-code</a>        of @ref beast::http::status::switching_protocols is sent to        the peer, otherwise a non-successful error is associated with        the operation.        If the request size exceeds the capacity of the stream's        internal buffer, the error @ref error::buffer_overflow will be        indicated. To handle larger requests, an application should        read the HTTP request directly using @ref http::read and then        pass the request to the appropriate overload of @ref accept or        @ref async_accept        @param ec Set to indicate what error occurred, if any.        @see        @li <a href="https://tools.ietf.org/html/rfc6455#section-4.2">Websocket Opening Handshake Server Requirements (RFC6455)</a>    */    void    accept(error_code& ec);    /** Read and respond to a WebSocket HTTP Upgrade request.        This function is used to perform the        <a href="https://en.wikipedia.org/wiki/WebSocket#Protocol_handshake">WebSocket handshake</a>,        required before messages can be sent and received. During the handshake,        the client sends the Websocket Upgrade HTTP request, and the server        replies with an HTTP response indicating the result of the handshake.        The call blocks until one of the following conditions is true:        @li The request is received and the response is sent.        @li An error occurs.        The algorithm, known as a <em>composed operation</em>, is implemented        in terms of calls to the next layer's `read_some` and `write_some`        functions.        If a valid upgrade request is received, an HTTP response with a        <a href="https://tools.ietf.org/html/rfc7230#section-3.1.2">status-code</a>        of @ref beast::http::status::switching_protocols is sent to        the peer, otherwise a non-successful error is associated with        the operation.        If the request size exceeds the capacity of the stream's        internal buffer, the error @ref error::buffer_overflow will be        indicated. To handle larger requests, an application should        read the HTTP request directly using @ref http::read and then        pass the request to the appropriate overload of @ref accept or        @ref async_accept        @param buffers Caller provided data that has already been        received on the stream. The implementation will copy the        caller provided data before the function returns.        @throws system_error Thrown on failure.        @see        @li <a href="https://tools.ietf.org/html/rfc6455#section-4.2">Websocket Opening Handshake Server Requirements (RFC6455)</a>    */    template<class ConstBufferSequence>#if BOOST_BEAST_DOXYGEN    void#else    typename std::enable_if<! http::detail::is_header<        ConstBufferSequence>::value>::type#endif    accept(ConstBufferSequence const& buffers);    /** Read and respond to a WebSocket HTTP Upgrade request.        This function is used to perform the        <a href="https://en.wikipedia.org/wiki/WebSocket#Protocol_handshake">WebSocket handshake</a>,        required before messages can be sent and received. During the handshake,        the client sends the Websocket Upgrade HTTP request, and the server        replies with an HTTP response indicating the result of the handshake.        The call blocks until one of the following conditions is true:        @li The request is received and the response is sent.        @li An error occurs.        The algorithm, known as a <em>composed operation</em>, is implemented        in terms of calls to the next layer's `read_some` and `write_some`        functions.        If a valid upgrade request is received, an HTTP response with a        <a href="https://tools.ietf.org/html/rfc7230#section-3.1.2">status-code</a>        of @ref beast::http::status::switching_protocols is sent to        the peer, otherwise a non-successful error is associated with        the operation.        If the request size exceeds the capacity of the stream's        internal buffer, the error @ref error::buffer_overflow will be        indicated. To handle larger requests, an application should        read the HTTP request directly using @ref http::read and then        pass the request to the appropriate overload of @ref accept or        @ref async_accept        @param buffers Caller provided data that has already been        received on the stream. The implementation will copy the        caller provided data before the function returns.        @param ec Set to indicate what error occurred, if any.        @see        @li <a href="https://tools.ietf.org/html/rfc6455#section-4.2">Websocket Opening Handshake Server Requirements (RFC6455)</a>    */    template<class ConstBufferSequence>#if BOOST_BEAST_DOXYGEN    void#else    typename std::enable_if<! http::detail::is_header<        ConstBufferSequence>::value>::type#endif    accept(        ConstBufferSequence const& buffers,        error_code& ec);    /** Respond to a WebSocket HTTP Upgrade request        This function is used to perform the        <a href="https://en.wikipedia.org/wiki/WebSocket#Protocol_handshake">WebSocket handshake</a>,        required before messages can be sent and received. During the handshake,        the client sends the Websocket Upgrade HTTP request, and the server        replies with an HTTP response indicating the result of the handshake.        The call blocks until one of the following conditions is true:        @li The response is sent.        @li An error occurs.        The algorithm, known as a <em>composed operation</em>, is implemented        in terms of calls to the next layer's `read_some` and `write_some`        functions.        If a valid upgrade request is received, an HTTP response with a        <a href="https://tools.ietf.org/html/rfc7230#section-3.1.2">status-code</a>        of @ref beast::http::status::switching_protocols is sent to        the peer, otherwise a non-successful error is associated with        the operation.        @param req An object containing the HTTP Upgrade request.        Ownership is not transferred, the implementation will not        access this object from other threads.        @throws system_error Thrown on failure.        @see        @li <a href="https://tools.ietf.org/html/rfc6455#section-4.2">Websocket Opening Handshake Server Requirements (RFC6455)</a>    */    template<class Body, class Allocator>    void    accept(http::request<Body,        http::basic_fields<Allocator>> const& req);    /** Respond to a WebSocket HTTP Upgrade request        This function is used to perform the        <a href="https://en.wikipedia.org/wiki/WebSocket#Protocol_handshake">WebSocket handshake</a>,        required before messages can be sent and received. During the handshake,        the client sends the Websocket Upgrade HTTP request, and the server        replies with an HTTP response indicating the result of the handshake.        The call blocks until one of the following conditions is true:        @li The response is sent.        @li An error occurs.        The algorithm, known as a <em>composed operation</em>, is implemented        in terms of calls to the next layer's `read_some` and `write_some`        functions.        If a valid upgrade request is received, an HTTP response with a        <a href="https://tools.ietf.org/html/rfc7230#section-3.1.2">status-code</a>        of @ref beast::http::status::switching_protocols is sent to        the peer, otherwise a non-successful error is associated with        the operation.        @param req An object containing the HTTP Upgrade request.        Ownership is not transferred, the implementation will not        access this object from other threads.        @param ec Set to indicate what error occurred, if any.        @see        @li <a href="https://tools.ietf.org/html/rfc6455#section-4.2">Websocket Opening Handshake Server Requirements (RFC6455)</a>    */    template<class Body, class Allocator>    void    accept(http::request<Body,        http::basic_fields<Allocator>> const& req,            error_code& ec);    /** Perform the WebSocket handshake asynchronously in the server role.        This initiating function is used to asynchronously begin performing the        <a href="https://en.wikipedia.org/wiki/WebSocket#Protocol_handshake">WebSocket handshake</a>,        required before messages can be sent and received. During the handshake,        the client sends the Websocket Upgrade HTTP request, and the server        replies with an HTTP response indicating the result of the handshake.        This call always returns immediately. The asynchronous operation        will continue until one of the following conditions is true:        @li The request is received and the response is sent.        @li An error occurs.        The algorithm, known as a <em>composed asynchronous operation</em>,        is implemented in terms of calls to the next layer's `async_read_some`        and `async_write_some` functions. No other operation may be performed        on the stream until this operation completes.        If a valid upgrade request is received, an HTTP response with a        <a href="https://tools.ietf.org/html/rfc7230#section-3.1.2">status-code</a>        of @ref beast::http::status::switching_protocols is sent to        the peer, otherwise a non-successful error is associated with        the operation.        If the request size exceeds the capacity of the stream's        internal buffer, the error @ref error::buffer_overflow will be        indicated. To handle larger requests, an application should        read the HTTP request directly using @ref http::async_read and then        pass the request to the appropriate overload of @ref accept or        @ref async_accept        @param handler The completion handler to invoke when the operation        completes. The implementation takes ownership of the handler by        performing a decay-copy. The equivalent function signature of        the handler must be:        @code        void handler(            error_code const& ec    // Result of operation        );        @endcode        If the handler has an associated immediate executor,        an immediate completion will be dispatched to it.        Otherwise, the handler will not be invoked from within        this function. Invocation of the handler will be performed        by dispatching to the immediate executor. If no        immediate executor is specified, this is equivalent        to using `net::post`.        @see        @li <a href="https://tools.ietf.org/html/rfc6455#section-4.2">Websocket Opening Handshake Server Requirements (RFC6455)</a>    */    template<        BOOST_BEAST_ASYNC_TPARAM1 AcceptHandler =            net::default_completion_token_t<executor_type>    >    BOOST_BEAST_ASYNC_RESULT1(AcceptHandler)    async_accept(        AcceptHandler&& handler =            net::default_completion_token_t<                executor_type>{}#ifndef BOOST_BEAST_DOXYGEN        , typename std::enable_if<            ! net::is_const_buffer_sequence<            AcceptHandler>::value>::type* = nullptr#endif    );    /** Perform the WebSocket handshake asynchronously in the server role.        This initiating function is used to asynchronously begin performing the        <a href="https://en.wikipedia.org/wiki/WebSocket#Protocol_handshake">WebSocket handshake</a>,        required before messages can be sent and received. During the handshake,        the client sends the Websocket Upgrade HTTP request, and the server        replies with an HTTP response indicating the result of the handshake.        This call always returns immediately. The asynchronous operation        will continue until one of the following conditions is true:        @li The request is received and the response is sent.        @li An error occurs.        The algorithm, known as a <em>composed asynchronous operation</em>,        is implemented in terms of calls to the next layer's `async_read_some`        and `async_write_some` functions. No other operation may be performed        on the stream until this operation completes.        If a valid upgrade request is received, an HTTP response with a        <a href="https://tools.ietf.org/html/rfc7230#section-3.1.2">status-code</a>        of @ref beast::http::status::switching_protocols is sent to        the peer, otherwise a non-successful error is associated with        the operation.        If the request size exceeds the capacity of the stream's        internal buffer, the error @ref error::buffer_overflow will be        indicated. To handle larger requests, an application should        read the HTTP request directly using @ref http::async_read and then        pass the request to the appropriate overload of @ref accept or        @ref async_accept        @param buffers Caller provided data that has already been        received on the stream. This may be used for implementations        allowing multiple protocols on the same stream. The        buffered data will first be applied to the handshake, and        then to received WebSocket frames. The implementation will        copy the caller provided data before the function returns.        @param handler The completion handler to invoke when the operation        completes. The implementation takes ownership of the handler by        performing a decay-copy. The equivalent function signature of        the handler must be:        @code        void handler(            error_code const& ec    // Result of operation        );        @endcode        If the handler has an associated immediate executor,        an immediate completion will be dispatched to it.        Otherwise, the handler will not be invoked from within        this function. Invocation of the handler will be performed        by dispatching to the immediate executor. If no        immediate executor is specified, this is equivalent        to using `net::post`.        @see        @li <a href="https://tools.ietf.org/html/rfc6455#section-4.2">Websocket Opening Handshake Server Requirements (RFC6455)</a>    */    template<        class ConstBufferSequence,        BOOST_BEAST_ASYNC_TPARAM1 AcceptHandler =            net::default_completion_token_t<executor_type>    >    BOOST_BEAST_ASYNC_RESULT1(AcceptHandler)    async_accept(        ConstBufferSequence const& buffers,        AcceptHandler&& handler =            net::default_completion_token_t<                executor_type>{}#ifndef BOOST_BEAST_DOXYGEN        , typename std::enable_if<            net::is_const_buffer_sequence<            ConstBufferSequence>::value>::type* = 0        , typename std::enable_if<            ! http::detail::is_header<            ConstBufferSequence>::value>::type* = 0#endif    );    /** Perform the WebSocket handshake asynchronously in the server role.        This initiating function is used to asynchronously begin performing the        <a href="https://en.wikipedia.org/wiki/WebSocket#Protocol_handshake">WebSocket handshake</a>,        required before messages can be sent and received. During the handshake,        the client sends the Websocket Upgrade HTTP request, and the server        replies with an HTTP response indicating the result of the handshake.        This call always returns immediately. The asynchronous operation        will continue until one of the following conditions is true:        @li The request is received and the response is sent.        @li An error occurs.        The algorithm, known as a <em>composed asynchronous operation</em>,        is implemented in terms of calls to the next layer's `async_read_some`        and `async_write_some` functions. No other operation may be performed        on the stream until this operation completes.        If a valid upgrade request is received, an HTTP response with a        <a href="https://tools.ietf.org/html/rfc7230#section-3.1.2">status-code</a>        of @ref beast::http::status::switching_protocols is sent to        the peer, otherwise a non-successful error is associated with        the operation.        @param req An object containing the HTTP Upgrade request.        Ownership is not transferred, the implementation will not access        this object from other threads.        @param handler The completion handler to invoke when the operation        completes. The implementation takes ownership of the handler by        performing a decay-copy. The equivalent function signature of        the handler must be:        @code        void handler(            error_code const& ec    // Result of operation        );        @endcode        If the handler has an associated immediate executor,        an immediate completion will be dispatched to it.        Otherwise, the handler will not be invoked from within        this function. Invocation of the handler will be performed        by dispatching to the immediate executor. If no        immediate executor is specified, this is equivalent        to using `net::post`.        @see        @li <a href="https://tools.ietf.org/html/rfc6455#section-4.2">Websocket Opening Handshake Server Requirements (RFC6455)</a>    */    template<        class Body, class Allocator,        BOOST_BEAST_ASYNC_TPARAM1 AcceptHandler =            net::default_completion_token_t<executor_type>    >    BOOST_BEAST_ASYNC_RESULT1(AcceptHandler)    async_accept(        http::request<Body,            http::basic_fields<Allocator>> const& req,        AcceptHandler&& handler =            net::default_completion_token_t<                executor_type>{});    //--------------------------------------------------------------------------    //    // Close Frames    //    //--------------------------------------------------------------------------    /** Send a websocket close control frame.        This function is used to send a        <a href="https://tools.ietf.org/html/rfc6455#section-5.5.1">close frame</a>,        which begins the websocket closing handshake. The session ends when        both ends of the connection have sent and received a close frame.        The call blocks until one of the following conditions is true:        @li The close frame is written.        @li An error occurs.        The algorithm, known as a <em>composed operation</em>, is implemented        in terms of calls to the next layer's `write_some` function.        After beginning the closing handshake, the program should not write        further message data, pings, or pongs. Instead, the program should        continue reading message data until an error occurs. A read returning        @ref error::closed indicates a successful connection closure.        @param cr The reason for the close.        If the close reason specifies a close code other than        @ref beast::websocket::close_code::none, the close frame is        sent with the close code and optional reason string. Otherwise,        the close frame is sent with no payload.        @throws system_error Thrown on failure.        @see        @li <a href="https://tools.ietf.org/html/rfc6455#section-7.1.2">Websocket Closing Handshake (RFC6455)</a>    */    void    close(close_reason const& cr);    /** Send a websocket close control frame.        This function is used to send a        <a href="https://tools.ietf.org/html/rfc6455#section-5.5.1">close frame</a>,        which begins the websocket closing handshake. The session ends when        both ends of the connection have sent and received a close frame.        The call blocks until one of the following conditions is true:        @li The close frame is written.        @li An error occurs.        The algorithm, known as a <em>composed operation</em>, is implemented        in terms of calls to the next layer's `write_some` function.        After beginning the closing handshake, the program should not write        further message data, pings, or pongs. Instead, the program should        continue reading message data until an error occurs. A read returning        @ref error::closed indicates a successful connection closure.        @param cr The reason for the close.        If the close reason specifies a close code other than        @ref beast::websocket::close_code::none, the close frame is        sent with the close code and optional reason string. Otherwise,        the close frame is sent with no payload.        @param ec Set to indicate what error occurred, if any.        @see        @li <a href="https://tools.ietf.org/html/rfc6455#section-7.1.2">Websocket Closing Handshake (RFC6455)</a>    */    void    close(close_reason const& cr, error_code& ec);    /** Send a websocket close control frame asynchronously.        This function is used to asynchronously send a        <a href="https://tools.ietf.org/html/rfc6455#section-5.5.1">close frame</a>,        which begins the websocket closing handshake. The session ends when        both ends of the connection have sent and received a close frame.        This call always returns immediately. The asynchronous operation        will continue until one of the following conditions is true:        @li The close frame finishes sending.        @li An error occurs.        The algorithm, known as a <em>composed asynchronous operation</em>,        is implemented in terms of calls to the next layer's `async_write_some`        function. No other operations except for message reading operations        should be initiated on the stream after a close operation is started.        After beginning the closing handshake, the program should not write        further message data, pings, or pongs. Instead, the program should        continue reading message data until an error occurs. A read returning        @ref error::closed indicates a successful connection closure.        @param cr The reason for the close.        If the close reason specifies a close code other than        @ref beast::websocket::close_code::none, the close frame is        sent with the close code and optional reason string. Otherwise,        the close frame is sent with no payload.        @param handler The completion handler to invoke when the operation        completes. The implementation takes ownership of the handler by        performing a decay-copy. The equivalent function signature of        the handler must be:        @code        void handler(            error_code const& ec     // Result of operation        );        @endcode        If the handler has an associated immediate executor,        an immediate completion will be dispatched to it.        Otherwise, the handler will not be invoked from within        this function. Invocation of the handler will be performed        by dispatching to the immediate executor. If no        immediate executor is specified, this is equivalent        to using `net::post`.        @par Per-Operation Cancellation        This asynchronous operation supports cancellation for the following        net::cancellation_type values:        @li @c net::cancellation_type::terminal        @li @c net::cancellation_type::total        `total` cancellation succeeds if the operation is suspended due to ongoing        control operations such as a ping/pong.        `terminal` cancellation succeeds when supported by the underlying stream.        @note `terminal` cancellation will may close the underlying socket.        @see        @li <a href="https://tools.ietf.org/html/rfc6455#section-7.1.2">Websocket Closing Handshake (RFC6455)</a>    */    template<        BOOST_BEAST_ASYNC_TPARAM1 CloseHandler =            net::default_completion_token_t<executor_type>    >    BOOST_BEAST_ASYNC_RESULT1(CloseHandler)    async_close(        close_reason const& cr,        CloseHandler&& handler =            net::default_completion_token_t<                executor_type>{});    //--------------------------------------------------------------------------    //    // Ping/Pong Frames    //    //--------------------------------------------------------------------------    /** Send a websocket ping control frame.        This function is used to send a        <a href="https://tools.ietf.org/html/rfc6455#section-5.5.2">ping frame</a>,        which usually elicits an automatic pong control frame response from        the peer.        The call blocks until one of the following conditions is true:        @li The ping frame is written.        @li An error occurs.        The algorithm, known as a <em>composed operation</em>, is implemented        in terms of calls to the next layer's `write_some` function.        @param payload The payload of the ping message, which may be empty.        @throws system_error Thrown on failure.    */    void    ping(ping_data const& payload);    /** Send a websocket ping control frame.        This function is used to send a        <a href="https://tools.ietf.org/html/rfc6455#section-5.5.2">ping frame</a>,        which usually elicits an automatic pong control frame response from        the peer.        The call blocks until one of the following conditions is true:        @li The ping frame is written.        @li An error occurs.        The algorithm, known as a <em>composed operation</em>, is implemented        in terms of calls to the next layer's `write_some` function.        @param payload The payload of the ping message, which may be empty.        @param ec Set to indicate what error occurred, if any.    */    void    ping(ping_data const& payload, error_code& ec);    /** Send a websocket ping control frame asynchronously.        This function is used to asynchronously send a        <a href="https://tools.ietf.org/html/rfc6455#section-5.5.2">ping frame</a>,        which usually elicits an automatic pong control frame response from        the peer.        @li The ping frame is written.        @li An error occurs.        The algorithm, known as a <em>composed asynchronous operation</em>,        is implemented in terms of calls to the next layer's `async_write_some`        function. The program must ensure that no other calls to @ref ping,        @ref pong, @ref async_ping, or @ref async_pong are performed until        this operation completes.        If a close frame is sent or received before the ping frame is        sent, the error received by this completion handler will be        `net::error::operation_aborted`.        @param payload The payload of the ping message, which may be empty.        The implementation will not access the contents of this object after        the initiating function returns.        @param handler The completion handler to invoke when the operation        completes. The implementation takes ownership of the handler by        performing a decay-copy. The equivalent function signature of        the handler must be:        @code        void handler(            error_code const& ec     // Result of operation        );        @endcode        If the handler has an associated immediate executor,        an immediate completion will be dispatched to it.        Otherwise, the handler will not be invoked from within        this function. Invocation of the handler will be performed        by dispatching to the immediate executor. If no        immediate executor is specified, this is equivalent        to using `net::post`.        @par Per-Operation Cancellation        This asynchronous operation supports cancellation for the following        net::cancellation_type values:        @li @c net::cancellation_type::terminal        @li @c net::cancellation_type::total        `total` cancellation succeeds if the operation is suspended due to ongoing        control operations such as a ping/pong.        `terminal` cancellation succeeds when supported by the underlying stream.        `terminal` cancellation leaves the stream in an undefined state,        so that only closing it is guaranteed to succeed.    */    template<        BOOST_BEAST_ASYNC_TPARAM1 PingHandler =            net::default_completion_token_t<executor_type>    >    BOOST_BEAST_ASYNC_RESULT1(PingHandler)    async_ping(        ping_data const& payload,        PingHandler&& handler =            net::default_completion_token_t<                executor_type>{});    /** Send a websocket pong control frame.        This function is used to send a        <a href="https://tools.ietf.org/html/rfc6455#section-5.5.3">pong frame</a>,        which is usually sent automatically in response to a ping frame        from the remote peer.        The call blocks until one of the following conditions is true:        @li The pong frame is written.        @li An error occurs.        The algorithm, known as a <em>composed operation</em>, is implemented        in terms of calls to the next layer's `write_some` function.        WebSocket allows pong frames to be sent at any time, without first        receiving a ping. An unsolicited pong sent in this fashion may        indicate to the remote peer that the connection is still active.        @param payload The payload of the pong message, which may be empty.        @throws system_error Thrown on failure.    */    void    pong(ping_data const& payload);    /** Send a websocket pong control frame.        This function is used to send a        <a href="https://tools.ietf.org/html/rfc6455#section-5.5.3">pong frame</a>,        which is usually sent automatically in response to a ping frame        from the remote peer.        The call blocks until one of the following conditions is true:        @li The pong frame is written.        @li An error occurs.        The algorithm, known as a <em>composed operation</em>, is implemented        in terms of calls to the next layer's `write_some` function.        WebSocket allows pong frames to be sent at any time, without first        receiving a ping. An unsolicited pong sent in this fashion may        indicate to the remote peer that the connection is still active.        @param payload The payload of the pong message, which may be empty.        @param ec Set to indicate what error occurred, if any.    */    void    pong(ping_data const& payload, error_code& ec);    /** Send a websocket pong control frame asynchronously.        This function is used to asynchronously send a        <a href="https://tools.ietf.org/html/rfc6455#section-5.5.3">pong frame</a>,        which is usually sent automatically in response to a ping frame        from the remote peer.        @li The pong frame is written.        @li An error occurs.        The algorithm, known as a <em>composed asynchronous operation</em>,        is implemented in terms of calls to the next layer's `async_write_some`        function. The program must ensure that no other calls to @ref ping,        @ref pong, @ref async_ping, or @ref async_pong are performed until        this operation completes.        If a close frame is sent or received before the pong frame is        sent, the error received by this completion handler will be        `net::error::operation_aborted`.        WebSocket allows pong frames to be sent at any time, without first        receiving a ping. An unsolicited pong sent in this fashion may        indicate to the remote peer that the connection is still active.        @param payload The payload of the pong message, which may be empty.        The implementation will not access the contents of this object after        the initiating function returns.        @param handler The completion handler to invoke when the operation        completes. The implementation takes ownership of the handler by        performing a decay-copy. The equivalent function signature of        the handler must be:        @code        void handler(            error_code const& ec     // Result of operation        );        @endcode        If the handler has an associated immediate executor,        an immediate completion will be dispatched to it.        Otherwise, the handler will not be invoked from within        this function. Invocation of the handler will be performed        by dispatching to the immediate executor. If no        immediate executor is specified, this is equivalent        to using `net::post`.        @par Per-Operation Cancellation        This asynchronous operation supports cancellation for the following        net::cancellation_type values:        @li @c net::cancellation_type::terminal        @li @c net::cancellation_type::total        `total` cancellation succeeds if the operation is suspended due to ongoing        control operations such as a ping/pong.        `terminal` cancellation succeeds when supported by the underlying stream.        `terminal` cancellation leaves the stream in an undefined state,        so that only closing it is guaranteed to succeed.    */    template<        BOOST_BEAST_ASYNC_TPARAM1 PongHandler =            net::default_completion_token_t<executor_type>    >    BOOST_BEAST_ASYNC_RESULT1(PongHandler)    async_pong(        ping_data const& payload,        PongHandler&& handler =            net::default_completion_token_t<                executor_type>{});    //--------------------------------------------------------------------------    //    // Reading    //    //--------------------------------------------------------------------------    /** Read a complete message.        This function is used to read a complete message.        The call blocks until one of the following is true:        @li A complete message is received.        @li A close frame is received. In this case the error indicated by            the function will be @ref error::closed.        @li An error occurs.        The algorithm, known as a <em>composed operation</em>, is implemented        in terms of calls to the next layer's `read_some` and `write_some`        functions.        Received message data is appended to the buffer.        The functions @ref got_binary and @ref got_text may be used        to query the stream and determine the type of the last received message.        Until the call returns, the implementation will read incoming control        frames and handle them automatically as follows:        @li The @ref control_callback will be invoked for each control frame.        @li For each received ping frame, a pong frame will be            automatically sent.        @li If a close frame is received, the WebSocket closing handshake is            performed. In this case, when the function returns, the error            @ref error::closed will be indicated.        @return The number of message payload bytes appended to the buffer.        @param buffer A dynamic buffer to append message data to.        @throws system_error Thrown on failure.    */    template<class DynamicBuffer>    std::size_t    read(DynamicBuffer& buffer);    /** Read a complete message.        This function is used to read a complete message.        The call blocks until one of the following is true:        @li A complete message is received.        @li A close frame is received. In this case the error indicated by            the function will be @ref error::closed.        @li An error occurs.        The algorithm, known as a <em>composed operation</em>, is implemented        in terms of calls to the next layer's `read_some` and `write_some`        functions.        Received message data is appended to the buffer.        The functions @ref got_binary and @ref got_text may be used        to query the stream and determine the type of the last received message.        Until the call returns, the implementation will read incoming control        frames and handle them automatically as follows:        @li The @ref control_callback will be invoked for each control frame.        @li For each received ping frame, a pong frame will be            automatically sent.        @li If a close frame is received, the WebSocket closing handshake is            performed. In this case, when the function returns, the error            @ref error::closed will be indicated.        @return The number of message payload bytes appended to the buffer.        @param buffer A dynamic buffer to append message data to.        @param ec Set to indicate what error occurred, if any.    */    template<class DynamicBuffer>    std::size_t    read(DynamicBuffer& buffer, error_code& ec);    /** Read a complete message asynchronously.        This function is used to asynchronously read a complete message.        This call always returns immediately. The asynchronous operation        will continue until one of the following conditions is true:        @li A complete message is received.        @li A close frame is received. In this case the error indicated by            the function will be @ref error::closed.        @li An error occurs.        The algorithm, known as a <em>composed asynchronous operation</em>,        is implemented in terms of calls to the next layer's `async_read_some`        and `async_write_some` functions. The program must ensure that no other        calls to @ref read, @ref read_some, @ref async_read, or @ref async_read_some        are performed until this operation completes.        Received message data is appended to the buffer.        The functions @ref got_binary and @ref got_text may be used        to query the stream and determine the type of the last received message.        Until the operation completes, the implementation will read incoming        control frames and handle them automatically as follows:        @li The @ref control_callback will be invoked for each control frame.        @li For each received ping frame, a pong frame will be            automatically sent.        @li If a close frame is received, the WebSocket close procedure is            performed. In this case, when the function returns, the error            @ref error::closed will be indicated.        Pong frames and close frames sent by the implementation while the        read operation is outstanding do not prevent the application from        also writing message data, sending pings, sending pongs, or sending        close frames.        @param buffer A dynamic buffer to append message data to.        @param handler The completion handler to invoke when the operation        completes. The implementation takes ownership of the handler by        performing a decay-copy. The equivalent function signature of        the handler must be:        @code        void handler(            error_code const& ec,       // Result of operation            std::size_t bytes_written   // Number of bytes appended to buffer        );        @endcode        If the handler has an associated immediate executor,        an immediate completion will be dispatched to it.        Otherwise, the handler will not be invoked from within        this function. Invocation of the handler will be performed        by dispatching to the immediate executor. If no        immediate executor is specified, this is equivalent        to using `net::post`.        @par Per-Operation Cancellation        This asynchronous operation supports cancellation for the following        net::cancellation_type values:        @li @c net::cancellation_type::terminal        @li @c net::cancellation_type::total        `total` cancellation succeeds if the operation is suspended due to ongoing        control operations such as a ping/pong.        `terminal` cancellation succeeds when supported by the underlying stream.        `terminal` cancellation leaves the stream in an undefined state,        so that only closing it is guaranteed to succeed.    */    template<        class DynamicBuffer,        BOOST_BEAST_ASYNC_TPARAM2 ReadHandler =            net::default_completion_token_t<                executor_type>>    BOOST_BEAST_ASYNC_RESULT2(ReadHandler)    async_read(        DynamicBuffer& buffer,        ReadHandler&& handler =            net::default_completion_token_t<                executor_type>{});    //--------------------------------------------------------------------------    /** Read some message data.        This function is used to read some message data.        The call blocks until one of the following is true:        @li Some message data is received.        @li A close frame is received. In this case the error indicated by            the function will be @ref error::closed.        @li An error occurs.        The algorithm, known as a <em>composed operation</em>, is implemented        in terms of calls to the next layer's `read_some` and `write_some`        functions.        Received message data is appended to the buffer.        The functions @ref got_binary and @ref got_text may be used        to query the stream and determine the type of the last received message.        The function @ref is_message_done may be called to determine if the        message received by the last read operation is complete.        Until the call returns, the implementation will read incoming control        frames and handle them automatically as follows:        @li The @ref control_callback will be invoked for each control frame.        @li For each received ping frame, a pong frame will be            automatically sent.        @li If a close frame is received, the WebSocket closing handshake is            performed. In this case, when the function returns, the error            @ref error::closed will be indicated.        @return The number of message payload bytes appended to the buffer.        @param buffer A dynamic buffer to append message data to.        @param limit An upper limit on the number of bytes this function        will append into the buffer. If this value is zero, then a reasonable        size will be chosen automatically.        @throws system_error Thrown on failure.    */    template<class DynamicBuffer>    std::size_t    read_some(        DynamicBuffer& buffer,        std::size_t limit);    /** Read some message data.        This function is used to read some message data.        The call blocks until one of the following is true:        @li Some message data is received.        @li A close frame is received. In this case the error indicated by            the function will be @ref error::closed.        @li An error occurs.        The algorithm, known as a <em>composed operation</em>, is implemented        in terms of calls to the next layer's `read_some` and `write_some`        functions.        Received message data is appended to the buffer.        The functions @ref got_binary and @ref got_text may be used        to query the stream and determine the type of the last received message.        The function @ref is_message_done may be called to determine if the        message received by the last read operation is complete.        Until the call returns, the implementation will read incoming control        frames and handle them automatically as follows:        @li The @ref control_callback will be invoked for each control frame.        @li For each received ping frame, a pong frame will be            automatically sent.        @li If a close frame is received, the WebSocket closing handshake is            performed. In this case, when the function returns, the error            @ref error::closed will be indicated.        @return The number of message payload bytes appended to the buffer.        @param buffer A dynamic buffer to append message data to.        @param limit An upper limit on the number of bytes this function        will append into the buffer. If this value is zero, then a reasonable        size will be chosen automatically.        @param ec Set to indicate what error occurred, if any.    */    template<class DynamicBuffer>    std::size_t    read_some(        DynamicBuffer& buffer,        std::size_t limit,        error_code& ec);    /** Read some message data asynchronously.        This function is used to asynchronously read some message data.        This call always returns immediately. The asynchronous operation        will continue until one of the following conditions is true:        @li Some message data is received.        @li A close frame is received. In this case the error indicated by            the function will be @ref error::closed.        @li An error occurs.        The algorithm, known as a <em>composed asynchronous operation</em>,        is implemented in terms of calls to the next layer's `async_read_some`        and `async_write_some` functions. The program must ensure that no other        calls to @ref read, @ref read_some, @ref async_read, or @ref async_read_some        are performed until this operation completes.        Received message data is appended to the buffer.        The functions @ref got_binary and @ref got_text may be used        to query the stream and determine the type of the last received message.        Until the operation completes, the implementation will read incoming        control frames and handle them automatically as follows:        @li The @ref control_callback will be invoked for each control frame.        @li For each received ping frame, a pong frame will be            automatically sent.        @li If a close frame is received, the WebSocket close procedure is            performed. In this case, when the function returns, the error            @ref error::closed will be indicated.        Pong frames and close frames sent by the implementation while the        read operation is outstanding do not prevent the application from        also writing message data, sending pings, sending pongs, or sending        close frames.        @param buffer A dynamic buffer to append message data to.        @param limit An upper limit on the number of bytes this function        will append into the buffer. If this value is zero, then a reasonable        size will be chosen automatically.        @param handler The completion handler to invoke when the operation        completes. The implementation takes ownership of the handler by        performing a decay-copy. The equivalent function signature of        the handler must be:        @code        void handler(            error_code const& ec,       // Result of operation            std::size_t bytes_written   // Number of bytes appended to buffer        );        @endcode        If the handler has an associated immediate executor,        an immediate completion will be dispatched to it.        Otherwise, the handler will not be invoked from within        this function. Invocation of the handler will be performed        by dispatching to the immediate executor. If no        immediate executor is specified, this is equivalent        to using `net::post`.        @par Per-Operation Cancellation        This asynchronous operation supports cancellation for the following        net::cancellation_type values:        @li @c net::cancellation_type::terminal        @li @c net::cancellation_type::total        `total` cancellation succeeds if the operation is suspended due to ongoing        control operations such as a ping/pong.        `terminal` cancellation succeeds when supported by the underlying stream.        `terminal` cancellation leaves the stream in an undefined state,        so that only closing it is guaranteed to succeed.    */    template<        class DynamicBuffer,        BOOST_BEAST_ASYNC_TPARAM2 ReadHandler =            net::default_completion_token_t<                executor_type>>    BOOST_BEAST_ASYNC_RESULT2(ReadHandler)    async_read_some(        DynamicBuffer& buffer,        std::size_t limit,        ReadHandler&& handler =            net::default_completion_token_t<                executor_type>{});    //--------------------------------------------------------------------------    /** Read some message data.        This function is used to read some message data.        The call blocks until one of the following is true:        @li Some message data is received.        @li A close frame is received. In this case the error indicated by            the function will be @ref error::closed.        @li An error occurs.        The algorithm, known as a <em>composed operation</em>, is implemented        in terms of calls to the next layer's `read_some` and `write_some`        functions.        The functions @ref got_binary and @ref got_text may be used        to query the stream and determine the type of the last received message.        The function @ref is_message_done may be called to determine if the        message received by the last read operation is complete.        Until the call returns, the implementation will read incoming control        frames and handle them automatically as follows:        @li The @ref control_callback will be invoked for each control frame.        @li For each received ping frame, a pong frame will be            automatically sent.        @li If a close frame is received, the WebSocket closing handshake is            performed. In this case, when the function returns, the error            @ref error::closed will be indicated.        @return The number of message payload bytes appended to the buffer.        @param buffers A buffer sequence to write message data into.        The previous contents of the buffers will be overwritten, starting        from the beginning.        @throws system_error Thrown on failure.    */    template<class MutableBufferSequence>    std::size_t    read_some(        MutableBufferSequence const& buffers);    /** Read some message data.        This function is used to read some message data.        The call blocks until one of the following is true:        @li Some message data is received.        @li A close frame is received. In this case the error indicated by            the function will be @ref error::closed.        @li An error occurs.        The algorithm, known as a <em>composed operation</em>, is implemented        in terms of calls to the next layer's `read_some` and `write_some`        functions.        The functions @ref got_binary and @ref got_text may be used        to query the stream and determine the type of the last received message.        The function @ref is_message_done may be called to determine if the        message received by the last read operation is complete.        Until the call returns, the implementation will read incoming control        frames and handle them automatically as follows:        @li The @ref control_callback will be invoked for each control frame.        @li For each received ping frame, a pong frame will be            automatically sent.        @li If a close frame is received, the WebSocket closing handshake is            performed. In this case, when the function returns, the error            @ref error::closed will be indicated.        @return The number of message payload bytes appended to the buffer.        @param buffers A buffer sequence to write message data into.        The previous contents of the buffers will be overwritten, starting        from the beginning.        @param ec Set to indicate what error occurred, if any.        @par Per-Operation Cancellation        This asynchronous operation supports cancellation for the following        net::cancellation_type values:        @li @c net::cancellation_type::terminal        @li @c net::cancellation_type::total        `total` cancellation succeeds if the operation is suspended due to ongoing        control operations such as a ping/pong.        `terminal` cancellation succeeds when supported by the underlying stream.        `terminal` cancellation leaves the stream in an undefined state,        so that only closing it is guaranteed to succeed.    */    template<class MutableBufferSequence>    std::size_t    read_some(        MutableBufferSequence const& buffers,        error_code& ec);    /** Read some message data asynchronously.        This function is used to asynchronously read some message data.        This call always returns immediately. The asynchronous operation        will continue until one of the following conditions is true:        @li Some message data is received.        @li A close frame is received. In this case the error indicated by            the function will be @ref error::closed.        @li An error occurs.        The algorithm, known as a <em>composed asynchronous operation</em>,        is implemented in terms of calls to the next layer's `async_read_some`        and `async_write_some` functions. The program must ensure that no other        calls to @ref read, @ref read_some, @ref async_read, or @ref async_read_some        are performed until this operation completes.        Received message data is appended to the buffer.        The functions @ref got_binary and @ref got_text may be used        to query the stream and determine the type of the last received message.        Until the operation completes, the implementation will read incoming        control frames and handle them automatically as follows:        @li The @ref control_callback will be invoked for each control frame.        @li For each received ping frame, a pong frame will be            automatically sent.        @li If a close frame is received, the WebSocket close procedure is            performed. In this case, when the function returns, the error            @ref error::closed will be indicated.        Pong frames and close frames sent by the implementation while the        read operation is outstanding do not prevent the application from        also writing message data, sending pings, sending pongs, or sending        close frames.        @param buffers A buffer sequence to write message data into.        The previous contents of the buffers will be overwritten, starting        from the beginning.        The implementation will make copies of this object as needed, but        but ownership of the underlying memory is not transferred. The        caller is responsible for ensuring that the memory locations        pointed to by the buffer sequence remain valid until the        completion handler is called.        @param handler The completion handler to invoke when the operation        completes. The implementation takes ownership of the handler by        performing a decay-copy. The equivalent function signature of        the handler must be:        @code        void handler(            error_code const& ec,       // Result of operation            std::size_t bytes_written   // Number of bytes written to the buffers        );        @endcode        If the handler has an associated immediate executor,        an immediate completion will be dispatched to it.        Otherwise, the handler will not be invoked from within        this function. Invocation of the handler will be performed        by dispatching to the immediate executor. If no        immediate executor is specified, this is equivalent        to using `net::post`.        @par Per-Operation Cancellation        This asynchronous operation supports cancellation for the following        net::cancellation_type values:        @li @c net::cancellation_type::terminal        @li @c net::cancellation_type::total        `total` cancellation succeeds if the operation is suspended due to ongoing        control operations such as a ping/pong.        `terminal` cancellation succeeds when supported by the underlying stream.        `terminal` cancellation leaves the stream in an undefined state,        so that only closing it is guaranteed to succeed.    */    template<        class MutableBufferSequence,        BOOST_BEAST_ASYNC_TPARAM2 ReadHandler =            net::default_completion_token_t<                executor_type>>    BOOST_BEAST_ASYNC_RESULT2(ReadHandler)    async_read_some(        MutableBufferSequence const& buffers,        ReadHandler&& handler =            net::default_completion_token_t<                executor_type>{});    //--------------------------------------------------------------------------    //    // Writing    //    //--------------------------------------------------------------------------    /** Write a complete message.        This function is used to write a complete message.        The call blocks until one of the following is true:        @li The message is written.        @li An error occurs.        The algorithm, known as a <em>composed operation</em>, is implemented        in terms of calls to the next layer's `write_some` function.        The current setting of the @ref binary option controls        whether the message opcode is set to text or binary. If the        @ref auto_fragment option is set, the message will be split        into one or more frames as necessary. The actual payload contents        sent may be transformed as per the WebSocket protocol settings.        @param buffers The buffers containing the message to send.        @return The number of bytes sent from the buffers.        @throws system_error Thrown on failure.    */    template<class ConstBufferSequence>    std::size_t    write(ConstBufferSequence const& buffers);    /** Write a complete message.        This function is used to write a complete message.        The call blocks until one of the following is true:        @li The complete message is written.        @li An error occurs.        The algorithm, known as a <em>composed operation</em>, is implemented        in terms of calls to the next layer's `write_some` function.        The current setting of the @ref binary option controls        whether the message opcode is set to text or binary. If the        @ref auto_fragment option is set, the message will be split        into one or more frames as necessary. The actual payload contents        sent may be transformed as per the WebSocket protocol settings.        @param buffers The buffers containing the message to send.        @param ec Set to indicate what error occurred, if any.        @return The number of bytes sent from the buffers.    */    template<class ConstBufferSequence>    std::size_t    write(ConstBufferSequence const& buffers, error_code& ec);    /** Write a complete message asynchronously.        This function is used to asynchronously write a complete message.        This call always returns immediately. The asynchronous operation        will continue until one of the following conditions is true:        @li The complete message is written.        @li An error occurs.        The algorithm, known as a <em>composed asynchronous operation</em>,        is implemented in terms of calls to the next layer's        `async_write_some` function. The program must ensure that no other        calls to @ref write, @ref write_some, @ref async_write, or        @ref async_write_some are performed until this operation completes.        The current setting of the @ref binary option controls        whether the message opcode is set to text or binary. If the        @ref auto_fragment option is set, the message will be split        into one or more frames as necessary. The actual payload contents        sent may be transformed as per the WebSocket protocol settings.        @param buffers A buffer sequence containing the entire message        payload. The implementation will make copies of this object        as needed, but ownership of the underlying memory is not        transferred. The caller is responsible for ensuring that        the memory locations pointed to by buffers remains valid        until the completion handler is called.        @param handler The completion handler to invoke when the operation        completes. The implementation takes ownership of the handler by        performing a decay-copy. The equivalent function signature of        the handler must be:        @code        void handler(            error_code const& ec,           // Result of operation            std::size_t bytes_transferred   // Number of bytes sent from the                                            // buffers. If an error occurred,                                            // this will be less than the buffer_size.        );        @endcode        If the handler has an associated immediate executor,        an immediate completion will be dispatched to it.        Otherwise, the handler will not be invoked from within        this function. Invocation of the handler will be performed        by dispatching to the immediate executor. If no        immediate executor is specified, this is equivalent        to using `net::post`.        @par Per-Operation Cancellation        This asynchronous operation supports cancellation for the following        net::cancellation_type values:        @li @c net::cancellation_type::terminal        @li @c net::cancellation_type::total        `total` cancellation succeeds if the operation is suspended due to ongoing        control operations such as a ping/pong.        `terminal` cancellation succeeds when supported by the underlying stream.        `terminal` cancellation leaves the stream in an undefined state,        so that only closing it is guaranteed to succeed.    */    template<        class ConstBufferSequence,        BOOST_BEAST_ASYNC_TPARAM2 WriteHandler =            net::default_completion_token_t<                executor_type>>    BOOST_BEAST_ASYNC_RESULT2(WriteHandler)    async_write(        ConstBufferSequence const& buffers,        WriteHandler&& handler =            net::default_completion_token_t<                executor_type>{});    /** Write some message data.        This function is used to send part of a message.        The call blocks until one of the following is true:        @li The message data is written.        @li An error occurs.        The algorithm, known as a <em>composed operation</em>, is implemented        in terms of calls to the next layer's `write_some` function.        If this is the beginning of a new message, the message opcode        will be set to text or binary based on the current setting of        the @ref binary (or @ref text) option. The actual payload sent        may be transformed as per the WebSocket protocol settings.        @param fin `true` if this is the last part of the message.        @param buffers The buffers containing the message part to send.        @return The number of bytes sent from the buffers.        @throws system_error Thrown on failure.    */    template<class ConstBufferSequence>    std::size_t    write_some(bool fin, ConstBufferSequence const& buffers);    /** Write some message data.        This function is used to send part of a message.        The call blocks until one of the following is true:        @li The message data is written.        @li An error occurs.        The algorithm, known as a <em>composed operation</em>, is implemented        in terms of calls to the next layer's `write_some` function.        If this is the beginning of a new message, the message opcode        will be set to text or binary based on the current setting of        the @ref binary (or @ref text) option. The actual payload sent        may be transformed as per the WebSocket protocol settings.        This function always writes a complete WebSocket frame (not WebSocket        message) upon successful completion, so it is well defined to perform        ping, pong, and close operations after this operation completes.        @param fin `true` if this is the last part of the message.        @param buffers The buffers containing the message part to send.        @param ec Set to indicate what error occurred, if any.        @return The number of bytes sent from the buffers.        @return The number of bytes consumed in the input buffers.    */    template<class ConstBufferSequence>    std::size_t    write_some(bool fin,        ConstBufferSequence const& buffers, error_code& ec);    /** Write some message data asynchronously.        This function is used to asynchronously write part of a message.        This call always returns immediately. The asynchronous operation        will continue until one of the following conditions is true:        @li The message data is written.        @li An error occurs.        The algorithm, known as a <em>composed asynchronous operation</em>,        is implemented in terms of calls to the next layer's        `async_write_some` function. The program must ensure that no other        calls to @ref write, @ref write_some, @ref async_write, or        @ref async_write_some are performed until this operation completes.        If this is the beginning of a new message, the message opcode        will be set to text or binary based on the current setting of        the @ref binary (or @ref text) option. The actual payload sent        may be transformed as per the WebSocket protocol settings.        This function always writes a complete WebSocket frame (not WebSocket        message) upon successful completion, so it is well defined to perform        ping, pong, and close operations in parallel to this operation.        @param fin `true` if this is the last part of the message.        @param buffers The buffers containing the message part to send.        The implementation will make copies of this object        as needed, but ownership of the underlying memory is not        transferred. The caller is responsible for ensuring that        the memory locations pointed to by buffers remains valid        until the completion handler is called.        @param handler The completion handler to invoke when the operation        completes. The implementation takes ownership of the handler by        performing a decay-copy. The equivalent function signature of        the handler must be:        @code        void handler(            error_code const& ec,           // Result of operation            std::size_t bytes_transferred   // Number of bytes sent from the                                            // buffers. If an error occurred,                                            // this will be less than the buffer_size.        );        @endcode        If the handler has an associated immediate executor,        an immediate completion will be dispatched to it.        Otherwise, the handler will not be invoked from within        this function. Invocation of the handler will be performed        by dispatching to the immediate executor. If no        immediate executor is specified, this is equivalent        to using `net::post`.        @par Per-Operation Cancellation        This asynchronous operation supports cancellation for the following        net::cancellation_type values:        @li @c net::cancellation_type::terminal        @li @c net::cancellation_type::total        `total` cancellation succeeds if the operation is suspended due to ongoing        control operations such as a ping/pong.        `terminal` cancellation succeeds when supported by the underlying stream.        `terminal` cancellation leaves the stream in an undefined state,        so that only closing it is guaranteed to succeed.    */    template<        class ConstBufferSequence,        BOOST_BEAST_ASYNC_TPARAM2 WriteHandler =            net::default_completion_token_t<                executor_type>>    BOOST_BEAST_ASYNC_RESULT2(WriteHandler)    async_write_some(        bool fin,        ConstBufferSequence const& buffers,        WriteHandler&& handler =            net::default_completion_token_t<                executor_type>{});private:    template<class, class>  class accept_op;    template<class>         class close_op;    template<class>         class handshake_op;    template<class>         class ping_op;    template<class>         class idle_ping_op;    template<class, class>  class read_some_op;    template<class, class>  class read_op;    template<class>         class response_op;    template<class, class>  class write_some_op;    template<class, class>  class write_op;    struct run_accept_op;    struct run_close_op;    struct run_handshake_op;    struct run_ping_op;    struct run_idle_ping_op;    struct run_read_some_op;    struct run_read_op;    struct run_response_op;    struct run_write_some_op;    struct run_write_op;    static void default_decorate_req(request_type&) {}    static void default_decorate_res(response_type&) {}    //    // accept / handshake    //    template<class Buffers, class Decorator>    void    do_accept(        Buffers const& buffers,        Decorator const& decorator,        error_code& ec);    template<        class Body, class Allocator,        class Decorator>    void    do_accept(        http::request<Body,            http::basic_fields<Allocator>> const& req,        Decorator const& decorator,        error_code& ec);    template<class RequestDecorator>    void    do_handshake(response_type* res_p,        string_view host, string_view target,            RequestDecorator const& decorator,                error_code& ec);    //    // fail    //    void    do_fail(        std::uint16_t code,        error_code ev,        error_code& ec);};/** Manually provide a one-time seed to initialize the PRNG    This function invokes the specified seed sequence to produce a seed    suitable for use with the pseudo-random number generator used to    create masks and perform WebSocket protocol handshakes.    If a seed is not manually provided, the implementation will    perform a one-time seed generation using `std::random_device`. This    function may be used when the application runs in an environment    where the random device is unreliable or does not provide sufficient    entropy.    @par Preconditions    This function may not be called after any websocket @ref stream objects    have been constructed.    @param ss A reference to a `std::seed_seq` which will be used to seed    the pseudo-random number generator. The seed sequence should have at    least 256 bits of entropy.    @see stream::secure_prng*/inlinevoidseed_prng(std::seed_seq& ss){    detail::prng_seed(&ss);}} // websocket} // beast} // boost#include <boost/beast/websocket/impl/stream_impl.hpp> // must be first#include <boost/beast/websocket/impl/accept.hpp>#include <boost/beast/websocket/impl/close.hpp>#include <boost/beast/websocket/impl/handshake.hpp>#include <boost/beast/websocket/impl/ping.hpp>#include <boost/beast/websocket/impl/read.hpp>#include <boost/beast/websocket/impl/stream.hpp>#include <boost/beast/websocket/impl/write.hpp>#endif
 |