CernVM-FS  2.12.0
 All Classes Namespaces Files Functions Variables Typedefs Enumerations Enumerator Friends Macros Pages
logging.cc File Reference
#include "util/logging_internal.h"
#include <errno.h>
#include <fcntl.h>
#include <pthread.h>
#include <syslog.h>
#include <time.h>
#include <unistd.h>
#include <cassert>
#include <cstdio>
#include <cstdlib>
#include <cstring>
#include <ctime>
#include <vector>
#include "util/export.h"
#include "util/mutex.h"
#include "util/platform.h"
#include "util/posix.h"
#include "util/single_copy.h"
#include "util/smalloc.h"
Include dependency graph for logging.cc:

Go to the source code of this file.

Classes

class  anonymous_namespace{logging.cc}::LogBuffer
 

Namespaces

 anonymous_namespace{logging.cc}
 

Functions

static void LogCustom (unsigned id, const std::string &message)
 
void SetLogSyslogLevel (const int level)
 
int GetLogSyslogLevel ()
 
void SetLogSyslogFacility (const int local_facility)
 
int GetLogSyslogFacility ()
 
void SetLogSyslogPrefix (const std::string &prefix)
 
void SetLogSyslogShowPID (bool flag)
 
void SetLogVerbosity (const LogLevels max_level)
 
void SetLogMicroSyslogMaxSize (unsigned bytes)
 
void SetLogMicroSyslog (const std::string &filename)
 
std::string GetLogMicroSyslog ()
 
static void LogMicroSyslog (const std::string &message)
 
void SetAltLogFunc (void(*fn)(const LogSource source, const int mask, const char *msg))
 
CVMFS_EXPORT void vLogCvmfs (const LogSource source, const int mask, const char *format, va_list variadic_list)
 
CVMFS_EXPORT void LogCvmfs (const LogSource source, const int mask, const char *format,...)
 
std::vector< LogBufferEntryGetLogBuffer ()
 
void ClearLogBuffer ()
 
void PrintError (const string &message)
 
void PrintWarning (const string &message)
 
void SetLogCustomFile (unsigned id, const std::string &filename)
 
void LogShutdown ()
 

Variables

unsigned anonymous_namespace{logging.cc}::gMicroSyslogMax = 500 * 1024
 
pthread_mutex_t anonymous_namespace{logging.cc}::lock_stdout = PTHREAD_MUTEX_INITIALIZER
 
pthread_mutex_t anonymous_namespace{logging.cc}::lock_stderr = PTHREAD_MUTEX_INITIALIZER
 
const char * anonymous_namespace{logging.cc}::module_names []
 
int anonymous_namespace{logging.cc}::syslog_facility = LOG_USER
 
int anonymous_namespace{logging.cc}::syslog_level = LOG_NOTICE
 
char * anonymous_namespace{logging.cc}::syslog_prefix = NULL
 
string * anonymous_namespace{logging.cc}::usyslog_dest = NULL
 
int anonymous_namespace{logging.cc}::usyslog_fd = -1
 
int anonymous_namespace{logging.cc}::usyslog_fd1 = -1
 
unsigned anonymous_namespace{logging.cc}::usyslog_size = 0
 
pthread_mutex_t anonymous_namespace{logging.cc}::lock_usyslock = PTHREAD_MUTEX_INITIALIZER
 
const unsigned anonymous_namespace{logging.cc}::kMaxCustomlog = 3
 
string * anonymous_namespace{logging.cc}::customlog_dests [] = {NULL, NULL, NULL}
 
int anonymous_namespace{logging.cc}::customlog_fds [] = {-1, -1, -1}
 
pthread_mutex_t anonymous_namespace{logging.cc}::customlog_locks []
 
LogLevels anonymous_namespace{logging.cc}::max_log_level = kLogNormal
 
static void(* anonymous_namespace{logging.cc}::alt_log_func )(const LogSource source, const int mask, const char *msg) = NULL
 
LogBuffer anonymous_namespace{logging.cc}::g_log_buffer
 

Function Documentation

void ClearLogBuffer ( )

Definition at line 539 of file logging.cc.

Here is the call graph for this function:

std::vector<LogBufferEntry> GetLogBuffer ( )

Definition at line 535 of file logging.cc.

Referenced by LogBufferXattr::FinalizeValue().

Here is the call graph for this function:

Here is the caller graph for this function:

std::string GetLogMicroSyslog ( )

Definition at line 308 of file logging.cc.

Referenced by PosixQuotaManager::CreateShared(), and Watchdog::Fork().

Here is the caller graph for this function:

int GetLogSyslogFacility ( )

Definition at line 214 of file logging.cc.

Referenced by PosixQuotaManager::CreateShared(), AuthzExternalFetcher::Handshake(), and SetLogSyslogShowPID().

Here is the caller graph for this function:

int GetLogSyslogLevel ( )

Definition at line 168 of file logging.cc.

Referenced by PosixQuotaManager::CreateShared(), and AuthzExternalFetcher::Handshake().

Here is the caller graph for this function:

static void LogCustom ( unsigned  id,
const std::string &  message 
)
static

Definition at line 585 of file logging.cc.

