server.go 91 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785786787788789790791792793794795796797798799800801802803804805806807808809810811812813814815816817818819820821822823824825826827828829830831832833834835836837838839840841842843844845846847848849850851852853854855856857858859860861862863864865866867868869870871872873874875876877878879880881882883884885886887888889890891892893894895896897898899900901902903904905906907908909910911912913914915916917918919920921922923924925926927928929930931932933934935936937938939940941942943944945946947948949950951952953954955956957958959960961962963964965966967968969970971972973974975976977978979980981982983984985986987988989990991992993994995996997998999100010011002100310041005100610071008100910101011101210131014101510161017101810191020102110221023102410251026102710281029103010311032103310341035103610371038103910401041104210431044104510461047104810491050105110521053105410551056105710581059106010611062106310641065106610671068106910701071107210731074107510761077107810791080108110821083108410851086108710881089109010911092109310941095109610971098109911001101110211031104110511061107110811091110111111121113111411151116111711181119112011211122112311241125112611271128112911301131113211331134113511361137113811391140114111421143114411451146114711481149115011511152115311541155115611571158115911601161116211631164116511661167116811691170117111721173117411751176117711781179118011811182118311841185118611871188118911901191119211931194119511961197119811991200120112021203120412051206120712081209121012111212121312141215121612171218121912201221122212231224122512261227122812291230123112321233123412351236123712381239124012411242124312441245124612471248124912501251125212531254125512561257125812591260126112621263126412651266126712681269127012711272127312741275127612771278127912801281128212831284128512861287128812891290129112921293129412951296129712981299130013011302130313041305130613071308130913101311131213131314131513161317131813191320132113221323132413251326132713281329133013311332133313341335133613371338133913401341134213431344134513461347134813491350135113521353135413551356135713581359136013611362136313641365136613671368136913701371137213731374137513761377137813791380138113821383138413851386138713881389139013911392139313941395139613971398139914001401140214031404140514061407140814091410141114121413141414151416141714181419142014211422142314241425142614271428142914301431143214331434143514361437143814391440144114421443144414451446144714481449145014511452145314541455145614571458145914601461146214631464146514661467146814691470147114721473147414751476147714781479148014811482148314841485148614871488148914901491149214931494149514961497149814991500150115021503150415051506150715081509151015111512151315141515151615171518151915201521152215231524152515261527152815291530153115321533153415351536153715381539154015411542154315441545154615471548154915501551155215531554155515561557155815591560156115621563156415651566156715681569157015711572157315741575157615771578157915801581158215831584158515861587158815891590159115921593159415951596159715981599160016011602160316041605160616071608160916101611161216131614161516161617161816191620162116221623162416251626162716281629163016311632163316341635163616371638163916401641164216431644164516461647164816491650165116521653165416551656165716581659166016611662166316641665166616671668166916701671167216731674167516761677167816791680168116821683168416851686168716881689169016911692169316941695169616971698169917001701170217031704170517061707170817091710171117121713171417151716171717181719172017211722172317241725172617271728172917301731173217331734173517361737173817391740174117421743174417451746174717481749175017511752175317541755175617571758175917601761176217631764176517661767176817691770177117721773177417751776177717781779178017811782178317841785178617871788178917901791179217931794179517961797179817991800180118021803180418051806180718081809181018111812181318141815181618171818181918201821182218231824182518261827182818291830183118321833183418351836183718381839184018411842184318441845184618471848184918501851185218531854185518561857185818591860186118621863186418651866186718681869187018711872187318741875187618771878187918801881188218831884188518861887188818891890189118921893189418951896189718981899190019011902190319041905190619071908190919101911191219131914191519161917191819191920192119221923192419251926192719281929193019311932193319341935193619371938193919401941194219431944194519461947194819491950195119521953195419551956195719581959196019611962196319641965196619671968196919701971197219731974197519761977197819791980198119821983198419851986198719881989199019911992199319941995199619971998199920002001200220032004200520062007200820092010201120122013201420152016201720182019202020212022202320242025202620272028202920302031203220332034203520362037203820392040204120422043204420452046204720482049205020512052205320542055205620572058205920602061206220632064206520662067206820692070207120722073207420752076207720782079208020812082208320842085208620872088208920902091209220932094209520962097209820992100210121022103210421052106210721082109211021112112211321142115211621172118211921202121212221232124212521262127212821292130213121322133213421352136213721382139214021412142214321442145214621472148214921502151215221532154215521562157215821592160216121622163216421652166216721682169217021712172217321742175217621772178217921802181218221832184218521862187218821892190219121922193219421952196219721982199220022012202220322042205220622072208220922102211221222132214221522162217221822192220222122222223222422252226222722282229223022312232223322342235223622372238223922402241224222432244224522462247224822492250225122522253225422552256225722582259226022612262226322642265226622672268226922702271227222732274227522762277227822792280228122822283228422852286228722882289229022912292229322942295229622972298229923002301230223032304230523062307230823092310231123122313231423152316231723182319232023212322232323242325232623272328232923302331233223332334233523362337233823392340234123422343234423452346234723482349235023512352235323542355235623572358235923602361236223632364236523662367236823692370237123722373237423752376237723782379238023812382238323842385238623872388238923902391239223932394239523962397239823992400240124022403240424052406240724082409241024112412241324142415241624172418241924202421242224232424242524262427242824292430243124322433243424352436243724382439244024412442244324442445244624472448244924502451245224532454245524562457245824592460246124622463246424652466246724682469247024712472247324742475247624772478247924802481248224832484248524862487248824892490249124922493249424952496249724982499250025012502250325042505250625072508250925102511251225132514251525162517251825192520252125222523252425252526252725282529253025312532253325342535253625372538253925402541254225432544254525462547254825492550255125522553255425552556255725582559256025612562256325642565256625672568256925702571257225732574257525762577257825792580258125822583258425852586258725882589259025912592259325942595259625972598259926002601260226032604260526062607260826092610261126122613261426152616261726182619262026212622262326242625262626272628262926302631263226332634263526362637263826392640264126422643264426452646264726482649265026512652265326542655265626572658265926602661266226632664266526662667266826692670267126722673267426752676267726782679268026812682268326842685268626872688268926902691269226932694269526962697269826992700270127022703270427052706270727082709271027112712271327142715271627172718271927202721272227232724272527262727272827292730273127322733273427352736273727382739274027412742274327442745274627472748274927502751275227532754275527562757275827592760276127622763276427652766276727682769277027712772277327742775277627772778277927802781278227832784278527862787278827892790279127922793279427952796279727982799280028012802280328042805280628072808280928102811281228132814281528162817281828192820282128222823282428252826282728282829283028312832283328342835283628372838283928402841284228432844284528462847284828492850285128522853285428552856285728582859286028612862286328642865286628672868286928702871287228732874287528762877287828792880288128822883288428852886288728882889289028912892289328942895289628972898289929002901290229032904290529062907290829092910291129122913291429152916291729182919292029212922292329242925292629272928292929302931293229332934293529362937293829392940294129422943294429452946294729482949295029512952295329542955295629572958295929602961296229632964296529662967
  1. // Copyright 2014 The Go Authors. All rights reserved.
  2. // Use of this source code is governed by a BSD-style
  3. // license that can be found in the LICENSE file.
  4. // TODO: turn off the serve goroutine when idle, so
  5. // an idle conn only has the readFrames goroutine active. (which could
  6. // also be optimized probably to pin less memory in crypto/tls). This
  7. // would involve tracking when the serve goroutine is active (atomic
  8. // int32 read/CAS probably?) and starting it up when frames arrive,
  9. // and shutting it down when all handlers exit. the occasional PING
  10. // packets could use time.AfterFunc to call sc.wakeStartServeLoop()
  11. // (which is a no-op if already running) and then queue the PING write
  12. // as normal. The serve loop would then exit in most cases (if no
  13. // Handlers running) and not be woken up again until the PING packet
  14. // returns.
  15. // TODO (maybe): add a mechanism for Handlers to going into
  16. // half-closed-local mode (rw.(io.Closer) test?) but not exit their
  17. // handler, and continue to be able to read from the
  18. // Request.Body. This would be a somewhat semantic change from HTTP/1
  19. // (or at least what we expose in net/http), so I'd probably want to
  20. // add it there too. For now, this package says that returning from
  21. // the Handler ServeHTTP function means you're both done reading and
  22. // done writing, without a way to stop just one or the other.
  23. package http2
  24. import (
  25. "bufio"
  26. "bytes"
  27. "context"
  28. "crypto/tls"
  29. "errors"
  30. "fmt"
  31. "io"
  32. "log"
  33. "math"
  34. "net"
  35. "net/http"
  36. "net/textproto"
  37. "net/url"
  38. "os"
  39. "reflect"
  40. "runtime"
  41. "strconv"
  42. "strings"
  43. "sync"
  44. "time"
  45. "golang.org/x/net/http/httpguts"
  46. "golang.org/x/net/http2/hpack"
  47. )
  48. const (
  49. prefaceTimeout = 10 * time.Second
  50. firstSettingsTimeout = 2 * time.Second // should be in-flight with preface anyway
  51. handlerChunkWriteSize = 4 << 10
  52. defaultMaxStreams = 250 // TODO: make this 100 as the GFE seems to?
  53. maxQueuedControlFrames = 10000
  54. )
  55. var (
  56. errClientDisconnected = errors.New("client disconnected")
  57. errClosedBody = errors.New("body closed by handler")
  58. errHandlerComplete = errors.New("http2: request body closed due to handler exiting")
  59. errStreamClosed = errors.New("http2: stream closed")
  60. )
  61. var responseWriterStatePool = sync.Pool{
  62. New: func() interface{} {
  63. rws := &responseWriterState{}
  64. rws.bw = bufio.NewWriterSize(chunkWriter{rws}, handlerChunkWriteSize)
  65. return rws
  66. },
  67. }
  68. // Test hooks.
  69. var (
  70. testHookOnConn func()
  71. testHookGetServerConn func(*serverConn)
  72. testHookOnPanicMu *sync.Mutex // nil except in tests
  73. testHookOnPanic func(sc *serverConn, panicVal interface{}) (rePanic bool)
  74. )
  75. // Server is an HTTP/2 server.
  76. type Server struct {
  77. // MaxHandlers limits the number of http.Handler ServeHTTP goroutines
  78. // which may run at a time over all connections.
  79. // Negative or zero no limit.
  80. // TODO: implement
  81. MaxHandlers int
  82. // MaxConcurrentStreams optionally specifies the number of
  83. // concurrent streams that each client may have open at a
  84. // time. This is unrelated to the number of http.Handler goroutines
  85. // which may be active globally, which is MaxHandlers.
  86. // If zero, MaxConcurrentStreams defaults to at least 100, per
  87. // the HTTP/2 spec's recommendations.
  88. MaxConcurrentStreams uint32
  89. // MaxReadFrameSize optionally specifies the largest frame
  90. // this server is willing to read. A valid value is between
  91. // 16k and 16M, inclusive. If zero or otherwise invalid, a
  92. // default value is used.
  93. MaxReadFrameSize uint32
  94. // PermitProhibitedCipherSuites, if true, permits the use of
  95. // cipher suites prohibited by the HTTP/2 spec.
  96. PermitProhibitedCipherSuites bool
  97. // IdleTimeout specifies how long until idle clients should be
  98. // closed with a GOAWAY frame. PING frames are not considered
  99. // activity for the purposes of IdleTimeout.
  100. IdleTimeout time.Duration
  101. // MaxUploadBufferPerConnection is the size of the initial flow
  102. // control window for each connections. The HTTP/2 spec does not
  103. // allow this to be smaller than 65535 or larger than 2^32-1.
  104. // If the value is outside this range, a default value will be
  105. // used instead.
  106. MaxUploadBufferPerConnection int32
  107. // MaxUploadBufferPerStream is the size of the initial flow control
  108. // window for each stream. The HTTP/2 spec does not allow this to
  109. // be larger than 2^32-1. If the value is zero or larger than the
  110. // maximum, a default value will be used instead.
  111. MaxUploadBufferPerStream int32
  112. // NewWriteScheduler constructs a write scheduler for a connection.
  113. // If nil, a default scheduler is chosen.
  114. NewWriteScheduler func() WriteScheduler
  115. // Internal state. This is a pointer (rather than embedded directly)
  116. // so that we don't embed a Mutex in this struct, which will make the
  117. // struct non-copyable, which might break some callers.
  118. state *serverInternalState
  119. }
  120. func (s *Server) initialConnRecvWindowSize() int32 {
  121. if s.MaxUploadBufferPerConnection > initialWindowSize {
  122. return s.MaxUploadBufferPerConnection
  123. }
  124. return 1 << 20
  125. }
  126. func (s *Server) initialStreamRecvWindowSize() int32 {
  127. if s.MaxUploadBufferPerStream > 0 {
  128. return s.MaxUploadBufferPerStream
  129. }
  130. return 1 << 20
  131. }
  132. func (s *Server) maxReadFrameSize() uint32 {
  133. if v := s.MaxReadFrameSize; v >= minMaxFrameSize && v <= maxFrameSize {
  134. return v
  135. }
  136. return defaultMaxReadFrameSize
  137. }
  138. func (s *Server) maxConcurrentStreams() uint32 {
  139. if v := s.MaxConcurrentStreams; v > 0 {
  140. return v
  141. }
  142. return defaultMaxStreams
  143. }
  144. // maxQueuedControlFrames is the maximum number of control frames like
  145. // SETTINGS, PING and RST_STREAM that will be queued for writing before
  146. // the connection is closed to prevent memory exhaustion attacks.
  147. func (s *Server) maxQueuedControlFrames() int {
  148. // TODO: if anybody asks, add a Server field, and remember to define the
  149. // behavior of negative values.
  150. return maxQueuedControlFrames
  151. }
  152. type serverInternalState struct {
  153. mu sync.Mutex
  154. activeConns map[*serverConn]struct{}
  155. }
  156. func (s *serverInternalState) registerConn(sc *serverConn) {
  157. if s == nil {
  158. return // if the Server was used without calling ConfigureServer
  159. }
  160. s.mu.Lock()
  161. s.activeConns[sc] = struct{}{}
  162. s.mu.Unlock()
  163. }
  164. func (s *serverInternalState) unregisterConn(sc *serverConn) {
  165. if s == nil {
  166. return // if the Server was used without calling ConfigureServer
  167. }
  168. s.mu.Lock()
  169. delete(s.activeConns, sc)
  170. s.mu.Unlock()
  171. }
  172. func (s *serverInternalState) startGracefulShutdown() {
  173. if s == nil {
  174. return // if the Server was used without calling ConfigureServer
  175. }
  176. s.mu.Lock()
  177. for sc := range s.activeConns {
  178. sc.startGracefulShutdown()
  179. }
  180. s.mu.Unlock()
  181. }
  182. // ConfigureServer adds HTTP/2 support to a net/http Server.
  183. //
  184. // The configuration conf may be nil.
  185. //
  186. // ConfigureServer must be called before s begins serving.
  187. func ConfigureServer(s *http.Server, conf *Server) error {
  188. if s == nil {
  189. panic("nil *http.Server")
  190. }
  191. if conf == nil {
  192. conf = new(Server)
  193. }
  194. conf.state = &serverInternalState{activeConns: make(map[*serverConn]struct{})}
  195. if h1, h2 := s, conf; h2.IdleTimeout == 0 {
  196. if h1.IdleTimeout != 0 {
  197. h2.IdleTimeout = h1.IdleTimeout
  198. } else {
  199. h2.IdleTimeout = h1.ReadTimeout
  200. }
  201. }
  202. s.RegisterOnShutdown(conf.state.startGracefulShutdown)
  203. if s.TLSConfig == nil {
  204. s.TLSConfig = new(tls.Config)
  205. } else if s.TLSConfig.CipherSuites != nil {
  206. // If they already provided a CipherSuite list, return
  207. // an error if it has a bad order or is missing
  208. // ECDHE_RSA_WITH_AES_128_GCM_SHA256 or ECDHE_ECDSA_WITH_AES_128_GCM_SHA256.
  209. haveRequired := false
  210. sawBad := false
  211. for i, cs := range s.TLSConfig.CipherSuites {
  212. switch cs {
  213. case tls.TLS_ECDHE_RSA_WITH_AES_128_GCM_SHA256,
  214. // Alternative MTI cipher to not discourage ECDSA-only servers.
  215. // See http://golang.org/cl/30721 for further information.
  216. tls.TLS_ECDHE_ECDSA_WITH_AES_128_GCM_SHA256:
  217. haveRequired = true
  218. }
  219. if isBadCipher(cs) {
  220. sawBad = true
  221. } else if sawBad {
  222. return fmt.Errorf("http2: TLSConfig.CipherSuites index %d contains an HTTP/2-approved cipher suite (%#04x), but it comes after unapproved cipher suites. With this configuration, clients that don't support previous, approved cipher suites may be given an unapproved one and reject the connection.", i, cs)
  223. }
  224. }
  225. if !haveRequired {
  226. return fmt.Errorf("http2: TLSConfig.CipherSuites is missing an HTTP/2-required AES_128_GCM_SHA256 cipher (need at least one of TLS_ECDHE_RSA_WITH_AES_128_GCM_SHA256 or TLS_ECDHE_ECDSA_WITH_AES_128_GCM_SHA256).")
  227. }
  228. }
  229. // Note: not setting MinVersion to tls.VersionTLS12,
  230. // as we don't want to interfere with HTTP/1.1 traffic
  231. // on the user's server. We enforce TLS 1.2 later once
  232. // we accept a connection. Ideally this should be done
  233. // during next-proto selection, but using TLS <1.2 with
  234. // HTTP/2 is still the client's bug.
  235. s.TLSConfig.PreferServerCipherSuites = true
  236. haveNPN := false
  237. for _, p := range s.TLSConfig.NextProtos {
  238. if p == NextProtoTLS {
  239. haveNPN = true
  240. break
  241. }
  242. }
  243. if !haveNPN {
  244. s.TLSConfig.NextProtos = append(s.TLSConfig.NextProtos, NextProtoTLS)
  245. }
  246. if s.TLSNextProto == nil {
  247. s.TLSNextProto = map[string]func(*http.Server, *tls.Conn, http.Handler){}
  248. }
  249. protoHandler := func(hs *http.Server, c *tls.Conn, h http.Handler) {
  250. if testHookOnConn != nil {
  251. testHookOnConn()
  252. }
  253. // The TLSNextProto interface predates contexts, so
  254. // the net/http package passes down its per-connection
  255. // base context via an exported but unadvertised
  256. // method on the Handler. This is for internal
  257. // net/http<=>http2 use only.
  258. var ctx context.Context
  259. type baseContexter interface {
  260. BaseContext() context.Context
  261. }
  262. if bc, ok := h.(baseContexter); ok {
  263. ctx = bc.BaseContext()
  264. }
  265. conf.ServeConn(c, &ServeConnOpts{
  266. Context: ctx,
  267. Handler: h,
  268. BaseConfig: hs,
  269. })
  270. }
  271. s.TLSNextProto[NextProtoTLS] = protoHandler
  272. return nil
  273. }
  274. // ServeConnOpts are options for the Server.ServeConn method.
  275. type ServeConnOpts struct {
  276. // Context is the base context to use.
  277. // If nil, context.Background is used.
  278. Context context.Context
  279. // BaseConfig optionally sets the base configuration
  280. // for values. If nil, defaults are used.
  281. BaseConfig *http.Server
  282. // Handler specifies which handler to use for processing
  283. // requests. If nil, BaseConfig.Handler is used. If BaseConfig
  284. // or BaseConfig.Handler is nil, http.DefaultServeMux is used.
  285. Handler http.Handler
  286. }
  287. func (o *ServeConnOpts) context() context.Context {
  288. if o != nil && o.Context != nil {
  289. return o.Context
  290. }
  291. return context.Background()
  292. }
  293. func (o *ServeConnOpts) baseConfig() *http.Server {
  294. if o != nil && o.BaseConfig != nil {
  295. return o.BaseConfig
  296. }
  297. return new(http.Server)
  298. }
  299. func (o *ServeConnOpts) handler() http.Handler {
  300. if o != nil {
  301. if o.Handler != nil {
  302. return o.Handler
  303. }
  304. if o.BaseConfig != nil && o.BaseConfig.Handler != nil {
  305. return o.BaseConfig.Handler
  306. }
  307. }
  308. return http.DefaultServeMux
  309. }
  310. // ServeConn serves HTTP/2 requests on the provided connection and
  311. // blocks until the connection is no longer readable.
  312. //
  313. // ServeConn starts speaking HTTP/2 assuming that c has not had any
  314. // reads or writes. It writes its initial settings frame and expects
  315. // to be able to read the preface and settings frame from the
  316. // client. If c has a ConnectionState method like a *tls.Conn, the
  317. // ConnectionState is used to verify the TLS ciphersuite and to set
  318. // the Request.TLS field in Handlers.
  319. //
  320. // ServeConn does not support h2c by itself. Any h2c support must be
  321. // implemented in terms of providing a suitably-behaving net.Conn.
  322. //
  323. // The opts parameter is optional. If nil, default values are used.
  324. func (s *Server) ServeConn(c net.Conn, opts *ServeConnOpts) {
  325. baseCtx, cancel := serverConnBaseContext(c, opts)
  326. defer cancel()
  327. sc := &serverConn{
  328. srv: s,
  329. hs: opts.baseConfig(),
  330. conn: c,
  331. baseCtx: baseCtx,
  332. remoteAddrStr: c.RemoteAddr().String(),
  333. bw: newBufferedWriter(c),
  334. handler: opts.handler(),
  335. streams: make(map[uint32]*stream),
  336. readFrameCh: make(chan readFrameResult),
  337. wantWriteFrameCh: make(chan FrameWriteRequest, 8),
  338. serveMsgCh: make(chan interface{}, 8),
  339. wroteFrameCh: make(chan frameWriteResult, 1), // buffered; one send in writeFrameAsync
  340. bodyReadCh: make(chan bodyReadMsg), // buffering doesn't matter either way
  341. doneServing: make(chan struct{}),
  342. clientMaxStreams: math.MaxUint32, // Section 6.5.2: "Initially, there is no limit to this value"
  343. advMaxStreams: s.maxConcurrentStreams(),
  344. initialStreamSendWindowSize: initialWindowSize,
  345. maxFrameSize: initialMaxFrameSize,
  346. headerTableSize: initialHeaderTableSize,
  347. serveG: newGoroutineLock(),
  348. pushEnabled: true,
  349. }
  350. s.state.registerConn(sc)
  351. defer s.state.unregisterConn(sc)
  352. // The net/http package sets the write deadline from the
  353. // http.Server.WriteTimeout during the TLS handshake, but then
  354. // passes the connection off to us with the deadline already set.
  355. // Write deadlines are set per stream in serverConn.newStream.
  356. // Disarm the net.Conn write deadline here.
  357. if sc.hs.WriteTimeout != 0 {
  358. sc.conn.SetWriteDeadline(time.Time{})
  359. }
  360. if s.NewWriteScheduler != nil {
  361. sc.writeSched = s.NewWriteScheduler()
  362. } else {
  363. sc.writeSched = NewRandomWriteScheduler()
  364. }
  365. // These start at the RFC-specified defaults. If there is a higher
  366. // configured value for inflow, that will be updated when we send a
  367. // WINDOW_UPDATE shortly after sending SETTINGS.
  368. sc.flow.add(initialWindowSize)
  369. sc.inflow.add(initialWindowSize)
  370. sc.hpackEncoder = hpack.NewEncoder(&sc.headerWriteBuf)
  371. fr := NewFramer(sc.bw, c)
  372. fr.ReadMetaHeaders = hpack.NewDecoder(initialHeaderTableSize, nil)
  373. fr.MaxHeaderListSize = sc.maxHeaderListSize()
  374. fr.SetMaxReadFrameSize(s.maxReadFrameSize())
  375. sc.framer = fr
  376. if tc, ok := c.(connectionStater); ok {
  377. sc.tlsState = new(tls.ConnectionState)
  378. *sc.tlsState = tc.ConnectionState()
  379. // 9.2 Use of TLS Features
  380. // An implementation of HTTP/2 over TLS MUST use TLS
  381. // 1.2 or higher with the restrictions on feature set
  382. // and cipher suite described in this section. Due to
  383. // implementation limitations, it might not be
  384. // possible to fail TLS negotiation. An endpoint MUST
  385. // immediately terminate an HTTP/2 connection that
  386. // does not meet the TLS requirements described in
  387. // this section with a connection error (Section
  388. // 5.4.1) of type INADEQUATE_SECURITY.
  389. if sc.tlsState.Version < tls.VersionTLS12 {
  390. sc.rejectConn(ErrCodeInadequateSecurity, "TLS version too low")
  391. return
  392. }
  393. if sc.tlsState.ServerName == "" {
  394. // Client must use SNI, but we don't enforce that anymore,
  395. // since it was causing problems when connecting to bare IP
  396. // addresses during development.
  397. //
  398. // TODO: optionally enforce? Or enforce at the time we receive
  399. // a new request, and verify the ServerName matches the :authority?
  400. // But that precludes proxy situations, perhaps.
  401. //
  402. // So for now, do nothing here again.
  403. }
  404. if !s.PermitProhibitedCipherSuites && isBadCipher(sc.tlsState.CipherSuite) {
  405. // "Endpoints MAY choose to generate a connection error
  406. // (Section 5.4.1) of type INADEQUATE_SECURITY if one of
  407. // the prohibited cipher suites are negotiated."
  408. //
  409. // We choose that. In my opinion, the spec is weak
  410. // here. It also says both parties must support at least
  411. // TLS_ECDHE_RSA_WITH_AES_128_GCM_SHA256 so there's no
  412. // excuses here. If we really must, we could allow an
  413. // "AllowInsecureWeakCiphers" option on the server later.
  414. // Let's see how it plays out first.
  415. sc.rejectConn(ErrCodeInadequateSecurity, fmt.Sprintf("Prohibited TLS 1.2 Cipher Suite: %x", sc.tlsState.CipherSuite))
  416. return
  417. }
  418. }
  419. if hook := testHookGetServerConn; hook != nil {
  420. hook(sc)
  421. }
  422. sc.serve()
  423. }
  424. func serverConnBaseContext(c net.Conn, opts *ServeConnOpts) (ctx context.Context, cancel func()) {
  425. ctx, cancel = context.WithCancel(opts.context())
  426. ctx = context.WithValue(ctx, http.LocalAddrContextKey, c.LocalAddr())
  427. if hs := opts.baseConfig(); hs != nil {
  428. ctx = context.WithValue(ctx, http.ServerContextKey, hs)
  429. }
  430. return
  431. }
  432. func (sc *serverConn) rejectConn(err ErrCode, debug string) {
  433. sc.vlogf("http2: server rejecting conn: %v, %s", err, debug)
  434. // ignoring errors. hanging up anyway.
  435. sc.framer.WriteGoAway(0, err, []byte(debug))
  436. sc.bw.Flush()
  437. sc.conn.Close()
  438. }
  439. type serverConn struct {
  440. // Immutable:
  441. srv *Server
  442. hs *http.Server
  443. conn net.Conn
  444. bw *bufferedWriter // writing to conn
  445. handler http.Handler
  446. baseCtx context.Context
  447. framer *Framer
  448. doneServing chan struct{} // closed when serverConn.serve ends
  449. readFrameCh chan readFrameResult // written by serverConn.readFrames
  450. wantWriteFrameCh chan FrameWriteRequest // from handlers -> serve
  451. wroteFrameCh chan frameWriteResult // from writeFrameAsync -> serve, tickles more frame writes
  452. bodyReadCh chan bodyReadMsg // from handlers -> serve
  453. serveMsgCh chan interface{} // misc messages & code to send to / run on the serve loop
  454. flow flow // conn-wide (not stream-specific) outbound flow control
  455. inflow flow // conn-wide inbound flow control
  456. tlsState *tls.ConnectionState // shared by all handlers, like net/http
  457. remoteAddrStr string
  458. writeSched WriteScheduler
  459. // Everything following is owned by the serve loop; use serveG.check():
  460. serveG goroutineLock // used to verify funcs are on serve()
  461. pushEnabled bool
  462. sawFirstSettings bool // got the initial SETTINGS frame after the preface
  463. needToSendSettingsAck bool
  464. unackedSettings int // how many SETTINGS have we sent without ACKs?
  465. queuedControlFrames int // control frames in the writeSched queue
  466. clientMaxStreams uint32 // SETTINGS_MAX_CONCURRENT_STREAMS from client (our PUSH_PROMISE limit)
  467. advMaxStreams uint32 // our SETTINGS_MAX_CONCURRENT_STREAMS advertised the client
  468. curClientStreams uint32 // number of open streams initiated by the client
  469. curPushedStreams uint32 // number of open streams initiated by server push
  470. maxClientStreamID uint32 // max ever seen from client (odd), or 0 if there have been no client requests
  471. maxPushPromiseID uint32 // ID of the last push promise (even), or 0 if there have been no pushes
  472. streams map[uint32]*stream
  473. initialStreamSendWindowSize int32
  474. maxFrameSize int32
  475. headerTableSize uint32
  476. peerMaxHeaderListSize uint32 // zero means unknown (default)
  477. canonHeader map[string]string // http2-lower-case -> Go-Canonical-Case
  478. writingFrame bool // started writing a frame (on serve goroutine or separate)
  479. writingFrameAsync bool // started a frame on its own goroutine but haven't heard back on wroteFrameCh
  480. needsFrameFlush bool // last frame write wasn't a flush
  481. inGoAway bool // we've started to or sent GOAWAY
  482. inFrameScheduleLoop bool // whether we're in the scheduleFrameWrite loop
  483. needToSendGoAway bool // we need to schedule a GOAWAY frame write
  484. goAwayCode ErrCode
  485. shutdownTimer *time.Timer // nil until used
  486. idleTimer *time.Timer // nil if unused
  487. // Owned by the writeFrameAsync goroutine:
  488. headerWriteBuf bytes.Buffer
  489. hpackEncoder *hpack.Encoder
  490. // Used by startGracefulShutdown.
  491. shutdownOnce sync.Once
  492. }
  493. func (sc *serverConn) maxHeaderListSize() uint32 {
  494. n := sc.hs.MaxHeaderBytes
  495. if n <= 0 {
  496. n = http.DefaultMaxHeaderBytes
  497. }
  498. // http2's count is in a slightly different unit and includes 32 bytes per pair.
  499. // So, take the net/http.Server value and pad it up a bit, assuming 10 headers.
  500. const perFieldOverhead = 32 // per http2 spec
  501. const typicalHeaders = 10 // conservative
  502. return uint32(n + typicalHeaders*perFieldOverhead)
  503. }
  504. func (sc *serverConn) curOpenStreams() uint32 {
  505. sc.serveG.check()
  506. return sc.curClientStreams + sc.curPushedStreams
  507. }
  508. // stream represents a stream. This is the minimal metadata needed by
  509. // the serve goroutine. Most of the actual stream state is owned by
  510. // the http.Handler's goroutine in the responseWriter. Because the
  511. // responseWriter's responseWriterState is recycled at the end of a
  512. // handler, this struct intentionally has no pointer to the
  513. // *responseWriter{,State} itself, as the Handler ending nils out the
  514. // responseWriter's state field.
  515. type stream struct {
  516. // immutable:
  517. sc *serverConn
  518. id uint32
  519. body *pipe // non-nil if expecting DATA frames
  520. cw closeWaiter // closed wait stream transitions to closed state
  521. ctx context.Context
  522. cancelCtx func()
  523. // owned by serverConn's serve loop:
  524. bodyBytes int64 // body bytes seen so far
  525. declBodyBytes int64 // or -1 if undeclared
  526. flow flow // limits writing from Handler to client
  527. inflow flow // what the client is allowed to POST/etc to us
  528. state streamState
  529. resetQueued bool // RST_STREAM queued for write; set by sc.resetStream
  530. gotTrailerHeader bool // HEADER frame for trailers was seen
  531. wroteHeaders bool // whether we wrote headers (not status 100)
  532. writeDeadline *time.Timer // nil if unused
  533. trailer http.Header // accumulated trailers
  534. reqTrailer http.Header // handler's Request.Trailer
  535. }
  536. func (sc *serverConn) Framer() *Framer { return sc.framer }
  537. func (sc *serverConn) CloseConn() error { return sc.conn.Close() }
  538. func (sc *serverConn) Flush() error { return sc.bw.Flush() }
  539. func (sc *serverConn) HeaderEncoder() (*hpack.Encoder, *bytes.Buffer) {
  540. return sc.hpackEncoder, &sc.headerWriteBuf
  541. }
  542. func (sc *serverConn) state(streamID uint32) (streamState, *stream) {
  543. sc.serveG.check()
  544. // http://tools.ietf.org/html/rfc7540#section-5.1
  545. if st, ok := sc.streams[streamID]; ok {
  546. return st.state, st
  547. }
  548. // "The first use of a new stream identifier implicitly closes all
  549. // streams in the "idle" state that might have been initiated by
  550. // that peer with a lower-valued stream identifier. For example, if
  551. // a client sends a HEADERS frame on stream 7 without ever sending a
  552. // frame on stream 5, then stream 5 transitions to the "closed"
  553. // state when the first frame for stream 7 is sent or received."
  554. if streamID%2 == 1 {
  555. if streamID <= sc.maxClientStreamID {
  556. return stateClosed, nil
  557. }
  558. } else {
  559. if streamID <= sc.maxPushPromiseID {
  560. return stateClosed, nil
  561. }
  562. }
  563. return stateIdle, nil
  564. }
  565. // setConnState calls the net/http ConnState hook for this connection, if configured.
  566. // Note that the net/http package does StateNew and StateClosed for us.
  567. // There is currently no plan for StateHijacked or hijacking HTTP/2 connections.
  568. func (sc *serverConn) setConnState(state http.ConnState) {
  569. if sc.hs.ConnState != nil {
  570. sc.hs.ConnState(sc.conn, state)
  571. }
  572. }
  573. func (sc *serverConn) vlogf(format string, args ...interface{}) {
  574. if VerboseLogs {
  575. sc.logf(format, args...)
  576. }
  577. }
  578. func (sc *serverConn) logf(format string, args ...interface{}) {
  579. if lg := sc.hs.ErrorLog; lg != nil {
  580. lg.Printf(format, args...)
  581. } else {
  582. log.Printf(format, args...)
  583. }
  584. }
  585. // errno returns v's underlying uintptr, else 0.
  586. //
  587. // TODO: remove this helper function once http2 can use build
  588. // tags. See comment in isClosedConnError.
  589. func errno(v error) uintptr {
  590. if rv := reflect.ValueOf(v); rv.Kind() == reflect.Uintptr {
  591. return uintptr(rv.Uint())
  592. }
  593. return 0
  594. }
  595. // isClosedConnError reports whether err is an error from use of a closed
  596. // network connection.
  597. func isClosedConnError(err error) bool {
  598. if err == nil {
  599. return false
  600. }
  601. // TODO: remove this string search and be more like the Windows
  602. // case below. That might involve modifying the standard library
  603. // to return better error types.
  604. str := err.Error()
  605. if strings.Contains(str, "use of closed network connection") {
  606. return true
  607. }
  608. // TODO(bradfitz): x/tools/cmd/bundle doesn't really support
  609. // build tags, so I can't make an http2_windows.go file with
  610. // Windows-specific stuff. Fix that and move this, once we
  611. // have a way to bundle this into std's net/http somehow.
  612. if runtime.GOOS == "windows" {
  613. if oe, ok := err.(*net.OpError); ok && oe.Op == "read" {
  614. if se, ok := oe.Err.(*os.SyscallError); ok && se.Syscall == "wsarecv" {
  615. const WSAECONNABORTED = 10053
  616. const WSAECONNRESET = 10054
  617. if n := errno(se.Err); n == WSAECONNRESET || n == WSAECONNABORTED {
  618. return true
  619. }
  620. }
  621. }
  622. }
  623. return false
  624. }
  625. func (sc *serverConn) condlogf(err error, format string, args ...interface{}) {
  626. if err == nil {
  627. return
  628. }
  629. if err == io.EOF || err == io.ErrUnexpectedEOF || isClosedConnError(err) || err == errPrefaceTimeout {
  630. // Boring, expected errors.
  631. sc.vlogf(format, args...)
  632. } else {
  633. sc.logf(format, args...)
  634. }
  635. }
  636. func (sc *serverConn) canonicalHeader(v string) string {
  637. sc.serveG.check()
  638. buildCommonHeaderMapsOnce()
  639. cv, ok := commonCanonHeader[v]
  640. if ok {
  641. return cv
  642. }
  643. cv, ok = sc.canonHeader[v]
  644. if ok {
  645. return cv
  646. }
  647. if sc.canonHeader == nil {
  648. sc.canonHeader = make(map[string]string)
  649. }
  650. cv = http.CanonicalHeaderKey(v)
  651. sc.canonHeader[v] = cv
  652. return cv
  653. }
  654. type readFrameResult struct {
  655. f Frame // valid until readMore is called
  656. err error
  657. // readMore should be called once the consumer no longer needs or
  658. // retains f. After readMore, f is invalid and more frames can be
  659. // read.
  660. readMore func()
  661. }
  662. // readFrames is the loop that reads incoming frames.
  663. // It takes care to only read one frame at a time, blocking until the
  664. // consumer is done with the frame.
  665. // It's run on its own goroutine.
  666. func (sc *serverConn) readFrames() {
  667. gate := make(gate)
  668. gateDone := gate.Done
  669. for {
  670. f, err := sc.framer.ReadFrame()
  671. select {
  672. case sc.readFrameCh <- readFrameResult{f, err, gateDone}:
  673. case <-sc.doneServing:
  674. return
  675. }
  676. select {
  677. case <-gate:
  678. case <-sc.doneServing:
  679. return
  680. }
  681. if terminalReadFrameError(err) {
  682. return
  683. }
  684. }
  685. }
  686. // frameWriteResult is the message passed from writeFrameAsync to the serve goroutine.
  687. type frameWriteResult struct {
  688. _ incomparable
  689. wr FrameWriteRequest // what was written (or attempted)
  690. err error // result of the writeFrame call
  691. }
  692. // writeFrameAsync runs in its own goroutine and writes a single frame
  693. // and then reports when it's done.
  694. // At most one goroutine can be running writeFrameAsync at a time per
  695. // serverConn.
  696. func (sc *serverConn) writeFrameAsync(wr FrameWriteRequest) {
  697. err := wr.write.writeFrame(sc)
  698. sc.wroteFrameCh <- frameWriteResult{wr: wr, err: err}
  699. }
  700. func (sc *serverConn) closeAllStreamsOnConnClose() {
  701. sc.serveG.check()
  702. for _, st := range sc.streams {
  703. sc.closeStream(st, errClientDisconnected)
  704. }
  705. }
  706. func (sc *serverConn) stopShutdownTimer() {
  707. sc.serveG.check()
  708. if t := sc.shutdownTimer; t != nil {
  709. t.Stop()
  710. }
  711. }
  712. func (sc *serverConn) notePanic() {
  713. // Note: this is for serverConn.serve panicking, not http.Handler code.
  714. if testHookOnPanicMu != nil {
  715. testHookOnPanicMu.Lock()
  716. defer testHookOnPanicMu.Unlock()
  717. }
  718. if testHookOnPanic != nil {
  719. if e := recover(); e != nil {
  720. if testHookOnPanic(sc, e) {
  721. panic(e)
  722. }
  723. }
  724. }
  725. }
  726. func (sc *serverConn) serve() {
  727. sc.serveG.check()
  728. defer sc.notePanic()
  729. defer sc.conn.Close()
  730. defer sc.closeAllStreamsOnConnClose()
  731. defer sc.stopShutdownTimer()
  732. defer close(sc.doneServing) // unblocks handlers trying to send
  733. if VerboseLogs {
  734. sc.vlogf("http2: server connection from %v on %p", sc.conn.RemoteAddr(), sc.hs)
  735. }
  736. sc.writeFrame(FrameWriteRequest{
  737. write: writeSettings{
  738. {SettingMaxFrameSize, sc.srv.maxReadFrameSize()},
  739. {SettingMaxConcurrentStreams, sc.advMaxStreams},
  740. {SettingMaxHeaderListSize, sc.maxHeaderListSize()},
  741. {SettingInitialWindowSize, uint32(sc.srv.initialStreamRecvWindowSize())},
  742. },
  743. })
  744. sc.unackedSettings++
  745. // Each connection starts with intialWindowSize inflow tokens.
  746. // If a higher value is configured, we add more tokens.
  747. if diff := sc.srv.initialConnRecvWindowSize() - initialWindowSize; diff > 0 {
  748. sc.sendWindowUpdate(nil, int(diff))
  749. }
  750. if err := sc.readPreface(); err != nil {
  751. sc.condlogf(err, "http2: server: error reading preface from client %v: %v", sc.conn.RemoteAddr(), err)
  752. return
  753. }
  754. // Now that we've got the preface, get us out of the
  755. // "StateNew" state. We can't go directly to idle, though.
  756. // Active means we read some data and anticipate a request. We'll
  757. // do another Active when we get a HEADERS frame.
  758. sc.setConnState(http.StateActive)
  759. sc.setConnState(http.StateIdle)
  760. if sc.srv.IdleTimeout != 0 {
  761. sc.idleTimer = time.AfterFunc(sc.srv.IdleTimeout, sc.onIdleTimer)
  762. defer sc.idleTimer.Stop()
  763. }
  764. go sc.readFrames() // closed by defer sc.conn.Close above
  765. settingsTimer := time.AfterFunc(firstSettingsTimeout, sc.onSettingsTimer)
  766. defer settingsTimer.Stop()
  767. loopNum := 0
  768. for {
  769. loopNum++
  770. select {
  771. case wr := <-sc.wantWriteFrameCh:
  772. if se, ok := wr.write.(StreamError); ok {
  773. sc.resetStream(se)
  774. break
  775. }
  776. sc.writeFrame(wr)
  777. case res := <-sc.wroteFrameCh:
  778. sc.wroteFrame(res)
  779. case res := <-sc.readFrameCh:
  780. if !sc.processFrameFromReader(res) {
  781. return
  782. }
  783. res.readMore()
  784. if settingsTimer != nil {
  785. settingsTimer.Stop()
  786. settingsTimer = nil
  787. }
  788. case m := <-sc.bodyReadCh:
  789. sc.noteBodyRead(m.st, m.n)
  790. case msg := <-sc.serveMsgCh:
  791. switch v := msg.(type) {
  792. case func(int):
  793. v(loopNum) // for testing
  794. case *serverMessage:
  795. switch v {
  796. case settingsTimerMsg:
  797. sc.logf("timeout waiting for SETTINGS frames from %v", sc.conn.RemoteAddr())
  798. return
  799. case idleTimerMsg:
  800. sc.vlogf("connection is idle")
  801. sc.goAway(ErrCodeNo)
  802. case shutdownTimerMsg:
  803. sc.vlogf("GOAWAY close timer fired; closing conn from %v", sc.conn.RemoteAddr())
  804. return
  805. case gracefulShutdownMsg:
  806. sc.startGracefulShutdownInternal()
  807. default:
  808. panic("unknown timer")
  809. }
  810. case *startPushRequest:
  811. sc.startPush(v)
  812. default:
  813. panic(fmt.Sprintf("unexpected type %T", v))
  814. }
  815. }
  816. // If the peer is causing us to generate a lot of control frames,
  817. // but not reading them from us, assume they are trying to make us
  818. // run out of memory.
  819. if sc.queuedControlFrames > sc.srv.maxQueuedControlFrames() {
  820. sc.vlogf("http2: too many control frames in send queue, closing connection")
  821. return
  822. }
  823. // Start the shutdown timer after sending a GOAWAY. When sending GOAWAY
  824. // with no error code (graceful shutdown), don't start the timer until
  825. // all open streams have been completed.
  826. sentGoAway := sc.inGoAway && !sc.needToSendGoAway && !sc.writingFrame
  827. gracefulShutdownComplete := sc.goAwayCode == ErrCodeNo && sc.curOpenStreams() == 0
  828. if sentGoAway && sc.shutdownTimer == nil && (sc.goAwayCode != ErrCodeNo || gracefulShutdownComplete) {
  829. sc.shutDownIn(goAwayTimeout)
  830. }
  831. }
  832. }
  833. func (sc *serverConn) awaitGracefulShutdown(sharedCh <-chan struct{}, privateCh chan struct{}) {
  834. select {
  835. case <-sc.doneServing:
  836. case <-sharedCh:
  837. close(privateCh)
  838. }
  839. }
  840. type serverMessage int
  841. // Message values sent to serveMsgCh.
  842. var (
  843. settingsTimerMsg = new(serverMessage)
  844. idleTimerMsg = new(serverMessage)
  845. shutdownTimerMsg = new(serverMessage)
  846. gracefulShutdownMsg = new(serverMessage)
  847. )
  848. func (sc *serverConn) onSettingsTimer() { sc.sendServeMsg(settingsTimerMsg) }
  849. func (sc *serverConn) onIdleTimer() { sc.sendServeMsg(idleTimerMsg) }
  850. func (sc *serverConn) onShutdownTimer() { sc.sendServeMsg(shutdownTimerMsg) }
  851. func (sc *serverConn) sendServeMsg(msg interface{}) {
  852. sc.serveG.checkNotOn() // NOT
  853. select {
  854. case sc.serveMsgCh <- msg:
  855. case <-sc.doneServing:
  856. }
  857. }
  858. var errPrefaceTimeout = errors.New("timeout waiting for client preface")
  859. // readPreface reads the ClientPreface greeting from the peer or
  860. // returns errPrefaceTimeout on timeout, or an error if the greeting
  861. // is invalid.
  862. func (sc *serverConn) readPreface() error {
  863. errc := make(chan error, 1)
  864. go func() {
  865. // Read the client preface
  866. buf := make([]byte, len(ClientPreface))
  867. if _, err := io.ReadFull(sc.conn, buf); err != nil {
  868. errc <- err
  869. } else if !bytes.Equal(buf, clientPreface) {
  870. errc <- fmt.Errorf("bogus greeting %q", buf)
  871. } else {
  872. errc <- nil
  873. }
  874. }()
  875. timer := time.NewTimer(prefaceTimeout) // TODO: configurable on *Server?
  876. defer timer.Stop()
  877. select {
  878. case <-timer.C:
  879. return errPrefaceTimeout
  880. case err := <-errc:
  881. if err == nil {
  882. if VerboseLogs {
  883. sc.vlogf("http2: server: client %v said hello", sc.conn.RemoteAddr())
  884. }
  885. }
  886. return err
  887. }
  888. }
  889. var errChanPool = sync.Pool{
  890. New: func() interface{} { return make(chan error, 1) },
  891. }
  892. var writeDataPool = sync.Pool{
  893. New: func() interface{} { return new(writeData) },
  894. }
  895. // writeDataFromHandler writes DATA response frames from a handler on
  896. // the given stream.
  897. func (sc *serverConn) writeDataFromHandler(stream *stream, data []byte, endStream bool) error {
  898. ch := errChanPool.Get().(chan error)
  899. writeArg := writeDataPool.Get().(*writeData)
  900. *writeArg = writeData{stream.id, data, endStream}
  901. err := sc.writeFrameFromHandler(FrameWriteRequest{
  902. write: writeArg,
  903. stream: stream,
  904. done: ch,
  905. })
  906. if err != nil {
  907. return err
  908. }
  909. var frameWriteDone bool // the frame write is done (successfully or not)
  910. select {
  911. case err = <-ch:
  912. frameWriteDone = true
  913. case <-sc.doneServing:
  914. return errClientDisconnected
  915. case <-stream.cw:
  916. // If both ch and stream.cw were ready (as might
  917. // happen on the final Write after an http.Handler
  918. // ends), prefer the write result. Otherwise this
  919. // might just be us successfully closing the stream.
  920. // The writeFrameAsync and serve goroutines guarantee
  921. // that the ch send will happen before the stream.cw
  922. // close.
  923. select {
  924. case err = <-ch:
  925. frameWriteDone = true
  926. default:
  927. return errStreamClosed
  928. }
  929. }
  930. errChanPool.Put(ch)
  931. if frameWriteDone {
  932. writeDataPool.Put(writeArg)
  933. }
  934. return err
  935. }
  936. // writeFrameFromHandler sends wr to sc.wantWriteFrameCh, but aborts
  937. // if the connection has gone away.
  938. //
  939. // This must not be run from the serve goroutine itself, else it might
  940. // deadlock writing to sc.wantWriteFrameCh (which is only mildly
  941. // buffered and is read by serve itself). If you're on the serve
  942. // goroutine, call writeFrame instead.
  943. func (sc *serverConn) writeFrameFromHandler(wr FrameWriteRequest) error {
  944. sc.serveG.checkNotOn() // NOT
  945. select {
  946. case sc.wantWriteFrameCh <- wr:
  947. return nil
  948. case <-sc.doneServing:
  949. // Serve loop is gone.
  950. // Client has closed their connection to the server.
  951. return errClientDisconnected
  952. }
  953. }
  954. // writeFrame schedules a frame to write and sends it if there's nothing
  955. // already being written.
  956. //
  957. // There is no pushback here (the serve goroutine never blocks). It's
  958. // the http.Handlers that block, waiting for their previous frames to
  959. // make it onto the wire
  960. //
  961. // If you're not on the serve goroutine, use writeFrameFromHandler instead.
  962. func (sc *serverConn) writeFrame(wr FrameWriteRequest) {
  963. sc.serveG.check()
  964. // If true, wr will not be written and wr.done will not be signaled.
  965. var ignoreWrite bool
  966. // We are not allowed to write frames on closed streams. RFC 7540 Section
  967. // 5.1.1 says: "An endpoint MUST NOT send frames other than PRIORITY on
  968. // a closed stream." Our server never sends PRIORITY, so that exception
  969. // does not apply.
  970. //
  971. // The serverConn might close an open stream while the stream's handler
  972. // is still running. For example, the server might close a stream when it
  973. // receives bad data from the client. If this happens, the handler might
  974. // attempt to write a frame after the stream has been closed (since the
  975. // handler hasn't yet been notified of the close). In this case, we simply
  976. // ignore the frame. The handler will notice that the stream is closed when
  977. // it waits for the frame to be written.
  978. //
  979. // As an exception to this rule, we allow sending RST_STREAM after close.
  980. // This allows us to immediately reject new streams without tracking any
  981. // state for those streams (except for the queued RST_STREAM frame). This
  982. // may result in duplicate RST_STREAMs in some cases, but the client should
  983. // ignore those.
  984. if wr.StreamID() != 0 {
  985. _, isReset := wr.write.(StreamError)
  986. if state, _ := sc.state(wr.StreamID()); state == stateClosed && !isReset {
  987. ignoreWrite = true
  988. }
  989. }
  990. // Don't send a 100-continue response if we've already sent headers.
  991. // See golang.org/issue/14030.
  992. switch wr.write.(type) {
  993. case *writeResHeaders:
  994. wr.stream.wroteHeaders = true
  995. case write100ContinueHeadersFrame:
  996. if wr.stream.wroteHeaders {
  997. // We do not need to notify wr.done because this frame is
  998. // never written with wr.done != nil.
  999. if wr.done != nil {
  1000. panic("wr.done != nil for write100ContinueHeadersFrame")
  1001. }
  1002. ignoreWrite = true
  1003. }
  1004. }
  1005. if !ignoreWrite {
  1006. if wr.isControl() {
  1007. sc.queuedControlFrames++
  1008. // For extra safety, detect wraparounds, which should not happen,
  1009. // and pull the plug.
  1010. if sc.queuedControlFrames < 0 {
  1011. sc.conn.Close()
  1012. }
  1013. }
  1014. sc.writeSched.Push(wr)
  1015. }
  1016. sc.scheduleFrameWrite()
  1017. }
  1018. // startFrameWrite starts a goroutine to write wr (in a separate
  1019. // goroutine since that might block on the network), and updates the
  1020. // serve goroutine's state about the world, updated from info in wr.
  1021. func (sc *serverConn) startFrameWrite(wr FrameWriteRequest) {
  1022. sc.serveG.check()
  1023. if sc.writingFrame {
  1024. panic("internal error: can only be writing one frame at a time")
  1025. }
  1026. st := wr.stream
  1027. if st != nil {
  1028. switch st.state {
  1029. case stateHalfClosedLocal:
  1030. switch wr.write.(type) {
  1031. case StreamError, handlerPanicRST, writeWindowUpdate:
  1032. // RFC 7540 Section 5.1 allows sending RST_STREAM, PRIORITY, and WINDOW_UPDATE
  1033. // in this state. (We never send PRIORITY from the server, so that is not checked.)
  1034. default:
  1035. panic(fmt.Sprintf("internal error: attempt to send frame on a half-closed-local stream: %v", wr))
  1036. }
  1037. case stateClosed:
  1038. panic(fmt.Sprintf("internal error: attempt to send frame on a closed stream: %v", wr))
  1039. }
  1040. }
  1041. if wpp, ok := wr.write.(*writePushPromise); ok {
  1042. var err error
  1043. wpp.promisedID, err = wpp.allocatePromisedID()
  1044. if err != nil {
  1045. sc.writingFrameAsync = false
  1046. wr.replyToWriter(err)
  1047. return
  1048. }
  1049. }
  1050. sc.writingFrame = true
  1051. sc.needsFrameFlush = true
  1052. if wr.write.staysWithinBuffer(sc.bw.Available()) {
  1053. sc.writingFrameAsync = false
  1054. err := wr.write.writeFrame(sc)
  1055. sc.wroteFrame(frameWriteResult{wr: wr, err: err})
  1056. } else {
  1057. sc.writingFrameAsync = true
  1058. go sc.writeFrameAsync(wr)
  1059. }
  1060. }
  1061. // errHandlerPanicked is the error given to any callers blocked in a read from
  1062. // Request.Body when the main goroutine panics. Since most handlers read in the
  1063. // main ServeHTTP goroutine, this will show up rarely.
  1064. var errHandlerPanicked = errors.New("http2: handler panicked")
  1065. // wroteFrame is called on the serve goroutine with the result of
  1066. // whatever happened on writeFrameAsync.
  1067. func (sc *serverConn) wroteFrame(res frameWriteResult) {
  1068. sc.serveG.check()
  1069. if !sc.writingFrame {
  1070. panic("internal error: expected to be already writing a frame")
  1071. }
  1072. sc.writingFrame = false
  1073. sc.writingFrameAsync = false
  1074. wr := res.wr
  1075. if writeEndsStream(wr.write) {
  1076. st := wr.stream
  1077. if st == nil {
  1078. panic("internal error: expecting non-nil stream")
  1079. }
  1080. switch st.state {
  1081. case stateOpen:
  1082. // Here we would go to stateHalfClosedLocal in
  1083. // theory, but since our handler is done and
  1084. // the net/http package provides no mechanism
  1085. // for closing a ResponseWriter while still
  1086. // reading data (see possible TODO at top of
  1087. // this file), we go into closed state here
  1088. // anyway, after telling the peer we're
  1089. // hanging up on them. We'll transition to
  1090. // stateClosed after the RST_STREAM frame is
  1091. // written.
  1092. st.state = stateHalfClosedLocal
  1093. // Section 8.1: a server MAY request that the client abort
  1094. // transmission of a request without error by sending a
  1095. // RST_STREAM with an error code of NO_ERROR after sending
  1096. // a complete response.
  1097. sc.resetStream(streamError(st.id, ErrCodeNo))
  1098. case stateHalfClosedRemote:
  1099. sc.closeStream(st, errHandlerComplete)
  1100. }
  1101. } else {
  1102. switch v := wr.write.(type) {
  1103. case StreamError:
  1104. // st may be unknown if the RST_STREAM was generated to reject bad input.
  1105. if st, ok := sc.streams[v.StreamID]; ok {
  1106. sc.closeStream(st, v)
  1107. }
  1108. case handlerPanicRST:
  1109. sc.closeStream(wr.stream, errHandlerPanicked)
  1110. }
  1111. }
  1112. // Reply (if requested) to unblock the ServeHTTP goroutine.
  1113. wr.replyToWriter(res.err)
  1114. sc.scheduleFrameWrite()
  1115. }
  1116. // scheduleFrameWrite tickles the frame writing scheduler.
  1117. //
  1118. // If a frame is already being written, nothing happens. This will be called again
  1119. // when the frame is done being written.
  1120. //
  1121. // If a frame isn't being written and we need to send one, the best frame
  1122. // to send is selected by writeSched.
  1123. //
  1124. // If a frame isn't being written and there's nothing else to send, we
  1125. // flush the write buffer.
  1126. func (sc *serverConn) scheduleFrameWrite() {
  1127. sc.serveG.check()
  1128. if sc.writingFrame || sc.inFrameScheduleLoop {
  1129. return
  1130. }
  1131. sc.inFrameScheduleLoop = true
  1132. for !sc.writingFrameAsync {
  1133. if sc.needToSendGoAway {
  1134. sc.needToSendGoAway = false
  1135. sc.startFrameWrite(FrameWriteRequest{
  1136. write: &writeGoAway{
  1137. maxStreamID: sc.maxClientStreamID,
  1138. code: sc.goAwayCode,
  1139. },
  1140. })
  1141. continue
  1142. }
  1143. if sc.needToSendSettingsAck {
  1144. sc.needToSendSettingsAck = false
  1145. sc.startFrameWrite(FrameWriteRequest{write: writeSettingsAck{}})
  1146. continue
  1147. }
  1148. if !sc.inGoAway || sc.goAwayCode == ErrCodeNo {
  1149. if wr, ok := sc.writeSched.Pop(); ok {
  1150. if wr.isControl() {
  1151. sc.queuedControlFrames--
  1152. }
  1153. sc.startFrameWrite(wr)
  1154. continue
  1155. }
  1156. }
  1157. if sc.needsFrameFlush {
  1158. sc.startFrameWrite(FrameWriteRequest{write: flushFrameWriter{}})
  1159. sc.needsFrameFlush = false // after startFrameWrite, since it sets this true
  1160. continue
  1161. }
  1162. break
  1163. }
  1164. sc.inFrameScheduleLoop = false
  1165. }
  1166. // startGracefulShutdown gracefully shuts down a connection. This
  1167. // sends GOAWAY with ErrCodeNo to tell the client we're gracefully
  1168. // shutting down. The connection isn't closed until all current
  1169. // streams are done.
  1170. //
  1171. // startGracefulShutdown returns immediately; it does not wait until
  1172. // the connection has shut down.
  1173. func (sc *serverConn) startGracefulShutdown() {
  1174. sc.serveG.checkNotOn() // NOT
  1175. sc.shutdownOnce.Do(func() { sc.sendServeMsg(gracefulShutdownMsg) })
  1176. }
  1177. // After sending GOAWAY, the connection will close after goAwayTimeout.
  1178. // If we close the connection immediately after sending GOAWAY, there may
  1179. // be unsent data in our kernel receive buffer, which will cause the kernel
  1180. // to send a TCP RST on close() instead of a FIN. This RST will abort the
  1181. // connection immediately, whether or not the client had received the GOAWAY.
  1182. //
  1183. // Ideally we should delay for at least 1 RTT + epsilon so the client has
  1184. // a chance to read the GOAWAY and stop sending messages. Measuring RTT
  1185. // is hard, so we approximate with 1 second. See golang.org/issue/18701.
  1186. //
  1187. // This is a var so it can be shorter in tests, where all requests uses the
  1188. // loopback interface making the expected RTT very small.
  1189. //
  1190. // TODO: configurable?
  1191. var goAwayTimeout = 1 * time.Second
  1192. func (sc *serverConn) startGracefulShutdownInternal() {
  1193. sc.goAway(ErrCodeNo)
  1194. }
  1195. func (sc *serverConn) goAway(code ErrCode) {
  1196. sc.serveG.check()
  1197. if sc.inGoAway {
  1198. return
  1199. }
  1200. sc.inGoAway = true
  1201. sc.needToSendGoAway = true
  1202. sc.goAwayCode = code
  1203. sc.scheduleFrameWrite()
  1204. }
  1205. func (sc *serverConn) shutDownIn(d time.Duration) {
  1206. sc.serveG.check()
  1207. sc.shutdownTimer = time.AfterFunc(d, sc.onShutdownTimer)
  1208. }
  1209. func (sc *serverConn) resetStream(se StreamError) {
  1210. sc.serveG.check()
  1211. sc.writeFrame(FrameWriteRequest{write: se})
  1212. if st, ok := sc.streams[se.StreamID]; ok {
  1213. st.resetQueued = true
  1214. }
  1215. }
  1216. // processFrameFromReader processes the serve loop's read from readFrameCh from the
  1217. // frame-reading goroutine.
  1218. // processFrameFromReader returns whether the connection should be kept open.
  1219. func (sc *serverConn) processFrameFromReader(res readFrameResult) bool {
  1220. sc.serveG.check()
  1221. err := res.err
  1222. if err != nil {
  1223. if err == ErrFrameTooLarge {
  1224. sc.goAway(ErrCodeFrameSize)
  1225. return true // goAway will close the loop
  1226. }
  1227. clientGone := err == io.EOF || err == io.ErrUnexpectedEOF || isClosedConnError(err)
  1228. if clientGone {
  1229. // TODO: could we also get into this state if
  1230. // the peer does a half close
  1231. // (e.g. CloseWrite) because they're done
  1232. // sending frames but they're still wanting
  1233. // our open replies? Investigate.
  1234. // TODO: add CloseWrite to crypto/tls.Conn first
  1235. // so we have a way to test this? I suppose
  1236. // just for testing we could have a non-TLS mode.
  1237. return false
  1238. }
  1239. } else {
  1240. f := res.f
  1241. if VerboseLogs {
  1242. sc.vlogf("http2: server read frame %v", summarizeFrame(f))
  1243. }
  1244. err = sc.processFrame(f)
  1245. if err == nil {
  1246. return true
  1247. }
  1248. }
  1249. switch ev := err.(type) {
  1250. case StreamError:
  1251. sc.resetStream(ev)
  1252. return true
  1253. case goAwayFlowError:
  1254. sc.goAway(ErrCodeFlowControl)
  1255. return true
  1256. case ConnectionError:
  1257. sc.logf("http2: server connection error from %v: %v", sc.conn.RemoteAddr(), ev)
  1258. sc.goAway(ErrCode(ev))
  1259. return true // goAway will handle shutdown
  1260. default:
  1261. if res.err != nil {
  1262. sc.vlogf("http2: server closing client connection; error reading frame from client %s: %v", sc.conn.RemoteAddr(), err)
  1263. } else {
  1264. sc.logf("http2: server closing client connection: %v", err)
  1265. }
  1266. return false
  1267. }
  1268. }
  1269. func (sc *serverConn) processFrame(f Frame) error {
  1270. sc.serveG.check()
  1271. // First frame received must be SETTINGS.
  1272. if !sc.sawFirstSettings {
  1273. if _, ok := f.(*SettingsFrame); !ok {
  1274. return ConnectionError(ErrCodeProtocol)
  1275. }
  1276. sc.sawFirstSettings = true
  1277. }
  1278. switch f := f.(type) {
  1279. case *SettingsFrame:
  1280. return sc.processSettings(f)
  1281. case *MetaHeadersFrame:
  1282. return sc.processHeaders(f)
  1283. case *WindowUpdateFrame:
  1284. return sc.processWindowUpdate(f)
  1285. case *PingFrame:
  1286. return sc.processPing(f)
  1287. case *DataFrame:
  1288. return sc.processData(f)
  1289. case *RSTStreamFrame:
  1290. return sc.processResetStream(f)
  1291. case *PriorityFrame:
  1292. return sc.processPriority(f)
  1293. case *GoAwayFrame:
  1294. return sc.processGoAway(f)
  1295. case *PushPromiseFrame:
  1296. // A client cannot push. Thus, servers MUST treat the receipt of a PUSH_PROMISE
  1297. // frame as a connection error (Section 5.4.1) of type PROTOCOL_ERROR.
  1298. return ConnectionError(ErrCodeProtocol)
  1299. default:
  1300. sc.vlogf("http2: server ignoring frame: %v", f.Header())
  1301. return nil
  1302. }
  1303. }
  1304. func (sc *serverConn) processPing(f *PingFrame) error {
  1305. sc.serveG.check()
  1306. if f.IsAck() {
  1307. // 6.7 PING: " An endpoint MUST NOT respond to PING frames
  1308. // containing this flag."
  1309. return nil
  1310. }
  1311. if f.StreamID != 0 {
  1312. // "PING frames are not associated with any individual
  1313. // stream. If a PING frame is received with a stream
  1314. // identifier field value other than 0x0, the recipient MUST
  1315. // respond with a connection error (Section 5.4.1) of type
  1316. // PROTOCOL_ERROR."
  1317. return ConnectionError(ErrCodeProtocol)
  1318. }
  1319. if sc.inGoAway && sc.goAwayCode != ErrCodeNo {
  1320. return nil
  1321. }
  1322. sc.writeFrame(FrameWriteRequest{write: writePingAck{f}})
  1323. return nil
  1324. }
  1325. func (sc *serverConn) processWindowUpdate(f *WindowUpdateFrame) error {
  1326. sc.serveG.check()
  1327. switch {
  1328. case f.StreamID != 0: // stream-level flow control
  1329. state, st := sc.state(f.StreamID)
  1330. if state == stateIdle {
  1331. // Section 5.1: "Receiving any frame other than HEADERS
  1332. // or PRIORITY on a stream in this state MUST be
  1333. // treated as a connection error (Section 5.4.1) of
  1334. // type PROTOCOL_ERROR."
  1335. return ConnectionError(ErrCodeProtocol)
  1336. }
  1337. if st == nil {
  1338. // "WINDOW_UPDATE can be sent by a peer that has sent a
  1339. // frame bearing the END_STREAM flag. This means that a
  1340. // receiver could receive a WINDOW_UPDATE frame on a "half
  1341. // closed (remote)" or "closed" stream. A receiver MUST
  1342. // NOT treat this as an error, see Section 5.1."
  1343. return nil
  1344. }
  1345. if !st.flow.add(int32(f.Increment)) {
  1346. return streamError(f.StreamID, ErrCodeFlowControl)
  1347. }
  1348. default: // connection-level flow control
  1349. if !sc.flow.add(int32(f.Increment)) {
  1350. return goAwayFlowError{}
  1351. }
  1352. }
  1353. sc.scheduleFrameWrite()
  1354. return nil
  1355. }
  1356. func (sc *serverConn) processResetStream(f *RSTStreamFrame) error {
  1357. sc.serveG.check()
  1358. state, st := sc.state(f.StreamID)
  1359. if state == stateIdle {
  1360. // 6.4 "RST_STREAM frames MUST NOT be sent for a
  1361. // stream in the "idle" state. If a RST_STREAM frame
  1362. // identifying an idle stream is received, the
  1363. // recipient MUST treat this as a connection error
  1364. // (Section 5.4.1) of type PROTOCOL_ERROR.
  1365. return ConnectionError(ErrCodeProtocol)
  1366. }
  1367. if st != nil {
  1368. st.cancelCtx()
  1369. sc.closeStream(st, streamError(f.StreamID, f.ErrCode))
  1370. }
  1371. return nil
  1372. }
  1373. func (sc *serverConn) closeStream(st *stream, err error) {
  1374. sc.serveG.check()
  1375. if st.state == stateIdle || st.state == stateClosed {
  1376. panic(fmt.Sprintf("invariant; can't close stream in state %v", st.state))
  1377. }
  1378. st.state = stateClosed
  1379. if st.writeDeadline != nil {
  1380. st.writeDeadline.Stop()
  1381. }
  1382. if st.isPushed() {
  1383. sc.curPushedStreams--
  1384. } else {
  1385. sc.curClientStreams--
  1386. }
  1387. delete(sc.streams, st.id)
  1388. if len(sc.streams) == 0 {
  1389. sc.setConnState(http.StateIdle)
  1390. if sc.srv.IdleTimeout != 0 {
  1391. sc.idleTimer.Reset(sc.srv.IdleTimeout)
  1392. }
  1393. if h1ServerKeepAlivesDisabled(sc.hs) {
  1394. sc.startGracefulShutdownInternal()
  1395. }
  1396. }
  1397. if p := st.body; p != nil {
  1398. // Return any buffered unread bytes worth of conn-level flow control.
  1399. // See golang.org/issue/16481
  1400. sc.sendWindowUpdate(nil, p.Len())
  1401. p.CloseWithError(err)
  1402. }
  1403. st.cw.Close() // signals Handler's CloseNotifier, unblocks writes, etc
  1404. sc.writeSched.CloseStream(st.id)
  1405. }
  1406. func (sc *serverConn) processSettings(f *SettingsFrame) error {
  1407. sc.serveG.check()
  1408. if f.IsAck() {
  1409. sc.unackedSettings--
  1410. if sc.unackedSettings < 0 {
  1411. // Why is the peer ACKing settings we never sent?
  1412. // The spec doesn't mention this case, but
  1413. // hang up on them anyway.
  1414. return ConnectionError(ErrCodeProtocol)
  1415. }
  1416. return nil
  1417. }
  1418. if f.NumSettings() > 100 || f.HasDuplicates() {
  1419. // This isn't actually in the spec, but hang up on
  1420. // suspiciously large settings frames or those with
  1421. // duplicate entries.
  1422. return ConnectionError(ErrCodeProtocol)
  1423. }
  1424. if err := f.ForeachSetting(sc.processSetting); err != nil {
  1425. return err
  1426. }
  1427. // TODO: judging by RFC 7540, Section 6.5.3 each SETTINGS frame should be
  1428. // acknowledged individually, even if multiple are received before the ACK.
  1429. sc.needToSendSettingsAck = true
  1430. sc.scheduleFrameWrite()
  1431. return nil
  1432. }
  1433. func (sc *serverConn) processSetting(s Setting) error {
  1434. sc.serveG.check()
  1435. if err := s.Valid(); err != nil {
  1436. return err
  1437. }
  1438. if VerboseLogs {
  1439. sc.vlogf("http2: server processing setting %v", s)
  1440. }
  1441. switch s.ID {
  1442. case SettingHeaderTableSize:
  1443. sc.headerTableSize = s.Val
  1444. sc.hpackEncoder.SetMaxDynamicTableSize(s.Val)
  1445. case SettingEnablePush:
  1446. sc.pushEnabled = s.Val != 0
  1447. case SettingMaxConcurrentStreams:
  1448. sc.clientMaxStreams = s.Val
  1449. case SettingInitialWindowSize:
  1450. return sc.processSettingInitialWindowSize(s.Val)
  1451. case SettingMaxFrameSize:
  1452. sc.maxFrameSize = int32(s.Val) // the maximum valid s.Val is < 2^31
  1453. case SettingMaxHeaderListSize:
  1454. sc.peerMaxHeaderListSize = s.Val
  1455. default:
  1456. // Unknown setting: "An endpoint that receives a SETTINGS
  1457. // frame with any unknown or unsupported identifier MUST
  1458. // ignore that setting."
  1459. if VerboseLogs {
  1460. sc.vlogf("http2: server ignoring unknown setting %v", s)
  1461. }
  1462. }
  1463. return nil
  1464. }
  1465. func (sc *serverConn) processSettingInitialWindowSize(val uint32) error {
  1466. sc.serveG.check()
  1467. // Note: val already validated to be within range by
  1468. // processSetting's Valid call.
  1469. // "A SETTINGS frame can alter the initial flow control window
  1470. // size for all current streams. When the value of
  1471. // SETTINGS_INITIAL_WINDOW_SIZE changes, a receiver MUST
  1472. // adjust the size of all stream flow control windows that it
  1473. // maintains by the difference between the new value and the
  1474. // old value."
  1475. old := sc.initialStreamSendWindowSize
  1476. sc.initialStreamSendWindowSize = int32(val)
  1477. growth := int32(val) - old // may be negative
  1478. for _, st := range sc.streams {
  1479. if !st.flow.add(growth) {
  1480. // 6.9.2 Initial Flow Control Window Size
  1481. // "An endpoint MUST treat a change to
  1482. // SETTINGS_INITIAL_WINDOW_SIZE that causes any flow
  1483. // control window to exceed the maximum size as a
  1484. // connection error (Section 5.4.1) of type
  1485. // FLOW_CONTROL_ERROR."
  1486. return ConnectionError(ErrCodeFlowControl)
  1487. }
  1488. }
  1489. return nil
  1490. }
  1491. func (sc *serverConn) processData(f *DataFrame) error {
  1492. sc.serveG.check()
  1493. if sc.inGoAway && sc.goAwayCode != ErrCodeNo {
  1494. return nil
  1495. }
  1496. data := f.Data()
  1497. // "If a DATA frame is received whose stream is not in "open"
  1498. // or "half closed (local)" state, the recipient MUST respond
  1499. // with a stream error (Section 5.4.2) of type STREAM_CLOSED."
  1500. id := f.Header().StreamID
  1501. state, st := sc.state(id)
  1502. if id == 0 || state == stateIdle {
  1503. // Section 5.1: "Receiving any frame other than HEADERS
  1504. // or PRIORITY on a stream in this state MUST be
  1505. // treated as a connection error (Section 5.4.1) of
  1506. // type PROTOCOL_ERROR."
  1507. return ConnectionError(ErrCodeProtocol)
  1508. }
  1509. if st == nil || state != stateOpen || st.gotTrailerHeader || st.resetQueued {
  1510. // This includes sending a RST_STREAM if the stream is
  1511. // in stateHalfClosedLocal (which currently means that
  1512. // the http.Handler returned, so it's done reading &
  1513. // done writing). Try to stop the client from sending
  1514. // more DATA.
  1515. // But still enforce their connection-level flow control,
  1516. // and return any flow control bytes since we're not going
  1517. // to consume them.
  1518. if sc.inflow.available() < int32(f.Length) {
  1519. return streamError(id, ErrCodeFlowControl)
  1520. }
  1521. // Deduct the flow control from inflow, since we're
  1522. // going to immediately add it back in
  1523. // sendWindowUpdate, which also schedules sending the
  1524. // frames.
  1525. sc.inflow.take(int32(f.Length))
  1526. sc.sendWindowUpdate(nil, int(f.Length)) // conn-level
  1527. if st != nil && st.resetQueued {
  1528. // Already have a stream error in flight. Don't send another.
  1529. return nil
  1530. }
  1531. return streamError(id, ErrCodeStreamClosed)
  1532. }
  1533. if st.body == nil {
  1534. panic("internal error: should have a body in this state")
  1535. }
  1536. // Sender sending more than they'd declared?
  1537. if st.declBodyBytes != -1 && st.bodyBytes+int64(len(data)) > st.declBodyBytes {
  1538. st.body.CloseWithError(fmt.Errorf("sender tried to send more than declared Content-Length of %d bytes", st.declBodyBytes))
  1539. // RFC 7540, sec 8.1.2.6: A request or response is also malformed if the
  1540. // value of a content-length header field does not equal the sum of the
  1541. // DATA frame payload lengths that form the body.
  1542. return streamError(id, ErrCodeProtocol)
  1543. }
  1544. if f.Length > 0 {
  1545. // Check whether the client has flow control quota.
  1546. if st.inflow.available() < int32(f.Length) {
  1547. return streamError(id, ErrCodeFlowControl)
  1548. }
  1549. st.inflow.take(int32(f.Length))
  1550. if len(data) > 0 {
  1551. wrote, err := st.body.Write(data)
  1552. if err != nil {
  1553. return streamError(id, ErrCodeStreamClosed)
  1554. }
  1555. if wrote != len(data) {
  1556. panic("internal error: bad Writer")
  1557. }
  1558. st.bodyBytes += int64(len(data))
  1559. }
  1560. // Return any padded flow control now, since we won't
  1561. // refund it later on body reads.
  1562. if pad := int32(f.Length) - int32(len(data)); pad > 0 {
  1563. sc.sendWindowUpdate32(nil, pad)
  1564. sc.sendWindowUpdate32(st, pad)
  1565. }
  1566. }
  1567. if f.StreamEnded() {
  1568. st.endStream()
  1569. }
  1570. return nil
  1571. }
  1572. func (sc *serverConn) processGoAway(f *GoAwayFrame) error {
  1573. sc.serveG.check()
  1574. if f.ErrCode != ErrCodeNo {
  1575. sc.logf("http2: received GOAWAY %+v, starting graceful shutdown", f)
  1576. } else {
  1577. sc.vlogf("http2: received GOAWAY %+v, starting graceful shutdown", f)
  1578. }
  1579. sc.startGracefulShutdownInternal()
  1580. // http://tools.ietf.org/html/rfc7540#section-6.8
  1581. // We should not create any new streams, which means we should disable push.
  1582. sc.pushEnabled = false
  1583. return nil
  1584. }
  1585. // isPushed reports whether the stream is server-initiated.
  1586. func (st *stream) isPushed() bool {
  1587. return st.id%2 == 0
  1588. }
  1589. // endStream closes a Request.Body's pipe. It is called when a DATA
  1590. // frame says a request body is over (or after trailers).
  1591. func (st *stream) endStream() {
  1592. sc := st.sc
  1593. sc.serveG.check()
  1594. if st.declBodyBytes != -1 && st.declBodyBytes != st.bodyBytes {
  1595. st.body.CloseWithError(fmt.Errorf("request declared a Content-Length of %d but only wrote %d bytes",
  1596. st.declBodyBytes, st.bodyBytes))
  1597. } else {
  1598. st.body.closeWithErrorAndCode(io.EOF, st.copyTrailersToHandlerRequest)
  1599. st.body.CloseWithError(io.EOF)
  1600. }
  1601. st.state = stateHalfClosedRemote
  1602. }
  1603. // copyTrailersToHandlerRequest is run in the Handler's goroutine in
  1604. // its Request.Body.Read just before it gets io.EOF.
  1605. func (st *stream) copyTrailersToHandlerRequest() {
  1606. for k, vv := range st.trailer {
  1607. if _, ok := st.reqTrailer[k]; ok {
  1608. // Only copy it over it was pre-declared.
  1609. st.reqTrailer[k] = vv
  1610. }
  1611. }
  1612. }
  1613. // onWriteTimeout is run on its own goroutine (from time.AfterFunc)
  1614. // when the stream's WriteTimeout has fired.
  1615. func (st *stream) onWriteTimeout() {
  1616. st.sc.writeFrameFromHandler(FrameWriteRequest{write: streamError(st.id, ErrCodeInternal)})
  1617. }
  1618. func (sc *serverConn) processHeaders(f *MetaHeadersFrame) error {
  1619. sc.serveG.check()
  1620. id := f.StreamID
  1621. if sc.inGoAway {
  1622. // Ignore.
  1623. return nil
  1624. }
  1625. // http://tools.ietf.org/html/rfc7540#section-5.1.1
  1626. // Streams initiated by a client MUST use odd-numbered stream
  1627. // identifiers. [...] An endpoint that receives an unexpected
  1628. // stream identifier MUST respond with a connection error
  1629. // (Section 5.4.1) of type PROTOCOL_ERROR.
  1630. if id%2 != 1 {
  1631. return ConnectionError(ErrCodeProtocol)
  1632. }
  1633. // A HEADERS frame can be used to create a new stream or
  1634. // send a trailer for an open one. If we already have a stream
  1635. // open, let it process its own HEADERS frame (trailers at this
  1636. // point, if it's valid).
  1637. if st := sc.streams[f.StreamID]; st != nil {
  1638. if st.resetQueued {
  1639. // We're sending RST_STREAM to close the stream, so don't bother
  1640. // processing this frame.
  1641. return nil
  1642. }
  1643. // RFC 7540, sec 5.1: If an endpoint receives additional frames, other than
  1644. // WINDOW_UPDATE, PRIORITY, or RST_STREAM, for a stream that is in
  1645. // this state, it MUST respond with a stream error (Section 5.4.2) of
  1646. // type STREAM_CLOSED.
  1647. if st.state == stateHalfClosedRemote {
  1648. return streamError(id, ErrCodeStreamClosed)
  1649. }
  1650. return st.processTrailerHeaders(f)
  1651. }
  1652. // [...] The identifier of a newly established stream MUST be
  1653. // numerically greater than all streams that the initiating
  1654. // endpoint has opened or reserved. [...] An endpoint that
  1655. // receives an unexpected stream identifier MUST respond with
  1656. // a connection error (Section 5.4.1) of type PROTOCOL_ERROR.
  1657. if id <= sc.maxClientStreamID {
  1658. return ConnectionError(ErrCodeProtocol)
  1659. }
  1660. sc.maxClientStreamID = id
  1661. if sc.idleTimer != nil {
  1662. sc.idleTimer.Stop()
  1663. }
  1664. // http://tools.ietf.org/html/rfc7540#section-5.1.2
  1665. // [...] Endpoints MUST NOT exceed the limit set by their peer. An
  1666. // endpoint that receives a HEADERS frame that causes their
  1667. // advertised concurrent stream limit to be exceeded MUST treat
  1668. // this as a stream error (Section 5.4.2) of type PROTOCOL_ERROR
  1669. // or REFUSED_STREAM.
  1670. if sc.curClientStreams+1 > sc.advMaxStreams {
  1671. if sc.unackedSettings == 0 {
  1672. // They should know better.
  1673. return streamError(id, ErrCodeProtocol)
  1674. }
  1675. // Assume it's a network race, where they just haven't
  1676. // received our last SETTINGS update. But actually
  1677. // this can't happen yet, because we don't yet provide
  1678. // a way for users to adjust server parameters at
  1679. // runtime.
  1680. return streamError(id, ErrCodeRefusedStream)
  1681. }
  1682. initialState := stateOpen
  1683. if f.StreamEnded() {
  1684. initialState = stateHalfClosedRemote
  1685. }
  1686. st := sc.newStream(id, 0, initialState)
  1687. if f.HasPriority() {
  1688. if err := checkPriority(f.StreamID, f.Priority); err != nil {
  1689. return err
  1690. }
  1691. sc.writeSched.AdjustStream(st.id, f.Priority)
  1692. }
  1693. rw, req, err := sc.newWriterAndRequest(st, f)
  1694. if err != nil {
  1695. return err
  1696. }
  1697. st.reqTrailer = req.Trailer
  1698. if st.reqTrailer != nil {
  1699. st.trailer = make(http.Header)
  1700. }
  1701. st.body = req.Body.(*requestBody).pipe // may be nil
  1702. st.declBodyBytes = req.ContentLength
  1703. handler := sc.handler.ServeHTTP
  1704. if f.Truncated {
  1705. // Their header list was too long. Send a 431 error.
  1706. handler = handleHeaderListTooLong
  1707. } else if err := checkValidHTTP2RequestHeaders(req.Header); err != nil {
  1708. handler = new400Handler(err)
  1709. }
  1710. // The net/http package sets the read deadline from the
  1711. // http.Server.ReadTimeout during the TLS handshake, but then
  1712. // passes the connection off to us with the deadline already
  1713. // set. Disarm it here after the request headers are read,
  1714. // similar to how the http1 server works. Here it's
  1715. // technically more like the http1 Server's ReadHeaderTimeout
  1716. // (in Go 1.8), though. That's a more sane option anyway.
  1717. if sc.hs.ReadTimeout != 0 {
  1718. sc.conn.SetReadDeadline(time.Time{})
  1719. }
  1720. go sc.runHandler(rw, req, handler)
  1721. return nil
  1722. }
  1723. func (st *stream) processTrailerHeaders(f *MetaHeadersFrame) error {
  1724. sc := st.sc
  1725. sc.serveG.check()
  1726. if st.gotTrailerHeader {
  1727. return ConnectionError(ErrCodeProtocol)
  1728. }
  1729. st.gotTrailerHeader = true
  1730. if !f.StreamEnded() {
  1731. return streamError(st.id, ErrCodeProtocol)
  1732. }
  1733. if len(f.PseudoFields()) > 0 {
  1734. return streamError(st.id, ErrCodeProtocol)
  1735. }
  1736. if st.trailer != nil {
  1737. for _, hf := range f.RegularFields() {
  1738. key := sc.canonicalHeader(hf.Name)
  1739. if !httpguts.ValidTrailerHeader(key) {
  1740. // TODO: send more details to the peer somehow. But http2 has
  1741. // no way to send debug data at a stream level. Discuss with
  1742. // HTTP folk.
  1743. return streamError(st.id, ErrCodeProtocol)
  1744. }
  1745. st.trailer[key] = append(st.trailer[key], hf.Value)
  1746. }
  1747. }
  1748. st.endStream()
  1749. return nil
  1750. }
  1751. func checkPriority(streamID uint32, p PriorityParam) error {
  1752. if streamID == p.StreamDep {
  1753. // Section 5.3.1: "A stream cannot depend on itself. An endpoint MUST treat
  1754. // this as a stream error (Section 5.4.2) of type PROTOCOL_ERROR."
  1755. // Section 5.3.3 says that a stream can depend on one of its dependencies,
  1756. // so it's only self-dependencies that are forbidden.
  1757. return streamError(streamID, ErrCodeProtocol)
  1758. }
  1759. return nil
  1760. }
  1761. func (sc *serverConn) processPriority(f *PriorityFrame) error {
  1762. if sc.inGoAway {
  1763. return nil
  1764. }
  1765. if err := checkPriority(f.StreamID, f.PriorityParam); err != nil {
  1766. return err
  1767. }
  1768. sc.writeSched.AdjustStream(f.StreamID, f.PriorityParam)
  1769. return nil
  1770. }
  1771. func (sc *serverConn) newStream(id, pusherID uint32, state streamState) *stream {
  1772. sc.serveG.check()
  1773. if id == 0 {
  1774. panic("internal error: cannot create stream with id 0")
  1775. }
  1776. ctx, cancelCtx := context.WithCancel(sc.baseCtx)
  1777. st := &stream{
  1778. sc: sc,
  1779. id: id,
  1780. state: state,
  1781. ctx: ctx,
  1782. cancelCtx: cancelCtx,
  1783. }
  1784. st.cw.Init()
  1785. st.flow.conn = &sc.flow // link to conn-level counter
  1786. st.flow.add(sc.initialStreamSendWindowSize)
  1787. st.inflow.conn = &sc.inflow // link to conn-level counter
  1788. st.inflow.add(sc.srv.initialStreamRecvWindowSize())
  1789. if sc.hs.WriteTimeout != 0 {
  1790. st.writeDeadline = time.AfterFunc(sc.hs.WriteTimeout, st.onWriteTimeout)
  1791. }
  1792. sc.streams[id] = st
  1793. sc.writeSched.OpenStream(st.id, OpenStreamOptions{PusherID: pusherID})
  1794. if st.isPushed() {
  1795. sc.curPushedStreams++
  1796. } else {
  1797. sc.curClientStreams++
  1798. }
  1799. if sc.curOpenStreams() == 1 {
  1800. sc.setConnState(http.StateActive)
  1801. }
  1802. return st
  1803. }
  1804. func (sc *serverConn) newWriterAndRequest(st *stream, f *MetaHeadersFrame) (*responseWriter, *http.Request, error) {
  1805. sc.serveG.check()
  1806. rp := requestParam{
  1807. method: f.PseudoValue("method"),
  1808. scheme: f.PseudoValue("scheme"),
  1809. authority: f.PseudoValue("authority"),
  1810. path: f.PseudoValue("path"),
  1811. }
  1812. isConnect := rp.method == "CONNECT"
  1813. if isConnect {
  1814. if rp.path != "" || rp.scheme != "" || rp.authority == "" {
  1815. return nil, nil, streamError(f.StreamID, ErrCodeProtocol)
  1816. }
  1817. } else if rp.method == "" || rp.path == "" || (rp.scheme != "https" && rp.scheme != "http") {
  1818. // See 8.1.2.6 Malformed Requests and Responses:
  1819. //
  1820. // Malformed requests or responses that are detected
  1821. // MUST be treated as a stream error (Section 5.4.2)
  1822. // of type PROTOCOL_ERROR."
  1823. //
  1824. // 8.1.2.3 Request Pseudo-Header Fields
  1825. // "All HTTP/2 requests MUST include exactly one valid
  1826. // value for the :method, :scheme, and :path
  1827. // pseudo-header fields"
  1828. return nil, nil, streamError(f.StreamID, ErrCodeProtocol)
  1829. }
  1830. bodyOpen := !f.StreamEnded()
  1831. if rp.method == "HEAD" && bodyOpen {
  1832. // HEAD requests can't have bodies
  1833. return nil, nil, streamError(f.StreamID, ErrCodeProtocol)
  1834. }
  1835. rp.header = make(http.Header)
  1836. for _, hf := range f.RegularFields() {
  1837. rp.header.Add(sc.canonicalHeader(hf.Name), hf.Value)
  1838. }
  1839. if rp.authority == "" {
  1840. rp.authority = rp.header.Get("Host")
  1841. }
  1842. rw, req, err := sc.newWriterAndRequestNoBody(st, rp)
  1843. if err != nil {
  1844. return nil, nil, err
  1845. }
  1846. if bodyOpen {
  1847. if vv, ok := rp.header["Content-Length"]; ok {
  1848. if cl, err := strconv.ParseUint(vv[0], 10, 63); err == nil {
  1849. req.ContentLength = int64(cl)
  1850. } else {
  1851. req.ContentLength = 0
  1852. }
  1853. } else {
  1854. req.ContentLength = -1
  1855. }
  1856. req.Body.(*requestBody).pipe = &pipe{
  1857. b: &dataBuffer{expected: req.ContentLength},
  1858. }
  1859. }
  1860. return rw, req, nil
  1861. }
  1862. type requestParam struct {
  1863. method string
  1864. scheme, authority, path string
  1865. header http.Header
  1866. }
  1867. func (sc *serverConn) newWriterAndRequestNoBody(st *stream, rp requestParam) (*responseWriter, *http.Request, error) {
  1868. sc.serveG.check()
  1869. var tlsState *tls.ConnectionState // nil if not scheme https
  1870. if rp.scheme == "https" {
  1871. tlsState = sc.tlsState
  1872. }
  1873. needsContinue := rp.header.Get("Expect") == "100-continue"
  1874. if needsContinue {
  1875. rp.header.Del("Expect")
  1876. }
  1877. // Merge Cookie headers into one "; "-delimited value.
  1878. if cookies := rp.header["Cookie"]; len(cookies) > 1 {
  1879. rp.header.Set("Cookie", strings.Join(cookies, "; "))
  1880. }
  1881. // Setup Trailers
  1882. var trailer http.Header
  1883. for _, v := range rp.header["Trailer"] {
  1884. for _, key := range strings.Split(v, ",") {
  1885. key = http.CanonicalHeaderKey(textproto.TrimString(key))
  1886. switch key {
  1887. case "Transfer-Encoding", "Trailer", "Content-Length":
  1888. // Bogus. (copy of http1 rules)
  1889. // Ignore.
  1890. default:
  1891. if trailer == nil {
  1892. trailer = make(http.Header)
  1893. }
  1894. trailer[key] = nil
  1895. }
  1896. }
  1897. }
  1898. delete(rp.header, "Trailer")
  1899. var url_ *url.URL
  1900. var requestURI string
  1901. if rp.method == "CONNECT" {
  1902. url_ = &url.URL{Host: rp.authority}
  1903. requestURI = rp.authority // mimic HTTP/1 server behavior
  1904. } else {
  1905. var err error
  1906. url_, err = url.ParseRequestURI(rp.path)
  1907. if err != nil {
  1908. return nil, nil, streamError(st.id, ErrCodeProtocol)
  1909. }
  1910. requestURI = rp.path
  1911. }
  1912. body := &requestBody{
  1913. conn: sc,
  1914. stream: st,
  1915. needsContinue: needsContinue,
  1916. }
  1917. req := &http.Request{
  1918. Method: rp.method,
  1919. URL: url_,
  1920. RemoteAddr: sc.remoteAddrStr,
  1921. Header: rp.header,
  1922. RequestURI: requestURI,
  1923. Proto: "HTTP/2.0",
  1924. ProtoMajor: 2,
  1925. ProtoMinor: 0,
  1926. TLS: tlsState,
  1927. Host: rp.authority,
  1928. Body: body,
  1929. Trailer: trailer,
  1930. }
  1931. req = req.WithContext(st.ctx)
  1932. rws := responseWriterStatePool.Get().(*responseWriterState)
  1933. bwSave := rws.bw
  1934. *rws = responseWriterState{} // zero all the fields
  1935. rws.conn = sc
  1936. rws.bw = bwSave
  1937. rws.bw.Reset(chunkWriter{rws})
  1938. rws.stream = st
  1939. rws.req = req
  1940. rws.body = body
  1941. rw := &responseWriter{rws: rws}
  1942. return rw, req, nil
  1943. }
  1944. // Run on its own goroutine.
  1945. func (sc *serverConn) runHandler(rw *responseWriter, req *http.Request, handler func(http.ResponseWriter, *http.Request)) {
  1946. didPanic := true
  1947. defer func() {
  1948. rw.rws.stream.cancelCtx()
  1949. if didPanic {
  1950. e := recover()
  1951. sc.writeFrameFromHandler(FrameWriteRequest{
  1952. write: handlerPanicRST{rw.rws.stream.id},
  1953. stream: rw.rws.stream,
  1954. })
  1955. // Same as net/http:
  1956. if e != nil && e != http.ErrAbortHandler {
  1957. const size = 64 << 10
  1958. buf := make([]byte, size)
  1959. buf = buf[:runtime.Stack(buf, false)]
  1960. sc.logf("http2: panic serving %v: %v\n%s", sc.conn.RemoteAddr(), e, buf)
  1961. }
  1962. return
  1963. }
  1964. rw.handlerDone()
  1965. }()
  1966. handler(rw, req)
  1967. didPanic = false
  1968. }
  1969. func handleHeaderListTooLong(w http.ResponseWriter, r *http.Request) {
  1970. // 10.5.1 Limits on Header Block Size:
  1971. // .. "A server that receives a larger header block than it is
  1972. // willing to handle can send an HTTP 431 (Request Header Fields Too
  1973. // Large) status code"
  1974. const statusRequestHeaderFieldsTooLarge = 431 // only in Go 1.6+
  1975. w.WriteHeader(statusRequestHeaderFieldsTooLarge)
  1976. io.WriteString(w, "<h1>HTTP Error 431</h1><p>Request Header Field(s) Too Large</p>")
  1977. }
  1978. // called from handler goroutines.
  1979. // h may be nil.
  1980. func (sc *serverConn) writeHeaders(st *stream, headerData *writeResHeaders) error {
  1981. sc.serveG.checkNotOn() // NOT on
  1982. var errc chan error
  1983. if headerData.h != nil {
  1984. // If there's a header map (which we don't own), so we have to block on
  1985. // waiting for this frame to be written, so an http.Flush mid-handler
  1986. // writes out the correct value of keys, before a handler later potentially
  1987. // mutates it.
  1988. errc = errChanPool.Get().(chan error)
  1989. }
  1990. if err := sc.writeFrameFromHandler(FrameWriteRequest{
  1991. write: headerData,
  1992. stream: st,
  1993. done: errc,
  1994. }); err != nil {
  1995. return err
  1996. }
  1997. if errc != nil {
  1998. select {
  1999. case err := <-errc:
  2000. errChanPool.Put(errc)
  2001. return err
  2002. case <-sc.doneServing:
  2003. return errClientDisconnected
  2004. case <-st.cw:
  2005. return errStreamClosed
  2006. }
  2007. }
  2008. return nil
  2009. }
  2010. // called from handler goroutines.
  2011. func (sc *serverConn) write100ContinueHeaders(st *stream) {
  2012. sc.writeFrameFromHandler(FrameWriteRequest{
  2013. write: write100ContinueHeadersFrame{st.id},
  2014. stream: st,
  2015. })
  2016. }
  2017. // A bodyReadMsg tells the server loop that the http.Handler read n
  2018. // bytes of the DATA from the client on the given stream.
  2019. type bodyReadMsg struct {
  2020. st *stream
  2021. n int
  2022. }
  2023. // called from handler goroutines.
  2024. // Notes that the handler for the given stream ID read n bytes of its body
  2025. // and schedules flow control tokens to be sent.
  2026. func (sc *serverConn) noteBodyReadFromHandler(st *stream, n int, err error) {
  2027. sc.serveG.checkNotOn() // NOT on
  2028. if n > 0 {
  2029. select {
  2030. case sc.bodyReadCh <- bodyReadMsg{st, n}:
  2031. case <-sc.doneServing:
  2032. }
  2033. }
  2034. }
  2035. func (sc *serverConn) noteBodyRead(st *stream, n int) {
  2036. sc.serveG.check()
  2037. sc.sendWindowUpdate(nil, n) // conn-level
  2038. if st.state != stateHalfClosedRemote && st.state != stateClosed {
  2039. // Don't send this WINDOW_UPDATE if the stream is closed
  2040. // remotely.
  2041. sc.sendWindowUpdate(st, n)
  2042. }
  2043. }
  2044. // st may be nil for conn-level
  2045. func (sc *serverConn) sendWindowUpdate(st *stream, n int) {
  2046. sc.serveG.check()
  2047. // "The legal range for the increment to the flow control
  2048. // window is 1 to 2^31-1 (2,147,483,647) octets."
  2049. // A Go Read call on 64-bit machines could in theory read
  2050. // a larger Read than this. Very unlikely, but we handle it here
  2051. // rather than elsewhere for now.
  2052. const maxUint31 = 1<<31 - 1
  2053. for n >= maxUint31 {
  2054. sc.sendWindowUpdate32(st, maxUint31)
  2055. n -= maxUint31
  2056. }
  2057. sc.sendWindowUpdate32(st, int32(n))
  2058. }
  2059. // st may be nil for conn-level
  2060. func (sc *serverConn) sendWindowUpdate32(st *stream, n int32) {
  2061. sc.serveG.check()
  2062. if n == 0 {
  2063. return
  2064. }
  2065. if n < 0 {
  2066. panic("negative update")
  2067. }
  2068. var streamID uint32
  2069. if st != nil {
  2070. streamID = st.id
  2071. }
  2072. sc.writeFrame(FrameWriteRequest{
  2073. write: writeWindowUpdate{streamID: streamID, n: uint32(n)},
  2074. stream: st,
  2075. })
  2076. var ok bool
  2077. if st == nil {
  2078. ok = sc.inflow.add(n)
  2079. } else {
  2080. ok = st.inflow.add(n)
  2081. }
  2082. if !ok {
  2083. panic("internal error; sent too many window updates without decrements?")
  2084. }
  2085. }
  2086. // requestBody is the Handler's Request.Body type.
  2087. // Read and Close may be called concurrently.
  2088. type requestBody struct {
  2089. _ incomparable
  2090. stream *stream
  2091. conn *serverConn
  2092. closed bool // for use by Close only
  2093. sawEOF bool // for use by Read only
  2094. pipe *pipe // non-nil if we have a HTTP entity message body
  2095. needsContinue bool // need to send a 100-continue
  2096. }
  2097. func (b *requestBody) Close() error {
  2098. if b.pipe != nil && !b.closed {
  2099. b.pipe.BreakWithError(errClosedBody)
  2100. }
  2101. b.closed = true
  2102. return nil
  2103. }
  2104. func (b *requestBody) Read(p []byte) (n int, err error) {
  2105. if b.needsContinue {
  2106. b.needsContinue = false
  2107. b.conn.write100ContinueHeaders(b.stream)
  2108. }
  2109. if b.pipe == nil || b.sawEOF {
  2110. return 0, io.EOF
  2111. }
  2112. n, err = b.pipe.Read(p)
  2113. if err == io.EOF {
  2114. b.sawEOF = true
  2115. }
  2116. if b.conn == nil && inTests {
  2117. return
  2118. }
  2119. b.conn.noteBodyReadFromHandler(b.stream, n, err)
  2120. return
  2121. }
  2122. // responseWriter is the http.ResponseWriter implementation. It's
  2123. // intentionally small (1 pointer wide) to minimize garbage. The
  2124. // responseWriterState pointer inside is zeroed at the end of a
  2125. // request (in handlerDone) and calls on the responseWriter thereafter
  2126. // simply crash (caller's mistake), but the much larger responseWriterState
  2127. // and buffers are reused between multiple requests.
  2128. type responseWriter struct {
  2129. rws *responseWriterState
  2130. }
  2131. // Optional http.ResponseWriter interfaces implemented.
  2132. var (
  2133. _ http.CloseNotifier = (*responseWriter)(nil)
  2134. _ http.Flusher = (*responseWriter)(nil)
  2135. _ stringWriter = (*responseWriter)(nil)
  2136. )
  2137. type responseWriterState struct {
  2138. // immutable within a request:
  2139. stream *stream
  2140. req *http.Request
  2141. body *requestBody // to close at end of request, if DATA frames didn't
  2142. conn *serverConn
  2143. // TODO: adjust buffer writing sizes based on server config, frame size updates from peer, etc
  2144. bw *bufio.Writer // writing to a chunkWriter{this *responseWriterState}
  2145. // mutated by http.Handler goroutine:
  2146. handlerHeader http.Header // nil until called
  2147. snapHeader http.Header // snapshot of handlerHeader at WriteHeader time
  2148. trailers []string // set in writeChunk
  2149. status int // status code passed to WriteHeader
  2150. wroteHeader bool // WriteHeader called (explicitly or implicitly). Not necessarily sent to user yet.
  2151. sentHeader bool // have we sent the header frame?
  2152. handlerDone bool // handler has finished
  2153. dirty bool // a Write failed; don't reuse this responseWriterState
  2154. sentContentLen int64 // non-zero if handler set a Content-Length header
  2155. wroteBytes int64
  2156. closeNotifierMu sync.Mutex // guards closeNotifierCh
  2157. closeNotifierCh chan bool // nil until first used
  2158. }
  2159. type chunkWriter struct{ rws *responseWriterState }
  2160. func (cw chunkWriter) Write(p []byte) (n int, err error) { return cw.rws.writeChunk(p) }
  2161. func (rws *responseWriterState) hasTrailers() bool { return len(rws.trailers) > 0 }
  2162. func (rws *responseWriterState) hasNonemptyTrailers() bool {
  2163. for _, trailer := range rws.trailers {
  2164. if _, ok := rws.handlerHeader[trailer]; ok {
  2165. return true
  2166. }
  2167. }
  2168. return false
  2169. }
  2170. // declareTrailer is called for each Trailer header when the
  2171. // response header is written. It notes that a header will need to be
  2172. // written in the trailers at the end of the response.
  2173. func (rws *responseWriterState) declareTrailer(k string) {
  2174. k = http.CanonicalHeaderKey(k)
  2175. if !httpguts.ValidTrailerHeader(k) {
  2176. // Forbidden by RFC 7230, section 4.1.2.
  2177. rws.conn.logf("ignoring invalid trailer %q", k)
  2178. return
  2179. }
  2180. if !strSliceContains(rws.trailers, k) {
  2181. rws.trailers = append(rws.trailers, k)
  2182. }
  2183. }
  2184. // writeChunk writes chunks from the bufio.Writer. But because
  2185. // bufio.Writer may bypass its chunking, sometimes p may be
  2186. // arbitrarily large.
  2187. //
  2188. // writeChunk is also responsible (on the first chunk) for sending the
  2189. // HEADER response.
  2190. func (rws *responseWriterState) writeChunk(p []byte) (n int, err error) {
  2191. if !rws.wroteHeader {
  2192. rws.writeHeader(200)
  2193. }
  2194. isHeadResp := rws.req.Method == "HEAD"
  2195. if !rws.sentHeader {
  2196. rws.sentHeader = true
  2197. var ctype, clen string
  2198. if clen = rws.snapHeader.Get("Content-Length"); clen != "" {
  2199. rws.snapHeader.Del("Content-Length")
  2200. if cl, err := strconv.ParseUint(clen, 10, 63); err == nil {
  2201. rws.sentContentLen = int64(cl)
  2202. } else {
  2203. clen = ""
  2204. }
  2205. }
  2206. if clen == "" && rws.handlerDone && bodyAllowedForStatus(rws.status) && (len(p) > 0 || !isHeadResp) {
  2207. clen = strconv.Itoa(len(p))
  2208. }
  2209. _, hasContentType := rws.snapHeader["Content-Type"]
  2210. // If the Content-Encoding is non-blank, we shouldn't
  2211. // sniff the body. See Issue golang.org/issue/31753.
  2212. ce := rws.snapHeader.Get("Content-Encoding")
  2213. hasCE := len(ce) > 0
  2214. if !hasCE && !hasContentType && bodyAllowedForStatus(rws.status) && len(p) > 0 {
  2215. ctype = http.DetectContentType(p)
  2216. }
  2217. var date string
  2218. if _, ok := rws.snapHeader["Date"]; !ok {
  2219. // TODO(bradfitz): be faster here, like net/http? measure.
  2220. date = time.Now().UTC().Format(http.TimeFormat)
  2221. }
  2222. for _, v := range rws.snapHeader["Trailer"] {
  2223. foreachHeaderElement(v, rws.declareTrailer)
  2224. }
  2225. // "Connection" headers aren't allowed in HTTP/2 (RFC 7540, 8.1.2.2),
  2226. // but respect "Connection" == "close" to mean sending a GOAWAY and tearing
  2227. // down the TCP connection when idle, like we do for HTTP/1.
  2228. // TODO: remove more Connection-specific header fields here, in addition
  2229. // to "Connection".
  2230. if _, ok := rws.snapHeader["Connection"]; ok {
  2231. v := rws.snapHeader.Get("Connection")
  2232. delete(rws.snapHeader, "Connection")
  2233. if v == "close" {
  2234. rws.conn.startGracefulShutdown()
  2235. }
  2236. }
  2237. endStream := (rws.handlerDone && !rws.hasTrailers() && len(p) == 0) || isHeadResp
  2238. err = rws.conn.writeHeaders(rws.stream, &writeResHeaders{
  2239. streamID: rws.stream.id,
  2240. httpResCode: rws.status,
  2241. h: rws.snapHeader,
  2242. endStream: endStream,
  2243. contentType: ctype,
  2244. contentLength: clen,
  2245. date: date,
  2246. })
  2247. if err != nil {
  2248. rws.dirty = true
  2249. return 0, err
  2250. }
  2251. if endStream {
  2252. return 0, nil
  2253. }
  2254. }
  2255. if isHeadResp {
  2256. return len(p), nil
  2257. }
  2258. if len(p) == 0 && !rws.handlerDone {
  2259. return 0, nil
  2260. }
  2261. if rws.handlerDone {
  2262. rws.promoteUndeclaredTrailers()
  2263. }
  2264. // only send trailers if they have actually been defined by the
  2265. // server handler.
  2266. hasNonemptyTrailers := rws.hasNonemptyTrailers()
  2267. endStream := rws.handlerDone && !hasNonemptyTrailers
  2268. if len(p) > 0 || endStream {
  2269. // only send a 0 byte DATA frame if we're ending the stream.
  2270. if err := rws.conn.writeDataFromHandler(rws.stream, p, endStream); err != nil {
  2271. rws.dirty = true
  2272. return 0, err
  2273. }
  2274. }
  2275. if rws.handlerDone && hasNonemptyTrailers {
  2276. err = rws.conn.writeHeaders(rws.stream, &writeResHeaders{
  2277. streamID: rws.stream.id,
  2278. h: rws.handlerHeader,
  2279. trailers: rws.trailers,
  2280. endStream: true,
  2281. })
  2282. if err != nil {
  2283. rws.dirty = true
  2284. }
  2285. return len(p), err
  2286. }
  2287. return len(p), nil
  2288. }
  2289. // TrailerPrefix is a magic prefix for ResponseWriter.Header map keys
  2290. // that, if present, signals that the map entry is actually for
  2291. // the response trailers, and not the response headers. The prefix
  2292. // is stripped after the ServeHTTP call finishes and the values are
  2293. // sent in the trailers.
  2294. //
  2295. // This mechanism is intended only for trailers that are not known
  2296. // prior to the headers being written. If the set of trailers is fixed
  2297. // or known before the header is written, the normal Go trailers mechanism
  2298. // is preferred:
  2299. // https://golang.org/pkg/net/http/#ResponseWriter
  2300. // https://golang.org/pkg/net/http/#example_ResponseWriter_trailers
  2301. const TrailerPrefix = "Trailer:"
  2302. // promoteUndeclaredTrailers permits http.Handlers to set trailers
  2303. // after the header has already been flushed. Because the Go
  2304. // ResponseWriter interface has no way to set Trailers (only the
  2305. // Header), and because we didn't want to expand the ResponseWriter
  2306. // interface, and because nobody used trailers, and because RFC 7230
  2307. // says you SHOULD (but not must) predeclare any trailers in the
  2308. // header, the official ResponseWriter rules said trailers in Go must
  2309. // be predeclared, and then we reuse the same ResponseWriter.Header()
  2310. // map to mean both Headers and Trailers. When it's time to write the
  2311. // Trailers, we pick out the fields of Headers that were declared as
  2312. // trailers. That worked for a while, until we found the first major
  2313. // user of Trailers in the wild: gRPC (using them only over http2),
  2314. // and gRPC libraries permit setting trailers mid-stream without
  2315. // predeclaring them. So: change of plans. We still permit the old
  2316. // way, but we also permit this hack: if a Header() key begins with
  2317. // "Trailer:", the suffix of that key is a Trailer. Because ':' is an
  2318. // invalid token byte anyway, there is no ambiguity. (And it's already
  2319. // filtered out) It's mildly hacky, but not terrible.
  2320. //
  2321. // This method runs after the Handler is done and promotes any Header
  2322. // fields to be trailers.
  2323. func (rws *responseWriterState) promoteUndeclaredTrailers() {
  2324. for k, vv := range rws.handlerHeader {
  2325. if !strings.HasPrefix(k, TrailerPrefix) {
  2326. continue
  2327. }
  2328. trailerKey := strings.TrimPrefix(k, TrailerPrefix)
  2329. rws.declareTrailer(trailerKey)
  2330. rws.handlerHeader[http.CanonicalHeaderKey(trailerKey)] = vv
  2331. }
  2332. if len(rws.trailers) > 1 {
  2333. sorter := sorterPool.Get().(*sorter)
  2334. sorter.SortStrings(rws.trailers)
  2335. sorterPool.Put(sorter)
  2336. }
  2337. }
  2338. func (w *responseWriter) Flush() {
  2339. rws := w.rws
  2340. if rws == nil {
  2341. panic("Header called after Handler finished")
  2342. }
  2343. if rws.bw.Buffered() > 0 {
  2344. if err := rws.bw.Flush(); err != nil {
  2345. // Ignore the error. The frame writer already knows.
  2346. return
  2347. }
  2348. } else {
  2349. // The bufio.Writer won't call chunkWriter.Write
  2350. // (writeChunk with zero bytes, so we have to do it
  2351. // ourselves to force the HTTP response header and/or
  2352. // final DATA frame (with END_STREAM) to be sent.
  2353. rws.writeChunk(nil)
  2354. }
  2355. }
  2356. func (w *responseWriter) CloseNotify() <-chan bool {
  2357. rws := w.rws
  2358. if rws == nil {
  2359. panic("CloseNotify called after Handler finished")
  2360. }
  2361. rws.closeNotifierMu.Lock()
  2362. ch := rws.closeNotifierCh
  2363. if ch == nil {
  2364. ch = make(chan bool, 1)
  2365. rws.closeNotifierCh = ch
  2366. cw := rws.stream.cw
  2367. go func() {
  2368. cw.Wait() // wait for close
  2369. ch <- true
  2370. }()
  2371. }
  2372. rws.closeNotifierMu.Unlock()
  2373. return ch
  2374. }
  2375. func (w *responseWriter) Header() http.Header {
  2376. rws := w.rws
  2377. if rws == nil {
  2378. panic("Header called after Handler finished")
  2379. }
  2380. if rws.handlerHeader == nil {
  2381. rws.handlerHeader = make(http.Header)
  2382. }
  2383. return rws.handlerHeader
  2384. }
  2385. // checkWriteHeaderCode is a copy of net/http's checkWriteHeaderCode.
  2386. func checkWriteHeaderCode(code int) {
  2387. // Issue 22880: require valid WriteHeader status codes.
  2388. // For now we only enforce that it's three digits.
  2389. // In the future we might block things over 599 (600 and above aren't defined
  2390. // at http://httpwg.org/specs/rfc7231.html#status.codes)
  2391. // and we might block under 200 (once we have more mature 1xx support).
  2392. // But for now any three digits.
  2393. //
  2394. // We used to send "HTTP/1.1 000 0" on the wire in responses but there's
  2395. // no equivalent bogus thing we can realistically send in HTTP/2,
  2396. // so we'll consistently panic instead and help people find their bugs
  2397. // early. (We can't return an error from WriteHeader even if we wanted to.)
  2398. if code < 100 || code > 999 {
  2399. panic(fmt.Sprintf("invalid WriteHeader code %v", code))
  2400. }
  2401. }
  2402. func (w *responseWriter) WriteHeader(code int) {
  2403. rws := w.rws
  2404. if rws == nil {
  2405. panic("WriteHeader called after Handler finished")
  2406. }
  2407. rws.writeHeader(code)
  2408. }
  2409. func (rws *responseWriterState) writeHeader(code int) {
  2410. if !rws.wroteHeader {
  2411. checkWriteHeaderCode(code)
  2412. rws.wroteHeader = true
  2413. rws.status = code
  2414. if len(rws.handlerHeader) > 0 {
  2415. rws.snapHeader = cloneHeader(rws.handlerHeader)
  2416. }
  2417. }
  2418. }
  2419. func cloneHeader(h http.Header) http.Header {
  2420. h2 := make(http.Header, len(h))
  2421. for k, vv := range h {
  2422. vv2 := make([]string, len(vv))
  2423. copy(vv2, vv)
  2424. h2[k] = vv2
  2425. }
  2426. return h2
  2427. }
  2428. // The Life Of A Write is like this:
  2429. //
  2430. // * Handler calls w.Write or w.WriteString ->
  2431. // * -> rws.bw (*bufio.Writer) ->
  2432. // * (Handler might call Flush)
  2433. // * -> chunkWriter{rws}
  2434. // * -> responseWriterState.writeChunk(p []byte)
  2435. // * -> responseWriterState.writeChunk (most of the magic; see comment there)
  2436. func (w *responseWriter) Write(p []byte) (n int, err error) {
  2437. return w.write(len(p), p, "")
  2438. }
  2439. func (w *responseWriter) WriteString(s string) (n int, err error) {
  2440. return w.write(len(s), nil, s)
  2441. }
  2442. // either dataB or dataS is non-zero.
  2443. func (w *responseWriter) write(lenData int, dataB []byte, dataS string) (n int, err error) {
  2444. rws := w.rws
  2445. if rws == nil {
  2446. panic("Write called after Handler finished")
  2447. }
  2448. if !rws.wroteHeader {
  2449. w.WriteHeader(200)
  2450. }
  2451. if !bodyAllowedForStatus(rws.status) {
  2452. return 0, http.ErrBodyNotAllowed
  2453. }
  2454. rws.wroteBytes += int64(len(dataB)) + int64(len(dataS)) // only one can be set
  2455. if rws.sentContentLen != 0 && rws.wroteBytes > rws.sentContentLen {
  2456. // TODO: send a RST_STREAM
  2457. return 0, errors.New("http2: handler wrote more than declared Content-Length")
  2458. }
  2459. if dataB != nil {
  2460. return rws.bw.Write(dataB)
  2461. } else {
  2462. return rws.bw.WriteString(dataS)
  2463. }
  2464. }
  2465. func (w *responseWriter) handlerDone() {
  2466. rws := w.rws
  2467. dirty := rws.dirty
  2468. rws.handlerDone = true
  2469. w.Flush()
  2470. w.rws = nil
  2471. if !dirty {
  2472. // Only recycle the pool if all prior Write calls to
  2473. // the serverConn goroutine completed successfully. If
  2474. // they returned earlier due to resets from the peer
  2475. // there might still be write goroutines outstanding
  2476. // from the serverConn referencing the rws memory. See
  2477. // issue 20704.
  2478. responseWriterStatePool.Put(rws)
  2479. }
  2480. }
  2481. // Push errors.
  2482. var (
  2483. ErrRecursivePush = errors.New("http2: recursive push not allowed")
  2484. ErrPushLimitReached = errors.New("http2: push would exceed peer's SETTINGS_MAX_CONCURRENT_STREAMS")
  2485. )
  2486. var _ http.Pusher = (*responseWriter)(nil)
  2487. func (w *responseWriter) Push(target string, opts *http.PushOptions) error {
  2488. st := w.rws.stream
  2489. sc := st.sc
  2490. sc.serveG.checkNotOn()
  2491. // No recursive pushes: "PUSH_PROMISE frames MUST only be sent on a peer-initiated stream."
  2492. // http://tools.ietf.org/html/rfc7540#section-6.6
  2493. if st.isPushed() {
  2494. return ErrRecursivePush
  2495. }
  2496. if opts == nil {
  2497. opts = new(http.PushOptions)
  2498. }
  2499. // Default options.
  2500. if opts.Method == "" {
  2501. opts.Method = "GET"
  2502. }
  2503. if opts.Header == nil {
  2504. opts.Header = http.Header{}
  2505. }
  2506. wantScheme := "http"
  2507. if w.rws.req.TLS != nil {
  2508. wantScheme = "https"
  2509. }
  2510. // Validate the request.
  2511. u, err := url.Parse(target)
  2512. if err != nil {
  2513. return err
  2514. }
  2515. if u.Scheme == "" {
  2516. if !strings.HasPrefix(target, "/") {
  2517. return fmt.Errorf("target must be an absolute URL or an absolute path: %q", target)
  2518. }
  2519. u.Scheme = wantScheme
  2520. u.Host = w.rws.req.Host
  2521. } else {
  2522. if u.Scheme != wantScheme {
  2523. return fmt.Errorf("cannot push URL with scheme %q from request with scheme %q", u.Scheme, wantScheme)
  2524. }
  2525. if u.Host == "" {
  2526. return errors.New("URL must have a host")
  2527. }
  2528. }
  2529. for k := range opts.Header {
  2530. if strings.HasPrefix(k, ":") {
  2531. return fmt.Errorf("promised request headers cannot include pseudo header %q", k)
  2532. }
  2533. // These headers are meaningful only if the request has a body,
  2534. // but PUSH_PROMISE requests cannot have a body.
  2535. // http://tools.ietf.org/html/rfc7540#section-8.2
  2536. // Also disallow Host, since the promised URL must be absolute.
  2537. switch strings.ToLower(k) {
  2538. case "content-length", "content-encoding", "trailer", "te", "expect", "host":
  2539. return fmt.Errorf("promised request headers cannot include %q", k)
  2540. }
  2541. }
  2542. if err := checkValidHTTP2RequestHeaders(opts.Header); err != nil {
  2543. return err
  2544. }
  2545. // The RFC effectively limits promised requests to GET and HEAD:
  2546. // "Promised requests MUST be cacheable [GET, HEAD, or POST], and MUST be safe [GET or HEAD]"
  2547. // http://tools.ietf.org/html/rfc7540#section-8.2
  2548. if opts.Method != "GET" && opts.Method != "HEAD" {
  2549. return fmt.Errorf("method %q must be GET or HEAD", opts.Method)
  2550. }
  2551. msg := &startPushRequest{
  2552. parent: st,
  2553. method: opts.Method,
  2554. url: u,
  2555. header: cloneHeader(opts.Header),
  2556. done: errChanPool.Get().(chan error),
  2557. }
  2558. select {
  2559. case <-sc.doneServing:
  2560. return errClientDisconnected
  2561. case <-st.cw:
  2562. return errStreamClosed
  2563. case sc.serveMsgCh <- msg:
  2564. }
  2565. select {
  2566. case <-sc.doneServing:
  2567. return errClientDisconnected
  2568. case <-st.cw:
  2569. return errStreamClosed
  2570. case err := <-msg.done:
  2571. errChanPool.Put(msg.done)
  2572. return err
  2573. }
  2574. }
  2575. type startPushRequest struct {
  2576. parent *stream
  2577. method string
  2578. url *url.URL
  2579. header http.Header
  2580. done chan error
  2581. }
  2582. func (sc *serverConn) startPush(msg *startPushRequest) {
  2583. sc.serveG.check()
  2584. // http://tools.ietf.org/html/rfc7540#section-6.6.
  2585. // PUSH_PROMISE frames MUST only be sent on a peer-initiated stream that
  2586. // is in either the "open" or "half-closed (remote)" state.
  2587. if msg.parent.state != stateOpen && msg.parent.state != stateHalfClosedRemote {
  2588. // responseWriter.Push checks that the stream is peer-initiated.
  2589. msg.done <- errStreamClosed
  2590. return
  2591. }
  2592. // http://tools.ietf.org/html/rfc7540#section-6.6.
  2593. if !sc.pushEnabled {
  2594. msg.done <- http.ErrNotSupported
  2595. return
  2596. }
  2597. // PUSH_PROMISE frames must be sent in increasing order by stream ID, so
  2598. // we allocate an ID for the promised stream lazily, when the PUSH_PROMISE
  2599. // is written. Once the ID is allocated, we start the request handler.
  2600. allocatePromisedID := func() (uint32, error) {
  2601. sc.serveG.check()
  2602. // Check this again, just in case. Technically, we might have received
  2603. // an updated SETTINGS by the time we got around to writing this frame.
  2604. if !sc.pushEnabled {
  2605. return 0, http.ErrNotSupported
  2606. }
  2607. // http://tools.ietf.org/html/rfc7540#section-6.5.2.
  2608. if sc.curPushedStreams+1 > sc.clientMaxStreams {
  2609. return 0, ErrPushLimitReached
  2610. }
  2611. // http://tools.ietf.org/html/rfc7540#section-5.1.1.
  2612. // Streams initiated by the server MUST use even-numbered identifiers.
  2613. // A server that is unable to establish a new stream identifier can send a GOAWAY
  2614. // frame so that the client is forced to open a new connection for new streams.
  2615. if sc.maxPushPromiseID+2 >= 1<<31 {
  2616. sc.startGracefulShutdownInternal()
  2617. return 0, ErrPushLimitReached
  2618. }
  2619. sc.maxPushPromiseID += 2
  2620. promisedID := sc.maxPushPromiseID
  2621. // http://tools.ietf.org/html/rfc7540#section-8.2.
  2622. // Strictly speaking, the new stream should start in "reserved (local)", then
  2623. // transition to "half closed (remote)" after sending the initial HEADERS, but
  2624. // we start in "half closed (remote)" for simplicity.
  2625. // See further comments at the definition of stateHalfClosedRemote.
  2626. promised := sc.newStream(promisedID, msg.parent.id, stateHalfClosedRemote)
  2627. rw, req, err := sc.newWriterAndRequestNoBody(promised, requestParam{
  2628. method: msg.method,
  2629. scheme: msg.url.Scheme,
  2630. authority: msg.url.Host,
  2631. path: msg.url.RequestURI(),
  2632. header: cloneHeader(msg.header), // clone since handler runs concurrently with writing the PUSH_PROMISE
  2633. })
  2634. if err != nil {
  2635. // Should not happen, since we've already validated msg.url.
  2636. panic(fmt.Sprintf("newWriterAndRequestNoBody(%+v): %v", msg.url, err))
  2637. }
  2638. go sc.runHandler(rw, req, sc.handler.ServeHTTP)
  2639. return promisedID, nil
  2640. }
  2641. sc.writeFrame(FrameWriteRequest{
  2642. write: &writePushPromise{
  2643. streamID: msg.parent.id,
  2644. method: msg.method,
  2645. url: msg.url,
  2646. h: msg.header,
  2647. allocatePromisedID: allocatePromisedID,
  2648. },
  2649. stream: msg.parent,
  2650. done: msg.done,
  2651. })
  2652. }
  2653. // foreachHeaderElement splits v according to the "#rule" construction
  2654. // in RFC 7230 section 7 and calls fn for each non-empty element.
  2655. func foreachHeaderElement(v string, fn func(string)) {
  2656. v = textproto.TrimString(v)
  2657. if v == "" {
  2658. return
  2659. }
  2660. if !strings.Contains(v, ",") {
  2661. fn(v)
  2662. return
  2663. }
  2664. for _, f := range strings.Split(v, ",") {
  2665. if f = textproto.TrimString(f); f != "" {
  2666. fn(f)
  2667. }
  2668. }
  2669. }
  2670. // From http://httpwg.org/specs/rfc7540.html#rfc.section.8.1.2.2
  2671. var connHeaders = []string{
  2672. "Connection",
  2673. "Keep-Alive",
  2674. "Proxy-Connection",
  2675. "Transfer-Encoding",
  2676. "Upgrade",
  2677. }
  2678. // checkValidHTTP2RequestHeaders checks whether h is a valid HTTP/2 request,
  2679. // per RFC 7540 Section 8.1.2.2.
  2680. // The returned error is reported to users.
  2681. func checkValidHTTP2RequestHeaders(h http.Header) error {
  2682. for _, k := range connHeaders {
  2683. if _, ok := h[k]; ok {
  2684. return fmt.Errorf("request header %q is not valid in HTTP/2", k)
  2685. }
  2686. }
  2687. te := h["Te"]
  2688. if len(te) > 0 && (len(te) > 1 || (te[0] != "trailers" && te[0] != "")) {
  2689. return errors.New(`request header "TE" may only be "trailers" in HTTP/2`)
  2690. }
  2691. return nil
  2692. }
  2693. func new400Handler(err error) http.HandlerFunc {
  2694. return func(w http.ResponseWriter, r *http.Request) {
  2695. http.Error(w, err.Error(), http.StatusBadRequest)
  2696. }
  2697. }
  2698. // h1ServerKeepAlivesDisabled reports whether hs has its keep-alives
  2699. // disabled. See comments on h1ServerShutdownChan above for why
  2700. // the code is written this way.
  2701. func h1ServerKeepAlivesDisabled(hs *http.Server) bool {
  2702. var x interface{} = hs
  2703. type I interface {
  2704. doKeepAlives() bool
  2705. }
  2706. if hs, ok := x.(I); ok {
  2707. return !hs.doKeepAlives()
  2708. }
  2709. return false
  2710. }