| addAckToLastByteEvent(HTTPTransaction *txn, const ByteEvent &lastByteEvent) | proxygen::HTTPSession | private |
| addCodecFilter(Args &&...args) | proxygen::HTTPSessionBase | inline |
| addLastByteEvent(HTTPTransaction *txn, uint64_t byteNo) noexcept | proxygen::HTTPSession | private |
| addWaitingForReplaySafety(ReplaySafetyCallback *callback) noexceptoverride | proxygen::HTTPSession | inlineprivate |
| proxygen::HTTPTransaction::Transport::addWaitingForReplaySafety(folly::AsyncTransport::ReplaySafetyCallback *callback) noexcept=0 | proxygen::HTTPTransaction::Transport | pure virtual |
| allTransactionsStarted() const =0 | proxygen::HTTPSession | protectedpure virtual |
| attachThreadLocals(folly::EventBase *eventBase, folly::SSLContextPtr sslContext, const WheelTimerInstance &timeout, HTTPSessionStats *stats, FilterIteratorFn fn, HeaderCodec::Stats *headerCodecStats, HTTPSessionController *controller)=0 | proxygen::HTTPSessionBase | pure virtual |
| attachToSessionController() | proxygen::HTTPSessionBase | protected |
| bodyBytesPerWriteBuf_ | proxygen::HTTPSession | private |
| byteEventTracker_ | proxygen::HTTPSession | private |
| bytesScheduled_ | proxygen::HTTPSession | private |
| bytesWritten_ | proxygen::HTTPSession | private |
| Callback()=default | folly::HHWheelTimer::Callback | |
| callbackCanceled() noexcept | folly::HHWheelTimer::Callback | inlinevirtual |
| cancelLoopCallback() | folly::EventBase::LoopCallback | inlineprivate |
| cancelLoopCallbacks() | proxygen::HTTPSession | inlineprotected |
| cancelTimeout() | folly::HHWheelTimer::Callback | inline |
| checkForShutdown() | proxygen::HTTPSession | protected |
| closeWhenIdle() override | proxygen::HTTPSession | virtual |
| codec_ | proxygen::HTTPSessionBase | protected |
| commonEom(HTTPTransaction *txn, size_t encodedSize, bool piggybacked) noexcept | proxygen::HTTPSession | private |
| connCloseByRemote() override | proxygen::HTTPSession | inlinevirtual |
| connFlowControl_ | proxygen::HTTPSession | private |
| createTransaction(HTTPCodec::StreamID streamID, const folly::Optional< HTTPCodec::StreamID > &assocStreamID, const folly::Optional< HTTPCodec::ExAttributes > &exAttributes, const http2::PriorityUpdate &priority=http2::DefaultPriority) | proxygen::HTTPSession | protected |
| decrementTransactionCount(HTTPTransaction *txn, bool ingressEOM, bool egressEOM) | proxygen::HTTPSession | protected |
| DelayedDestruction() | folly::DelayedDestruction | inlineprotected |
| DelayedDestructionBase() | folly::DelayedDestructionBase | inlineprotected |
| describe(std::ostream &os) const override | proxygen::HTTPSession | virtual |
| destroy() | folly::DelayedDestruction | inlinevirtual |
| detach(HTTPTransaction *txn) noexceptoverride | proxygen::HTTPSession | protectedvirtual |
| detachThreadLocals(bool detachSSLContext=false)=0 | proxygen::HTTPSessionBase | pure virtual |
| drain() override | proxygen::HTTPSession | protectedvirtual |
| drainImpl() | proxygen::HTTPSession | protected |
| draining_ | proxygen::HTTPSession | protected |
| drainTimeout_ | proxygen::HTTPSession | private |
| dropConnection() override | proxygen::HTTPSession | virtual |
| dumpConnectionState(uint8_t loglevel) override | proxygen::HTTPSession | virtual |
| egressBodySizeLimit_ | proxygen::HTTPSessionBase | protectedstatic |
| egressBytesLimit_ | proxygen::HTTPSession | private |
| egressLimitExceeded() const | proxygen::HTTPSessionBase | inlineprotected |
| enableDoubleGoawayDrain() override | proxygen::HTTPSession | inlinevirtual |
| enableExHeadersSettings() noexcept | proxygen::HTTPSessionBase | |
| errorOnAllTransactions(ProxygenError err, const std::string &errorMsg) | proxygen::HTTPSession | protected |
| errorOnTransactionId(HTTPCodec::StreamID id, HTTPException ex) | proxygen::HTTPSession | protected |
| errorOnTransactionIds(const std::vector< HTTPCodec::StreamID > &ids, ProxygenError err, const std::string &extraErrorMsg="") | proxygen::HTTPSession | protected |
| FilterIteratorFn typedef | proxygen::HTTPSessionBase | |
| findTransaction(HTTPCodec::StreamID streamID) | proxygen::HTTPSession | protected |
| fireCloseWhenIdle(bool force_to_close=false) | wangle::ManagedConnection | inline |
| fireNotifyPendingShutdown() | wangle::ManagedConnection | inline |
| flowControlTimeout_ | proxygen::HTTPSession | private |
| flowControlTimeoutExpired() noexcept | proxygen::HTTPSession | protected |
| getByteEventTracker() | proxygen::HTTPSession | inline |
| getCertAuthSettingVal() | proxygen::HTTPSession | private |
| getCodec() const noexceptoverride | proxygen::HTTPSession | inlineprotectedvirtual |
| getCodecProtocol() const | proxygen::HTTPSessionBase | inlinevirtual |
| getCodecSendWindowSize() const | proxygen::HTTPSession | protected |
| getConnectionCloseReason() const | proxygen::HTTPSessionBase | inline |
| getConnectionManager() | wangle::ManagedConnection | inline |
| getController() | proxygen::HTTPSessionBase | inline |
| getCurrentTransportInfo(wangle::TransportInfo *tinfo) override | proxygen::HTTPSession | virtual |
| getCurrentTransportInfoWithoutUpdate(wangle::TransportInfo *tinfo) const override | proxygen::HTTPSession | virtual |
| getCurTime() | folly::HHWheelTimer::Callback | inlineprotectedvirtual |
| getDestroyPending() const | folly::DelayedDestruction | inline |
| getDestructorGuardCount() const | folly::DelayedDestructionBase | inlineprotected |
| getEventBase() const override | proxygen::HTTPSession | inlinevirtual |
| getGracefulGoawayAck() const | proxygen::HTTPSession | private |
| getHistoricalMaxOutgoingStreams() const | proxygen::HTTPSessionBase | inline |
| getHTTP2PrioritiesEnabled() const override | proxygen::HTTPSession | inlinevirtual |
| getHTTPPriority(uint8_t) override | proxygen::HTTPSession | inlineprotectedvirtual |
| getInfoCallback() const | proxygen::HTTPSessionBase | inline |
| getLatestIdleTime() const | proxygen::HTTPSessionBase | inline |
| getLocalAddress() const noexceptoverride | proxygen::HTTPSession | inlinevirtual |
| getMaxConcurrentOutgoingStreams() const | proxygen::HTTPSessionBase | inline |
| getMaxConcurrentOutgoingStreamsRemote() const override | proxygen::HTTPSession | inlineprivatevirtual |
| getMessagePriority(const HTTPMessage *msg) | proxygen::HTTPSession | private |
| getNextToSend(bool *cork, bool *eom) | proxygen::HTTPSession | protected |
| getNumIncomingStreams() const override | proxygen::HTTPSession | inlinevirtual |
| getNumOutgoingStreams() const override | proxygen::HTTPSession | inlinevirtual |
| getNumTxnServed() const | proxygen::HTTPSessionBase | inline |
| getParseErrorHandler(HTTPTransaction *txn, const HTTPException &error) | proxygen::HTTPSessionBase | |
| getPeerAddress() const noexceptoverride | proxygen::HTTPSession | inlinevirtual |
| getPipelineStreamCount() const | proxygen::HTTPSession | inlineprivate |
| getReadBuffer(void **buf, size_t *bufSize) override | proxygen::HTTPSession | protectedvirtual |
| getSecondAuthManager() const | proxygen::HTTPSession | |
| getSecurityProtocol() const override | proxygen::HTTPSession | inlineprotectedvirtual |
| getSetupTransportInfo() const noexceptoverride | proxygen::HTTPSession | inlinevirtual |
| proxygen::HTTPSessionBase::getSetupTransportInfo() noexcept | proxygen::HTTPSessionBase | inline |
| getTimeRemaining() | folly::HHWheelTimer::Callback | inline |
| getTransactionTimeoutHandler(HTTPTransaction *txn)=0 | proxygen::HTTPSession | protectedpure virtual |
| getTransport() override | proxygen::HTTPSession | inlinevirtual |
| getTransport() const override | proxygen::HTTPSession | inlinevirtual |
| getType() const noexceptoverride | proxygen::HTTPSession | inlinevirtual |
| getUnderlyingTransport() const noexceptoverride | proxygen::HTTPSession | inlineprotectedvirtual |
| getWriteBufferLimit() const | proxygen::HTTPSessionBase | inline |
| handleErrorDirectly(HTTPTransaction *txn, const HTTPException &error) | proxygen::HTTPSessionBase | protected |
| handleLastByteEvents(ByteEventTracker *byteEventTracker, HTTPTransaction *txn, size_t encodedSize, size_t byteOffset, bool piggybacked) | proxygen::HTTPSessionBase | protectedstatic |
| hasActiveTransactions() const override | proxygen::HTTPSession | inlinevirtual |
| hasMoreWrites() const | proxygen::HTTPSession | protected |
| HTTPSession(const WheelTimerInstance &timeout, folly::AsyncTransportWrapper::UniquePtr sock, const folly::SocketAddress &localAddr, const folly::SocketAddress &peerAddr, HTTPSessionController *controller, std::unique_ptr< HTTPCodec > codec, const wangle::TransportInfo &tinfo, InfoCallback *infoCallback) | proxygen::HTTPSession | protected |
| HTTPSession(folly::HHWheelTimer *transactionTimeouts, folly::AsyncTransportWrapper::UniquePtr sock, const folly::SocketAddress &localAddr, const folly::SocketAddress &peerAddr, HTTPSessionController *controller, std::unique_ptr< HTTPCodec > codec, const wangle::TransportInfo &tinfo, InfoCallback *infoCallback) | proxygen::HTTPSession | protected |
| HTTPSessionBase(const folly::SocketAddress &localAddr, const folly::SocketAddress &peerAddr, HTTPSessionController *controller, const wangle::TransportInfo &tinfo, InfoCallback *infoCallback, std::unique_ptr< HTTPCodec > codec) | proxygen::HTTPSessionBase | |
| immediateShutdown() | proxygen::HTTPSession | protected |
| incomingStreams_ | proxygen::HTTPSession | private |
| incrementOutgoingStreams() | proxygen::HTTPSession | private |
| incrementSeqNo() | proxygen::HTTPSessionBase | inlineprotected |
| infoCallback_ | proxygen::HTTPSessionBase | protected |
| ingressError_ | proxygen::HTTPSession | protected |
| ingressLimitExceeded() const | proxygen::HTTPSessionBase | inlineprotected |
| ingressUpgraded_ | proxygen::HTTPSession | private |
| initCodecHeaderIndexingStrategy() | proxygen::HTTPSessionBase | protected |
| initialReceiveWindow_ | proxygen::HTTPSession | private |
| inLoopCallback_ | proxygen::HTTPSession | private |
| inResume_ | proxygen::HTTPSession | private |
| invalidStream(HTTPCodec::StreamID stream, ErrorCode code=ErrorCode::_SPDY_INVALID_STREAM) | proxygen::HTTPSession | private |
| invokeOnAllTransactions(void(HTTPTransaction::*fn)(Args1...), Args2 &&...args) | proxygen::HTTPSession | inlineprotected |
| isBufferMovable() noexceptoverride | proxygen::HTTPSession | protectedvirtual |
| isBusy() const override | proxygen::HTTPSession | virtual |
| isClosing() const =0 | proxygen::HTTPSessionBase | pure virtual |
| isConnWindowFull() const | proxygen::HTTPSession | inlineprivate |
| isDetachable(bool checkSocket) const =0 | proxygen::HTTPSessionBase | pure virtual |
| isDownstream() const | proxygen::HTTPSession | private |
| isDraining() const override | proxygen::HTTPSession | inlineprotectedvirtual |
| isExHeadersEnabled() noexcept | proxygen::HTTPSessionBase | inline |
| isLoopCallbackScheduled() const | folly::EventBase::LoopCallback | inlineprivate |
| isPrioritySampled() const | proxygen::HTTPSessionBase | inlineprotected |
| proxygen::isReplaySafe() const =0 | proxygen::HTTPSessionBase | pure virtual |
| proxygen::HTTPTransaction::Transport::isReplaySafe() const =0 | proxygen::HTTPTransaction::Transport | pure virtual |
| isReusable() const =0 | proxygen::HTTPSessionBase | pure virtual |
| isScheduled() const | folly::HHWheelTimer::Callback | inline |
| isUpstream() const | proxygen::HTTPSession | private |
| kDefaultReadBufLimit | proxygen::HTTPSessionBase | protectedstatic |
| kDefaultWriteBufLimit | proxygen::HTTPSessionBase | protectedstatic |
| liveTransactions_ | proxygen::HTTPSession | protected |
| localAddr_ | proxygen::HTTPSessionBase | protected |
| ManagedConnection() | wangle::ManagedConnection | |
| maxBufferSize() const | folly::AsyncReader::ReadCallback | inlineprivatevirtual |
| maxConcurrentIncomingStreams_ | proxygen::HTTPSession | private |
| maxConcurrentOutgoingStreamsRemote_ | proxygen::HTTPSession | private |
| maxReadBufferSize_ | proxygen::HTTPSessionBase | protectedstatic |
| maybeResumePausedPipelinedTransaction(size_t oldStreamCount, uint32_t txnSeqn) | proxygen::HTTPSession | private |
| needToBlockForReplaySafety() const override | proxygen::HTTPSession | inlineprivatevirtual |
| newExTransaction(HTTPTransaction::Handler *handler, HTTPCodec::StreamID controlStream, bool unidirectional=false) noexceptoverride | proxygen::HTTPSession | protectedvirtual |
| newPushedTransaction(HTTPCodec::StreamID assocStreamId, HTTPTransaction::PushHandler *handler) noexceptoverride | proxygen::HTTPSession | protectedvirtual |
| newTransaction(HTTPTransaction::Handler *handler)=0 | proxygen::HTTPSessionBase | pure virtual |
| nextEgressResults_ | proxygen::HTTPSession | private |
| notifyBodyProcessed(uint32_t bytes) | proxygen::HTTPSessionBase | protected |
| notifyEgressBodyBuffered(int64_t bytes) noexceptoverride | proxygen::HTTPSession | protectedvirtual |
| notifyIngressBodyProcessed(uint32_t bytes) noexceptoverride | proxygen::HTTPSession | protectedvirtual |
| notifyPendingEgress() noexceptoverride | proxygen::HTTPSession | protectedvirtual |
| notifyPendingShutdown() override | proxygen::HTTPSession | virtual |
| numActiveWrites_ | proxygen::HTTPSession | protected |
| numIncomingStreams() const override | proxygen::HTTPSession | inlineprotectedvirtual |
| numOutgoingStreams() const override | proxygen::HTTPSession | inlineprotectedvirtual |
| onAbort(HTTPCodec::StreamID streamID, ErrorCode code) override | proxygen::HTTPSession | protectedvirtual |
| onBody(HTTPCodec::StreamID streamID, std::unique_ptr< folly::IOBuf > chain, uint16_t padding) override | proxygen::HTTPSession | protectedvirtual |
| onBodyImpl(std::unique_ptr< folly::IOBuf > chain, size_t length, uint16_t padding, HTTPTransaction *txn) | proxygen::HTTPSessionBase | protected |
| onCertificate(uint16_t certId, std::unique_ptr< folly::IOBuf > authenticator) override | proxygen::HTTPSession | protectedvirtual |
| onCertificateRequest(uint16_t requestId, std::unique_ptr< folly::IOBuf > authRequest) override | proxygen::HTTPSession | protectedvirtual |
| onChunkComplete(HTTPCodec::StreamID stream) override | proxygen::HTTPSession | protectedvirtual |
| onChunkHeader(HTTPCodec::StreamID stream, size_t length) override | proxygen::HTTPSession | protectedvirtual |
| onCodecChanged() | proxygen::HTTPSessionBase | protected |
| onConnectionSendWindowClosed() override | proxygen::HTTPSession | privatevirtual |
| onConnectionSendWindowOpen() override | proxygen::HTTPSession | privatevirtual |
| onCreateTransaction() | proxygen::HTTPSessionBase | inlineprotected |
| onDeleteAckEvent() noexceptoverride | proxygen::HTTPSession | privatevirtual |
| onEgressBufferCleared() override | proxygen::HTTPSession | privatevirtual |
| onEgressBuffered() override | proxygen::HTTPSession | privatevirtual |
| onEgressMessageFinished(HTTPTransaction *txn, bool withRST=false) | proxygen::HTTPSession | protected |
| onError(HTTPCodec::StreamID streamID, const HTTPException &error, bool newTxn) override | proxygen::HTTPSession | protectedvirtual |
| onExMessageBegin(HTTPCodec::StreamID streamID, HTTPCodec::StreamID controlStream, bool unidirectional, HTTPMessage *msg) override | proxygen::HTTPSession | protectedvirtual |
| onFrameHeader(StreamID, uint8_t, uint64_t, uint8_t, uint16_t=0) | proxygen::HTTPCodec::Callback | inlineprivatevirtual |
| onGenerateFrameHeader(StreamID, uint8_t, uint64_t, uint16_t=0) | proxygen::HTTPCodec::Callback | inlineprivatevirtual |
| onGoaway(uint64_t lastGoodStreamID, ErrorCode code, std::unique_ptr< folly::IOBuf > debugData=nullptr) override | proxygen::HTTPSession | protectedvirtual |
| onHeadersComplete(HTTPCodec::StreamID streamID, std::unique_ptr< HTTPMessage > msg) override | proxygen::HTTPSession | protectedvirtual |
| onHeadersSent(const HTTPMessage &, bool) | proxygen::HTTPSession | inlineprotectedvirtual |
| onLastByteEvent(HTTPTransaction *txn, uint64_t offset, bool eomTracked) noexceptoverride | proxygen::HTTPSession | privatevirtual |
| onMessageBegin(HTTPCodec::StreamID streamID, HTTPMessage *msg) override | proxygen::HTTPSession | protectedvirtual |
| onMessageComplete(HTTPCodec::StreamID streamID, bool upgrade) override | proxygen::HTTPSession | protectedvirtual |
| onNativeProtocolUpgrade(StreamID, CodecProtocol, const std::string &, HTTPMessage &) | proxygen::HTTPCodec::Callback | inlineprivatevirtual |
| onNativeProtocolUpgradeImpl(HTTPCodec::StreamID txn, std::unique_ptr< HTTPCodec > codec, const std::string &protocolString) | proxygen::HTTPSession | protected |
| onNewOutgoingStream(uint32_t outgoingStreams) | proxygen::HTTPSessionBase | inlineprotected |
| onNewTransactionParseError(HTTPCodec::StreamID streamID, const HTTPException &error) | proxygen::HTTPSession | protected |
| onPingReply(uint64_t uniqueID) override | proxygen::HTTPSession | protectedvirtual |
| onPingReplyLatency(int64_t latency) noexceptoverride | proxygen::HTTPSession | privatevirtual |
| onPingRequest(uint64_t uniqueID) override | proxygen::HTTPSession | protectedvirtual |
| onPriority(HTTPCodec::StreamID stream, const HTTPMessage::HTTPPriority &) override | proxygen::HTTPSession | protectedvirtual |
| onPushMessageBegin(HTTPCodec::StreamID streamID, HTTPCodec::StreamID assocStreamID, HTTPMessage *msg) override | proxygen::HTTPSession | protectedvirtual |
| onReplaySafe() noexceptoverride | proxygen::HTTPSession | privatevirtual |
| onSessionParseError(const HTTPException &error) | proxygen::HTTPSession | protected |
| onSetMaxInitiatedStreams(uint32_t maxTxns) | proxygen::HTTPSession | private |
| onSetSendWindow(uint32_t windowSize) | proxygen::HTTPSession | private |
| onSettings(const SettingsList &settings) override | proxygen::HTTPSession | protectedvirtual |
| onSettingsAck() override | proxygen::HTTPSession | protectedvirtual |
| onTrailersComplete(HTTPCodec::StreamID streamID, std::unique_ptr< HTTPHeaders > trailers) override | proxygen::HTTPSession | protectedvirtual |
| onWindowUpdate(HTTPCodec::StreamID stream, uint32_t amount) override | proxygen::HTTPSession | protectedvirtual |
| onWriteCompleted() | proxygen::HTTPSession | protected |
| onWriteError(size_t bytesWritten, const folly::AsyncSocketException &ex) | proxygen::HTTPSession | protected |
| onWriteSuccess(uint64_t bytesWritten) | proxygen::HTTPSession | protected |
| outgoingStreams_ | proxygen::HTTPSession | private |
| PAUSED enum value | proxygen::HTTPSession | private |
| pauseIngress(HTTPTransaction *txn) noexceptoverride | proxygen::HTTPSession | protectedvirtual |
| pauseReads() | proxygen::HTTPSession | protected |
| pauseReadsImpl() | proxygen::HTTPSession | protected |
| peerAddr_ | proxygen::HTTPSessionBase | protected |
| pendingPause_ | proxygen::HTTPSession | private |
| pendingWrites_ | proxygen::HTTPSession | private |
| pendingWriteSizeDelta_ | proxygen::HTTPSession | private |
| processReadData() | proxygen::HTTPSession | protected |
| readBuf_ | proxygen::HTTPSession | protected |
| readBufferAvailable(std::unique_ptr< folly::IOBuf >) noexceptoverride | proxygen::HTTPSession | protectedvirtual |
| readDataAvailable(size_t readSize) noexceptoverride | proxygen::HTTPSession | protectedvirtual |
| readEOF() noexceptoverride | proxygen::HTTPSession | protectedvirtual |
| readErr(const folly::AsyncSocketException &) noexceptoverride | proxygen::HTTPSession | protectedvirtual |
| reads_ | proxygen::HTTPSession | private |
| readsPaused() const | proxygen::HTTPSession | inlineprotected |
| readsShutdown() const | proxygen::HTTPSession | inlineprotected |
| readsUnpaused() const | proxygen::HTTPSession | inlineprotected |
| readTimeoutExpired() noexcept | proxygen::HTTPSession | protected |
| receiveSessionWindowSize_ | proxygen::HTTPSession | private |
| receiveStreamWindowSize_ | proxygen::HTTPSession | private |
| removeWaitingForReplaySafety(ReplaySafetyCallback *callback) noexceptoverride | proxygen::HTTPSession | inlineprivate |
| proxygen::HTTPTransaction::Transport::removeWaitingForReplaySafety(folly::AsyncTransport::ReplaySafetyCallback *callback) noexcept=0 | proxygen::HTTPTransaction::Transport | pure virtual |
| rescheduleLoopCallbacks() | proxygen::HTTPSession | inlineprotected |
| resetAfterDrainingWrites_ | proxygen::HTTPSession | protected |
| resetSocketOnShutdown_ | proxygen::HTTPSession | private |
| resetTimeout() | wangle::ManagedConnection | virtual |
| resetTimeoutTo(std::chrono::milliseconds) | wangle::ManagedConnection | |
| resumeIngress(HTTPTransaction *txn) noexceptoverride | proxygen::HTTPSession | protectedvirtual |
| resumeReads() | proxygen::HTTPSession | protected |
| resumeReadsImpl() | proxygen::HTTPSession | protected |
| resumeTransactions() | proxygen::HTTPSession | protected |
| runDestroyCallbacks() | proxygen::HTTPSessionBase | protected |
| runLoopCallback() noexceptoverride | proxygen::HTTPSession | protectedvirtual |
| scheduleTimeout(folly::HHWheelTimer::Callback *callback, std::chrono::milliseconds timeout) | wangle::ManagedConnection | virtual |
| scheduleWrite() | proxygen::HTTPSession | protected |
| secondAuthManager_ | proxygen::HTTPSession | private |
| sendAbort(HTTPTransaction *txn, ErrorCode statusCode) noexceptoverride | proxygen::HTTPSession | protectedvirtual |
| sendBody(HTTPTransaction *txn, std::unique_ptr< folly::IOBuf >, bool includeEOM, bool trackLastByteFlushed) noexceptoverride | proxygen::HTTPSession | protectedvirtual |
| sendCertificateRequest(std::unique_ptr< folly::IOBuf > certificateRequestContext, std::vector< fizz::Extension > extensions) override | proxygen::HTTPSession | virtual |
| sendChunkHeader(HTTPTransaction *txn, size_t length) noexceptoverride | proxygen::HTTPSession | protectedvirtual |
| sendChunkTerminator(HTTPTransaction *txn) noexceptoverride | proxygen::HTTPSession | protectedvirtual |
| sendEOM(HTTPTransaction *txn, const HTTPHeaders *trailers) noexceptoverride | proxygen::HTTPSession | protectedvirtual |
| sendHeaders(HTTPTransaction *txn, const HTTPMessage &headers, HTTPHeaderSize *size, bool includeEOM) noexceptoverride | proxygen::HTTPSession | protectedvirtual |
| sendPing() override | proxygen::HTTPSession | virtual |
| sendPriority(http2::PriorityUpdate pri) override | proxygen::HTTPSession | virtual |
| sendPriority(HTTPCodec::StreamID id, http2::PriorityUpdate pri) override | proxygen::HTTPSession | virtual |
| sendPriority(HTTPTransaction *txn, const http2::PriorityUpdate &pri) noexceptoverride | proxygen::HTTPSession | protectedvirtual |
| sendPriorityImpl(HTTPCodec::StreamID streamID, http2::PriorityUpdate pri) | proxygen::HTTPSession | protected |
| sendSettings() override | proxygen::HTTPSession | virtual |
| sendWindowUpdate(HTTPTransaction *txn, uint32_t bytes) noexceptoverride | proxygen::HTTPSession | protectedvirtual |
| sessionByteOffset() | proxygen::HTTPSession | inlineprotected |
| sessionStats_ | proxygen::HTTPSessionBase | protected |
| SessionType enum name | proxygen::HTTPSessionBase | |
| setByteEventTracker(std::shared_ptr< ByteEventTracker > byteEventTracker) | proxygen::HTTPSession | |
| setCloseReason(ConnectionCloseReason reason) | proxygen::HTTPSessionBase | inlineprotected |
| setController(HTTPSessionController *controller) | proxygen::HTTPSessionBase | inline |
| setDefaultReadBufferLimit(uint32_t limit) | proxygen::HTTPSessionBase | inlinestatic |
| setDefaultWriteBufferLimit(uint32_t max) | proxygen::HTTPSessionBase | inlinestatic |
| setEgressBytesLimit(uint64_t bytesLimit) | proxygen::HTTPSession | |
| setEgressSettings(const SettingsList &inSettings) override | proxygen::HTTPSession | virtual |
| setFlowControl(size_t initialReceiveWindow, size_t receiveStreamWindowSize, size_t receiveSessionWindowSize) override | proxygen::HTTPSession | virtual |
| setFlowControlledBodySizeLimit(uint32_t limit) | proxygen::HTTPSessionBase | inlinestatic |
| setHeaderCodecStats(HeaderCodec::Stats *stats) override | proxygen::HTTPSession | inlinevirtual |
| setHTTP2PrioritiesEnabled(bool enabled) override | proxygen::HTTPSession | inlinevirtual |
| setInfoCallback(InfoCallback *callback) | proxygen::HTTPSessionBase | inline |
| setLatestActive() | proxygen::HTTPSessionBase | inlineprotected |
| setMaxConcurrentIncomingStreams(uint32_t num) override | proxygen::HTTPSession | virtual |
| setMaxConcurrentOutgoingStreams(uint32_t num) | proxygen::HTTPSessionBase | inline |
| setMaxReadBufferSize(uint32_t bytes) | proxygen::HTTPSessionBase | inlinestatic |
| setNewTransactionPauseState(HTTPCodec::StreamID streamID) | proxygen::HTTPSession | protected |
| setPrioritySampled(bool sampled) | proxygen::HTTPSessionBase | inline |
| setReadBufferLimit(uint32_t limit) | proxygen::HTTPSessionBase | inline |
| setSecondAuthManager(std::unique_ptr< SecondaryAuthManager > secondAuthManager) | proxygen::HTTPSession | |
| setSessionStats(HTTPSessionStats *stats) override | proxygen::HTTPSession | virtual |
| setupCodec() | proxygen::HTTPSession | private |
| setupOnHeadersComplete(HTTPTransaction *txn, HTTPMessage *msg)=0 | proxygen::HTTPSession | protectedpure virtual |
| setWriteBufferLimit(uint32_t limit) | proxygen::HTTPSessionBase | inline |
| shouldShutdown() const | proxygen::HTTPSession | protected |
| SHUTDOWN enum value | proxygen::HTTPSession | private |
| shutdownTransport(bool shutdownReads=true, bool shutdownWrites=true, const std::string &errorMsg="") | proxygen::HTTPSession | protected |
| shutdownTransportCb_ | proxygen::HTTPSession | private |
| shutdownTransportWithReset(ProxygenError errorCode, const std::string &errorMsg="") | proxygen::HTTPSession | protected |
| sock_ | proxygen::HTTPSession | protected |
| SocketState enum name | proxygen::HTTPSession | private |
| started_ | proxygen::HTTPSession | protected |
| startNow() override | proxygen::HTTPSession | virtual |
| supportsMoreTransactions() const | proxygen::HTTPSessionBase | inline |
| timeout_ | proxygen::HTTPSession | protected |
| timeoutExpired() noexceptoverride | proxygen::HTTPSession | inlinevirtual |
| transactions_ | proxygen::HTTPSession | protected |
| transactionTimeout(HTTPTransaction *txn) noexceptoverride | proxygen::HTTPSession | protectedvirtual |
| transportInfo_ | proxygen::HTTPSessionBase | protected |
| txnEgressQueue_ | proxygen::HTTPSession | protected |
| UniquePtr typedef | proxygen::HTTPSession | |
| UNPAUSED enum value | proxygen::HTTPSession | private |
| updatePendingWriteSize(int64_t delta) | proxygen::HTTPSessionBase | inlineprotected |
| updateWriteBufSize(int64_t delta) | proxygen::HTTPSession | protected |
| updateWriteCount() | proxygen::HTTPSession | protected |
| verifyCertAuthSetting(uint32_t value) | proxygen::HTTPSession | private |
| waitingForReplaySafety_ | proxygen::HTTPSession | private |
| writeBuf_ | proxygen::HTTPSession | protected |
| writes_ | proxygen::HTTPSession | private |
| writesDraining_ | proxygen::HTTPSession | protected |
| WriteSegmentList typedef | proxygen::HTTPSession | private |
| writesPaused() const | proxygen::HTTPSession | inlineprotected |
| writesShutdown() const | proxygen::HTTPSession | inlineprotected |
| writesUnpaused() const | proxygen::HTTPSession | inlineprotected |
| writeTimeout_ | proxygen::HTTPSession | protected |
| writeTimeoutExpired() noexcept | proxygen::HTTPSession | protected |
| ~BufferCallback() | folly::AsyncTransport::BufferCallback | inlineprotectedvirtual |
| proxygen::~Callback() | folly::HHWheelTimer::Callback | virtual |
| proxygen::ByteEventTracker::Callback::~Callback() | proxygen::ByteEventTracker::Callback | inlinevirtual |
| proxygen::FlowControlFilter::Callback::~Callback() | proxygen::FlowControlFilter::Callback | inlineprivatevirtual |
| proxygen::HTTPCodec::Callback::~Callback() | proxygen::HTTPCodec::Callback | inlineprivatevirtual |
| ~DelayedDestruction() override=default | folly::DelayedDestruction | protected |
| ~DelayedDestructionBase()=default | folly::DelayedDestructionBase | virtual |
| ~HTTPPriorityMapFactoryProvider()=default | proxygen::HTTPPriorityMapFactoryProvider | protectedvirtual |
| ~HTTPSession() override | proxygen::HTTPSession | protected |
| ~HTTPSessionBase() | proxygen::HTTPSessionBase | inlinevirtual |
| ~LoopCallback()=default | folly::EventBase::LoopCallback | privatevirtual |
| ~ManagedConnection() override | wangle::ManagedConnection | protected |
| ~ReadCallback()=default | folly::AsyncReader::ReadCallback | privatevirtual |
| ~ReplaySafetyCallback()=default | folly::AsyncTransport::ReplaySafetyCallback | privatevirtual |
| ~Transport() | proxygen::HTTPTransaction::Transport | inlinevirtual |