Referenced by vLogCvmfs().

Here is the call graph for this function:

Here is the caller graph for this function:

CVMFS_EXPORT void LogCvmfs ( const LogSource  source,
const int  mask,
const char *  format,
  ... 
)

Definition at line 528 of file logging.cc.

Referenced by publish::Abort(), PosixCacheManager::AbortTxn(), RamCacheManager::AbortTxn(), catalog::AbstractCatalogManager< CatalogT >::AcquireInodes(), ExternalCacheManager::AcquireQuotaManager(), RamCacheManager::AcquireQuotaManager(), publish::SyncMediator::Add(), catalog::CatalogBalancer< CatalogMgrT >::AddCatalog(), catalog::WritableCatalogManager::AddDirectory(), RamCacheManager::AddFd(), catalog::WritableCatalogManager::AddFile(), catalog::WritableCatalog::AddFileChunk(), catalog::WritableCatalogManager::AddHardlinkGroup(), publish::SyncDiffReporter::AddImpl(), swissknife::CommandEditTag::AddNewTag(), swissknife::CommandReconstructReflog::AddStaticManifestObjects(), cvmfs::AddToDirListing(), publish::AlterMountpoint(), swissknife::CommandMigrate::AnalyzeCatalogStatistics(), GarbageCollector< CatalogTraversalT, HashFilterT >::AnalyzePreservedCatalogTree(), sqlite::ApplyFdMap(), catalog::AbstractCatalogManager< CatalogT >::AttachCatalog(), AttachMount(), download::AutoProxy(), file_watcher::FileWatcher::BackgroundThread(), download::DownloadManager::Backoff(), s3fanout::S3FanoutManager::Backoff(), catalog::WritableCatalogManager::Balance(), PosixQuotaManager::BindReturnPipe(), QuotaManager::BroadcastBackchannels(), NfsMapsSqlite::BusyHandler(), signature::CallbackCertVerify(), s3fanout::CallbackCurlData(), download::CallbackCurlData(), s3fanout::CallbackCurlHeader(), download::CallbackCurlHeader(), s3fanout::S3FanoutManager::CallbackCurlSocket(), AuthzAttachment::CallbackSslCtx(), swissknife::CommandListReflog::CatalogCallback(), swissknife::CommandListCatalogs::CatalogCallback(), swissknife::CommandMigrate::CatalogCallback(), catalog::WritableCatalogManager::CatalogUploadCallback(), SigningTool::CertificateUploadCallback(), FuseRemounter::ChangeRoot(), catalog::AbstractCatalogManager< CatalogT >::ChangeRoot(), FuseRemounter::Check(), GarbageCollector< CatalogTraversalT, HashFilterT >::CheckAndSweep(), PosixQuotaManager::CheckFreeSpace(), CheckFuse(), publish::SyncItem::CheckGraft(), PosixQuotaManager::CheckHighPinWatermark(), PluginRamCache::CheckHighPinWatermark(), catalog::AbstractCatalogManager< CatalogT >::CheckInodeWatermark(), CheckMaxOpenFiles(), loader::CheckPremounted(), GarbageCollector< CatalogTraversalT, HashFilterT >::CheckPreservedRevisions(), CheckProxy(), CheckStrictMount(), swissknife::CommandGraft::ChecksumFdWithChunks(), anonymous_namespace{shrinkwrap.cc}::Params::CheckType(), cvmfs::CheckVoms(), PosixQuotaManager::CleanupPipes(), publish::CmdEnter::CleanupSession(), catalog::ClientCatalogManager::ClientCatalogManager(), catalog::WritableCatalogManager::CloneTreeImpl(), FdRefcountMgr::Close(), LibContext::Close(), RamCacheManager::Close(), sqlite::Database< DerivedT >::DatabaseRaiiWrapper::Close(), swissknife::CommandTag::CloseAndPublishHistory(), swissknife::CatalogTraversalBase< ObjectFetcherT >::CloseCatalog(), GarbageCollectorAux< CatalogTraversalT, HashFilterT >::CollectOlderThan(), catalog::WritableCatalog::Commit(), catalog::WritableCatalogManager::Commit(), publish::SyncMediator::Commit(), upload::SessionContextBase::CommitBucket(), publish::SyncDiffReporter::CommitReport(), RamCacheManager::CommitToKvStore(), ExternalCacheManager::CommitTxn(), PosixCacheManager::CommitTxn(), MemoryKvStore::CompactMemory(), swissknife::CommandCheck::CompareCounters(), swissknife::CommandCheck::CompareEntries(), publish::SyncMediator::CompleteHardlinks(), zlib::CompressFd2Null(), zlib::CompressFile2File(), zlib::CompressFile2Null(), zlib::CompressMem2File(), zlib::CompressPath2Path(), AuthzAttachment::ConfigureCurlHandle(), AuthzAttachment::ConfigureSciTokenCurl(), ExternalCacheManager::ConnectLocator(), ConnectTcpEndpoint(), anonymous_namespace{notification_client.cc}::ActivitySubscriber::Consume(), anonymous_namespace{cmd_sub.cc}::SwissknifeSubscriber::Consume(), receiver::PayloadProcessor::ConsumerEventCallback(), PosixQuotaManager::Contains(), shrinkwrap::copyFile(), NfsMapsSqlite::Create(), TalkManager::Create(), NfsMapsLeveldb::Create(), manifest::Reflog::Create(), PosixQuotaManager::Create(), upload::GatewayUploader::Create(), perf::TelemetryAggregator::Create(), ExternalCacheManager::Create(), history::SqliteHistory::Create(), sqlite::Database< DerivedT >::Create(), FileSystem::Create(), dns::CaresResolver::Create(), dns::HostfileResolver::Create(), upload::AbstractUploader::CreateAndOpenTemporaryChunkFile(), MountPoint::CreateCatalogManager(), swissknife::CommandApplyDirtab::CreateCatalogMarkers(), manifest::Reflog::CreateDatabase(), history::SqliteHistory::CreateDatabase(), MountPoint::CreateDownloadManagers(), ServerTool::CreateEmptyReflog(), receiver::CatalogMergeTool< RwCatalogMgr, RoCatalogMgr >::CreateNewManifest(), anonymous_namespace{commit_processor.cc}::CreateNewTag(), ExternalCacheManager::CreatePlugin(), catalog::WritableCatalogManager::CreateRepository(), MountPoint::CreateResolvConfWatcher(), PosixQuotaManager::CreateShared(), MountPoint::CreateSignatureManager(), swissknife::CommandEditTag::CreateTag(), MountPoint::CreateTracer(), publish::CmdEnter::CreateUnderlay(), RamCacheManager::CtrlTxn(), notify::SubscriberSSE::CurlProgressCB(), cvmfs_attach_repo(), cvmfs_attach_repo_v2(), cvmfs::cvmfs_destroy(), cvmfs::cvmfs_forget(), cvmfs::cvmfs_getattr(), cvmfs::cvmfs_getxattr(), cvmfs::cvmfs_init(), cvmfs_init_v2(), cvmfs::cvmfs_listxattr(), cvmfs::cvmfs_lookup(), cvmfs::cvmfs_open(), cvmfs::cvmfs_opendir(), cvmfs::cvmfs_read(), cvmfs::cvmfs_readdir(), cvmfs::cvmfs_readlink(), cvmfs::cvmfs_release(), cvmfs::cvmfs_releasedir(), cvmfs::cvmfs_statfs(), Daemonize(), zlib::DecompressFile2File(), zlib::DecompressZStream2File(), swissknife::CommandApplyDirtab::DetermineNestedCatalogCandidates(), InstanceInfo::DeterminePaths(), MountPoint::DetermineRootHash(), PosixQuotaManager::DoCleanup(), MemoryKvStore::DoCommit(), MemoryKvStore::DoDelete(), manifest::DoFetch(), PosixQuotaManager::DoInsert(), swissknife::CommandMigrate::DoMigrationAndCommit(), ExternalCacheManager::DoOpen(), RamCacheManager::DoOpen(), notify::DoPublish(), FileSystemTraversal< T >::DoRecursion(), upload::S3Uploader::DoRemoveAsync(), PosixCacheManager::DoRestoreState(), PluginRamCache::DoShrink(), notify::DoSubscribe(), cvmfs::DoTraceInode(), upload::LocalUploader::DoUpload(), upload::S3Uploader::DoUpload(), upload::GatewayUploader::DoUpload(), upload::SessionContext::DoUpload(), manifest::DoVerify(), HttpObjectFetcher< CatalogT, HistoryT, ReflogT >::Download(), swissknife::CommandCheck::DownloadPiece(), lru::InodeCache::Drop(), lru::PathCache::Drop(), lru::Md5PathCache::Drop(), DropBreadcrumbs(), sqlite::Database< DerivedT >::DropFileOwnership(), FdRefcountMgr::Dup(), RamCacheManager::Dup(), catalog::VirtualCatalog::EnsurePresence(), AuthzExternalFetcher::EnterFailState(), swissknife::Error(), download::DownloadManager::EscapeUrl(), AuthzExternalFetcher::ExecHelper(), sqlite::Sql::Execute(), swissknife::CommandCheck::Exists(), expand_path(), receiver::Reactor::ExtractStatsFromReq(), AuthzExternalFetcher::Fetch(), cvmfs::Fetcher::Fetch(), download::DownloadManager::Fetch(), manifest::Fetch(), LocalObjectFetcher< CatalogT, HistoryT, ReflogT >::Fetch(), swissknife::CommandCheck::FetchCatalog(), catalog::ClientCatalogManager::FetchCatalogByHash(), HttpObjectFetcher< CatalogT, HistoryT, ReflogT >::FetchManifest(), swissknife::Assistant::FetchObject(), swissknife::CommandTag::FetchObject(), ServerTool::FetchReflog(), ServerTool::FetchRemoteManifest(), sqlite::Database< DerivedT >::FileReadAhead(), swissknife::CommandApplyDirtab::FilterCandidatesFromGlobResult(), upload::SessionContextBase::Finalize(), receiver::PayloadProcessor::Finalize(), catalog::WritableCatalogManager::FinalizeCatalog(), upload::LocalUploader::FinalizeStreamedUpload(), upload::GatewayUploader::FinalizeStreamedUpload(), swissknife::CommandCheck::Find(), AuthzExternalFetcher::FindHelper(), NfsMapsSqlite::FindInode(), NfsMapsLeveldb::FindInode(), shrinkwrap::FindInterface(), swissknife::CommandMigrate::MigrationWorker_20x::FixNestedCatalogTransitionPoints(), catalog::WritableCatalogManager::FixWeight(), ExternalCacheManager::Flush(), lru::Md5PathCache::Forget(), notify::msg::Activity::FromJSONString(), FuseMain(), shrinkwrap::GarbageCollect(), StatisticsDatabase::GcExtendedStats(), signature::SignatureManager::GenerateKeyText(), catalog::VirtualCatalog::GenerateSnapshots(), download::DownloadManager::GeoSortServers(), LibContext::GetAttr(), PosixQuotaManager::GetCapacity(), GetCvmfsUser(), StatisticsDatabase::GetDBParams(), InstanceInfo::GetDefaultDomain(), cvmfs::GetDirentForInode(), LibContext::GetDirentForPath(), cvmfs::GetDirentForPath(), ResolvConfEventHandler::GetDnsAddresses(), LibContext::GetExtAttr(), swissknife::Assistant::GetHistory(), swissknife::CommandTag::GetHistory(), LibContext::GetNestedCatalogAttr(), catalog::ClientCatalogManager::GetNewRootCatalogContext(), GetNextFile(), GetNumberOfCpuCores(), receiver::GetParamsFromFile(), NfsMapsLeveldb::GetPath(), cvmfs::GetPathForInode(), AuthzSessionManager::GetPidInfo(), Pathspec::GetPrefixRegularExpression(), MemoryKvStore::GetRefcount(), Pathspec::GetRegularExpression(), Pathspec::GetRelaxedRegularExpression(), swissknife::CatalogTraversalBase< ObjectFetcherT >::GetRepositoryRootCatalogHash(), RamCacheManager::GetSize(), MemoryKvStore::GetSize(), swissknife::CommandEditTag::GetTagRootHash(), OptionsTemplateManager::GetTemplate(), GetWorkspace(), catalog::SqlLookupXattrs::GetXattrs(), shrinkwrap::handle_dir(), shrinkwrap::handle_file(), receiver::Reactor::HandleCheckToken(), receiver::Reactor::HandleCommit(), receiver::Reactor::HandleGenerateToken(), receiver::Reactor::HandleRequest(), CachePlugin::HandleRequest(), receiver::Reactor::HandleSubmitPayload(), OptionsManager::HasConfigRepository(), publish::SyncUnionOverlayfs::HasXattr(), catalog::InodeGenerationAnnotation::IncGeneration(), catalog::InodeNfsGenerationAnnotation::IncGeneration(), MemoryKvStore::IncRef(), IngestionPipeline::IngestionPipeline(), loader::loader_talk::Init(), CatalogDiffTool< RoCatalogMgr >::Init(), anonymous_namespace{cmd_sub.cc}::SwissknifeSubscriber::Init(), catalog::AbstractCatalogManager< CatalogT >::Init(), sqlite::Sql::Init(), Init(), PosixCacheManager::InitCacheDirectory(), PosixQuotaManager::InitDatabase(), catalog::ClientCatalogManager::InitFixed(), publish::SyncUnionTarball::Initialize(), upload::SessionContextBase::Initialize(), receiver::PayloadProcessor::Initialize(), LibGlobals::Initialize(), sqlite::Database< DerivedT >::Initialize(), ConcurrentWorkers< WorkerT >::Initialize(), s3fanout::S3FanoutManager::InitializeDnsSettings(), swissknife::CommandTag::InitializeEnvironment(), download::DownloadManager::InitializeRequest(), InitializeWarningFile(), ServerTool::InitSigningSignatureManager(), InitSystemFs(), ServerTool::InitVerifyingSignatureManager(), lru::InodeCache::Insert(), lru::PathCache::Insert(), lru::Md5PathCache::Insert(), publish::SyncMediator::InsertHardlink(), publish::SyncMediator::InsertLegacyHardlink(), catalog::VirtualCatalog::InsertSnapshot(), swissknife::CommandCheck::InspectHistory(), swissknife::CommandCheck::InspectReflog(), swissknife::CommandCheck::InspectTree(), download::Interrupted(), publish::SyncUnionOverlayfs::IsOpaqueDirPath(), catalog::ClientCatalogManager::IsRevisionBlacklisted(), NfsMapsSqlite::IssueInode(), publish::SyncUnionOverlayfs::IsWhiteoutSymlinkPath(), ConcurrentWorkers< WorkerT >::JobDone(), libcvmfs_initialize(), LibContext::ListDirectory(), LibContext::ListDirectoryStat(), CachePlugin::Listen(), LibContext::ListNestedCatalogs(), catalog::Catalog::ListNestedCatalogs(), history::SqliteHistory::ListTagsAffectedByRollback(), history::HistoryDatabase::LiveSchemaUpgradeIfNecessary(), StatisticsDatabase::LiveSchemaUpgradeIfNecessary(), catalog::CatalogDatabase::LiveSchemaUpgradeIfNecessary(), signature::SignatureManager::LoadBlacklist(), swissknife::CommandMigrate::LoadCatalogs(), loader::LoadLibrary(), signature::SignatureManager::LoadPublicRsaKeys(), LockFile(), LogCustom(), GarbageCollector< CatalogTraversalT, HashFilterT >::LogDeletion(), Watchdog::LogEmergency(), AuthzAttachment::LogOpenSSLErrors(), CachePlugin::LogSessionError(), CachePlugin::LogSessionInfo(), FileSystem::LogSqliteError(), lru::InodeCache::Lookup(), lru::PathCache::Lookup(), lru::Md5PathCache::Lookup(), AuthzSessionManager::LookupAuthzData(), catalog::AbstractCatalogManager< CatalogT >::LookupPath(), AuthzSessionManager::LookupSessionKey(), swissknife::CommandGc::Main(), swissknife::CommandInfo::Main(), swissknife::CommandLease::Main(), publish::CmdHelp::Main(), swissknife::CommandReconstructReflog::Main(), publish::CmdLsof::Main(), swissknife::CommandListReflog::Main(), swissknife::CommandListCatalogs::Main(), swissknife::CommandLetter::Main(), publish::CmdHash::Main(), publish::CmdInfo::Main(), swissknife::CommandVersion::Main(), publish::CmdAbort::Main(), swissknife::CommandGraft::Main(), publish::CmdCommit::Main(), swissknife::Ingest::Main(), swissknife::CommandPull::Main(), publish::CmdEnter::Main(), publish::CmdTransaction::Main(), swissknife::CommandCheck::Main(), swissknife::CommandFileStats::Main(), publish::CmdMkfs::Main(), swissknife::CommandEditTag::Main(), swissknife::CommandListTags::Main(), swissknife::CommandCreate::Main(), swissknife::CommandUpload::Main(), swissknife::CommandInfoTag::Main(), swissknife::CommandPeek::Main(), swissknife::CommandRollbackTag::Main(), swissknife::CommandRemove::Main(), swissknife::CommandEmptyRecycleBin::Main(), swissknife::CommandApplyDirtab::Main(), swissknife::CommandSync::Main(), swissknife::CommandMigrate::Main(), main(), PosixQuotaManager::MainCacheManager(), MainCheck(), glue::DentryTracker::MainCleaner(), upload::S3Uploader::MainCollectResults(), PosixQuotaManager::MainCommandServer(), download::DownloadManager::MainDownload(), FuseInvalidator::MainInvalidator(), swissknife::CommandFileStats::MainProcessing(), CachePlugin::MainProcessRequests(), ExternalCacheManager::MainRead(), loader::loader_talk::MainReload(), FuseRemounter::MainRemountTrigger(), download::MainResolveProxyDescription(), TalkManager::MainResponder(), loader::loader_talk::MainTalk(), perf::TelemetryAggregator::MainTelemetry(), quota::MainUnpinListener(), s3fanout::S3FanoutManager::MainUpload(), quota::MainWatchdogListener(), Watchdog::MainWatchdogListener(), swissknife::MainWorker(), shrinkwrap::MainWorker(), MakeAcquireRequest(), anonymous_namespace{repository_session.cc}::MakeAcquireRequest(), anonymous_namespace{repository_session.cc}::MakeDropRequest(), MakeEndRequest(), MakeSocket(), MakeTcpEndpoint(), ManagedExec(), swissknife::CommandEditTag::ManipulateTag(), MemoryMappedFile::Map(), publish::SyncUnionOverlayfs::MaskFileHardlinks(), SigningTool::MetainfoUploadCallback(), MkFqrn(), s3fanout::S3FanoutManager::MkV2Authz(), publish::SyncDiffReporter::ModifyImpl(), catalog::AbstractCatalogManager< CatalogT >::MountCatalog(), catalog::AbstractCatalogManager< CatalogT >::MountSubtree(), upload::LocalUploader::Move(), swissknife::CommandEditTag::MoveTag(), swissknife::ObtainDacReadSearchCapability(), publish::ObtainSysAdminCapabilityInternal(), anonymous_namespace{cmd_diff.cc}::DiffReporter::OnAdd(), MemoryKvStore::OnBlockMove(), anonymous_namespace{cmd_diff.cc}::DiffReporter::OnInit(), anonymous_namespace{cmd_diff.cc}::DiffReporter::OnModify(), anonymous_namespace{cmd_diff.cc}::DiffReporter::OnRemove(), anonymous_namespace{cmd_diff.cc}::DiffReporter::OnStats(), manifest::Reflog::Open(), FileIngestionSource::Open(), PosixCacheManager::Open(), LibContext::Open(), sqlite::Database< DerivedT >::Open(), catalog::Dirtab::Open(), history::SqliteHistory::Open(), catalog::Catalog::OpenDatabase(), history::SqliteHistory::OpenDatabase(), sqlite::Database< DerivedT >::OpenDatabase(), ExternalCacheManager::OpenFromTxn(), RamCacheManager::OpenFromTxn(), perf::TelemetryAggregatorInflux::OpenSocket(), StatisticsDatabase::OpenStandardDB(), download::PacProxy2Cvmfs(), Panic(), JsonDocument::Parse(), ParseAcquireReply(), anonymous_namespace{repository_session.cc}::ParseAcquireReply(), ParseDropReply(), anonymous_namespace{repository_session.cc}::ParseDropReply(), loader::ParseFuseOptions(), dns::HostfileResolver::ParseHostFile(), AuthzExternalFetcher::ParseMsg(), AuthzExternalFetcher::ParseMsgId(), publish::Command::ParseOptions(), download::ParsePac(), BashOptionsManager::ParsePath(), AuthzExternalFetcher::ParsePermit(), AuthzExternalFetcher::ParseRevision(), upload::GatewayUploader::ParseSpoolerDefinition(), upload::S3Uploader::ParseSpoolerDefinition(), whitelist::Whitelist::ParseWhitelist(), catalog::CatalogBalancer< CatalogMgrT >::PartitionOptimally(), PosixQuotaManager::Pin(), PluginRamCache::PluginRamCache(), OptionsManager::PopulateParameter(), posix_archive_config(), posix_archive_provenance(), posix_do_link(), posix_initialize(), LibContext::Pread(), RamCacheManager::Pread(), swissknife::CatalogTraversalBase< ObjectFetcherT >::PrepareCatalog(), download::PrepareDownloadDestination(), ChunkListMagicXattr::PrepareValueFenced(), ChunksMagicXattr::PrepareValueFenced(), GarbageCollector< CatalogTraversalT, HashFilterT >::PreserveDataObjects(), swissknife::CommandScrub::PrintAlert(), GarbageCollector< CatalogTraversalT, HashFilterT >::PrintCatalogTreeEntry(), swissknife::CommandRollbackTag::PrintDeletedTagList(), publish::SyncDiffReporter::PrintDots(), PrintError(), swissknife::CommandListTags::PrintHumanReadableBranchList(), swissknife::CommandInfoTag::PrintHumanReadableInfo(), swissknife::CommandListTags::PrintHumanReadableTagList(), swissknife::CommandListTags::PrintMachineReadableBranchList(), download::PrintPacError(), Pathspec::PrintRegularExpressionError(), sqlite::Database< DerivedT >::PrintSqlError(), swissknife::CommandMigrate::PrintStatusMessage(), swissknife::CommandTag::PrintTagMachineReadable(), PrintVersion(), PrintWarning(), download::DownloadManager::ProbeHosts(), receiver::CommitProcessor::Process(), TaskRegister::Process(), receiver::PayloadProcessor::Process(), publish::SyncUnion::ProcessBlockDevice(), publish::SyncUnion::ProcessCharacterDevice(), PosixQuotaManager::ProcessCommandBunch(), publish::SyncUnion::ProcessFifo(), publish::SyncUnion::ProcessFile(), publish::SyncUnion::ProcessRegularFile(), publish::SyncUnion::ProcessSocket(), publish::SyncUnion::ProcessSymlink(), StatisticsDatabase::Prune(), notify::PublisherHTTP::Publish(), swissknife::CommandGraft::Publish(), publish::SyncMediator::PublishFilesCallback(), publish::SyncMediator::PublishHardlinksCallback(), swissknife::CommandPull::Pull(), swissknife::CommandPull::PullRecursion(), NfsMapsLeveldb::PutInode2Path(), NfsMapsLeveldb::PutPath2Inode(), RamCacheManager::RamCacheManager(), FileIngestionSource::Read(), MemoryKvStore::Read(), TarIngestionSource::Read(), PosixCacheManager::Readahead(), RamCacheManager::Readahead(), ReadCmdLineArguments(), LibContext::Readlink(), publish::SyncUnionOverlayfs::ReadlinkEquals(), ReadResponse(), upload::GatewayUploader::ReadSessionTokenFile(), AuthzExternalFetcher::ReapHelper(), PosixQuotaManager::RebuildDatabase(), AuthzExternalFetcher::Recv(), file_watcher::FileWatcher::RegisterFilter(), loader::Reload(), LibContext::Remount(), catalog::AbstractCatalogManager< CatalogT >::Remount(), catalog::AbstractCatalogManager< CatalogT >::RemountDryrun(), catalog::VirtualCatalog::Remove(), swissknife::CommandMigrate::MigrationWorker_20x::RemoveDanglingNestedMountpoints(), catalog::WritableCatalogManager::RemoveDirectory(), publish::SyncMediator::RemoveFile(), publish::SyncDiffReporter::RemoveImpl(), catalog::VirtualCatalog::RemoveSnapshot(), swissknife::CommandEditTag::RemoveTags(), PosixCacheManager::Rename(), swissknife::CatalogTraversalBase< ObjectFetcherT >::ReopenCatalog(), cvmfs::ReplyNegative(), swissknife::ReportDownloadError(), Watchdog::ReportSignalAndTerminate(), RamCacheManager::Reset(), dns::Resolver::ResolveMany(), download::ResolveProxyDescription(), RestoreState(), NfsMapsSqlite::RetryGetInode(), history::SqliteHistory::Rollback(), SigningTool::Run(), NotificationClient::Run(), receiver::Reactor::Run(), swissknife::CommandListReflog::Run(), ConcurrentWorkers< WorkerT >::RunCallbackThreadWrapper(), file_watcher::FileWatcherInotify::RunEventLoop(), file_watcher::FileWatcherKqueue::RunEventLoop(), RunGarbageCollection(), ConcurrentWorkers< WorkerT >::RunWorker(), MagicXattrManager::SanityCheckProtectedXattrs(), SaveState(), NfsMapsLeveldb::ForkAwareEnv::Schedule(), ConcurrentWorkers< WorkerT >::Schedule(), SendCommand(), CacheTransport::SendData(), cvmfs::SendFuseFd(), perf::TelemetryAggregatorInflux::SendToInflux(), Watchdog::SendTrace(), ResolvConfEventHandler::SetDnsAddress(), download::DownloadManager::SetDnsServer(), NfsMaps::SetInodeResidue(), SetLogCustomFile(), FuseRemounter::SetOfflineMode(), download::DownloadManager::SetProxyChain(), download::DownloadManager::SetShardingPolicy(), MountPoint::SetupBehavior(), FileSystem::SetupCacheMgr(), FileSystem::SetupCrashGuard(), FileSystem::SetupPosixQuotaMgr(), FileSystem::SetupUuid(), download::DownloadManager::SetUrlOptions(), swissknife::CommandScrub::ShowAlertsHelpMessage(), MemoryKvStore::ShrinkTo(), catalog::WritableCatalogManager::SnapshotCatalogs(), catalog::WritableCatalogManager::SnapshotCatalogsSerialized(), NotificationClient::Spawn(), Watchdog::Spawn(), perf::TelemetryAggregator::Spawn(), download::DownloadManager::Spawn(), s3fanout::S3FanoutManager::Spawn(), ExternalCacheManager::SpawnPlugin(), ConcurrentWorkers< WorkerT >::SpawnWorkers(), SplitHardlink(), upload::SpoolerDefinition::SpoolerDefinition(), catalog::AbstractCatalogManager< CatalogT >::StageNestedCatalogAndUnlock(), PosixCacheManager::StartTxn(), RamCacheManager::StartTxn(), StatisticsDatabase::StoreEntry(), upload::LocalUploader::StreamedUpload(), upload::GatewayUploader::StreamedUpload(), AuthzExternalFetcher::StripAuthzSchema(), notify::SubscriberSSE::Subscribe(), GarbageCollectorAux< CatalogTraversalT, HashFilterT >::Sweep(), GarbageCollector< CatalogTraversalT, HashFilterT >::SweepDataObjects(), GarbageCollector< CatalogTraversalT, HashFilterT >::SweepReflog(), SwitchCredentials(), download::DownloadManager::SwitchHost(), download::DownloadManager::SwitchProxy(), publish::Sync(), shrinkwrap::Sync(), shrinkwrap::SyncFull(), shrinkwrap::SyncInit(), sqlite::Database< DerivedT >::TakeFileOwnership(), notify::SubscriberSupervisor::Task(), FileSystem::TearDown2ReadOnly(), perf::TelemetryAggregatorInflux::TelemetryAggregatorInflux(), ConcurrentWorkers< WorkerT >::Terminate(), BackoffThrottle::Throttle(), catalog::WritableCatalogManager::TouchDirectory(), catalog::WritableCatalog::Transaction(), publish::TransactionImpl(), publish::TransactionRetry(), publish::SyncUnionAufs::Traverse(), publish::SyncUnionOverlayfs::Traverse(), publish::SyncUnionTarball::Traverse(), swissknife::CatalogTraversalBase< ObjectFetcherT >::TraverseNamedSnapshots(), FuseRemounter::TryFinish(), PluginRamCache::TryFreeSpace(), SimpleOptionsParser::TryParsePath(), anonymous_namespace{repository_abort.cc}::TrySessionDrop(), auto_umount::UmountOnCrash(), catalog::ClientCatalogManager::UnloadCatalog(), MemoryMappedFile::Unmap(), PosixQuotaManager::Unpin(), MemoryKvStore::Unref(), download::DownloadManager::UpdateProxiesUnlocked(), swissknife::CommandTag::UpdateUndoTags(), history::HistoryDatabase::UpgradeSchemaRevision_10_1(), history::HistoryDatabase::UpgradeSchemaRevision_10_2(), history::HistoryDatabase::UpgradeSchemaRevision_10_3(), swissknife::CommandTag::UploadCatalogAndUpdateManifest(), swissknife::CommandTag::UploadClosure(), swissknife::CommandMigrate::UploadHistoryClosure(), upload::S3Uploader::UploadJobInfo(), StatisticsDatabase::UploadStatistics(), swissknife::Usage(), anonymous_namespace{shrinkwrap.cc}::Usage(), loader::Usage(), Usage(), catalog::WritableCatalog::VacuumDatabaseIfNecessary(), anonymous_namespace{swissknife_notify.cc}::ValidateArgs(), download::DownloadManager::ValidateProxyIpsUnlocked(), s3fanout::S3FanoutManager::VerifyAndFinalize(), download::DownloadManager::VerifyAndFinalize(), signature::SignatureManager::VerifyPkcs7(), signature::SignatureManager::VerifyRsa(), whitelist::Whitelist::VerifyWhitelist(), sqlite::VfsRdOnlyOpen(), ConcurrentWorkers< WorkerT >::WaitForEmptyQueue(), WaitForReload(), Watchdog::WaitForSupervisee(), swissknife::RootChainWalker::WalkCatalogsInHistory(), swissknife::RootChainWalker::WalkHistories(), swissknife::RootChainWalker::WalkRootCatalogs(), ExternalCacheManager::Write(), PosixCacheManager::Write(), RamCacheManager::Write(), AuthzExternalFetcher::~AuthzExternalFetcher(), catalog::ClientCatalogManager::~ClientCatalogManager(), download::DownloadManager::~DownloadManager(), NfsMapsLeveldb::~NfsMapsLeveldb(), sqlite::Sql::~Sql(), TalkManager::~TalkManager(), and Watchdog::~Watchdog().

