| 123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785786787788789790791792793794795796797798799800801802803804805806807808809810811812813814815816817818819820821822823824825826827828829830831832833834835836837838839840841842843844845846847848849850851852853854855856857858859860861862863864865866867868869870871872873874875876877878879880881882883884885886887888889890891892893894895896897898899900901902903904905906907908909910911912913914915916917918919920921922923924925926927928929930931932933934935936937938939940941942943944945946947948949950951952953954955956957958959960961962963964965966967968969970971972973974975976977978979980981982983984985986987988989990991992993994995996997998999100010011002100310041005100610071008100910101011101210131014101510161017101810191020102110221023102410251026102710281029103010311032103310341035103610371038103910401041104210431044104510461047104810491050105110521053105410551056105710581059106010611062106310641065106610671068106910701071107210731074107510761077107810791080108110821083108410851086108710881089109010911092109310941095109610971098109911001101110211031104110511061107110811091110111111121113111411151116111711181119112011211122112311241125112611271128112911301131113211331134113511361137113811391140114111421143114411451146114711481149115011511152115311541155115611571158115911601161116211631164116511661167116811691170117111721173117411751176117711781179118011811182118311841185118611871188118911901191119211931194119511961197119811991200120112021203120412051206120712081209121012111212121312141215121612171218121912201221122212231224122512261227122812291230123112321233123412351236123712381239124012411242124312441245124612471248124912501251125212531254125512561257125812591260126112621263126412651266126712681269127012711272127312741275127612771278127912801281128212831284128512861287128812891290129112921293129412951296129712981299130013011302130313041305130613071308130913101311131213131314131513161317131813191320132113221323132413251326132713281329133013311332133313341335133613371338133913401341134213431344134513461347134813491350135113521353135413551356135713581359136013611362136313641365136613671368136913701371137213731374137513761377137813791380138113821383138413851386138713881389139013911392139313941395139613971398139914001401140214031404140514061407140814091410141114121413141414151416141714181419142014211422142314241425142614271428142914301431143214331434143514361437143814391440144114421443144414451446144714481449145014511452145314541455145614571458145914601461146214631464146514661467146814691470147114721473147414751476147714781479148014811482148314841485148614871488148914901491149214931494149514961497149814991500150115021503150415051506150715081509151015111512151315141515151615171518151915201521152215231524152515261527152815291530153115321533153415351536153715381539154015411542154315441545154615471548154915501551155215531554155515561557155815591560156115621563156415651566156715681569157015711572157315741575157615771578157915801581158215831584158515861587158815891590159115921593159415951596159715981599160016011602160316041605160616071608160916101611161216131614161516161617161816191620162116221623162416251626162716281629163016311632163316341635163616371638163916401641164216431644164516461647164816491650165116521653165416551656165716581659166016611662166316641665166616671668166916701671167216731674167516761677167816791680168116821683168416851686168716881689169016911692169316941695169616971698169917001701170217031704170517061707170817091710171117121713171417151716171717181719172017211722172317241725172617271728172917301731173217331734173517361737173817391740174117421743174417451746174717481749175017511752175317541755175617571758175917601761176217631764176517661767176817691770177117721773177417751776177717781779178017811782178317841785178617871788178917901791179217931794179517961797179817991800180118021803180418051806180718081809181018111812181318141815181618171818181918201821182218231824182518261827182818291830183118321833183418351836183718381839184018411842184318441845184618471848184918501851185218531854185518561857185818591860186118621863186418651866186718681869187018711872187318741875187618771878187918801881188218831884188518861887188818891890189118921893189418951896189718981899190019011902190319041905190619071908190919101911191219131914191519161917191819191920192119221923192419251926192719281929193019311932193319341935193619371938193919401941194219431944194519461947194819491950195119521953195419551956195719581959196019611962196319641965196619671968196919701971197219731974197519761977197819791980198119821983198419851986198719881989199019911992199319941995199619971998199920002001200220032004200520062007200820092010201120122013201420152016201720182019202020212022202320242025202620272028202920302031203220332034203520362037203820392040204120422043204420452046204720482049205020512052205320542055205620572058205920602061206220632064206520662067206820692070207120722073207420752076207720782079208020812082208320842085208620872088208920902091209220932094209520962097209820992100210121022103210421052106210721082109211021112112211321142115211621172118211921202121212221232124212521262127212821292130213121322133213421352136213721382139214021412142214321442145214621472148214921502151215221532154215521562157215821592160216121622163216421652166216721682169217021712172217321742175217621772178217921802181218221832184218521862187218821892190219121922193219421952196219721982199220022012202220322042205220622072208220922102211221222132214221522162217221822192220222122222223222422252226222722282229223022312232223322342235223622372238223922402241224222432244224522462247224822492250225122522253225422552256225722582259226022612262226322642265226622672268226922702271227222732274227522762277227822792280228122822283228422852286228722882289229022912292229322942295229622972298229923002301230223032304230523062307230823092310231123122313231423152316231723182319232023212322232323242325232623272328232923302331233223332334233523362337233823392340234123422343234423452346234723482349235023512352235323542355235623572358235923602361236223632364236523662367236823692370237123722373237423752376237723782379238023812382238323842385238623872388238923902391239223932394239523962397239823992400240124022403240424052406240724082409241024112412241324142415241624172418241924202421242224232424242524262427242824292430243124322433243424352436243724382439244024412442244324442445244624472448244924502451245224532454245524562457245824592460246124622463246424652466246724682469247024712472247324742475247624772478247924802481248224832484248524862487248824892490249124922493249424952496249724982499250025012502250325042505250625072508250925102511251225132514251525162517251825192520252125222523252425252526252725282529253025312532253325342535253625372538253925402541254225432544254525462547254825492550255125522553255425552556255725582559256025612562256325642565256625672568256925702571257225732574257525762577257825792580258125822583258425852586258725882589259025912592259325942595259625972598259926002601260226032604260526062607260826092610261126122613261426152616261726182619262026212622262326242625262626272628262926302631263226332634263526362637263826392640264126422643264426452646264726482649265026512652265326542655265626572658265926602661266226632664266526662667266826692670267126722673267426752676267726782679268026812682268326842685268626872688268926902691269226932694269526962697269826992700270127022703270427052706270727082709271027112712271327142715271627172718271927202721272227232724272527262727272827292730273127322733273427352736273727382739274027412742274327442745274627472748274927502751275227532754275527562757275827592760276127622763276427652766276727682769277027712772277327742775277627772778277927802781278227832784278527862787278827892790279127922793279427952796279727982799280028012802280328042805280628072808280928102811281228132814281528162817281828192820282128222823282428252826282728282829283028312832283328342835283628372838283928402841284228432844284528462847284828492850285128522853285428552856285728582859286028612862286328642865286628672868286928702871287228732874287528762877287828792880288128822883288428852886288728882889289028912892289328942895289628972898289929002901290229032904290529062907290829092910291129122913291429152916291729182919292029212922292329242925292629272928292929302931293229332934293529362937293829392940294129422943294429452946294729482949295029512952295329542955295629572958295929602961296229632964296529662967296829692970297129722973297429752976297729782979298029812982298329842985298629872988298929902991299229932994299529962997299829993000300130023003300430053006300730083009301030113012301330143015301630173018301930203021302230233024302530263027302830293030303130323033303430353036303730383039304030413042304330443045304630473048304930503051305230533054305530563057305830593060306130623063306430653066306730683069307030713072307330743075307630773078307930803081308230833084308530863087308830893090309130923093309430953096309730983099310031013102310331043105310631073108310931103111311231133114311531163117311831193120312131223123312431253126312731283129313031313132313331343135313631373138313931403141314231433144314531463147314831493150315131523153315431553156315731583159316031613162316331643165316631673168316931703171317231733174317531763177317831793180318131823183318431853186318731883189319031913192319331943195319631973198319932003201320232033204320532063207320832093210321132123213321432153216321732183219322032213222322332243225322632273228322932303231323232333234323532363237323832393240324132423243324432453246324732483249325032513252325332543255325632573258325932603261326232633264326532663267326832693270327132723273327432753276327732783279328032813282328332843285328632873288328932903291329232933294329532963297329832993300330133023303330433053306330733083309331033113312331333143315331633173318331933203321332233233324332533263327332833293330333133323333333433353336333733383339334033413342334333443345334633473348334933503351335233533354335533563357335833593360336133623363336433653366336733683369337033713372337333743375337633773378337933803381338233833384338533863387338833893390339133923393339433953396339733983399340034013402340334043405340634073408340934103411341234133414341534163417341834193420342134223423342434253426342734283429343034313432343334343435343634373438343934403441344234433444344534463447344834493450345134523453345434553456345734583459346034613462346334643465346634673468346934703471347234733474347534763477347834793480348134823483348434853486348734883489349034913492349334943495349634973498349935003501350235033504350535063507350835093510351135123513351435153516351735183519352035213522352335243525352635273528352935303531353235333534353535363537353835393540354135423543354435453546354735483549355035513552355335543555355635573558355935603561356235633564356535663567356835693570357135723573357435753576357735783579358035813582358335843585358635873588358935903591359235933594359535963597359835993600360136023603360436053606360736083609361036113612361336143615361636173618361936203621362236233624362536263627362836293630363136323633363436353636363736383639 |
- //
- // Copyright (c) 2016-2017 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/role.hpp>
- #include <boost/beast/websocket/rfc6455.hpp>
- #include <boost/beast/websocket/stream_fwd.hpp>
- #include <boost/beast/websocket/detail/frame.hpp>
- #include <boost/beast/websocket/detail/hybi13.hpp>
- #include <boost/beast/websocket/detail/mask.hpp>
- #include <boost/beast/websocket/detail/pausation.hpp>
- #include <boost/beast/websocket/detail/pmd_extension.hpp>
- #include <boost/beast/websocket/detail/stream_base.hpp>
- #include <boost/beast/websocket/detail/utf8_checker.hpp>
- #include <boost/beast/core/static_buffer.hpp>
- #include <boost/beast/core/string.hpp>
- #include <boost/beast/core/detail/type_traits.hpp>
- #include <boost/beast/http/empty_body.hpp>
- #include <boost/beast/http/message.hpp>
- #include <boost/beast/http/string_body.hpp>
- #include <boost/beast/http/detail/type_traits.hpp>
- #include <boost/asio/async_result.hpp>
- #include <boost/asio/error.hpp>
- #include <algorithm>
- #include <cstdint>
- #include <functional>
- #include <limits>
- #include <type_traits>
- namespace boost {
- namespace beast {
- namespace websocket {
- /// The type of object holding HTTP Upgrade requests
- using request_type = http::request<http::empty_body>;
- /// The type of object holding HTTP Upgrade responses
- using response_type = http::response<http::string_body>;
- /** 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 use the @ref stream template with an `ip::tcp::socket`,
- you would write:
- @code
- websocket::stream<ip::tcp::socket> ws{io_context};
- @endcode
- Alternatively, you can write:
- @code
- ip::tcp::socket sock{io_context};
- websocket::stream<ip::tcp::socket&> ws{sock};
- @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 @b SyncStream concept.
- For asynchronous operations, the type must support the
- @b AsyncStream 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
- @b AsyncStream,
- @b DynamicBuffer,
- @b SyncStream
- */
- template<
- class NextLayer,
- bool deflateSupported>
- class stream
- #if ! BOOST_BEAST_DOXYGEN
- : private detail::stream_base<deflateSupported>
- #endif
- {
- friend class close_test;
- friend class frame_test;
- friend class ping_test;
- friend class read1_test;
- friend class read2_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;
- using control_cb_type =
- std::function<void(frame_type, string_view)>;
- enum class status
- {
- open,
- closing,
- closed,
- failed
- };
- NextLayer stream_; // the wrapped stream
- close_reason cr_; // set from received close frame
- control_cb_type ctrl_cb_; // control callback
- std::size_t rd_msg_max_ // max message size
- = 16 * 1024 * 1024;
- std::uint64_t rd_size_ // total size of current message so far
- = 0;
- std::uint64_t rd_remain_ // message frame bytes left in current frame
- = 0;
- detail::frame_header rd_fh_; // current frame header
- detail::prepared_key rd_key_; // current stateful mask key
- detail::frame_buffer rd_fb_; // to write control frames (during reads)
- detail::utf8_checker rd_utf8_; // to validate utf8
- static_buffer<
- +tcp_frame_size> rd_buf_; // buffer for reads
- detail::opcode rd_op_ // current message binary or text
- = detail::opcode::text;
- bool rd_cont_ // `true` if the next frame is a continuation
- = false;
- bool rd_done_ // set when a message is done
- = true;
- bool rd_close_ // did we read a close frame?
- = false;
- detail::soft_mutex rd_block_; // op currently reading
- role_type role_ // server or client
- = role_type::client;
- status status_
- = status::closed;
- detail::soft_mutex wr_block_; // op currently writing
- bool wr_close_ // did we write a close frame?
- = false;
- bool wr_cont_ // next write is a continuation
- = false;
- bool wr_frag_ // autofrag the current message
- = false;
- bool wr_frag_opt_ // autofrag option setting
- = true;
- bool wr_compress_ // compress current message
- = false;
- detail::opcode wr_opcode_ // message type
- = detail::opcode::text;
- std::unique_ptr<
- std::uint8_t[]> wr_buf_; // write buffer
- std::size_t wr_buf_size_ // write buffer size (current message)
- = 0;
- std::size_t wr_buf_opt_ // write buffer size option setting
- = 4096;
- detail::fh_buffer wr_fb_; // header buffer used for writes
- detail::pausation paused_rd_; // paused read op
- detail::pausation paused_wr_; // paused write op
- detail::pausation paused_ping_; // paused ping op
- detail::pausation paused_close_; // paused close op
- detail::pausation paused_r_rd_; // paused read op (async read)
- detail::pausation paused_r_close_;// paused close op (async read)
- 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 lowest layer.
- using lowest_layer_type = get_lowest_layer<next_layer_type>;
- /// The type of the executor associated with the object.
- using executor_type = typename next_layer_type::executor_type;
- /** 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() = default;
- /** Constructor
- If `NextLayer` is move constructible, this function
- will move-construct a new stream from the existing stream.
- @note The behavior of move assignment on or from streams
- with active or pending operations is undefined.
- */
- stream(stream&&) = default;
- /** Assignment
- If `NextLayer` is move assignable, this function
- will move-assign a new stream from the existing stream.
- @note The behavior of move assignment on or from streams
- with active or pending operations is undefined.
- */
- stream& operator=(stream&&) = default;
- /** 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);
- //--------------------------------------------------------------------------
- /** 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
- {
- return stream_.get_executor();
- }
- /** 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()
- {
- return stream_;
- }
- /** 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
- {
- return stream_;
- }
- /** Get a reference to the lowest layer
- This function returns a reference to the lowest layer
- in a stack of stream layers.
- @return A reference to the lowest layer in the stack of
- stream layers.
- */
- lowest_layer_type&
- lowest_layer()
- {
- return stream_.lowest_layer();
- }
- /** Get a reference to the lowest layer
- This function returns a reference to the lowest layer
- in a stack of stream layers.
- @return A reference to the lowest layer in the stack of
- stream layers. Ownership is not transferred to the caller.
- */
- lowest_layer_type const&
- lowest_layer() const
- {
- return stream_.lowest_layer();
- }
- //--------------------------------------------------------------------------
- //
- // 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
- {
- return status_ == status::open;
- }
- /** 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
- {
- return rd_op_ == detail::opcode::binary;
- }
- /** 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
- {
- return rd_done_;
- }
- /** Returns the close reason received from the peer.
- This is only valid after a read completes with error::closed.
- */
- close_reason const&
- reason() const
- {
- return cr_;
- }
- /** 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
- {
- return read_size_hint(initial_size,
- is_deflate_supported{});
- }
- /** 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
- //
- //--------------------------------------------------------------------------
- /** Set the permessage-deflate extension options
- @throws invalid_argument if `deflateSupported == false`, and either
- `client_enable` or `server_enable` is `true`.
- */
- void
- set_option(permessage_deflate const& o)
- {
- set_option(o, is_deflate_supported{});
- }
- /// Get the permessage-deflate extension options
- void
- get_option(permessage_deflate& o)
- {
- get_option(o, is_deflate_supported{});
- }
- /** 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)
- {
- wr_frag_opt_ = value;
- }
- /// Returns `true` if the automatic fragmentation option is set.
- bool
- auto_fragment() const
- {
- return wr_frag_opt_;
- }
- /** 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)
- {
- wr_opcode_ = value ?
- detail::opcode::binary :
- detail::opcode::text;
- }
- /// Returns `true` if the binary message write option is set.
- bool
- binary() const
- {
- return wr_opcode_ == detail::opcode::binary;
- }
- /** 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 possiblity 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)
- {
- ctrl_cb_ = std::move(cb);
- }
- /** Reset the control frame callback.
- This function removes any previously set control frame callback.
- */
- void
- control_callback()
- {
- ctrl_cb_ = {};
- }
- /** 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)
- {
- rd_msg_max_ = amount;
- }
- /// Returns the maximum incoming message size setting.
- std::size_t
- read_message_max() const
- {
- return rd_msg_max_;
- }
- /** 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)
- {
- this->secure_prng_ = 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_size(8192);
- @endcode
- @param amount The size of the write buffer in bytes.
- */
- void
- write_buffer_size(std::size_t amount)
- {
- if(amount < 8)
- BOOST_THROW_EXCEPTION(std::invalid_argument{
- "write buffer size underflow"});
- wr_buf_opt_ = amount;
- };
- /// Returns the size of the write buffer.
- std::size_t
- write_buffer_size() const
- {
- return wr_buf_opt_;
- }
- /** 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)
- {
- wr_opcode_ = value ?
- detail::opcode::text :
- detail::opcode::binary;
- }
- /// Returns `true` if the text message write option is set.
- bool
- text() const
- {
- return wr_opcode_ == detail::opcode::text;
- }
- //--------------------------------------------------------------------------
- //
- // Handshaking (Client)
- //
- //--------------------------------------------------------------------------
- /** Send an HTTP WebSocket Upgrade request and receive the response.
- This function is used to synchronously send the WebSocket
- upgrade HTTP request. 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 on the stream
- This function is implemented in terms of one or more calls to the
- next layer's `read_some` and `write_some` functions.
- The operation is successful if the received HTTP response indicates
- a successful HTTP Upgrade (represented by a Status-Code of 101,
- "switching protocols").
- @param host The name of the remote host,
- required by the HTTP protocol.
- @param target The Request Target, which may not be empty,
- required by the HTTP protocol.
- @throws system_error Thrown on failure.
- @par Example
- @code
- websocket::stream<ip::tcp::socket> ws{io_context};
- ...
- try
- {
- ws.handshake("localhost", "/");
- }
- catch(...)
- {
- // An error occurred.
- }
- @endcode
- */
- void
- handshake(
- string_view host,
- string_view target);
- /** Send an HTTP WebSocket Upgrade request and receive the response.
- This function is used to synchronously send the WebSocket
- upgrade HTTP request. 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 on the stream
- This function is implemented in terms of one or more calls to the
- next layer's `read_some` and `write_some` functions.
- The operation is successful if the received HTTP response indicates
- a successful HTTP Upgrade (represented by a Status-Code of 101,
- "switching protocols").
- @param res The HTTP Upgrade response returned by the remote
- endpoint.
- @param host The name of the remote host,
- required by the HTTP protocol.
- @param target The Request Target, which may not be empty,
- required by the HTTP protocol.
- @throws system_error Thrown on failure.
- @par Example
- @code
- websocket::stream<ip::tcp::socket> ws{io_context};
- ...
- try
- {
- response_type res;
- ws.handshake(res, "localhost", "/");
- }
- catch(...)
- {
- // An error occurred.
- }
- @endcode
- */
- void
- handshake(
- response_type& res,
- string_view host,
- string_view target);
- /** Send an HTTP WebSocket Upgrade request and receive the response.
- This function is used to synchronously send the WebSocket
- upgrade HTTP request. 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 on the stream
- This function is implemented in terms of one or more calls to the
- next layer's `read_some` and `write_some` functions.
- The operation is successful if the received HTTP response indicates
- a successful HTTP Upgrade (represented by a Status-Code of 101,
- "switching protocols").
- @param host The name of the remote host,
- required by the HTTP protocol.
- @param target The Request Target, which may not be empty,
- required by the HTTP protocol.
- @param decorator A function object which will be called to modify
- the HTTP request object generated by the implementation. This
- could be used to set the User-Agent field, subprotocols, or other
- application or HTTP specific fields. The object will be called
- with this equivalent signature:
- @code void decorator(
- request_type& req
- ); @endcode
- @throws system_error Thrown on failure.
- @par Example
- @code
- websocket::stream<ip::tcp::socket> ws{io_context};
- ...
- try
- {
- ws.handshake("localhost", "/",
- [](request_type& req)
- {
- req.set(field::user_agent, "Beast");
- });
- }
- catch(...)
- {
- // An error occurred.
- }
- @endcode
- */
- template<class RequestDecorator>
- void
- handshake_ex(
- string_view host,
- string_view target,
- RequestDecorator const& decorator);
- /** Send an HTTP WebSocket Upgrade request and receive the response.
- This function is used to synchronously send the WebSocket
- upgrade HTTP request. 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 on the stream
- This function is implemented in terms of one or more calls to the
- next layer's `read_some` and `write_some` functions.
- The operation is successful if the received HTTP response indicates
- a successful HTTP Upgrade (represented by a Status-Code of 101,
- "switching protocols").
- @param res The HTTP Upgrade response returned by the remote
- endpoint.
- @param host The name of the remote host,
- required by the HTTP protocol.
- @param target The Request Target, which may not be empty,
- required by the HTTP protocol.
- @param decorator A function object which will be called to modify
- the HTTP request object generated by the implementation. This
- could be used to set the User-Agent field, subprotocols, or other
- application or HTTP specific fields. The object will be called
- with this equivalent signature:
- @code void decorator(
- request_type& req
- ); @endcode
- @throws system_error Thrown on failure.
- @par Example
- @code
- websocket::stream<ip::tcp::socket> ws{io_context};
- ...
- try
- {
- response_type res;
- ws.handshake(res, "localhost", "/",
- [](request_type& req)
- {
- req.set(field::user_agent, "Beast");
- });
- }
- catch(...)
- {
- // An error occurred.
- }
- @endcode
- */
- template<class RequestDecorator>
- void
- handshake_ex(
- response_type& res,
- string_view host,
- string_view target,
- RequestDecorator const& decorator);
- /** Send an HTTP WebSocket Upgrade request and receive the response.
- This function is used to synchronously send the WebSocket
- upgrade HTTP request. 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 on the stream
- This function is implemented in terms of one or more calls to the
- next layer's `read_some` and `write_some` functions.
- The operation is successful if the received HTTP response indicates
- a successful HTTP Upgrade (represented by a Status-Code of 101,
- "switching protocols").
- @param host The name of the remote host,
- required by the HTTP protocol.
- @param target The Request Target, which may not be empty,
- required by the HTTP protocol.
- @param ec Set to indicate what error occurred, if any.
- @par Example
- @code
- websocket::stream<ip::tcp::socket> ws{io_context};
- ...
- error_code ec;
- ws.handshake(host, target, ec);
- if(ec)
- {
- // An error occurred.
- }
- @endcode
- */
- void
- handshake(
- string_view host,
- string_view target,
- error_code& ec);
- /** Send an HTTP WebSocket Upgrade request and receive the response.
- This function is used to synchronously send the WebSocket
- upgrade HTTP request. 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 on the stream
- This function is implemented in terms of one or more calls to the
- next layer's `read_some` and `write_some` functions.
- The operation is successful if the received HTTP response indicates
- a successful HTTP Upgrade (represented by a Status-Code of 101,
- "switching protocols").
- @param res The HTTP Upgrade response returned by the remote
- endpoint. If `ec` is set, the returned value is undefined.
- @param host The name of the remote host,
- required by the HTTP protocol.
- @param target The Request Target, which may not be empty,
- required by the HTTP protocol.
- @param ec Set to indicate what error occurred, if any.
- @par Example
- @code
- websocket::stream<ip::tcp::socket> ws{io_context};
- ...
- error_code ec;
- response_type res;
- ws.handshake(res, host, target, ec);
- if(ec)
- {
- // An error occurred.
- }
- @endcode
- */
- void
- handshake(
- response_type& res,
- string_view host,
- string_view target,
- error_code& ec);
- /** Send an HTTP WebSocket Upgrade request and receive the response.
- This function is used to synchronously send the WebSocket
- upgrade HTTP request. 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 on the stream
- This function is implemented in terms of one or more calls to the
- next layer's `read_some` and `write_some` functions.
- The operation is successful if the received HTTP response indicates
- a successful HTTP Upgrade (represented by a Status-Code of 101,
- "switching protocols").
- @param host The name of the remote host,
- required by the HTTP protocol.
- @param target The Request Target, which may not be empty,
- required by the HTTP protocol.
- @param decorator A function object which will be called to modify
- the HTTP request object generated by the implementation. This
- could be used to set the User-Agent field, subprotocols, or other
- application or HTTP specific fields. The object will be called
- with this equivalent signature:
- @code void decorator(
- request_type& req
- ); @endcode
- @param ec Set to indicate what error occurred, if any.
- @par Example
- @code
- websocket::stream<ip::tcp::socket> ws{io_context};
- ...
- error_code ec;
- ws.handshake("localhost", "/",
- [](request_type& req)
- {
- req.set(field::user_agent, "Beast");
- },
- ec);
- if(ec)
- {
- // An error occurred.
- }
- @endcode
- */
- template<class RequestDecorator>
- void
- handshake_ex(
- string_view host,
- string_view target,
- RequestDecorator const& decorator,
- error_code& ec);
- /** Send an HTTP WebSocket Upgrade request and receive the response.
- This function is used to synchronously send the WebSocket
- upgrade HTTP request. 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 on the stream
- This function is implemented in terms of one or more calls to the
- next layer's `read_some` and `write_some` functions.
- The operation is successful if the received HTTP response indicates
- a successful HTTP Upgrade (represented by a Status-Code of 101,
- "switching protocols").
- @param res The HTTP Upgrade response returned by the remote
- endpoint.
- @param host The name of the remote host,
- required by the HTTP protocol.
- @param target The Request Target, which may not be empty,
- required by the HTTP protocol.
- @param decorator A function object which will be called to modify
- the HTTP request object generated by the implementation. This
- could be used to set the User-Agent field, subprotocols, or other
- application or HTTP specific fields. The object will be called
- with this equivalent signature:
- @code void decorator(
- request_type& req
- ); @endcode
- @param ec Set to indicate what error occurred, if any.
- @par Example
- @code
- websocket::stream<ip::tcp::socket> ws{io_context};
- ...
- error_code ec;
- response_type res;
- ws.handshake(res, "localhost", "/",
- [](request_type& req)
- {
- req.set(field::user_agent, "Beast");
- },
- ec);
- if(ec)
- {
- // An error occurred.
- }
- @endcode
- */
- template<class RequestDecorator>
- void
- handshake_ex(
- response_type& res,
- string_view host,
- string_view target,
- RequestDecorator const& decorator,
- error_code& ec);
- /** Start an asynchronous operation to send an upgrade request and receive the response.
- This function is used to asynchronously send the HTTP WebSocket
- upgrade request and receive the HTTP WebSocket Upgrade response.
- This function 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 on the stream
- This operation is implemented in terms of one or more calls to the
- next layer's `async_read_some` and `async_write_some` functions, and
- is known as a <em>composed operation</em>. The program must ensure
- that the stream performs no other operations until this operation
- completes.
- The operation is successful if the received HTTP response indicates
- a successful HTTP Upgrade (represented by a Status-Code of 101,
- "switching protocols").
- @param host The name of the remote host, required by
- the HTTP protocol. Copies may be made as needed.
- @param target The Request Target, which may not be empty,
- required by the HTTP protocol. Copies of this parameter may
- be made as needed.
- @param handler Invoked when the operation completes.
- The handler may be moved or copied as needed.
- The equivalent function signature of the handler must be:
- @code void handler(
- error_code const& ec // Result of operation
- ); @endcode
- Regardless of whether the asynchronous operation completes
- immediately or not, the handler will not be invoked from within
- this function. Invocation of the handler will be performed in a
- manner equivalent to using `boost::asio::io_context::post`.
- */
- template<class HandshakeHandler>
- BOOST_ASIO_INITFN_RESULT_TYPE(
- HandshakeHandler, void(error_code))
- async_handshake(
- string_view host,
- string_view target,
- HandshakeHandler&& handler);
- /** Start an asynchronous operation to send an upgrade request and receive the response.
- This function is used to asynchronously send the HTTP WebSocket
- upgrade request and receive the HTTP WebSocket Upgrade response.
- This function 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 on the stream
- This operation is implemented in terms of one or more calls to the
- next layer's `async_read_some` and `async_write_some` functions, and
- is known as a <em>composed operation</em>. The program must ensure
- that the stream performs no other operations until this operation
- completes.
- The operation is successful if the received HTTP response indicates
- a successful HTTP Upgrade (represented by a Status-Code of 101,
- "switching protocols").
- @param res The HTTP Upgrade response returned by the remote
- endpoint. The caller must ensure this object is valid for at
- least until the completion handler is invoked.
- @param host The name of the remote host, required by
- the HTTP protocol. Copies may be made as needed.
- @param target The Request Target, which may not be empty,
- required by the HTTP protocol. Copies of this parameter may
- be made as needed.
- @param handler Invoked when the operation completes.
- The handler may be moved or copied as needed.
- The equivalent function signature of the handler must be:
- @code void handler(
- error_code const& ec // Result of operation
- ); @endcode
- Regardless of whether the asynchronous operation completes
- immediately or not, the handler will not be invoked from within
- this function. Invocation of the handler will be performed in a
- manner equivalent to using `boost::asio::io_context::post`.
- */
- template<class HandshakeHandler>
- BOOST_ASIO_INITFN_RESULT_TYPE(
- HandshakeHandler, void(error_code))
- async_handshake(
- response_type& res,
- string_view host,
- string_view target,
- HandshakeHandler&& handler);
- /** Start an asynchronous operation to send an upgrade request and receive the response.
- This function is used to asynchronously send the HTTP WebSocket
- upgrade request and receive the HTTP WebSocket Upgrade response.
- This function 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 on the stream
- This operation is implemented in terms of one or more calls to the
- next layer's `async_read_some` and `async_write_some` functions, and
- is known as a <em>composed operation</em>. The program must ensure
- that the stream performs no other operations until this operation
- completes.
- The operation is successful if the received HTTP response indicates
- a successful HTTP Upgrade (represented by a Status-Code of 101,
- "switching protocols").
- @param host The name of the remote host, required by
- the HTTP protocol. Copies may be made as needed.
- @param target The Request Target, which may not be empty,
- required by the HTTP protocol. Copies of this parameter may
- be made as needed.
- @param decorator A function object which will be called to modify
- the HTTP request object generated by the implementation. This
- could be used to set the User-Agent field, subprotocols, or other
- application or HTTP specific fields. The object will be called
- with this equivalent signature:
- @code void decorator(
- request_type& req
- ); @endcode
- @param handler Invoked when the operation completes.
- The handler may be moved or copied as needed.
- The equivalent function signature of the handler must be:
- @code void handler(
- error_code const& ec // Result of operation
- ); @endcode
- Regardless of whether the asynchronous operation completes
- immediately or not, the handler will not be invoked from within
- this function. Invocation of the handler will be performed in a
- manner equivalent to using `boost::asio::io_context::post`.
- */
- template<class RequestDecorator, class HandshakeHandler>
- BOOST_ASIO_INITFN_RESULT_TYPE(
- HandshakeHandler, void(error_code))
- async_handshake_ex(
- string_view host,
- string_view target,
- RequestDecorator const& decorator,
- HandshakeHandler&& handler);
- /** Start an asynchronous operation to send an upgrade request and receive the response.
- This function is used to asynchronously send the HTTP WebSocket
- upgrade request and receive the HTTP WebSocket Upgrade response.
- This function 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 on the stream
- This operation is implemented in terms of one or more calls to the
- next layer's `async_read_some` and `async_write_some` functions, and
- is known as a <em>composed operation</em>. The program must ensure
- that the stream performs no other operations until this operation
- completes.
- The operation is successful if the received HTTP response indicates
- a successful HTTP Upgrade (represented by a Status-Code of 101,
- "switching protocols").
- @param res The HTTP Upgrade response returned by the remote
- endpoint. The caller must ensure this object is valid for at
- least until the completion handler is invoked.
- @param host The name of the remote host, required by
- the HTTP protocol. Copies may be made as needed.
- @param target The Request Target, which may not be empty,
- required by the HTTP protocol. Copies of this parameter may
- be made as needed.
- @param decorator A function object which will be called to modify
- the HTTP request object generated by the implementation. This
- could be used to set the User-Agent field, subprotocols, or other
- application or HTTP specific fields. The object will be called
- with this equivalent signature:
- @code void decorator(
- request_type& req
- ); @endcode
- @param handler Invoked when the operation completes.
- The handler may be moved or copied as needed.
- The equivalent function signature of the handler must be:
- @code void handler(
- error_code const& ec // Result of operation
- ); @endcode
- Regardless of whether the asynchronous operation completes
- immediately or not, the handler will not be invoked from within
- this function. Invocation of the handler will be performed in a
- manner equivalent to using `boost::asio::io_context::post`.
- */
- template<class RequestDecorator, class HandshakeHandler>
- BOOST_ASIO_INITFN_RESULT_TYPE(
- HandshakeHandler, void(error_code))
- async_handshake_ex(
- response_type& res,
- string_view host,
- string_view target,
- RequestDecorator const& decorator,
- HandshakeHandler&& handler);
- //--------------------------------------------------------------------------
- //
- // Handshaking (Server)
- //
- //--------------------------------------------------------------------------
- /** Read and respond to a WebSocket HTTP Upgrade request.
- This function is used to synchronously read an HTTP WebSocket
- Upgrade request and send the HTTP response. The call blocks
- until one of the following conditions is true:
- @li The request is received and the response finishes sending.
- @li An error occurs on the stream.
- This function is implemented in terms of one or more calls to
- the next layer's `read_some` and `write_some` functions.
- If the stream receives a valid HTTP WebSocket Upgrade request,
- an HTTP response is sent back indicating a successful upgrade.
- When this call returns, the stream is then ready to send and
- receive WebSocket protocol frames and messages.
- If the HTTP Upgrade request is invalid or cannot be satisfied,
- an HTTP response is sent indicating the reason and status code
- (typically 400, "Bad Request"). This counts as a failure.
- The implementation uses fixed size internal storage to
- receive the request. If the request is too large, the error
- @ref error::buffer_overflow will be indicated. Applications
- that wish to receive larger requests should first read the
- request using their own buffer and a suitable overload of
- @ref http::read or @ref http::async_read, then call @ref accept
- or @ref async_accept with the request.
- @throws system_error Thrown on failure.
- */
- void
- accept();
- /** Read and respond to a WebSocket HTTP Upgrade request.
- This function is used to synchronously read an HTTP WebSocket
- Upgrade request and send the HTTP response. The call blocks
- until one of the following conditions is true:
- @li The request is received and the response finishes sending.
- @li An error occurs on the stream.
- This function is implemented in terms of one or more calls to
- the next layer's `read_some` and `write_some` functions.
- If the stream receives a valid HTTP WebSocket Upgrade request,
- an HTTP response is sent back indicating a successful upgrade.
- When this call returns, the stream is then ready to send and
- receive WebSocket protocol frames and messages.
- If the HTTP Upgrade request is invalid or cannot be satisfied,
- an HTTP response is sent indicating the reason and status code
- (typically 400, "Bad Request"). This counts as a failure.
- The implementation uses fixed size internal storage to
- receive the request. If the request is too large, the error
- @ref error::buffer_overflow will be indicated. Applications
- that wish to receive larger requests should first read the
- request using their own buffer and a suitable overload of
- @ref http::read or @ref http::async_read, then call @ref accept
- or @ref async_accept with the request.
- @param decorator A function object which will be called to modify
- the HTTP response object delivered by the implementation. This
- could be used to set the Server field, subprotocols, or other
- application or HTTP specific fields. The object will be called
- with this equivalent signature:
- @code void decorator(
- response_type& res
- ); @endcode
- @throws system_error Thrown on failure.
- */
- template<class ResponseDecorator>
- void
- accept_ex(ResponseDecorator const& decorator);
- /** Read and respond to a WebSocket HTTP Upgrade request.
- This function is used to synchronously read an HTTP WebSocket
- Upgrade request and send the HTTP response. The call blocks
- until one of the following conditions is true:
- @li The request is received and the response finishes sending.
- @li An error occurs on the stream.
- This function is implemented in terms of one or more calls to
- the next layer's `read_some` and `write_some` functions.
- If the stream receives a valid HTTP WebSocket Upgrade request,
- an HTTP response is sent back indicating a successful upgrade.
- When this call returns, the stream is then ready to send and
- receive WebSocket protocol frames and messages.
- If the HTTP Upgrade request is invalid or cannot be satisfied,
- an HTTP response is sent indicating the reason and status code
- (typically 400, "Bad Request"). This counts as a failure.
- The implementation uses fixed size internal storage to
- receive the request. If the request is too large, the error
- @ref error::buffer_overflow will be indicated. Applications
- that wish to receive larger requests should first read the
- request using their own buffer and a suitable overload of
- @ref http::read or @ref http::async_read, then call @ref accept
- or @ref async_accept with the request.
- @param ec Set to indicate what error occurred, if any.
- */
- void
- accept(error_code& ec);
- /** Read and respond to a WebSocket HTTP Upgrade request.
- This function is used to synchronously read an HTTP WebSocket
- Upgrade request and send the HTTP response. The call blocks
- until one of the following conditions is true:
- @li The request is received and the response finishes sending.
- @li An error occurs on the stream.
- This function is implemented in terms of one or more calls to
- the next layer's `read_some` and `write_some` functions.
- If the stream receives a valid HTTP WebSocket Upgrade request,
- an HTTP response is sent back indicating a successful upgrade.
- When this call returns, the stream is then ready to send and
- receive WebSocket protocol frames and messages.
- If the HTTP Upgrade request is invalid or cannot be satisfied,
- an HTTP response is sent indicating the reason and status code
- (typically 400, "Bad Request"). This counts as a failure.
- The implementation uses fixed size internal storage to
- receive the request. If the request is too large, the error
- @ref error::buffer_overflow will be indicated. Applications
- that wish to receive larger requests should first read the
- request using their own buffer and a suitable overload of
- @ref http::read or @ref http::async_read, then call @ref accept
- or @ref async_accept with the request.
- @param decorator A function object which will be called to modify
- the HTTP response object delivered by the implementation. This
- could be used to set the Server field, subprotocols, or other
- application or HTTP specific fields. The object will be called
- with this equivalent signature:
- @code void decorator(
- response_type& res
- ); @endcode
- @param ec Set to indicate what error occurred, if any.
- */
- template<class ResponseDecorator>
- void
- accept_ex(
- ResponseDecorator const& decorator,
- error_code& ec);
- /** Read and respond to a WebSocket HTTP Upgrade request.
- This function is used to synchronously read an HTTP WebSocket
- Upgrade request and send the HTTP response. The call blocks
- until one of the following conditions is true:
- @li The request is received and the response finishes sending.
- @li An error occurs on the stream.
- This function is implemented in terms of one or more calls to
- the next layer's `read_some` and `write_some` functions.
- If the stream receives a valid HTTP WebSocket Upgrade request,
- an HTTP response is sent back indicating a successful upgrade.
- When this call returns, the stream is then ready to send and
- receive WebSocket protocol frames and messages.
- If the HTTP Upgrade request is invalid or cannot be satisfied,
- an HTTP response is sent indicating the reason and status code
- (typically 400, "Bad Request"). This counts as a failure.
- The implementation uses fixed size internal storage to
- receive the request. If the request is too large, the error
- @ref error::buffer_overflow will be indicated. Applications
- that wish to receive larger requests should first read the
- request using their own buffer and a suitable overload of
- @ref http::read or @ref http::async_read, then call @ref accept
- or @ref async_accept with the request.
- @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.
- */
- 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 synchronously read an HTTP WebSocket
- Upgrade request and send the HTTP response. The call blocks
- until one of the following conditions is true:
- @li The request is received and the response finishes sending.
- @li An error occurs on the stream.
- This function is implemented in terms of one or more calls to
- the next layer's `read_some` and `write_some` functions.
- If the stream receives a valid HTTP WebSocket Upgrade request,
- an HTTP response is sent back indicating a successful upgrade.
- When this call returns, the stream is then ready to send and
- receive WebSocket protocol frames and messages.
- If the HTTP Upgrade request is invalid or cannot be satisfied,
- an HTTP response is sent indicating the reason and status code
- (typically 400, "Bad Request"). This counts as a failure.
- The implementation uses fixed size internal storage to
- receive the request. If the request is too large, the error
- @ref error::buffer_overflow will be indicated. Applications
- that wish to receive larger requests should first read the
- request using their own buffer and a suitable overload of
- @ref http::read or @ref http::async_read, then call @ref accept
- or @ref async_accept with the request.
- @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 decorator A function object which will be called to modify
- the HTTP response object delivered by the implementation. This
- could be used to set the Server field, subprotocols, or other
- application or HTTP specific fields. The object will be called
- with this equivalent signature:
- @code void decorator(
- response_type& res
- ); @endcode
- @throws system_error Thrown on failure.
- */
- template<class ConstBufferSequence,
- class ResponseDecorator>
- #if BOOST_BEAST_DOXYGEN
- void
- #else
- typename std::enable_if<! http::detail::is_header<
- ConstBufferSequence>::value>::type
- #endif
- accept_ex(
- ConstBufferSequence const& buffers,
- ResponseDecorator const& decorator);
- /** Read and respond to a WebSocket HTTP Upgrade request.
- This function is used to synchronously read an HTTP WebSocket
- Upgrade request and send the HTTP response. The call blocks
- until one of the following conditions is true:
- @li The request is received and the response finishes sending.
- @li An error occurs on the stream.
- This function is implemented in terms of one or more calls to
- the next layer's `read_some` and `write_some` functions.
- If the stream receives a valid HTTP WebSocket Upgrade request,
- an HTTP response is sent back indicating a successful upgrade.
- When this call returns, the stream is then ready to send and
- receive WebSocket protocol frames and messages.
- If the HTTP Upgrade request is invalid or cannot be satisfied,
- an HTTP response is sent indicating the reason and status code
- (typically 400, "Bad Request"). This counts as a failure.
- The implementation uses fixed size internal storage to
- receive the request. If the request is too large, the error
- @ref error::buffer_overflow will be indicated. Applications
- that wish to receive larger requests should first read the
- request using their own buffer and a suitable overload of
- @ref http::read or @ref http::async_read, then call @ref accept
- or @ref async_accept with the request.
- @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.
- */
- 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);
- /** Read and respond to a WebSocket HTTP Upgrade request.
- This function is used to synchronously read an HTTP WebSocket
- Upgrade request and send the HTTP response. The call blocks
- until one of the following conditions is true:
- @li The request is received and the response finishes sending.
- @li An error occurs on the stream.
- This function is implemented in terms of one or more calls to
- the next layer's `read_some` and `write_some` functions.
- If the stream receives a valid HTTP WebSocket Upgrade request,
- an HTTP response is sent back indicating a successful upgrade.
- When this call returns, the stream is then ready to send and
- receive WebSocket protocol frames and messages.
- If the HTTP Upgrade request is invalid or cannot be satisfied,
- an HTTP response is sent indicating the reason and status code
- (typically 400, "Bad Request"). This counts as a failure.
- The implementation uses fixed size internal storage to
- receive the request. If the request is too large, the error
- @ref error::buffer_overflow will be indicated. Applications
- that wish to receive larger requests should first read the
- request using their own buffer and a suitable overload of
- @ref http::read or @ref http::async_read, then call @ref accept
- or @ref async_accept with the request.
- @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 decorator A function object which will be called to modify
- the HTTP response object delivered by the implementation. This
- could be used to set the Server field, subprotocols, or other
- application or HTTP specific fields. The object will be called
- with this equivalent signature:
- @code void decorator(
- response_type& res
- ); @endcode
- @param ec Set to indicate what error occurred, if any.
- */
- template<class ConstBufferSequence, class ResponseDecorator>
- #if BOOST_BEAST_DOXYGEN
- void
- #else
- typename std::enable_if<! http::detail::is_header<
- ConstBufferSequence>::value>::type
- #endif
- accept_ex(
- ConstBufferSequence const& buffers,
- ResponseDecorator const& decorator,
- error_code& ec);
- /** Respond to a WebSocket HTTP Upgrade request
- This function is used to synchronously send the HTTP response
- to an HTTP request possibly containing a WebSocket Upgrade.
- The call blocks until one of the following conditions is true:
- @li The response finishes sending.
- @li An error occurs on the stream.
- This function is implemented in terms of one or more calls to
- the next layer's `read_some` and `write_some` functions.
- If the stream receives a valid HTTP WebSocket Upgrade request,
- an HTTP response is sent back indicating a successful upgrade.
- When this call returns, the stream is then ready to send and
- receive WebSocket protocol frames and messages.
- If the HTTP Upgrade request is invalid or cannot be satisfied,
- an HTTP response is sent indicating the reason and status code
- (typically 400, "Bad Request"). This counts as a failure.
- @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.
- */
- 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 synchronously send the HTTP response
- to an HTTP request possibly containing a WebSocket Upgrade.
- The call blocks until one of the following conditions is true:
- @li The response finishes sending.
- @li An error occurs on the stream.
- This function is implemented in terms of one or more calls to
- the next layer's `read_some` and `write_some` functions.
- If the stream receives a valid HTTP WebSocket Upgrade request,
- an HTTP response is sent back indicating a successful upgrade.
- When this call returns, the stream is then ready to send and
- receive WebSocket protocol frames and messages.
- If the HTTP Upgrade request is invalid or cannot be satisfied,
- an HTTP response is sent indicating the reason and status code
- (typically 400, "Bad Request"). This counts as a failure.
- @param req An object containing the HTTP Upgrade request.
- Ownership is not transferred, the implementation will not
- access this object from other threads.
- @param decorator A function object which will be called to modify
- the HTTP response object delivered by the implementation. This
- could be used to set the Server field, subprotocols, or other
- application or HTTP specific fields. The object will be called
- with this equivalent signature:
- @code void decorator(
- response_type& res
- ); @endcode
- @throws system_error Thrown on failure.
- */
- template<class Body, class Allocator,
- class ResponseDecorator>
- void
- accept_ex(http::request<Body,
- http::basic_fields<Allocator>> const& req,
- ResponseDecorator const& decorator);
- /** Respond to a WebSocket HTTP Upgrade request
- This function is used to synchronously send the HTTP response
- to an HTTP request possibly containing a WebSocket Upgrade.
- The call blocks until one of the following conditions is true:
- @li The response finishes sending.
- @li An error occurs on the stream.
- This function is implemented in terms of one or more calls to
- the next layer's `read_some` and `write_some` functions.
- If the stream receives a valid HTTP WebSocket Upgrade request,
- an HTTP response is sent back indicating a successful upgrade.
- When this call returns, the stream is then ready to send and
- receive WebSocket protocol frames and messages.
- If the HTTP Upgrade request is invalid or cannot be satisfied,
- an HTTP response is sent indicating the reason and status code
- (typically 400, "Bad Request"). This counts as a failure.
- @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.
- */
- template<class Body, class Allocator>
- void
- accept(http::request<Body,
- http::basic_fields<Allocator>> const& req,
- error_code& ec);
- /** Respond to a WebSocket HTTP Upgrade request
- This function is used to synchronously send the HTTP response
- to an HTTP request possibly containing a WebSocket Upgrade.
- The call blocks until one of the following conditions is true:
- @li The response finishes sending.
- @li An error occurs on the stream.
- This function is implemented in terms of one or more calls to
- the next layer's `read_some` and `write_some` functions.
- If the stream receives a valid HTTP WebSocket Upgrade request,
- an HTTP response is sent back indicating a successful upgrade.
- When this call returns, the stream is then ready to send and
- receive WebSocket protocol frames and messages.
- If the HTTP Upgrade request is invalid or cannot be satisfied,
- an HTTP response is sent indicating the reason and status code
- (typically 400, "Bad Request"). This counts as a failure.
- @param req An object containing the HTTP Upgrade request.
- Ownership is not transferred, the implementation will not
- access this object from other threads.
- @param decorator A function object which will be called to modify
- the HTTP response object delivered by the implementation. This
- could be used to set the Server field, subprotocols, or other
- application or HTTP specific fields. The object will be called
- with this equivalent signature:
- @code void decorator(
- response_type& res
- ); @endcode
- @param ec Set to indicate what error occurred, if any.
- */
- template<class Body, class Allocator,
- class ResponseDecorator>
- void
- accept_ex(http::request<Body,
- http::basic_fields<Allocator>> const& req,
- ResponseDecorator const& decorator,
- error_code& ec);
- /** Start reading and responding to a WebSocket HTTP Upgrade request.
- This function is used to asynchronously read an HTTP WebSocket
- Upgrade request and send the HTTP response. The function 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 finishes sending.
- @li An error occurs on the stream.
- This operation is implemented in terms of one or more calls to
- the next layer's `async_read_some` and `async_write_some`
- functions, and is known as a <em>composed operation</em>. The
- program must ensure that the stream performs no other
- asynchronous operations until this operation completes.
- If the stream receives a valid HTTP WebSocket Upgrade request,
- an HTTP response is sent back indicating a successful upgrade.
- When the completion handler is invoked, the stream is then
- ready to send and receive WebSocket protocol frames and
- messages.
- If the HTTP Upgrade request is invalid or cannot be satisfied,
- an HTTP response is sent indicating the reason and status code
- (typically 400, "Bad Request"). This counts as a failure, and
- the completion handler will be invoked with a suitable error
- code set.
- The implementation uses fixed size internal storage to
- receive the request. If the request is too large, the error
- @ref error::buffer_overflow will be indicated. Applications
- that wish to receive larger requests should first read the
- request using their own buffer and a suitable overload of
- @ref http::read or @ref http::async_read, then call @ref accept
- or @ref async_accept with the request.
- @param handler Invoked when the operation completes.
- The handler may be moved or copied as needed.
- The equivalent function signature of the handler must be:
- @code void handler(
- error_code const& ec // Result of operation
- ); @endcode
- Regardless of whether the asynchronous operation completes
- immediately or not, the handler will not be invoked from within
- this function. Invocation of the handler will be performed in a
- manner equivalent to using `boost::asio::io_context::post`.
- */
- template<class AcceptHandler>
- BOOST_ASIO_INITFN_RESULT_TYPE(
- AcceptHandler, void(error_code))
- async_accept(AcceptHandler&& handler);
- /** Start reading and responding to a WebSocket HTTP Upgrade request.
- This function is used to asynchronously read an HTTP WebSocket
- Upgrade request and send the HTTP response. The function 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 finishes sending.
- @li An error occurs on the stream.
- This operation is implemented in terms of one or more calls to
- the next layer's `async_read_some` and `async_write_some`
- functions, and is known as a <em>composed operation</em>. The
- program must ensure that the stream performs no other
- asynchronous operations until this operation completes.
- If the stream receives a valid HTTP WebSocket Upgrade request,
- an HTTP response is sent back indicating a successful upgrade.
- When the completion handler is invoked, the stream is then
- ready to send and receive WebSocket protocol frames and
- messages.
- If the HTTP Upgrade request is invalid or cannot be satisfied,
- an HTTP response is sent indicating the reason and status code
- (typically 400, "Bad Request"). This counts as a failure, and
- the completion handler will be invoked with a suitable error
- code set.
- The implementation uses fixed size internal storage to
- receive the request. If the request is too large, the error
- @ref error::buffer_overflow will be indicated. Applications
- that wish to receive larger requests should first read the
- request using their own buffer and a suitable overload of
- @ref http::read or @ref http::async_read, then call @ref accept
- or @ref async_accept with the request.
- @param decorator A function object which will be called to modify
- the HTTP response object delivered by the implementation. This
- could be used to set the Server field, subprotocols, or other
- application or HTTP specific fields. The object will be called
- with this equivalent signature:
- @code void decorator(
- response_type& res
- ); @endcode
- @param handler Invoked when the operation completes.
- The handler may be moved or copied as needed.
- The equivalent function signature of the handler must be:
- @code void handler(
- error_code const& ec // Result of operation
- ); @endcode
- Regardless of whether the asynchronous operation completes
- immediately or not, the handler will not be invoked from within
- this function. Invocation of the handler will be performed in a
- manner equivalent to using `boost::asio::io_context::post`.
- */
- template<
- class ResponseDecorator,
- class AcceptHandler>
- BOOST_ASIO_INITFN_RESULT_TYPE(
- AcceptHandler, void(error_code))
- async_accept_ex(
- ResponseDecorator const& decorator,
- AcceptHandler&& handler);
- /** Start reading and responding to a WebSocket HTTP Upgrade request.
- This function is used to asynchronously read an HTTP WebSocket
- Upgrade request and send the HTTP response. The function 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 finishes sending.
- @li An error occurs on the stream.
- This operation is implemented in terms of one or more calls to
- the next layer's `async_read_some` and `async_write_some`
- functions, and is known as a <em>composed operation</em>. The
- program must ensure that the stream performs no other
- asynchronous operations until this operation completes.
- If the stream receives a valid HTTP WebSocket Upgrade request,
- an HTTP response is sent back indicating a successful upgrade.
- When the completion handler is invoked, the stream is then
- ready to send and receive WebSocket protocol frames and
- messages.
- If the HTTP Upgrade request is invalid or cannot be satisfied,
- an HTTP response is sent indicating the reason and status code
- (typically 400, "Bad Request"). This counts as a failure, and
- the completion handler will be invoked with a suitable error
- code set.
- The implementation uses fixed size internal storage to
- receive the request. If the request is too large, the error
- @ref error::buffer_overflow will be indicated. Applications
- that wish to receive larger requests should first read the
- request using their own buffer and a suitable overload of
- @ref http::read or @ref http::async_read, then call @ref accept
- or @ref async_accept with the request.
- @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 Invoked when the operation completes.
- The handler may be moved or copied as needed.
- The equivalent function signature of the handler must be:
- @code void handler(
- error_code const& ec // Result of operation
- ); @endcode
- Regardless of whether the asynchronous operation completes
- immediately or not, the handler will not be invoked from within
- this function. Invocation of the handler will be performed in a
- manner equivalent to using `boost::asio::io_context::post`.
- */
- template<
- class ConstBufferSequence,
- class AcceptHandler>
- #if BOOST_BEAST_DOXYGEN
- void_or_deduced
- #else
- typename std::enable_if<
- ! http::detail::is_header<ConstBufferSequence>::value,
- BOOST_ASIO_INITFN_RESULT_TYPE(
- AcceptHandler, void(error_code))>::type
- #endif
- async_accept(
- ConstBufferSequence const& buffers,
- AcceptHandler&& handler);
- /** Start reading and responding to a WebSocket HTTP Upgrade request.
- This function is used to asynchronously read an HTTP WebSocket
- Upgrade request and send the HTTP response. The function 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 finishes sending.
- @li An error occurs on the stream.
- This operation is implemented in terms of one or more calls to
- the next layer's `async_read_some` and `async_write_some`
- functions, and is known as a <em>composed operation</em>. The
- program must ensure that the stream performs no other
- asynchronous operations until this operation completes.
- If the stream receives a valid HTTP WebSocket Upgrade request,
- an HTTP response is sent back indicating a successful upgrade.
- When the completion handler is invoked, the stream is then
- ready to send and receive WebSocket protocol frames and
- messages.
- If the HTTP Upgrade request is invalid or cannot be satisfied,
- an HTTP response is sent indicating the reason and status code
- (typically 400, "Bad Request"). This counts as a failure, and
- the completion handler will be invoked with a suitable error
- code set.
- The implementation uses fixed size internal storage to
- receive the request. If the request is too large, the error
- @ref error::buffer_overflow will be indicated. Applications
- that wish to receive larger requests should first read the
- request using their own buffer and a suitable overload of
- @ref http::read or @ref http::async_read, then call @ref accept
- or @ref async_accept with the request.
- @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 decorator A function object which will be called to modify
- the HTTP response object delivered by the implementation. This
- could be used to set the Server field, subprotocols, or other
- application or HTTP specific fields. The object will be called
- with this equivalent signature:
- @code void decorator(
- response_type& res
- ); @endcode
- @param handler Invoked when the operation completes.
- The handler may be moved or copied as needed.
- The equivalent function signature of the handler must be:
- @code void handler(
- error_code const& ec // Result of operation
- ); @endcode
- Regardless of whether the asynchronous operation completes
- immediately or not, the handler will not be invoked from within
- this function. Invocation of the handler will be performed in a
- manner equivalent to using `boost::asio::io_context::post`.
- */
- template<
- class ConstBufferSequence,
- class ResponseDecorator,
- class AcceptHandler>
- #if BOOST_BEAST_DOXYGEN
- void_or_deduced
- #else
- typename std::enable_if<
- ! http::detail::is_header<ConstBufferSequence>::value,
- BOOST_ASIO_INITFN_RESULT_TYPE(
- AcceptHandler, void(error_code))>::type
- #endif
- async_accept_ex(
- ConstBufferSequence const& buffers,
- ResponseDecorator const& decorator,
- AcceptHandler&& handler);
- /** Start responding to a WebSocket HTTP Upgrade request.
- This function is used to asynchronously send the HTTP response
- to an HTTP request possibly containing a WebSocket Upgrade
- request. The function call always returns immediately. The
- asynchronous operation will continue until one of the following
- conditions is true:
- @li The response finishes sending.
- @li An error occurs on the stream.
- This operation is implemented in terms of one or more calls to
- the next layer's `async_write_some` functions, and is known as
- a <em>composed operation</em>. The program must ensure that the
- stream performs no other operations until this operation
- completes.
- If the stream receives a valid HTTP WebSocket Upgrade request,
- an HTTP response is sent back indicating a successful upgrade.
- When the completion handler is invoked, the stream is then
- ready to send and receive WebSocket protocol frames and
- messages.
- If the HTTP Upgrade request is invalid or cannot be satisfied,
- an HTTP response is sent indicating the reason and status code
- (typically 400, "Bad Request"). This counts as a failure, and
- the completion handler will be invoked with a suitable error
- code set.
- @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 Invoked when the operation completes.
- The handler may be moved or copied as needed.
- The equivalent function signature of the handler must be:
- @code void handler(
- error_code const& ec // Result of operation
- ); @endcode
- Regardless of whether the asynchronous operation completes
- immediately or not, the handler will not be invoked from within
- this function. Invocation of the handler will be performed in a
- manner equivalent to using `boost::asio::io_context::post`.
- */
- template<
- class Body, class Allocator,
- class AcceptHandler>
- BOOST_ASIO_INITFN_RESULT_TYPE(
- AcceptHandler, void(error_code))
- async_accept(
- http::request<Body,
- http::basic_fields<Allocator>> const& req,
- AcceptHandler&& handler);
- /** Start responding to a WebSocket HTTP Upgrade request.
- This function is used to asynchronously send the HTTP response
- to an HTTP request possibly containing a WebSocket Upgrade
- request. The function call always returns immediately. The
- asynchronous operation will continue until one of the following
- conditions is true:
- @li The response finishes sending.
- @li An error occurs on the stream.
- This operation is implemented in terms of one or more calls to
- the next layer's `async_write_some` functions, and is known as
- a <em>composed operation</em>. The program must ensure that the
- stream performs no other operations until this operation
- completes.
- If the stream receives a valid HTTP WebSocket Upgrade request,
- an HTTP response is sent back indicating a successful upgrade.
- When the completion handler is invoked, the stream is then
- ready to send and receive WebSocket protocol frames and
- messages.
- If the HTTP Upgrade request is invalid or cannot be satisfied,
- an HTTP response is sent indicating the reason and status code
- (typically 400, "Bad Request"). This counts as a failure, and
- the completion handler will be invoked with a suitable error
- code set.
- @param req An object containing the HTTP Upgrade request.
- Ownership is not transferred, the implementation will not access
- this object from other threads.
- @param decorator A function object which will be called to modify
- the HTTP response object delivered by the implementation. This
- could be used to set the Server field, subprotocols, or other
- application or HTTP specific fields. The object will be called
- with this equivalent signature:
- @code void decorator(
- response_type& res
- ); @endcode
- @param handler Invoked when the operation completes.
- The handler may be moved or copied as needed.
- The equivalent function signature of the handler must be:
- @code void handler(
- error_code const& ec // Result of operation
- ); @endcode
- Regardless of whether the asynchronous operation completes
- immediately or not, the handler will not be invoked from within
- this function. Invocation of the handler will be performed in a
- manner equivalent to using `boost::asio::io_context::post`.
- */
- template<
- class Body, class Allocator,
- class ResponseDecorator,
- class AcceptHandler>
- BOOST_ASIO_INITFN_RESULT_TYPE(
- AcceptHandler, void(error_code))
- async_accept_ex(
- http::request<Body,
- http::basic_fields<Allocator>> const& req,
- ResponseDecorator const& decorator,
- AcceptHandler&& handler);
- //--------------------------------------------------------------------------
- //
- // Control Frames
- //
- //--------------------------------------------------------------------------
- /** Send a WebSocket close frame.
- This function is used to synchronously send a close frame on
- the stream. The call blocks until one of the following is true:
- @li The close frame finishes sending.
- @li An error occurs on the stream.
- This function is implemented in terms of one or more calls
- to the next layer's `write_some` functions.
- 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.
- Callers should not attempt to write WebSocket data after
- initiating the close. Instead, callers should continue
- reading until an error occurs. A read returning @ref error::closed
- indicates a successful connection closure.
- @param cr The reason for the close.
- @throws system_error Thrown on failure.
- */
- void
- close(close_reason const& cr);
- /** Send a WebSocket close frame.
- This function is used to synchronously send a close frame on
- the stream. The call blocks until one of the following is true:
- @li The close frame finishes sending.
- @li An error occurs on the stream.
- This function is implemented in terms of one or more calls
- to the next layer's `write_some` functions.
- 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.
- Callers should not attempt to write WebSocket data after
- initiating the close. Instead, callers should continue
- reading until an error occurs. A read returning @ref error::closed
- indicates a successful connection closure.
- @param cr The reason for the close.
- @param ec Set to indicate what error occurred, if any.
- */
- void
- close(close_reason const& cr, error_code& ec);
- /** Start an asynchronous operation to send a WebSocket close frame.
- This function is used to asynchronously send a close frame on
- the stream. This function 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 on the stream.
- This operation is implemented in terms of one or more calls to the
- next layer's `async_write_some` functions, and is known as a
- <em>composed operation</em>. The program must ensure that the
- stream performs no other write operations (such as @ref async_ping,
- @ref async_write, @ref async_write_some, or @ref async_close)
- until this operation completes.
- 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.
- Callers should not attempt to write WebSocket data after
- initiating the close. Instead, callers should continue
- reading until an error occurs. A read returning @ref error::closed
- indicates a successful connection closure.
- @param cr The reason for the close.
- @param handler Invoked when the operation completes.
- The handler may be moved or copied as needed.
- The function signature of the handler must be:
- @code
- void handler(
- error_code const& ec // Result of operation
- );
- @endcode
- Regardless of whether the asynchronous operation completes
- immediately or not, the handler will not be invoked from within
- this function. Invocation of the handler will be performed in a
- manner equivalent to using `boost::asio::io_context::post`.
- */
- template<class CloseHandler>
- BOOST_ASIO_INITFN_RESULT_TYPE(
- CloseHandler, void(error_code))
- async_close(close_reason const& cr, CloseHandler&& handler);
- /** Send a WebSocket ping frame.
- This function is used to synchronously send a ping frame on
- the stream. The call blocks until one of the following is true:
- @li The ping frame finishes sending.
- @li An error occurs on the stream.
- This function is implemented in terms of one or more calls to the
- next layer's `write_some` functions.
- @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 frame.
- This function is used to synchronously send a ping frame on
- the stream. The call blocks until one of the following is true:
- @li The ping frame finishes sending.
- @li An error occurs on the stream.
- This function is implemented in terms of one or more calls to the
- next layer's `write_some` functions.
- @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);
- /** Start an asynchronous operation to send a WebSocket ping frame.
- This function is used to asynchronously send a ping frame to
- the stream. The function call always returns immediately. The
- asynchronous operation will continue until one of the following
- is true:
- @li The entire ping frame is sent.
- @li An error occurs on the stream.
- This operation is implemented in terms of one or more calls to the
- next layer's `async_write_some` functions, and is known as a
- <em>composed operation</em>. The program must ensure that the
- stream performs no other writes until this operation completes.
- If a close frame is sent or received before the ping frame is
- sent, the completion handler will be called with the error
- set to `boost::asio::error::operation_aborted`.
- @param payload The payload of the ping message, which may be empty.
- @param handler Invoked when the operation completes.
- The handler may be moved or copied as needed.
- The function signature of the handler must be:
- @code
- void handler(
- error_code const& ec // Result of operation
- );
- @endcode
- Regardless of whether the asynchronous operation completes
- immediately or not, the handler will not be invoked from within
- this function. Invocation of the handler will be performed in a
- manner equivalent to using `boost::asio::io_context::post`.
- */
- template<class WriteHandler>
- BOOST_ASIO_INITFN_RESULT_TYPE(
- WriteHandler, void(error_code))
- async_ping(ping_data const& payload, WriteHandler&& handler);
- /** Send a WebSocket pong frame.
- This function is used to synchronously send a pong frame on
- the stream. The call blocks until one of the following is true:
- @li The pong frame finishes sending.
- @li An error occurs on the stream.
- This function is implemented in terms of one or more calls to the
- next layer's `write_some` functions.
- The WebSocket protocol allows pong frames to be sent from either
- end at any time. It is not necessary to first receive a ping in
- order to send a pong. The remote peer may use the receipt of a
- pong frame as an indication that the connection is not dead.
- @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 frame.
- This function is used to synchronously send a pong frame on
- the stream. The call blocks until one of the following is true:
- @li The pong frame finishes sending.
- @li An error occurs on the stream.
- This function is implemented in terms of one or more calls to the
- next layer's `write_some` functions.
- The WebSocket protocol allows pong frames to be sent from either
- end at any time. It is not necessary to first receive a ping in
- order to send a pong. The remote peer may use the receipt of a
- pong frame as an indication that the connection is not dead.
- @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);
- /** Start an asynchronous operation to send a WebSocket pong frame.
- This function is used to asynchronously send a pong frame to
- the stream. The function call always returns immediately. The
- asynchronous operation will continue until one of the following
- is true:
- @li The entire pong frame is sent.
- @li An error occurs on the stream.
- This operation is implemented in terms of one or more calls to the
- next layer's `async_write_some` functions, and is known as a
- <em>composed operation</em>. The program must ensure that the
- stream performs no other writes until this operation completes.
- The WebSocket protocol allows pong frames to be sent from either
- end at any time. It is not necessary to first receive a ping in
- order to send a pong. The remote peer may use the receipt of a
- pong frame as an indication that the connection is not dead.
- If a close frame is sent or received before the pong frame is
- sent, the completion handler will be called with the error
- set to `boost::asio::error::operation_aborted`.
- @param payload The payload of the pong message, which may be empty.
- @param handler Invoked when the operation completes.
- The handler may be moved or copied as needed.
- The function signature of the handler must be:
- @code
- void handler(
- error_code const& ec // Result of operation
- );
- @endcode
- Regardless of whether the asynchronous operation completes
- immediately or not, the handler will not be invoked from within
- this function. Invocation of the handler will be performed in a
- manner equivalent to using `boost::asio::io_context::post`.
- */
- template<class WriteHandler>
- BOOST_ASIO_INITFN_RESULT_TYPE(
- WriteHandler, void(error_code))
- async_pong(ping_data const& payload, WriteHandler&& handler);
- //--------------------------------------------------------------------------
- //
- // Reading
- //
- //--------------------------------------------------------------------------
- /** Read a message
- This function is used to synchronously read a complete
- message from the stream.
- 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 on the stream.
- This operation is implemented in terms of one or more calls to the next
- layer's `read_some` and `write_some` functions.
- Received message data, if any, is appended to the input area of 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.
- While this operation is active, 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.
- @return The number of message payload bytes appended to the buffer.
- @param buffer A dynamic buffer to hold the message data after any
- masking or decompression has been applied.
- @throws system_error Thrown to indicate an error. The corresponding
- error code may be retrieved from the exception object for inspection.
- */
- template<class DynamicBuffer>
- std::size_t
- read(DynamicBuffer& buffer);
- /** Read a message
- This function is used to synchronously read a complete
- message from the stream.
- 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 on the stream.
- This operation is implemented in terms of one or more calls to the next
- layer's `read_some` and `write_some` functions.
- Received message data, if any, is appended to the input area of 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.
- While this operation is active, 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.
- @return The number of message payload bytes appended to the buffer.
- @param buffer A dynamic buffer to hold the message data after any
- masking or decompression has been applied.
- @param ec Set to indicate what error occurred, if any.
- */
- template<class DynamicBuffer>
- std::size_t
- read(DynamicBuffer& buffer, error_code& ec);
- /** Read a message asynchronously
- This function is used to asynchronously read a complete
- message from the stream.
- The function call always returns immediately.
- The asynchronous operation will continue 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 on the stream.
- This operation is implemented in terms of one or more calls to the
- next layer's `async_read_some` and `async_write_some` functions,
- and is known as a <em>composed operation</em>. The program must
- ensure that the stream performs no other reads until this operation
- completes.
- Received message data, if any, is appended to the input area of 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.
- While this operation is active, 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.
- Because of the need to handle control frames, asynchronous read
- operations can cause writes to take place. These writes are managed
- transparently; callers can still have one active asynchronous
- read and asynchronous write operation pending simultaneously
- (a user initiated call to @ref async_close counts as a write).
- @param buffer A dynamic buffer to hold the message data after
- any masking or decompression has been applied. This object must
- remain valid until the handler is called.
- @param handler Invoked when the operation completes.
- The handler may be moved or copied as needed.
- 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
- Regardless of whether the asynchronous operation completes
- immediately or not, the handler will not be invoked from within
- this function. Invocation of the handler will be performed in a
- manner equivalent to using `boost::asio::io_context::post`.
- */
- template<class DynamicBuffer, class ReadHandler>
- BOOST_ASIO_INITFN_RESULT_TYPE(
- ReadHandler, void(error_code, std::size_t))
- async_read(
- DynamicBuffer& buffer,
- ReadHandler&& handler);
- //--------------------------------------------------------------------------
- /** Read part of a message
- This function is used to synchronously read some
- message data from the stream.
- The call blocks until one of the following is true:
- @li Some or all of the 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 on the stream.
- This operation is implemented in terms of one or more calls to the next
- layer's `read_some` and `write_some` functions.
- Received message data, if any, is appended to the input area of 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.
- While this operation is active, 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.
- @return The number of message payload bytes appended to the buffer.
- @param buffer A dynamic buffer to hold the message data after any
- masking or decompression has been applied.
- @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 to indicate an error. The corresponding
- error code may be retrieved from the exception object for inspection.
- */
- template<class DynamicBuffer>
- std::size_t
- read_some(
- DynamicBuffer& buffer,
- std::size_t limit);
- /** Read part of a message
- This function is used to synchronously read some
- message data from the stream.
- The call blocks until one of the following is true:
- @li Some or all of the 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 on the stream.
- This operation is implemented in terms of one or more calls to the next
- layer's `read_some` and `write_some` functions.
- Received message data, if any, is appended to the input area of 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.
- While this operation is active, 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.
- @return The number of message payload bytes appended to the buffer.
- @param buffer A dynamic buffer to hold the message data after any
- masking or decompression has been applied.
- @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 part of a message asynchronously
- This function is used to asynchronously read part of a
- message from the stream.
- The function call always returns immediately.
- The asynchronous operation will continue until one of the
- following is true:
- @li Some or all of the 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 on the stream.
- This operation is implemented in terms of one or more calls to the
- next layer's `async_read_some` and `async_write_some` functions,
- and is known as a <em>composed operation</em>. The program must
- ensure that the stream performs no other reads until this operation
- completes.
- Received message data, if any, is appended to the input area of 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.
- While this operation is active, 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.
- Because of the need to handle control frames, asynchronous read
- operations can cause writes to take place. These writes are managed
- transparently; callers can still have one active asynchronous
- read and asynchronous write operation pending simultaneously
- (a user initiated call to @ref async_close counts as a write).
- @param buffer A dynamic buffer to hold the message data after
- any masking or decompression has been applied. This object must
- remain valid until the handler is called.
- @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 Invoked when the operation completes.
- The handler may be moved or copied as needed.
- 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
- Regardless of whether the asynchronous operation completes
- immediately or not, the handler will not be invoked from within
- this function. Invocation of the handler will be performed in a
- manner equivalent to using `boost::asio::io_context::post`.
- */
- template<class DynamicBuffer, class ReadHandler>
- BOOST_ASIO_INITFN_RESULT_TYPE(
- ReadHandler, void(error_code, std::size_t))
- async_read_some(
- DynamicBuffer& buffer,
- std::size_t limit,
- ReadHandler&& handler);
- //--------------------------------------------------------------------------
- /** Read part of a message
- This function is used to synchronously read some
- message data from the stream.
- The call blocks until one of the following is true:
- @li Some or all of the 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 on the stream.
- This operation is implemented in terms of one or more calls to the next
- layer's `read_some` and `write_some` functions.
- Received message data, if any, is written to the buffer sequence.
- 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.
- While this operation is active, 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.
- @return The number of message payload bytes written to the
- buffer sequence.
- @param buffers A buffer sequence to hold the message data after any
- masking or decompression has been applied.
- @throws system_error Thrown to indicate an error. The corresponding
- error code may be retrieved from the exception object for inspection.
- */
- template<class MutableBufferSequence>
- std::size_t
- read_some(
- MutableBufferSequence const& buffers);
- /** Read part of a message
- This function is used to synchronously read some
- message data from the stream.
- The call blocks until one of the following is true:
- @li Some or all of the 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 on the stream.
- This operation is implemented in terms of one or more calls to the next
- layer's `read_some` and `write_some` functions.
- Received message data, if any, is written to the buffer sequence.
- 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.
- While this operation is active, 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.
- @return The number of message payload bytes written to the
- buffer sequence.
- @param buffers A buffer sequence to hold the message data after any
- masking or decompression has been applied.
- @param ec Set to indicate what error occurred, if any.
- */
- template<class MutableBufferSequence>
- std::size_t
- read_some(
- MutableBufferSequence const& buffers,
- error_code& ec);
- /** Read part of a message asynchronously
- This function is used to asynchronously read part of a
- message from the stream.
- The function call always returns immediately.
- The asynchronous operation will continue until one of the
- following is true:
- @li Some or all of the 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 on the stream.
- This operation is implemented in terms of one or more calls to the
- next layer's `async_read_some` and `async_write_some` functions,
- and is known as a <em>composed operation</em>. The program must
- ensure that the stream performs no other reads until this operation
- completes.
- Received message data, if any, is written to the buffer sequence.
- 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.
- While this operation is active, 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.
- Because of the need to handle control frames, asynchronous read
- operations can cause writes to take place. These writes are managed
- transparently; callers can still have one active asynchronous
- read and asynchronous write operation pending simultaneously
- (a user initiated call to @ref async_close counts as a write).
- @param buffers The buffer sequence into which message data will
- be placed after any masking or decompresison has been applied.
- 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 the buffer sequence remains valid
- until the completion handler is called.
- @param handler Invoked when the operation completes.
- The handler may be moved or copied as needed.
- 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 buffer sequence
- );
- @endcode
- Regardless of whether the asynchronous operation completes
- immediately or not, the handler will not be invoked from within
- this function. Invocation of the handler will be performed in a
- manner equivalent to using `boost::asio::io_context::post`.
- */
- template<class MutableBufferSequence, class ReadHandler>
- BOOST_ASIO_INITFN_RESULT_TYPE(
- ReadHandler, void(error_code, std::size_t))
- async_read_some(
- MutableBufferSequence const& buffers,
- ReadHandler&& handler);
- //--------------------------------------------------------------------------
- //
- // Writing
- //
- //--------------------------------------------------------------------------
- /** Write a message to the stream.
- This function is used to synchronously write a message to
- the stream. The call blocks until one of the following conditions
- is met:
- @li The entire message is sent.
- @li An error occurs.
- This operation is implemented in terms of one or more 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 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.
- @return The number of bytes written from the buffers.
- If an error occurred, this will be less than the sum
- of the buffer sizes.
- @throws system_error Thrown on failure.
- @note This function always sends an entire message. To
- send a message in fragments, use @ref write_some.
- */
- template<class ConstBufferSequence>
- std::size_t
- write(ConstBufferSequence const& buffers);
- /** Write a message to the stream.
- This function is used to synchronously write a message to
- the stream. The call blocks until one of the following conditions
- is met:
- @li The entire message is sent.
- @li An error occurs.
- This operation is implemented in terms of one or more 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 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.
- @return The number of bytes written from the buffers.
- If an error occurred, this will be less than the sum
- of the buffer sizes.
- @param ec Set to indicate what error occurred, if any.
- @throws system_error Thrown on failure.
- @note This function always sends an entire message. To
- send a message in fragments, use @ref write_some.
- */
- template<class ConstBufferSequence>
- std::size_t
- write(ConstBufferSequence const& buffers, error_code& ec);
- /** Start an asynchronous operation to write a message to the stream.
- This function is used to asynchronously write a message to
- the stream. The function call always returns immediately.
- The asynchronous operation will continue until one of the
- following conditions is true:
- @li The entire message is sent.
- @li An error occurs.
- This operation is implemented in terms of one or more calls
- to the next layer's `async_write_some` functions, and is known
- as a <em>composed operation</em>. The program must ensure that
- the stream performs no other write operations (such as
- @ref async_write, @ref async_write_some, or
- @ref async_close).
- 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 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 Invoked when the operation completes.
- The handler may be moved or copied as needed.
- The 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 written from the
- // buffers. If an error occurred,
- // this will be less than the sum
- // of the buffer sizes.
- );
- @endcode
- Regardless of whether the asynchronous operation completes
- immediately or not, the handler will not be invoked from within
- this function. Invocation of the handler will be performed in a
- manner equivalent to using `boost::asio::io_context::post`.
- */
- template<
- class ConstBufferSequence,
- class WriteHandler>
- BOOST_ASIO_INITFN_RESULT_TYPE(
- WriteHandler, void(error_code, std::size_t))
- async_write(
- ConstBufferSequence const& buffers,
- WriteHandler&& handler);
- /** Write partial message data on the stream.
- This function is used to write some or all of a message's
- payload to the stream. The call will block until one of the
- following conditions is true:
- @li A frame is sent.
- @li Message data is transferred to the write buffer.
- @li An error occurs.
- This operation is implemented in terms of one or more calls
- to the stream's `write_some` function.
- If this is the beginning of a new message, the message opcode
- will be set to text or binary as per the current setting of
- the @ref binary 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 input buffer sequence holding the data to write.
- @return The number of bytes written from the buffers.
- If an error occurred, this will be less than the sum
- of the buffer sizes.
- @throws system_error Thrown on failure.
- */
- template<class ConstBufferSequence>
- std::size_t
- write_some(bool fin, ConstBufferSequence const& buffers);
- /** Write partial message data on the stream.
- This function is used to write some or all of a message's
- payload to the stream. The call will block until one of the
- following conditions is true:
- @li A frame is sent.
- @li Message data is transferred to the write buffer.
- @li An error occurs.
- This operation is implemented in terms of one or more calls
- to the stream's `write_some` function.
- If this is the beginning of a new message, the message opcode
- will be set to text or binary as per the current setting of
- the @ref binary 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 input buffer sequence holding the data to write.
- @param ec Set to indicate what error occurred, if any.
- @return The number of bytes written from the buffers.
- If an error occurred, this will be less than the sum
- of the buffer sizes.
- @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);
- /** Start an asynchronous operation to send a message frame on the stream.
- This function is used to asynchronously write a message frame
- on the stream. This function call always returns immediately.
- The asynchronous operation will continue until one of the following
- conditions is true:
- @li The entire frame is sent.
- @li An error occurs.
- This operation is implemented in terms of one or more calls
- to the next layer's `async_write_some` functions, and is known
- as a <em>composed operation</em>. The actual payload sent
- may be transformed as per the WebSocket protocol settings. The
- program must ensure that the stream performs no other write
- operations (such as @ref async_write, @ref async_write_some,
- or @ref async_close).
- If this is the beginning of a new message, the message opcode
- will be set to text or binary as per the current setting of
- the @ref binary 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 A object meeting the requirements of
- ConstBufferSequence which holds the payload data before any
- masking or compression. Although the buffers object may be copied
- as necessary, ownership of the underlying buffers is retained by
- the caller, which must guarantee that they remain valid until
- the handler is called.
- @param handler Invoked when the operation completes.
- The handler may be moved or copied as needed.
- 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 written from the
- // buffers. If an error occurred,
- // this will be less than the sum
- // of the buffer sizes.
- ); @endcode
- */
- template<class ConstBufferSequence, class WriteHandler>
- BOOST_ASIO_INITFN_RESULT_TYPE(
- WriteHandler, void(error_code, std::size_t))
- async_write_some(bool fin,
- ConstBufferSequence const& buffers, WriteHandler&& handler);
- 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> 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;
- static void default_decorate_req(request_type&) {}
- static void default_decorate_res(response_type&) {}
- void
- set_option(permessage_deflate const& o, std::true_type);
- void
- set_option(permessage_deflate const&, std::false_type);
- void
- get_option(permessage_deflate& o, std::true_type)
- {
- o = this->pmd_opts_;
- }
- void
- get_option(permessage_deflate& o, std::false_type)
- {
- o = {};
- o.client_enable = false;
- o.server_enable = false;
- }
- void open(role_type role);
- void open_pmd(std::true_type);
- void open_pmd(std::false_type)
- {
- }
- void close();
- void close_pmd(std::true_type)
- {
- this->pmd_.reset();
- }
- void close_pmd(std::false_type)
- {
- }
-
- void reset();
- void begin_msg()
- {
- begin_msg(is_deflate_supported{});
- }
- void begin_msg(std::true_type);
- void begin_msg(std::false_type);
- std::size_t
- read_size_hint(
- std::size_t initial_size,
- std::true_type) const;
- std::size_t
- read_size_hint(
- std::size_t initial_size,
- std::false_type) const;
- bool
- check_open(error_code& ec)
- {
- if(status_ != status::open)
- {
- ec = boost::asio::error::operation_aborted;
- return false;
- }
- ec.assign(0, ec.category());
- return true;
- }
- bool
- check_ok(error_code& ec)
- {
- if(ec)
- {
- if(status_ != status::closed)
- status_ = status::failed;
- return false;
- }
- return true;
- }
- template<class DynamicBuffer>
- bool
- parse_fh(
- detail::frame_header& fh,
- DynamicBuffer& b,
- error_code& ec);
- template<class DynamicBuffer>
- void
- write_close(DynamicBuffer& b, close_reason const& rc);
- template<class DynamicBuffer>
- void
- write_ping(DynamicBuffer& b,
- detail::opcode op, ping_data const& data);
- //
- // upgrade
- //
- template<class Decorator>
- request_type
- build_request(detail::sec_ws_key_type& key,
- string_view host,
- string_view target,
- Decorator const& decorator);
- void
- build_request_pmd(request_type& req, std::true_type);
- void
- build_request_pmd(request_type&, std::false_type)
- {
- }
- template<
- class Body, class Allocator, class Decorator>
- response_type
- build_response(
- http::request<Body,
- http::basic_fields<Allocator>> const& req,
- Decorator const& decorator,
- error_code& ec);
- template<class Body, class Allocator>
- void
- build_response_pmd(
- response_type& res,
- http::request<Body,
- http::basic_fields<Allocator>> const& req,
- std::true_type);
- template<class Body, class Allocator>
- void
- build_response_pmd(
- response_type&,
- http::request<Body,
- http::basic_fields<Allocator>> const&,
- std::false_type)
- {
- }
- void
- on_response(
- response_type const& res,
- detail::sec_ws_key_type const& key,
- error_code& ec);
- void
- on_response_pmd(
- response_type const& res,
- std::true_type);
- void
- on_response_pmd(
- response_type const&,
- std::false_type)
- {
- }
- //
- // accept / handshake
- //
- template<class Allocator>
- void
- do_pmd_config(
- http::basic_fields<Allocator> const& h,
- std::true_type)
- {
- pmd_read(this->pmd_config_, h);
- }
- template<class Allocator>
- void
- do_pmd_config(
- http::basic_fields<Allocator> const&,
- std::false_type)
- {
- }
- template<class Decorator>
- void
- do_accept(
- 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
- */
- inline
- void
- seed_prng(std::seed_seq& ss)
- {
- detail::stream_prng::seed(&ss);
- }
- } // websocket
- } // beast
- } // boost
- #include <boost/beast/websocket/impl/accept.ipp>
- #include <boost/beast/websocket/impl/close.ipp>
- #include <boost/beast/websocket/impl/handshake.ipp>
- #include <boost/beast/websocket/impl/ping.ipp>
- #include <boost/beast/websocket/impl/read.ipp>
- #include <boost/beast/websocket/impl/stream.ipp>
- #include <boost/beast/websocket/impl/write.ipp>
- #endif
|