#include "base/Here.h"
#include "mem/AllocatorProxy.h"
#include <iostream>
#include <sstream>
#include <iomanip>

Go to the source code of this file.
Classes | |
class | Debug |
class | Debug::Context |
meta-information for debugs() or a similar debugging call More... | |
class | Raw |
class | RawPointerT< Pointer > |
debugs objects pointed by possibly nil pointers: label=object More... | |
class | AsHex< Integer > |
std::ostream manipulator to print integers as hex numbers prefixed by 0x More... | |
Macros | |
#define | assert(EX) ((EX)?((void)0):xassert("EX", __FILE__, __LINE__)) |
#define | MAX_DEBUG_SECTIONS 100 |
#define | DBG_CRITICAL 0 |
#define | DBG_IMPORTANT 1 |
#define | DBG_DATA 9 |
#define | DBG_PARSE_NOTE(x) (opt_parse_cfg_only?0:(x)) |
#define | debug_log DebugStream() |
change-avoidance macro; new code should call DebugStream() instead More... | |
#define | debugs(SECTION, LEVEL, CONTENT) |
#define | MYNAME __FUNCTION__ << " " |
Typedefs | |
typedef int | Ctx |
Functions | |
Ctx | ctx_enter (const char *descr) |
void | ctx_exit (Ctx ctx) |
FILE * | DebugStream () |
void | StopUsingDebugLog () |
start logging to stderr (instead of cache.log, if any) More... | |
void | ResyncDebugLog (FILE *newDestination) |
a hack for low-level file descriptor manipulations in ipcCreate() More... | |
std::ostream & | ForceAlert (std::ostream &s) |
std::ostream & | HERE (std::ostream &s) |
std::ostream & | operator<< (std::ostream &os, const uint8_t d) |
void | _db_init (const char *logfile, const char *options) |
void | _db_set_syslog (const char *facility) |
void | _db_rotate_log (void) |
std::ostream & | operator<< (std::ostream &os, const Raw &raw) |
template<class Pointer > | |
RawPointerT< Pointer > | RawPointer (const char *label, const Pointer &ptr) |
convenience wrapper for creating RawPointerT<> objects More... | |
template<class Pointer > | |
std::ostream & | operator<< (std::ostream &os, const RawPointerT< Pointer > &pd) |
prints RawPointerT<>, dereferencing the raw pointer if possible More... | |
template<class Integer > | |
std::ostream & | operator<< (std::ostream &os, const AsHex< Integer > number) |
template<class Integer > | |
AsHex< Integer > | asHex (const Integer n) |
a helper to ease AsHex object creation More... | |
Macro Definition Documentation
◆ assert
#define assert | ( | EX | ) | ((EX)?((void)0):xassert("EX", __FILE__, __LINE__)) |
◆ DBG_CRITICAL
#define DBG_CRITICAL 0 |
◆ DBG_DATA
#define DBG_DATA 9 |
◆ DBG_IMPORTANT
#define DBG_IMPORTANT 1 |
◆ DBG_PARSE_NOTE
#define DBG_PARSE_NOTE | ( | x | ) | (opt_parse_cfg_only?0:(x)) |
◆ debug_log
#define debug_log DebugStream() |
◆ debugs
#define debugs | ( | SECTION, | |
LEVEL, | |||
CONTENT | |||
) |
◆ MAX_DEBUG_SECTIONS
◆ MYNAME
Typedef Documentation
◆ Ctx
Function Documentation
◆ _db_init()
void _db_init | ( | const char * | logfile, |
const char * | options | ||
) |
Definition at line 490 of file debug.cc.
References APP_SHORTNAME, debugOpenLog(), Debug::log_syslog, logfile, and Debug::parseOptions().
Referenced by ConfigureDebugging(), main(), mainReconfigureFinish(), and IcmpPinger::Open().
◆ _db_rotate_log()
void _db_rotate_log | ( | void | ) |
Definition at line 508 of file debug.cc.
References Debug::cache_log, DebugFile::clear(), DBG_IMPORTANT, debugOpenLog(), debugs, MAXPATHLEN, DebugFile::name, Debug::rotateNumber, sb, TheLog, and xstrerr().
Referenced by mainRotate().
◆ _db_set_syslog()
void _db_set_syslog | ( | const char * | facility | ) |
Definition at line 55 of file stub_debug.cc.
Referenced by mainHandleCommandLineOption().
◆ asHex()
|
inline |
Definition at line 282 of file Debug.h.
Referenced by Security::ErrorDetail::ErrorDetail(), Security::ForgetErrors(), Acl::ConnMark::match(), operator<<(), and Security::ParseProtocolVersionBase().
◆ ctx_enter()
Ctx ctx_enter | ( | const char * | descr | ) |
Definition at line 721 of file debug.cc.
References Ctx_Current_Level, Ctx_Descrs, CTX_MAX_LEVEL, Ctx_Warn_Level, DBG_CRITICAL, and debugs.
Referenced by MemObject::~MemObject(), HttpStateData::haveParsedReplyHeaders(), and HttpStateData::processReplyHeader().
◆ ctx_exit()
void ctx_exit | ( | Ctx | ctx | ) |
Definition at line 737 of file debug.cc.
References assert, Ctx_Current_Level, and Ctx_Valid_Level.
Referenced by MemObject::~MemObject(), HttpStateData::haveParsedReplyHeaders(), and HttpStateData::processReplyHeader().
◆ DebugStream()
FILE* DebugStream | ( | ) |
cache.log FILE or, as the last resort, stderr stream; may be nil during static initialization and destruction!
Definition at line 78 of file debug.cc.
References DebugFile::file(), and TheLog.
◆ ForceAlert()
std::ostream& ForceAlert | ( | std::ostream & | s | ) |
Does not change the stream being manipulated. Exists for its side effect: In a debugs() context, forces the message to become a syslog ALERT. Outside of debugs() context, has no effect and should not be used.
Definition at line 877 of file debug.cc.
References Debug::ForceAlert().
Referenced by death(), and fatal_common().
◆ HERE()
|
inline |
stream manipulator which does nothing.
- Deprecated:
- Do not add to new code, and remove when editing old code
Its purpose is to inactivate calls made following previous debugs() guidelines such as debugs(1,2, HERE << "some message");
His former objective is now absorbed in the debugs call itself
Definition at line 157 of file Debug.h.
Referenced by Adaptation::AccessCheck::AccessCheck(), Mgr::ActionWriter::ActionWriter(), BodyPipe::BodyPipe(), Mgr::CountersAction::CountersAction(), DiskdAction::DiskdAction(), FileMap::FileMap(), Mgr::Filler::Filler(), Mgr::Forwarder::Forwarder(), Snmp::Forwarder::Forwarder(), Mgr::FunAction::FunAction(), HttpRequest::HttpRequest(), HttpStateData::HttpStateData(), Mgr::IndexAction::IndexAction(), Mgr::InfoAction::InfoAction(), Mgr::Inquirer::Inquirer(), Snmp::Inquirer::Inquirer(), Ipc::Inquirer::Inquirer(), Mgr::IntervalAction::IntervalAction(), Mgr::IoAction::IoAction(), mem_hdr::mem_hdr(), MemBlob::MemBlob(), Mgr::MenuAction::MenuAction(), MmappedFile::MmappedFile(), Adaptation::Icap::ModXact::ModXact(), Mgr::OfflineToggleAction::OfflineToggleAction(), Ipc::QueueReader::QueueReader(), Mgr::ReconfigureAction::ReconfigureAction(), Mgr::RotateAction::RotateAction(), Adaptation::Service::Service(), Mgr::ServiceTimesAction::ServiceTimesAction(), Mgr::ShutdownAction::ShutdownAction(), Mgr::StoreIoAction::StoreIoAction(), Mgr::StoreToCommWriter::StoreToCommWriter(), Ipc::UdsOp::UdsOp(), Auth::User::User(), Auth::UserRequest::UserRequest(), ACLFilledChecklist::~ACLFilledChecklist(), BodyPipe::~BodyPipe(), BodyPipeCheckout::~BodyPipeCheckout(), ConnStateData::~ConnStateData(), HttpRequest::~HttpRequest(), HttpStateData::~HttpStateData(), Ipc::Inquirer::~Inquirer(), MemBlob::~MemBlob(), Ipc::Mem::Segment::~Segment(), Ssl::ServerBump::~ServerBump(), Mgr::StoreToCommWriter::~StoreToCommWriter(), Ipc::UdsOp::~UdsOp(), Auth::User::~User(), Auth::UserRequest::~UserRequest(), _comm_close(), HttpStateData::abortAll(), ConnStateData::abortChunkedRequestBody(), Client::abortOnBadEntry(), Auth::User::absorb(), Comm::TcpAcceptor::acceptNext(), Comm::TcpAcceptor::acceptOne(), Adaptation::AccessCheck::AccessCheckCallbackWrapper(), aclDomainCompare(), aclGetDenyInfoPage(), aclMatchExternal(), Adaptation::Ecap::XactionRep::adaptationDelayed(), HttpRequest::adaptHistory(), Client::adaptOrFinalizeReply(), Client::adaptVirginReplyBody(), Mgr::CountersAction::add(), Mgr::InfoAction::add(), Mgr::IntervalAction::add(), Mgr::IoAction::add(), Mgr::ServiceTimesAction::add(), Mgr::StoreIoAction::add(), DiskdAction::add(), Fs::Ufs::UFSSwapDir::addDiskRestore(), Auth::User::addIp(), Auth::UserRequest::AddReplyAuthHeader(), Ftp::Gateway::appendSuccessHeader(), Mgr::Inquirer::applyQueryParams(), Auth::UserRequest::authenticate(), AuthenticateAcl(), authenticateActiveSchemeCount(), authenticateSchemeCount(), Adaptation::Answer::Block(), Adaptation::Ecap::XactionRep::blockVirgin(), Ipc::Coordinator::broadcastSignal(), ConnStateData::buildSslCertGenerationParams(), Adaptation::Icap::ServiceRep::busyCheckpoint(), Adaptation::Icap::ModXact::bypassFailure(), TunnelStateData::Connection::bytesIn(), ACLChecklist::calcImplicitAnswer(), HttpReply::calcMaxBodySize(), Adaptation::AccessCheck::callBack(), Rock::IoState::callBack(), Adaptation::Icap::Xaction::callEnd(), AsyncJob::callEnd(), Adaptation::Icap::ModXact::callException(), Ipc::Forwarder::callException(), Ipc::Inquirer::callException(), Adaptation::Icap::ServiceRep::callWhenReady(), AsyncJob::canBeCalled(), AsyncCall::cancel(), Adaptation::Icap::Launcher::canRepeat(), Rock::SwapDir::canStore(), Store::Disk::canStore(), IpcIoFile::canWait(), Adaptation::Icap::Options::cfgIntHeader(), Adaptation::Icap::Options::cfgTransferList(), Adaptation::Icap::ServiceRep::changeOptions(), Adaptation::AccessCheck::check(), Adaptation::AccessCheck::checkCandidates(), Adaptation::Icap::ModXact::checkConsuming(), ProxyAuthLookup::checkForAsync(), IdentLookup::checkForAsync(), FwdState::checkRetry(), Ipc::Mem::Segment::checkSupport(), IpcIoFile::CheckTimeouts(), Client::cleanAdaptation(), Comm::ConnOpener::cleanFd(), Adaptation::Config::clear(), BodyPipe::clearConsumer(), IdleConnList::clearHandlers(), BodyPipe::clearProducer(), client_Inst(), ClientRequestContext::clientAccessCheck2(), ConnStateData::clientAfterReadingRequests(), ConnStateData::clientParseRequests(), clientProcessRequestFinished(), ClientRequestContext::clientRedirectDone(), ClientRequestContext::clientRedirectStart(), ClientSocketContextPushDeferredIfNeeded(), DiskThreadsDiskFile::close(), MmappedFile::close(), IcmpSquid::Close(), Fs::Ufs::UFSStoreState::closeCompleted(), Adaptation::Icap::Xaction::closeConnection(), IdleConnList::closeN(), HttpStateData::closeServer(), Mgr::CountersAction::collect(), Mgr::ServiceTimesAction::collect(), comm_connect_addr(), comm_flush_updates(), comm_import_opened(), comm_init_opened(), comm_open_uds(), comm_update_fd(), commHalfClosedCheck(), commHalfClosedReader(), commSetConnTimeout(), commStartHalfClosedMonitor(), commStopHalfClosedMonitor(), commUnsetConnTimeout(), commUnsetFdTimeout(), FwdState::completed(), Client::completeForwarding(), constructHelperQuery(), HttpStateData::continueAfterParsingHeader(), TunnelStateData::copy(), Rock::SwapDir::create(), Ipc::Mem::Segment::create(), Fs::Ufs::UFSStrategy::create(), Auth::SchemeConfig::CreateAuthUser(), Rock::SwapDir::createStoreIO(), Ftp::Gateway::dataChannelConnected(), TunnelStateData::Connection::dataSent(), Adaptation::Icap::ModXact::decideOnParsingBody(), Adaptation::Icap::ModXact::decideOnPreview(), Adaptation::Icap::ModXact::decideWritingAfterPreview(), Ipc::UdsSender::delayedRetry(), Ipc::Forwarder::DequeueRequest(), Ipc::Inquirer::DequeueRequest(), Fs::Ufs::UFSSwapDir::dereference(), Rock::SwapDir::dereference(), destroyStoreEntry(), Adaptation::Icap::ServiceRep::detach(), JobDialer< Job >::dial(), Adaptation::Icap::Xaction::dieOnConnectionFailure(), Fs::Ufs::UFSSwapDir::DirClean(), Adaptation::Icap::ModXact::disableBypass(), DiskerClose(), IpcIoFile::DiskerHandleMoreRequests(), IpcIoFile::DiskerHandleRequest(), IpcIoFile::DiskerHandleRequests(), diskerRead(), Comm::TcpAcceptor::doAccept(), ClientHttpRequest::doCallouts(), Comm::ConnOpener::doConnect(), store_client::doCopy(), Ipc::Port::doListen(), IcmpSquid::DomainPing(), Ipc::Forwarder::doneAll(), HttpStateData::doneSendingRequestBody(), Client::doneSendingRequestBody(), Comm::DoSelect(), Fs::Ufs::UFSSwapDir::doubleCheck(), DiskdAction::dump(), Mgr::IndexAction::dump(), Mgr::MenuAction::dump(), Mgr::CountersAction::dump(), Mgr::FunAction::dump(), Mgr::InfoAction::dump(), Mgr::IntervalAction::dump(), Mgr::IoAction::dump(), Mgr::ServiceTimesAction::dump(), Mgr::StoreIoAction::dump(), Format::Format::dump(), Fs::Ufs::UFSSwapDir::dumpEntry(), Comm::ConnOpener::earlyAbort(), Adaptation::Icap::ModXact::echoMore(), BodyPipe::enableAutoConsumption(), ClientHttpRequest::endRequestSatisfaction(), Adaptation::Answer::Error(), TunnelStateData::Connection::error(), errorSendComplete(), esiBufferRecipient(), Adaptation::Icap::ModXact::estimateVirginBody(), HttpReply::expectedBodyTooLarge(), ConnStateData::expectNoForwarding(), external_acl_cache_add(), externalAclHandleReply(), acl_ip_data::FactoryParse(), FwdState::fail(), Ipc::FdNote(), Mgr::Action::fillEntry(), Adaptation::AccessRule::finalize(), Adaptation::Config::finalize(), Adaptation::ServiceGroup::finalize(), FinalizeEach(), IdleConnList::findIndexOf(), Ipc::FewToFewBiQueue::findOldest(), Adaptation::ServiceGroup::findService(), ConnStateData::finishDechunkingRequest(), HttpStateData::finishingBrokenPost(), HttpStateData::finishingChunkedRequest(), Adaptation::Ecap::XactionRep::forgetVb(), Adaptation::Answer::Forward(), mem_hdr::freeContent(), ESIContext::freeResources(), Ftp::Gateway::ftpAcceptDataConnection(), ftpListDir(), ftpReadCwd(), ftpReadEPRT(), ftpReadList(), ftpReadMdtm(), ftpReadMkdir(), ftpReadPass(), ftpReadPORT(), ftpReadRest(), ftpReadRetr(), ftpReadSize(), ftpReadTransferDone(), ftpReadType(), ftpReadUser(), ftpReadWelcome(), ftpRestOrList(), ftpSendCwd(), ftpSendList(), ftpSendMkdir(), ftpSendNlst(), ftpSendPassive(), ftpSendPORT(), ftpSendReply(), ftpSendRest(), ftpSendRetr(), ftpSendStor(), ftpTraverseDirectory(), ftpTrySlashHack(), ftpWriteTransferDone(), Ssl::ErrorDetailsManager::getCachedDetails(), Adaptation::Icap::ServiceRep::getConnection(), Ssl::ErrorDetailsManager::getErrorDetail(), Ip::Address::getInAddr(), Fs::Ufs::RebuildState::getNextFile(), getRoundRobinParent(), Ip::Address::getSockAddr(), ConnStateData::getSslContextStart(), gopherReadReply(), gopherSendComplete(), gopherTimeout(), Adaptation::ServiceConfig::grokBool(), Adaptation::ServiceConfig::grokUri(), FileMap::grow(), Ftp::Gateway::hackShortcut(), HttpStateData::handle1xx(), Adaptation::Icap::ModXact::handle206PartialContent(), Client::handleAdaptationAborted(), Adaptation::Iterator::handleAdaptationBlock(), Client::handleAdaptationBlocked(), Client::handleAdaptationCompleted(), Adaptation::Iterator::handleAdaptationError(), ClientHttpRequest::handleAdaptationFailure(), Adaptation::Iterator::handleAdaptedHeader(), ClientHttpRequest::handleAdaptedHeader(), Client::handleAdaptedHeader(), Ipc::Coordinator::handleCacheMgrRequest(), ConnStateData::handleChunkedRequestBody(), Adaptation::Icap::ModXact::handleCommConnected(), Adaptation::Icap::OptXact::handleCommConnected(), Adaptation::Icap::OptXact::handleCommRead(), Adaptation::Icap::Xaction::handleCommTimedout(), Adaptation::Icap::ModXact::handleCommWrote(), Adaptation::Icap::OptXact::handleCommWrote(), Ipc::Forwarder::handleException(), Ipc::Inquirer::handleException(), Snmp::Forwarder::handleException(), Store::Controller::handleIdleEntry(), Client::handleMoreAdaptedBodyAvailable(), Client::handleMoreRequestBodyAvailable(), HttpStateData::handleMoreRequestBodyAvailable(), Adaptation::Icap::ServiceRep::handleNewOptions(), IpcIoFile::HandleNotification(), IpcIoFile::HandleOpenResponse(), Ipc::Forwarder::handleRemoteAck(), Ipc::Forwarder::HandleRemoteAck(), Ipc::Inquirer::handleRemoteAck(), ConnStateData::handleRequestBodyData(), Ftp::Gateway::handleRequestBodyProducerAborted(), Client::handleRequestBodyProducerAborted(), Client::handleRequestBodyProductionEnded(), IpcIoFile::HandleResponses(), Ipc::Coordinator::handleSearchRequest(), Ipc::Coordinator::handleSharedListenRequest(), Ipc::Coordinator::handleSnmpRequest(), Ipc::Strand::handleSnmpRequest(), Ipc::Coordinator::handleSnmpResponse(), Ipc::Strand::handleSnmpResponse(), FwdState::HandleStoreAbort(), FwdState::handleUnregisteredServerEnd(), ClientRequestContext::hostHeaderIpVerify(), ClientRequestContext::hostHeaderVerify(), httpHeaderParseQuotedString(), httpsAccept(), HttpRequest::icapHistory(), DelayUser::id(), idnsGrokReply(), idnsInitVCConnected(), idnsReadVC(), idnsSendSlaveAAAAQuery(), Rock::SwapDir::ignoreReferences(), Rock::SwapDir::init(), Fs::Ufs::UFSSwapDir::init(), Adaptation::Icap::InitModule(), Ipc::Inquirer::inquire(), ipcacheStatPrint(), Ip::Intercept::IpfwInterception(), Adaptation::AccessCheck::isCandidate(), TunnelStateData::keepGoingAfterRead(), Adaptation::Icap::Launcher::launchXaction(), Ftp::Gateway::listenForDataChannel(), TemplateFile::loadFor(), Rock::Rebuild::loadingSteps(), Ip::Intercept::Lookup(), Ip::Address::lookupHostIP(), Comm::ConnOpener::lookupLocalAddress(), main(), AsyncCall::make(), Adaptation::Icap::ModXact::makeAdaptedBodyPipe(), Mmapping::map(), ACLChecklist::markFinished(), ACLIdent::match(), StoreEntry::mayStartSwapOut(), Store::Controller::memoryOut(), Adaptation::Ecap::XactionRep::moveAbContent(), Adaptation::Ecap::XactionRep::noteAbContentDone(), ClientHttpRequest::noteAdaptationAclCheckDone(), Client::noteAdaptationAclCheckDone(), Adaptation::Icap::Launcher::noteAdaptationAnswer(), Adaptation::Icap::ServiceRep::noteAdaptationAnswer(), Adaptation::AccessCheck::noteAnswer(), ClientHttpRequest::noteBodyProducerAborted(), Mgr::Forwarder::noteCommClosed(), Mgr::Inquirer::noteCommClosed(), Mgr::StoreToCommWriter::noteCommClosed(), Snmp::Forwarder::noteCommClosed(), Snmp::Inquirer::noteCommClosed(), Adaptation::Icap::Xaction::noteCommWrote(), Mgr::StoreToCommWriter::noteCommWrote(), Adaptation::Icap::ServiceRep::noteConnectionFailed(), Adaptation::Icap::ServiceRep::noteFailure(), Adaptation::Icap::Xaction::noteInitiatorAborted(), Ipc::Port::noteRead(), Mgr::StoreToCommWriter::noteStoreCopied(), Adaptation::Icap::ServiceRep::noteTimeToNotify(), Adaptation::Icap::ServiceRep::noteTimeToUpdate(), Mgr::Inquirer::noteWroteHeader(), Adaptation::Icap::Launcher::noteXactAbort(), IpcIoFile::Notify(), Ipc::Coordinator::notifySearcher(), IcmpSquid::Open(), Ipc::Mem::Segment::open(), Fs::Ufs::UFSStrategy::open(), Fs::Ufs::UFSStoreState::openDone(), Ipc::Coordinator::openListenSocket(), Fs::Ufs::UFSSwapDir::openLog(), Rock::SwapDir::openStoreIO(), Snmp::Var::operator+=(), Snmp::Var::operator/=(), Snmp::Var::operator<(), Snmp::Var::operator>(), Adaptation::Icap::ServiceRep::optionsFetchTime(), ACLIdent::parse(), Ssl::ErrorDetailFile::parse(), Format::Format::parse(), Format::Token::parse(), Adaptation::Icap::ModXact::parseBody(), parseConfigFileOrThrow(), Adaptation::Icap::ModXact::parseHeaders(), Adaptation::Icap::ModXact::parseIcapHead(), Ftp::Gateway::parseListing(), CacheManager::ParseUrl(), Store::Controller::peek(), HttpStateData::persistentConnStatus(), Ip::Intercept::PfInterception(), ConnStateData::pinConnection(), Ipc::BaseMultiQueue::pop(), PconnPool::popStored(), BodyPipe::postAppend(), BodyPipe::postConsume(), ACLChecklist::preCheck(), Adaptation::Icap::ModXact::prepEchoing(), Adaptation::Icap::ModXact::prepPartialBodyEchoing(), Adaptation::Ecap::XactionRep::preserveVb(), Ftp::Gateway::processHeadResponse(), Adaptation::Icap::History::processingTime(), HttpStateData::processReply(), Ftp::Gateway::processReplyBody(), HttpStateData::processReplyBody(), IdleConnList::push(), PconnPool::push(), Ipc::BaseMultiQueue::push(), IpcIoFile::push(), Adaptation::Icap::ServiceRep::putConnection(), ConnStateData::quitAfterError(), ClientInfo::quota(), BlockingFile::read(), IpcIoFile::read(), MmappedFile::read(), TunnelStateData::readClient(), IpcIoFile::readCompleted(), Adaptation::Icap::ModXact::readMore(), ConnStateData::readNextRequest(), WhoisState::readReply(), TunnelStateData::readServer(), TunnelStateData::ReadServer(), Ftp::Gateway::readStor(), Fs::Ufs::RebuildState::rebuildFromDirectory(), Fs::Ufs::RebuildState::rebuildFromSwapLog(), Fs::Ufs::RebuildState::rebuildStep(), Ipc::Coordinator::receive(), HttpReply::receivedBodyTooLarge(), Icmp4::Recv(), Icmp6::Recv(), IcmpPinger::Recv(), IcmpSquid::Recv(), redirectHandleReply(), Fs::Ufs::UFSSwapDir::reference(), Rock::SwapDir::reference(), FwdState::reforward(), CacheManager::registerProfile(), Ipc::Strand::registerSelf(), Ipc::Coordinator::registerStrand(), Fs::Ufs::UFSSwapDir::replacementAdd(), Fs::Ufs::UFSSwapDir::replacementRemove(), Ipc::Forwarder::requestTimedOut(), Ipc::Inquirer::requestTimedOut(), Ipc::Forwarder::RequestTimedOut(), Ipc::Inquirer::RequestTimedOut(), helper_server::requestTimeout(), Mgr::Action::respond(), Mgr::FunAction::respond(), Mgr::InfoAction::respond(), FwdState::retryOrBail(), HttpStateData::reusableReply(), Mgr::Action::run(), HttpRequest::sanityCheckStartLine(), Format::Token::scanForToken(), EventScheduler::schedule(), Mgr::StoreToCommWriter::scheduleCommWrite(), Adaptation::Icap::ServiceRep::scheduleNotification(), Mgr::StoreToCommWriter::scheduleStoreCopy(), Adaptation::Icap::ServiceRep::scheduleUpdate(), ConnStateData::sendControlMsg(), Icmp4::SendEcho(), Icmp6::SendEcho(), IcmpSquid::SendEcho(), Mgr::Forwarder::sendError(), Snmp::Forwarder::sendError(), Client::sendMoreRequestBody(), HttpStateData::sendRequest(), Snmp::Inquirer::sendResponse(), Snmp::SendResponse(), IcmpPinger::SendResult(), Client::sentRequestBody(), Client::serverComplete(), Client::serverComplete2(), BodyPipe::setBodySize(), BodyPipe::setConsumerIfNotLate(), Client::setFinalReply(), Adaptation::History::setFutureServices(), Adaptation::Icap::Xaction::setOutcome(), Comm::SetSelect(), Rock::StoreFileSystem::setup(), Client::setVirginReply(), MemStore::shouldCache(), Adaptation::Ecap::XactionRep::sinkVb(), snmp_meshCtblFn(), snmpAggrType(), snmpDecodePacket(), ClientRequestContext::sslBumpAccessCheck(), ClientHttpRequest::sslBumpEstablish(), SslBumpEstablish(), ClientHttpRequest::sslBumpNeed(), ClientHttpRequest::sslBumpStart(), ConnStateData::sslCrtdHandleReply(), Comm::TcpAcceptor::start(), Ipc::Forwarder::start(), Mgr::ActionWriter::start(), Mgr::Filler::start(), Mgr::Inquirer::start(), Mgr::StoreToCommWriter::start(), Snmp::Inquirer::start(), ExternalACLLookup::Start(), Adaptation::Icap::History::start(), FwdState::Start(), Adaptation::AccessCheck::Start(), ClientHttpRequest::startAdaptation(), Client::startAdaptation(), BodyPipe::startAutoConsumptionIfNeeded(), MemStore::startCaching(), ConnStateData::startDechunkingRequest(), Adaptation::Icap::ServiceRep::startGettingOptions(), Ipc::StartListening(), Client::startRequestBodyFlow(), Adaptation::Iterator::step(), Adaptation::Icap::History::stop(), Adaptation::Icap::ModXact::stopBackup(), ConnStateData::stopReceiving(), Adaptation::Icap::ModXact::stopSending(), ConnStateData::stopSending(), Adaptation::Icap::ModXact::stopWriting(), StoreEntry::storeClientType(), storeClose(), clientReplyContext::storeNotOKTransferDone(), clientReplyContext::storeOKTransferDone(), storeRebuildParseEntry(), storeSwapInStart(), storeSwapOutFileClosed(), Comm::TcpAcceptor::subscribe(), Adaptation::Icap::ServiceRep::suspend(), Adaptation::Icap::ModXact::swanSong(), Adaptation::Icap::ModXactLauncher::swanSong(), Adaptation::Icap::Xaction::swanSong(), Adaptation::Initiate::swanSong(), ConnStateData::swanSong(), Comm::TcpAcceptor::swanSong(), Ipc::Forwarder::swanSong(), Ipc::Inquirer::swanSong(), Mgr::Filler::swanSong(), Mgr::StoreToCommWriter::swanSong(), Rock::Rebuild::swanSong(), StoreEntry::swapOut(), CommConnectCbParams::syncWithComm(), CommIoCbParams::syncWithComm(), Ipc::Strand::timedout(), Ipc::UdsSender::timedout(), Comm::ConnOpener::timeout(), Adaptation::AccessCheck::topGroup(), Ip::Intercept::TproxyTransparent(), Rock::SwapDir::trackReferences(), Fs::Ufs::UFSStoreState::tryClosing(), Adaptation::Ecap::ServiceRep::tryConfigureAndStart(), TemplateFile::tryLoadTemplate(), tunnelConnectedWriteDone(), tunnelErrorComplete(), tunnelStart(), tunnelTimeout(), Ftp::Gateway::unhack(), uniqueHostname(), Fs::Ufs::UFSSwapDir::unlinkFile(), Mmapping::unmap(), ConnStateData::unpinConnection(), FwdState::unregister(), Comm::TcpAcceptor::unsubscribe(), Adaptation::History::updateNextServices(), Adaptation::Iterator::updatePlan(), Adaptation::Ecap::XactionRep::useAdapted(), Adaptation::AccessCheck::usedDynamicRules(), FwdState::useDestinations(), Adaptation::Ecap::XactionRep::useVirgin(), Auth::UserRequest::valid(), Adaptation::Icap::ModXact::virginConsume(), IpcIoFile::WaitBeforePop(), Adaptation::Icap::ModXact::waitForService(), ConnStateData::whenClientIpKnown(), whoisTimeout(), Ipc::UdsSender::write(), Fs::Ufs::UFSStoreState::write(), Comm::Write(), BlockingFile::write(), IpcIoFile::write(), MmappedFile::write(), mem_hdr::writeAvailable(), Fs::Ufs::UFSSwapDir::writeCleanStart(), TunnelStateData::writeClientDone(), Fs::Ufs::UFSStoreState::writeCompleted(), IpcIoFile::writeCompleted(), BlockingFile::writeDone(), Adaptation::Icap::ModXact::writeMore(), Adaptation::Icap::ModXact::writePreviewBody(), Adaptation::Icap::ModXact::writePrimeBody(), Ftp::Gateway::writeReplyBody(), TunnelStateData::writeServerDone(), Adaptation::Icap::ModXact::writeSomeBody(), Rock::IoState::writeToDisk(), Ipc::UdsSender::wrote(), and HttpStateData::wroteLast().
◆ operator<<() [1/4]
|
inline |
◆ operator<<() [2/4]
|
inline |
Definition at line 226 of file Debug.h.
References Raw::print().
◆ operator<<() [3/4]
|
inline |
Definition at line 251 of file Debug.h.
References RawPointerT< Pointer >::label, and RawPointerT< Pointer >::ptr.
◆ operator<<() [4/4]
|
inline |
◆ RawPointer()
|
inline |
Definition at line 244 of file Debug.h.
Referenced by Security::PeerConnector::sslCrtvdHandleReply().
◆ ResyncDebugLog()
void ResyncDebugLog | ( | FILE * | newDestination | ) |
Definition at line 68 of file debug.cc.
References DebugFile::file_, and TheLog.
Referenced by ipcCreate().
◆ StopUsingDebugLog()
void StopUsingDebugLog | ( | ) |
Definition at line 83 of file debug.cc.
References DebugFile::clear(), and TheLog.
Referenced by sendSignal().