Here is the call graph for this function:

static void LogMicroSyslog ( const std::string &  message)
static

Definition at line 316 of file logging.cc.

Referenced by vLogCvmfs().

Here is the call graph for this function:

Here is the caller graph for this function:

void LogShutdown ( )

Definition at line 606 of file logging.cc.

Here is the call graph for this function:

void PrintError ( const string &  message)
void PrintWarning ( const string &  message)

Definition at line 547 of file logging.cc.

Referenced by publish::SyncMediator::Add(), publish::SyncItem::MarkAsWhiteout(), publish::SyncMediator::Remove(), and publish::SyncMediator::Touch().

Here is the call graph for this function:

Here is the caller graph for this function:

void SetAltLogFunc ( void(*)(const LogSource source, const int mask, const char *msg)  fn)

Changes the debug log file from stderr. No effect if DEBUGMSG is undefined.

Definition at line 408 of file logging.cc.

Referenced by cvmfs_set_log_fn(), and download::MainResolveProxyDescription().

Here is the caller graph for this function:

void SetLogCustomFile ( unsigned  id,
const std::string &  filename 
)

Opens a custom log file

Definition at line 555 of file logging.cc.

Referenced by LogShutdown().

Here is the call graph for this function:

Here is the caller graph for this function:

void SetLogMicroSyslog ( const std::string &  filename)

