Source code
Revision control
Copy as Markdown
Other Tools
/* -*- Mode: C++; tab-width: 4; indent-tabs-mode: nil; c-basic-offset: 2 -*- */
/* vim:set et cin ts=4 sw=2 sts=2: */
/* This Source Code Form is subject to the terms of the Mozilla Public
* License, v. 2.0. If a copy of the MPL was not distributed with this
#ifndef nsHttpChannel_h__
#define nsHttpChannel_h__
#include "AlternateServices.h"
#include "AutoClose.h"
#include "HttpBaseChannel.h"
#include "nsIReplacedHttpResponse.h"
#include "TimingStruct.h"
#include "mozilla/AtomicBitfields.h"
#include "mozilla/Atomics.h"
#include "mozilla/Mutex.h"
#include "mozilla/extensions/PStreamFilterParent.h"
#include "mozilla/net/DocumentLoadListener.h"
#include "nsIAsyncVerifyRedirectCallback.h"
#include "nsICacheEntry.h"
#include "nsICacheEntryOpenCallback.h"
#include "nsICachingChannel.h"
#include "nsICorsPreflightCallback.h"
#include "nsIDNSListener.h"
#include "nsIEarlyHintObserver.h"
#include "nsIHttpAuthenticableChannel.h"
#include "nsIProtocolProxyCallback.h"
#include "nsIRaceCacheWithNetwork.h"
#include "nsIStreamListener.h"
#include "nsIThreadRetargetableRequest.h"
#include "nsIThreadRetargetableStreamListener.h"
#include "nsITransportSecurityInfo.h"
#include "nsTArray.h"
#include "nsWeakReference.h"
class nsDNSPrefetch;
class nsICancelable;
class nsIDNSRecord;
class nsIDNSHTTPSSVCRecord;
class nsIHttpChannelAuthProvider;
class nsInputStreamPump;
class nsITransportSecurityInfo;
namespace mozilla {
namespace net {
class nsChannelClassifier;
class HttpChannelSecurityWarningReporter;
using DNSPromise = MozPromise<nsCOMPtr<nsIDNSRecord>, nsresult, false>;
//-----------------------------------------------------------------------------
// nsHttpChannel
//-----------------------------------------------------------------------------
// Use to support QI nsIChannel to nsHttpChannel
#define NS_HTTPCHANNEL_IID \
{ \
0x301bf95b, 0x7bb3, 0x4ae1, { \
0xa9, 0x71, 0x40, 0xbc, 0xfa, 0x81, 0xde, 0x12 \
} \
}
class nsHttpChannel final : public HttpBaseChannel,
public HttpAsyncAborter<nsHttpChannel>,
public nsICachingChannel,
public nsICacheEntryOpenCallback,
public nsITransportEventSink,
public nsIProtocolProxyCallback,
public nsIHttpAuthenticableChannel,
public nsIAsyncVerifyRedirectCallback,
public nsIThreadRetargetableRequest,
public nsIThreadRetargetableStreamListener,
public nsIDNSListener,
public nsSupportsWeakReference,
public nsICorsPreflightCallback,
public nsIRaceCacheWithNetwork,
public nsIRequestTailUnblockCallback,
public nsIEarlyHintObserver {
public:
NS_DECL_ISUPPORTS_INHERITED
NS_DECL_NSIREQUESTOBSERVER
NS_DECL_NSISTREAMLISTENER
NS_DECL_NSITHREADRETARGETABLESTREAMLISTENER
NS_DECL_NSICACHEINFOCHANNEL
NS_DECL_NSICACHINGCHANNEL
NS_DECL_NSICACHEENTRYOPENCALLBACK
NS_DECL_NSITRANSPORTEVENTSINK
NS_DECL_NSIPROTOCOLPROXYCALLBACK
NS_DECL_NSIPROXIEDCHANNEL
NS_DECL_NSIASYNCVERIFYREDIRECTCALLBACK
NS_DECL_NSITHREADRETARGETABLEREQUEST
NS_DECL_NSIDNSLISTENER
NS_DECLARE_STATIC_IID_ACCESSOR(NS_HTTPCHANNEL_IID)
NS_DECL_NSIRACECACHEWITHNETWORK
NS_DECL_NSIREQUESTTAILUNBLOCKCALLBACK
NS_DECL_NSIEARLYHINTOBSERVER
// nsIHttpAuthenticableChannel. We can't use
// NS_DECL_NSIHTTPAUTHENTICABLECHANNEL because it duplicates cancel() and
// others.
NS_IMETHOD GetIsSSL(bool* aIsSSL) override;
NS_IMETHOD GetProxyMethodIsConnect(bool* aProxyMethodIsConnect) override;
NS_IMETHOD GetServerResponseHeader(
nsACString& aServerResponseHeader) override;
NS_IMETHOD GetProxyChallenges(nsACString& aChallenges) override;
NS_IMETHOD GetWWWChallenges(nsACString& aChallenges) override;
NS_IMETHOD SetProxyCredentials(const nsACString& aCredentials) override;
NS_IMETHOD SetWWWCredentials(const nsACString& aCredentials) override;
NS_IMETHOD OnAuthAvailable() override;
NS_IMETHOD OnAuthCancelled(bool userCancel) override;
NS_IMETHOD CloseStickyConnection() override;
NS_IMETHOD ConnectionRestartable(bool) override;
// Functions we implement from nsIHttpAuthenticableChannel but are
// declared in HttpBaseChannel must be implemented in this class. We
// just call the HttpBaseChannel:: impls.
NS_IMETHOD GetLoadFlags(nsLoadFlags* aLoadFlags) override;
NS_IMETHOD GetURI(nsIURI** aURI) override;
NS_IMETHOD GetNotificationCallbacks(
nsIInterfaceRequestor** aCallbacks) override;
NS_IMETHOD GetLoadGroup(nsILoadGroup** aLoadGroup) override;
NS_IMETHOD GetRequestMethod(nsACString& aMethod) override;
nsHttpChannel();
[[nodiscard]] virtual nsresult Init(nsIURI* aURI, uint32_t aCaps,
nsProxyInfo* aProxyInfo,
uint32_t aProxyResolveFlags,
nsIURI* aProxyURI, uint64_t aChannelId,
ExtContentPolicyType aContentPolicyType,
nsILoadInfo* aLoadInfo) override;
[[nodiscard]] nsresult OnPush(uint32_t aPushedStreamId,
const nsACString& aUrl,
const nsACString& aRequestString,
HttpTransactionShell* aTransaction);
static bool IsRedirectStatus(uint32_t status);
static bool WillRedirect(const nsHttpResponseHead& response);
// Methods HttpBaseChannel didn't implement for us or that we override.
//
// nsIRequest
NS_IMETHOD SetCanceledReason(const nsACString& aReason) override;
NS_IMETHOD GetCanceledReason(nsACString& aReason) override;
NS_IMETHOD CancelWithReason(nsresult status,
const nsACString& reason) override;
NS_IMETHOD Cancel(nsresult status) override;
NS_IMETHOD Suspend() override;
NS_IMETHOD Resume() override;
// nsIChannel
NS_IMETHOD GetSecurityInfo(nsITransportSecurityInfo** aSecurityInfo) override;
NS_IMETHOD AsyncOpen(nsIStreamListener* aListener) override;
// nsIHttpChannel
NS_IMETHOD GetEncodedBodySize(uint64_t* aEncodedBodySize) override;
// nsIHttpChannelInternal
NS_IMETHOD GetIsAuthChannel(bool* aIsAuthChannel) override;
NS_IMETHOD SetChannelIsForDownload(bool aChannelIsForDownload) override;
NS_IMETHOD GetNavigationStartTimeStamp(TimeStamp* aTimeStamp) override;
NS_IMETHOD SetNavigationStartTimeStamp(TimeStamp aTimeStamp) override;
NS_IMETHOD CancelByURLClassifier(nsresult aErrorCode) override;
NS_IMETHOD GetLastTransportStatus(nsresult* aLastTransportStatus) override;
// nsISupportsPriority
NS_IMETHOD SetPriority(int32_t value) override;
// nsIClassOfService
NS_IMETHOD SetClassFlags(uint32_t inFlags) override;
NS_IMETHOD AddClassFlags(uint32_t inFlags) override;
NS_IMETHOD ClearClassFlags(uint32_t inFlags) override;
NS_IMETHOD SetClassOfService(ClassOfService cos) override;
NS_IMETHOD SetIncremental(bool incremental) override;
// nsIResumableChannel
NS_IMETHOD ResumeAt(uint64_t startPos, const nsACString& entityID) override;
NS_IMETHOD SetNotificationCallbacks(
nsIInterfaceRequestor* aCallbacks) override;
NS_IMETHOD SetLoadGroup(nsILoadGroup* aLoadGroup) override;
// nsITimedChannel
NS_IMETHOD GetDomainLookupStart(
mozilla::TimeStamp* aDomainLookupStart) override;
NS_IMETHOD GetDomainLookupEnd(mozilla::TimeStamp* aDomainLookupEnd) override;
NS_IMETHOD GetConnectStart(mozilla::TimeStamp* aConnectStart) override;
NS_IMETHOD GetTcpConnectEnd(mozilla::TimeStamp* aTcpConnectEnd) override;
NS_IMETHOD GetSecureConnectionStart(
mozilla::TimeStamp* aSecureConnectionStart) override;
NS_IMETHOD GetConnectEnd(mozilla::TimeStamp* aConnectEnd) override;
NS_IMETHOD GetRequestStart(mozilla::TimeStamp* aRequestStart) override;
NS_IMETHOD GetResponseStart(mozilla::TimeStamp* aResponseStart) override;
NS_IMETHOD GetResponseEnd(mozilla::TimeStamp* aResponseEnd) override;
NS_IMETHOD GetTransactionPending(
mozilla::TimeStamp* aTransactionPending) override;
// nsICorsPreflightCallback
NS_IMETHOD OnPreflightSucceeded() override;
NS_IMETHOD OnPreflightFailed(nsresult aError) override;
[[nodiscard]] nsresult AddSecurityMessage(
const nsAString& aMessageTag, const nsAString& aMessageCategory) override;
NS_IMETHOD LogBlockedCORSRequest(const nsAString& aMessage,
const nsACString& aCategory,
bool aIsWarning) override;
NS_IMETHOD LogMimeTypeMismatch(const nsACString& aMessageName, bool aWarning,
const nsAString& aURL,
const nsAString& aContentType) override;
NS_IMETHOD SetEarlyHintObserver(nsIEarlyHintObserver* aObserver) override;
NS_IMETHOD SetWebTransportSessionEventListener(
WebTransportSessionEventListener* aListener) override;
NS_IMETHOD SetResponseOverride(
nsIReplacedHttpResponse* aReplacedHttpResponse) override;
NS_IMETHOD SetResponseStatus(uint32_t aStatus,
const nsACString& aStatusText) override;
void SetWarningReporter(HttpChannelSecurityWarningReporter* aReporter);
HttpChannelSecurityWarningReporter* GetWarningReporter();
bool DataSentToChildProcess() { return LoadDataSentToChildProcess(); }
enum class SnifferType { Media, Image };
void DisableIsOpaqueResponseAllowedAfterSniffCheck(SnifferType aType);
public: /* internal necko use only */
uint32_t GetRequestTime() const { return mRequestTime; }
void AsyncOpenFinal(TimeStamp aTimeStamp);
[[nodiscard]] nsresult OpenCacheEntry(bool isHttps);
[[nodiscard]] nsresult OpenCacheEntryInternal(bool isHttps);
[[nodiscard]] nsresult ContinueConnect();
[[nodiscard]] nsresult StartRedirectChannelToURI(nsIURI*, uint32_t);
SnifferCategoryType GetSnifferCategoryType() const {
return mSnifferCategoryType;
}
// Helper to keep cache callbacks wait flags consistent
class AutoCacheWaitFlags {
public:
explicit AutoCacheWaitFlags(nsHttpChannel* channel)
: mChannel(channel), mKeep(0) {
// Flags must be set before entering any AsyncOpenCacheEntry call.
mChannel->StoreWaitForCacheEntry(nsHttpChannel::WAIT_FOR_CACHE_ENTRY);
}
void Keep(uint32_t flags) {
// Called after successful call to appropriate AsyncOpenCacheEntry call.
mKeep |= flags;
}
~AutoCacheWaitFlags() {
// Keep only flags those are left to be wait for.
mChannel->StoreWaitForCacheEntry(mChannel->LoadWaitForCacheEntry() &
mKeep);
}
private:
nsHttpChannel* mChannel;
uint32_t mKeep : 1;
};
bool AwaitingCacheCallbacks();
void SetCouldBeSynthesized();
// Return true if the latest ODA is invoked by mCachePump.
// Should only be called on the same thread as ODA.
bool IsReadingFromCache() const { return mIsReadingFromCache; }
base::ProcessId ProcessId();
using ChildEndpointPromise =
MozPromise<mozilla::ipc::Endpoint<extensions::PStreamFilterChild>, bool,
true>;
[[nodiscard]] RefPtr<ChildEndpointPromise> AttachStreamFilter();
already_AddRefed<WebTransportSessionEventListener>
GetWebTransportSessionEventListener();
private: // used for alternate service validation
RefPtr<TransactionObserver> mTransactionObserver;
public:
void SetTransactionObserver(TransactionObserver* arg) {
mTransactionObserver = arg;
}
TransactionObserver* GetTransactionObserver() { return mTransactionObserver; }
CacheDisposition mCacheDisposition{kCacheUnresolved};
protected:
virtual ~nsHttpChannel();
private:
using nsContinueRedirectionFunc = nsresult (nsHttpChannel::*)(nsresult);
// Directly call |aFunc| if the channel is not canceled and not suspended.
// Otherwise, set |aFunc| to |mCallOnResume| and wait until the channel
// resumes.
nsresult CallOrWaitForResume(
const std::function<nsresult(nsHttpChannel*)>& aFunc);
bool RequestIsConditional();
void HandleContinueCancellingByURLClassifier(nsresult aErrorCode);
nsresult CancelInternal(nsresult status);
void ContinueCancellingByURLClassifier(nsresult aErrorCode);
// Connections will only be established in this function.
// (including DNS prefetch and speculative connection.)
void MaybeResolveProxyAndBeginConnect();
void MaybeStartDNSPrefetch();
// Based on the proxy configuration determine the strategy for resolving the
// end server host name.
ProxyDNSStrategy GetProxyDNSStrategy();
// We might synchronously or asynchronously call BeginConnect,
// which includes DNS prefetch and speculative connection, according to
// whether an async tracker lookup is required. If the tracker lookup
// is required, this funciton will just return NS_OK and BeginConnect()
nsresult BeginConnect();
[[nodiscard]] nsresult PrepareToConnect();
[[nodiscard]] nsresult ContinuePrepareToConnect();
[[nodiscard]] nsresult OnBeforeConnect();
[[nodiscard]] nsresult ContinueOnBeforeConnect(
bool aShouldUpgrade, nsresult aStatus, bool aUpgradeWithHTTPSRR = false);
nsresult MaybeUseHTTPSRRForUpgrade(bool aShouldUpgrade, nsresult aStatus);
void OnHTTPSRRAvailable(nsIDNSHTTPSSVCRecord* aRecord);
[[nodiscard]] nsresult Connect();
void SpeculativeConnect();
[[nodiscard]] nsresult SetupChannelForTransaction();
[[nodiscard]] nsresult InitTransaction();
[[nodiscard]] nsresult DispatchTransaction(
HttpTransactionShell* aTransWithStickyConn);
[[nodiscard]] nsresult CallOnStartRequest();
[[nodiscard]] nsresult ProcessResponse();
void AsyncContinueProcessResponse();
[[nodiscard]] nsresult ContinueProcessResponse1();
[[nodiscard]] nsresult ContinueProcessResponse2(nsresult);
nsresult HandleOverrideResponse();
public:
void UpdateCacheDisposition(bool aSuccessfulReval, bool aPartialContentUsed);
[[nodiscard]] nsresult ContinueProcessResponse3(nsresult);
[[nodiscard]] nsresult ContinueProcessResponse4(nsresult);
[[nodiscard]] nsresult ProcessNormal();
[[nodiscard]] nsresult ContinueProcessNormal(nsresult);
void ProcessAltService();
bool ShouldBypassProcessNotModified();
[[nodiscard]] nsresult ProcessNotModified(
const std::function<nsresult(nsHttpChannel*, nsresult)>&
aContinueProcessResponseFunc);
[[nodiscard]] nsresult ContinueProcessResponseAfterNotModified(nsresult aRv);
[[nodiscard]] nsresult AsyncProcessRedirection(uint32_t redirectType);
[[nodiscard]] nsresult ContinueProcessRedirection(nsresult);
[[nodiscard]] nsresult ContinueProcessRedirectionAfterFallback(nsresult);
[[nodiscard]] nsresult ProcessFailedProxyConnect(uint32_t httpStatus);
void HandleAsyncAbort();
[[nodiscard]] nsresult EnsureAssocReq();
void ProcessSSLInformation();
bool IsHTTPS();
[[nodiscard]] nsresult ContinueOnStartRequest1(nsresult);
[[nodiscard]] nsresult ContinueOnStartRequest2(nsresult);
[[nodiscard]] nsresult ContinueOnStartRequest3(nsresult);
[[nodiscard]] nsresult ContinueOnStartRequest4(nsresult);
void OnClassOfServiceUpdated();
// redirection specific methods
void HandleAsyncRedirect();
void HandleAsyncAPIRedirect();
[[nodiscard]] nsresult ContinueHandleAsyncRedirect(nsresult);
void HandleAsyncNotModified();
[[nodiscard]] nsresult PromptTempRedirect();
[[nodiscard]] virtual nsresult SetupReplacementChannel(
nsIURI*, nsIChannel*, bool preserveMethod,
uint32_t redirectFlags) override;
void HandleAsyncRedirectToUnstrippedURI();
// proxy specific methods
[[nodiscard]] nsresult ProxyFailover();
[[nodiscard]] nsresult AsyncDoReplaceWithProxy(nsIProxyInfo*);
[[nodiscard]] nsresult ResolveProxy();
// cache specific methods
[[nodiscard]] nsresult OnNormalCacheEntryAvailable(nsICacheEntry* aEntry,
bool aNew,
nsresult aEntryStatus);
[[nodiscard]] nsresult OnCacheEntryAvailableInternal(nsICacheEntry* entry,
bool aNew,
nsresult status);
[[nodiscard]] nsresult GenerateCacheKey(uint32_t postID, nsACString& key);
[[nodiscard]] nsresult UpdateExpirationTime();
[[nodiscard]] nsresult CheckPartial(nsICacheEntry* aEntry, int64_t* aSize,
int64_t* aContentLength);
[[nodiscard]] nsresult ReadFromCache(void);
void CloseCacheEntry(bool doomOnFailure);
[[nodiscard]] nsresult InitCacheEntry();
void UpdateInhibitPersistentCachingFlag();
[[nodiscard]] nsresult AddCacheEntryHeaders(nsICacheEntry* entry);
[[nodiscard]] nsresult FinalizeCacheEntry();
[[nodiscard]] nsresult InstallCacheListener(int64_t offset = 0);
void MaybeInvalidateCacheEntryForSubsequentGet();
void AsyncOnExamineCachedResponse();
// byte range request specific methods
[[nodiscard]] nsresult ProcessPartialContent(
const std::function<nsresult(nsHttpChannel*, nsresult)>&
aContinueProcessResponseFunc);
[[nodiscard]] nsresult ContinueProcessResponseAfterPartialContent(
nsresult aRv);
[[nodiscard]] nsresult OnDoneReadingPartialCacheEntry(bool* streamDone);
[[nodiscard]] nsresult DoAuthRetry(
HttpTransactionShell* aTransWithStickyConn,
const std::function<nsresult(nsHttpChannel*, nsresult)>&
aContinueOnStopRequestFunc);
[[nodiscard]] nsresult ContinueDoAuthRetry(
HttpTransactionShell* aTransWithStickyConn,
const std::function<nsresult(nsHttpChannel*, nsresult)>&
aContinueOnStopRequestFunc);
[[nodiscard]] MOZ_NEVER_INLINE nsresult
DoConnect(HttpTransactionShell* aTransWithStickyConn = nullptr);
[[nodiscard]] nsresult DoConnectActual(
HttpTransactionShell* aTransWithStickyConn);
[[nodiscard]] nsresult ContinueOnStopRequestAfterAuthRetry(
nsresult aStatus, bool aAuthRetry, bool aIsFromNet, bool aContentComplete,
HttpTransactionShell* aTransWithStickyConn);
[[nodiscard]] nsresult ContinueOnStopRequest(nsresult status, bool aIsFromNet,
bool aContentComplete);
void HandleAsyncRedirectChannelToHttps();
[[nodiscard]] nsresult StartRedirectChannelToHttps();
[[nodiscard]] nsresult ContinueAsyncRedirectChannelToURI(nsresult rv);
[[nodiscard]] nsresult OpenRedirectChannel(nsresult rv);
HttpTrafficCategory CreateTrafficCategory();
/**
* A function that takes care of reading STS and PKP headers and enforcing
* STS and PKP load rules. After a secure channel is erected, STS and PKP
* requires the channel to be trusted or any STS or PKP header data on
* the channel is ignored. This is called from ProcessResponse.
*/
[[nodiscard]] nsresult ProcessSecurityHeaders();
/**
* Taking care of the Content-Signature header and fail the channel if
* the signature verification fails or is required but the header is not
* present.
* This sets mListener to ContentVerifier, which buffers the entire response
* before verifying the Content-Signature header. If the verification is
* successful, the load proceeds as usual. If the verification fails, a
* NS_ERROR_INVALID_SIGNATURE is thrown and a fallback loaded in nsDocShell
*/
[[nodiscard]] nsresult ProcessContentSignatureHeader(
nsHttpResponseHead* aResponseHead);
/**
* A function to process HTTP Strict Transport Security (HSTS) headers.
* Some basic consistency checks have been applied to the channel. Called
* from ProcessSecurityHeaders.
*/
[[nodiscard]] nsresult ProcessHSTSHeader(nsITransportSecurityInfo* aSecInfo);
void InvalidateCacheEntryForLocation(const char* location);
void AssembleCacheKey(const char* spec, uint32_t postID, nsACString& key);
[[nodiscard]] nsresult CreateNewURI(const char* loc, nsIURI** newURI);
void DoInvalidateCacheEntry(nsIURI* aURI);
// Ref RFC2616 13.10: "invalidation... MUST only be performed if
// the host part is the same as in the Request-URI"
inline bool HostPartIsTheSame(nsIURI* uri) {
nsAutoCString tmpHost1, tmpHost2;
return (NS_SUCCEEDED(mURI->GetAsciiHost(tmpHost1)) &&
NS_SUCCEEDED(uri->GetAsciiHost(tmpHost2)) &&
(tmpHost1 == tmpHost2));
}
inline static bool DoNotRender3xxBody(nsresult rv) {
return rv == NS_ERROR_REDIRECT_LOOP || rv == NS_ERROR_CORRUPTED_CONTENT ||
rv == NS_ERROR_UNKNOWN_PROTOCOL || rv == NS_ERROR_MALFORMED_URI ||
rv == NS_ERROR_PORT_ACCESS_NOT_ALLOWED;
}
// Report telemetry for system principal request success rate
void ReportSystemChannelTelemetry(nsresult status);
// Report telemetry and stats to about:networking
void ReportRcwnStats(bool isFromNet);
// Create a aggregate set of the current notification callbacks
// and ensure the transaction is updated to use it.
void UpdateAggregateCallbacks();
static bool HasQueryString(nsHttpRequestHead::ParsedMethodType method,
nsIURI* uri);
bool ResponseWouldVary(nsICacheEntry* entry);
bool IsResumable(int64_t partialLen, int64_t contentLength,
bool ignoreMissingPartialLen = false) const;
[[nodiscard]] nsresult MaybeSetupByteRangeRequest(
int64_t partialLen, int64_t contentLength,
bool ignoreMissingPartialLen = false);
[[nodiscard]] nsresult SetupByteRangeRequest(int64_t partialLen);
void UntieByteRangeRequest();
void UntieValidationRequest();
[[nodiscard]] nsresult OpenCacheInputStream(nsICacheEntry* cacheEntry,
bool startBuffering);
void SetPushedStreamTransactionAndId(
HttpTransactionShell* aTransWithPushedStream, uint32_t aPushedStreamId);
void SetOriginHeader();
void SetDoNotTrack();
void SetGlobalPrivacyControl();
already_AddRefed<nsChannelClassifier> GetOrCreateChannelClassifier();
// Start an internal redirect to a new InterceptedHttpChannel which will
// resolve in firing a ServiceWorker FetchEvent.
[[nodiscard]] nsresult RedirectToInterceptedChannel();
// Start an internal redirect to a new channel for auth retry
[[nodiscard]] nsresult RedirectToNewChannelForAuthRetry();
// Determines and sets content type in the cache entry. It's called when
// writing a new entry. The content type is used in cache internally only.
void SetCachedContentType();
private:
// this section is for main-thread-only object
// all the references need to be proxy released on main thread.
// auth specific data
nsCOMPtr<nsIHttpChannelAuthProvider> mAuthProvider;
nsCOMPtr<nsIURI> mRedirectURI;
nsCOMPtr<nsIURI> mUnstrippedRedirectURI;
nsCOMPtr<nsIChannel> mRedirectChannel;
nsCOMPtr<nsIChannel> mPreflightChannel;
// nsChannelClassifier checks this channel's URI against
// the URI classifier service.
// nsChannelClassifier will be invoked twice in InitLocalBlockList() and
// BeginConnect(), so save the nsChannelClassifier here to keep the
// state of whether tracking protection is enabled or not.
RefPtr<nsChannelClassifier> mChannelClassifier;
// Proxy release all members above on main thread.
void ReleaseMainThreadOnlyReferences();
// Called after the channel is made aware of its tracking status in order
// to readjust the referrer if needed according to the referrer default
// policy preferences.
void ReEvaluateReferrerAfterTrackingStatusIsKnown();
// Create a dummy channel for the same principal, out of the load group
// just to revalidate the cache entry. We don't care if this fails.
// This method can be called on any thread, and creates an idle task
// to perform the revalidation with delay.
void PerformBackgroundCacheRevalidation();
// This method can only be called on the main thread.
void PerformBackgroundCacheRevalidationNow();
void SetPriorityHeader();
private:
nsCOMPtr<nsICancelable> mProxyRequest;
nsCOMPtr<nsIRequest> mTransactionPump;
RefPtr<HttpTransactionShell> mTransaction;
RefPtr<HttpTransactionShell> mTransactionSticky;
uint64_t mLogicalOffset{0};
// cache specific data
nsCOMPtr<nsICacheEntry> mCacheEntry;
// This will be set during OnStopRequest() before calling CloseCacheEntry(),
// but only if the listener wants to use alt-data (signaled by
// HttpBaseChannel::mPreferredCachedAltDataType being not empty)
// Needed because calling openAlternativeOutputStream needs a reference
// to the cache entry.
nsCOMPtr<nsICacheEntry> mAltDataCacheEntry;
nsCOMPtr<nsIURI> mCacheEntryURI;
nsCString mCacheIdExtension;
// We must close mCacheInputStream explicitly to avoid leaks.
AutoClose<nsIInputStream> mCacheInputStream;
RefPtr<nsInputStreamPump> mCachePump;
UniquePtr<nsHttpResponseHead> mCachedResponseHead;
nsCOMPtr<nsITransportSecurityInfo> mCachedSecurityInfo;
uint32_t mPostID{0};
uint32_t mRequestTime{0};
nsresult mLastTransportStatus{NS_OK};
nsTArray<StreamFilterRequest> mStreamFilterRequests;
mozilla::TimeStamp mOnStartRequestTimestamp;
// Timestamp of the time the channel was suspended.
mozilla::TimeStamp mSuspendTimestamp;
mozilla::TimeStamp mOnCacheEntryCheckTimestamp;
// Properties used for the profiler markers
// This keeps the timestamp for the start marker, to be reused for the end
// marker.
mozilla::TimeStamp mLastStatusReported;
// This is true when one end marker is output, so that we never output more
// than one.
bool mEndMarkerAdded = false;
// Is set to true when the NEL report is queued.
bool mReportedNEL = false;
// Total time the channel spent suspended. This value is reported to
// telemetry in nsHttpChannel::OnStartRequest().
TimeDuration mSuspendTotalTime{0};
friend class AutoRedirectVetoNotifier;
friend class HttpAsyncAborter<nsHttpChannel>;
uint32_t mRedirectType{0};
static const uint32_t WAIT_FOR_CACHE_ENTRY = 1;
bool mCacheOpenWithPriority{false};
uint32_t mCacheQueueSizeWhenOpen{0};
Atomic<bool, Relaxed> mCachedContentIsValid{false};
Atomic<bool> mIsAuthChannel{false};
Atomic<bool> mAuthRetryPending{false};
// clang-format off
// state flags