"Micro-Syslog" write kLogSyslog messages into filename. It rotates this file. Requires for µCernVM

Definition at line 272 of file logging.cc.

Referenced by Watchdog::Fork(), FuseMain(), LogShutdown(), main(), PosixQuotaManager::MainCacheManager(), loader::loader_talk::MainTalk(), FileSystem::SetupLoggingStandalone(), FileSystem::TearDown2ReadOnly(), and FileSystem::~FileSystem().

Here is the call graph for this function:

Here is the caller graph for this function:

void SetLogMicroSyslogMaxSize ( unsigned  bytes)

Definition at line 264 of file logging.cc.

void SetLogSyslogFacility ( const int  local_facility)

Sets the syslog facility to one of local0 .. local7. Falls back to LOG_USER if local_facility is not in [0..7]

Definition at line 183 of file logging.cc.

Referenced by FuseMain(), main(), PosixQuotaManager::MainCacheManager(), and FileSystem::SetupLoggingStandalone().

Here is the caller graph for this function:

void SetLogSyslogLevel ( const int  level)

Sets the level that is used for all messages to the syslog facility.

Definition at line 151 of file logging.cc.

Referenced by FuseMain(), main(), PosixQuotaManager::MainCacheManager(), and FileSystem::SetupLoggingStandalone().

Here is the caller graph for this function:

void SetLogSyslogPrefix ( const std::string &  prefix)

The syslog prefix is used to distinguish multiple repositories in /var/log/messages

Definition at line 241 of file logging.cc.

Referenced by FuseMain(), main(), FileSystem::SetupLoggingStandalone(), and FileSystem::~FileSystem().

Here is the caller graph for this function:

void SetLogSyslogShowPID ( bool  flag)

Definition at line 254 of file logging.cc.

Referenced by main().

Here is the call graph for this function:

Here is the caller graph for this function:

void SetLogVerbosity ( const LogLevels  max_level)

Set the maximum verbosity level. By default kLogNormal.

Definition at line 261 of file logging.cc.

Referenced by swissknife::CommandInfo::Main(), swissknife::CommandPull::Main(), swissknife::CommandCheck::Main(), swissknife::CommandCreate::Main(), and swissknife::CommandSync::Main().

Here is the caller graph for this function:

CVMFS_EXPORT void vLogCvmfs ( const LogSource  source,
const int  mask,
const char *  format,
va_list  variadic_list 
)

Logs a message to one or multiple facilities specified by mask. Mask can be extended by a log level in the future, using the higher bits.

Parameters
[in]sourceComponent that triggers the logging
[in]maskBit mask of log facilities
[in]formatFormat string followed by arguments like printf

Definition at line 423 of file logging.cc.

Referenced by LogCvmfs().

Here is the call graph for this function:

Here is the caller graph for this function: