Thrill  0.1
logger.hpp File Reference
+ Include dependency graph for logger.hpp:
+ This graph shows which files directly or indirectly include this file:

Go to the source code of this file.

Namespaces

 tlx
 

Macros

#define LOG   LOGC(debug)
 Default logging method: output if the local debug variable is true. More...
 
#define LOG0   LOGC(false)
 Override default output: never or always output log. More...
 
#define LOG1   LOGC(true)
 
#define LOGC(cond)   TLX_LOGC(cond)
 Explicitly specify the condition for logging. More...
 
#define sLOG   sLOGC(debug)
 Default logging method: output if the local debug variable is true. More...
 
#define sLOG0   sLOGC(false)
 Override default output: never or always output log. More...
 
#define sLOG1   sLOGC(true)
 
#define sLOGC(cond)   TLX_sLOGC(cond)
 Explicitly specify the condition for logging. More...
 

Macro Definition Documentation

◆ LOG

#define LOG   LOGC(debug)

Default logging method: output if the local debug variable is true.

Definition at line 24 of file logger.hpp.

Referenced by Socket::accept(), Dispatcher::AddAsyncRequest(), AlignedAllocator< Byte, thrill::mem::Allocator< char > >::allocate_bytes(), FlowControlChannel::AllReduce(), Group::AllReduceMaximumInt(), Group::AllReduceMaximumLong(), Group::AllReduceMaximumLongLong(), Group::AllReduceMaximumUnsignedInt(), Group::AllReduceMaximumUnsignedLong(), Group::AllReduceMaximumUnsignedLongLong(), Group::AllReduceMinimumInt(), Group::AllReduceMinimumLong(), Group::AllReduceMinimumLongLong(), Group::AllReduceMinimumUnsignedInt(), Group::AllReduceMinimumUnsignedLong(), Group::AllReduceMinimumUnsignedLongLong(), Group::AllReducePlusInt(), Group::AllReducePlusLong(), Group::AllReducePlusLongLong(), Group::AllReducePlusUnsignedInt(), Group::AllReducePlusUnsignedLong(), Group::AllReducePlusUnsignedLongLong(), BlockQueue::AppendBlock(), StreamSink::AppendBlock(), MixBlockQueue::AppendBlock(), StreamSink::AppendPinnedBlock(), Dispatcher::AsyncRead(), FlowControlChannel::Barrier(), BernoulliSampleNode< ValueType >::BernoulliSampleNode(), Socket::bind(), BlockQueueSink::BlockQueueSink(), FlowControlChannel::Broadcast(), Group::BroadcastInt(), Group::BroadcastLong(), Group::BroadcastLongLong(), Group::BroadcastUnsignedInt(), Group::BroadcastUnsignedLong(), Group::BroadcastUnsignedLongLong(), SampleNode< ValueType >::calc_local_samples(), Dispatcher::Cancel(), SelectDispatcher::Cancel(), StreamSink::Close(), MixStreamData::Close(), MixBlockQueue::Close(), CatStreamData::Close(), Socket::close(), Socket::connect(), Group::ConstructLoopbackMesh(), Socket::Create(), Dispatcher::Dispatch(), SelectDispatcher::DispatchOne(), Dispatcher::DispatchOne(), ZipNode< ValueType, ZipFunction, Pad, UnequalCheck, NoRebalance, kNumInputs >::DoScatter(), ZipWindowNode< ValueType, ZipFunction_, Pad_, UnequalCheck, UseStdArray, kNumInputs_ >::DoScatter(), SizeNode< ValueType >::Execute(), RebalanceNode< ValueType >::Execute(), PrefixSumNode< ValueType, SumFunction, Inclusive >::Execute(), ConcatNode< ValueType >::Execute(), Group::ExPrefixSumPlusInt(), Group::ExPrefixSumPlusLong(), Group::ExPrefixSumPlusLongLong(), Group::ExPrefixSumPlusUnsignedInt(), Group::ExPrefixSumPlusUnsignedLong(), Group::ExPrefixSumPlusUnsignedLongLong(), FlowControlChannel::ExPrefixSumTotal(), FileBlockSink::FileBlockSink(), SortNode< ValueType, CompareFunction, SortAlgorithm, Stable >::FindAndSendSplitters(), thrill::api::FindStages(), ReduceByHashPostPhase< TableItem, Key, ValueType, KeyExtractor, ReduceFunction, thrill::api::ReduceNode::Emitter, VolatileKey, ReduceConfig, thrill::core::ReduceByHash, KeyEqualFunction >::Flush(), LocationDetection< thrill::api::JoinNode::HashCount >::Flush(), ReduceOldProbingHashTable< TableItem, Key, Value, KeyExtractor, ReduceFunction, Emitter, VolatileKey, ReduceConfig_, IndexFunction, KeyEqualFunction >::FlushPartitionEmit(), ReduceProbingHashTable< TableItem, Key, Value, KeyExtractor, ReduceFunction, Emitter, VolatileKey, ReduceConfig_, IndexFunction, KeyEqualFunction >::FlushPartitionEmit(), ReduceBucketHashTable< TableItem, Key, Value, KeyExtractor, ReduceFunction, Emitter, VolatileKey, ReduceConfig, IndexFunction, KeyEqualFunction >::FlushPartitionEmit(), File::GetIndexOf(), Socket::GetLocalAddress(), Socket::GetPeerAddress(), Socket::getsockopt(), ReadLinesNode::InputLineIteratorCompressed::HasNext(), ReduceByIndexPostPhase< TableItem, Key, ValueType, KeyExtractor, ReduceFunction, thrill::api::ReduceToIndexNode::Emitter, VolatileKey, ReduceConfig >::Initialize(), ReadLinesNode::InputLineIteratorCompressed::InputLineIteratorCompressed(), ReduceByIndexPostPhase< TableItem, Key, ValueType, KeyExtractor, ReduceFunction, thrill::api::ReduceToIndexNode::Emitter, VolatileKey, ReduceConfig >::Insert(), ReduceProbingHashTable< TableItem, Key, Value, KeyExtractor, ReduceFunction, Emitter, VolatileKey, ReduceConfig_, IndexFunction, KeyEqualFunction >::Insert(), Multiplexer::IntReleaseCatStream(), Multiplexer::IntReleaseMixStream(), Dispatcher::IRecv(), Dispatcher::ISend(), Socket::listen(), GroupToIndexNode< ValueType, KeyExtractor, GroupFunction >::MainOp(), GroupByNode< ValueType, KeyExtractor, GroupFunction, HashFunction, UseLocationDetection >::MainOp(), MergeNode< ValueType, Comparator, kNumInputs >::MainOp(), BlockPool::max_total_bytes(), ReadLinesNode::InputLineIteratorUncompressed::Next(), ReadLinesNode::InputLineIteratorCompressed::Next(), ConsumeBlockQueueSource::NextBlock(), CacheBlockQueueSource::NextBlock(), ReadBinaryNode< ValueType >::VfsFileBlockSource::NextBlock(), Multiplexer::OnMultiplexerHeader(), CatStreamData::OnStreamBlock(), StreamData::OnWriterClosed(), StreamSet< StreamData >::OnWriterClosed(), BernoulliSampleNode< ValueType >::operator()(), examples::select::PickPivots(), PinnedBlock::PinnedBlock(), MixBlockQueue::Pop(), FlowControlChannel::Predecessor(), FlowControlChannel::PrefixSumBase(), Group::PrefixSumPlusInt(), Group::PrefixSumPlusLong(), Group::PrefixSumPlusLongLong(), Group::PrefixSumPlusUnsignedInt(), Group::PrefixSumPlusUnsignedLong(), Group::PrefixSumPlusUnsignedLongLong(), PrefixSumNode< ValueType, SumFunction, Inclusive >::PreOp(), WriteLinesNode< ValueType >::PreOp(), MixBlockQueueReader::PullBlock(), Dispatcher::PumpRecvQueue(), Dispatcher::PumpSendQueue(), GroupByNode< ValueType, KeyExtractor, GroupFunction, HashFunction, UseLocationDetection >::PushData(), ReadBinaryNode< ValueType >::PushData(), ConcatNode< ValueType >::PushData(), ReadBinaryNode< ValueType >::ReadBinaryNode(), ReadLinesNode::InputLineIterator::ReadBlock(), Socket::recv(), Socket::recv_one(), Socket::recvfrom(), FlowControlChannel::Reduce(), DIABase::RunScope(), RunSelect(), GroupByNode< ValueType, KeyExtractor, GroupFunction, HashFunction, UseLocationDetection >::RunUserFunc(), examples::select::Select(), MergeNode< ValueType, Comparator, kNumInputs >::SelectPivots(), Socket::send(), Socket::send_one(), Socket::sendto(), Socket::SetKeepAlive(), Socket::SetNoDelay(), Socket::SetNonBlocking(), Socket::SetRcvBuf(), Socket::SetReuseAddr(), Socket::SetSndBuf(), Socket::setsockopt(), SortNode< ValueType, CompareFunction, SortAlgorithm, Stable >::SortAndWriteToFile(), ReduceOldProbingHashTable< TableItem, Key, Value, KeyExtractor, ReduceFunction, Emitter, VolatileKey, ReduceConfig_, IndexFunction, KeyEqualFunction >::SpillPartition(), ReduceProbingHashTable< TableItem, Key, Value, KeyExtractor, ReduceFunction, Emitter, VolatileKey, ReduceConfig_, IndexFunction, KeyEqualFunction >::SpillPartition(), ReduceNode< ValueType, KeyExtractor, ReduceFunction, ReduceConfig, KeyHashFunction, KeyEqualFunction, VolatileKey, UseDuplicateDetection >::StartPreOp(), UnionNode< ValueType >::StartPreOp(), JoinNode< ValueType, FirstDIA, SecondDIA, KeyExtractor1, KeyExtractor2, JoinFunction, HashFunction, UseLocationDetection >::StartPreOp(), ZipNode< ValueType, ZipFunction, Pad, UnequalCheck, NoRebalance, kNumInputs >::StopPreOp(), ReduceNode< ValueType, KeyExtractor, ReduceFunction, ReduceConfig, KeyHashFunction, KeyEqualFunction, VolatileKey, UseDuplicateDetection >::StopPreOp(), ReduceToIndexNode< ValueType, KeyExtractor, ReduceFunction, ReduceConfig, VolatileKey, SkipPreReducePhase >::StopPreOp(), ZipWindowNode< ValueType, ZipFunction_, Pad_, UnequalCheck, UseStdArray, kNumInputs_ >::StopPreOp(), UnionNode< ValueType >::StopPreOp(), JoinNode< ValueType, FirstDIA, SecondDIA, KeyExtractor1, KeyExtractor2, JoinFunction, HashFunction, UseLocationDetection >::StopPreOp(), Connection::SyncRecv(), Connection::SyncSend(), Connection::SyncSendRecv(), BlockPool::total_blocks(), DispatcherThread::Work(), BlockQueueSink::~BlockQueueSink(), CatStreamData::~CatStreamData(), Dispatcher::~Dispatcher(), FileBlockSink::~FileBlockSink(), MixStreamData::~MixStreamData(), and PinnedBlock::~PinnedBlock().

◆ LOG0

◆ LOG1

#define LOG1   LOGC(true)

Definition at line 28 of file logger.hpp.

Referenced by AlignedAllocator< Byte, thrill::mem::Allocator< char > >::allocate_bytes(), examples::suffix_sorting::CheckSA(), Multiplexer::Close(), CountTrianglesGenerated(), Socket::CreatePair(), thrill::common::CreateThread(), Dispatcher::DispatchOne(), doubleSweepDiameter(), SelectDispatcher::Interrupt(), JoinNode< ValueType, FirstDIA, SecondDIA, KeyExtractor1, KeyExtractor2, JoinFunction, HashFunction, UseLocationDetection >::JoinAllElements(), JoinTPCH4(), Context::Launch(), main(), MergeNode< ValueType, Comparator, kNumInputs >::MainOp(), ZipfDistribution::make_dist(), AsyncWriteBuffer::operator()(), AsyncWriteBlock::operator()(), StochasticGradientDescent< Vector >::optimize(), thrill::data::OurNewHandler(), Percentiles(), examples::suffix_sorting::PrefixDoublingDiscarding(), examples::suffix_sorting::PrefixDoublingPack(), examples::suffix_sorting::PrefixDoublingSorting(), examples::suffix_sorting::PrefixDoublingWindow(), examples::suffix_sorting::PrefixQuadrupling(), examples::suffix_sorting::PrefixQuadruplingDiscarding(), Context::PrintCollectiveMeanStdev(), MergeNode< ValueType, Comparator, kNumInputs >::Stats::PrintToSQLPlotTool(), ConcatNode< ValueType >::PrintWarning(), BlockPool::RequestInternalMemory(), Buffer::Resize(), RunHashWordCount(), RunJoinPageRankEdgePerLine(), RunKMeansFile(), RunKMeansGenerated(), RunPageRankEdgePerLine(), RunPageRankGenerated(), RunPageRankJoinGenerated(), RunStochasticGradFile(), RunStochasticGradGenerated(), RunWordCount(), SelectDispatcher::SelectDispatcher(), thrill::common::SetCpuAffinity(), thrill::vfs::SysGlob(), thrill::vfs::SysOpenReadStream(), thrill::vfs::SysOpenWriteStream(), and Dispatcher::~Dispatcher().

◆ LOGC

#define LOGC (   cond)    TLX_LOGC(cond)

Explicitly specify the condition for logging.

Definition at line 21 of file logger.hpp.

Referenced by BlockPool::AdviseFree(), BlockPool::AllocateByteBlock(), AsyncReadBuffer::AsyncReadBuffer(), AsyncReadByteBlock::AsyncReadByteBlock(), AsyncRequest::AsyncRequest(), AsyncWriteBlock::AsyncWriteBlock(), AsyncWriteBuffer::AsyncWriteBuffer(), BlockPool::DecBlockPinCount(), BlockPool::DestroyBlock(), BlockPool::EvictBlockLRU(), MixStreamData::GetWriters(), CatStreamData::GetWriters(), ReduceBucketHashTable< TableItem, Key, Value, KeyExtractor, ReduceFunction, Emitter, VolatileKey, ReduceConfig, IndexFunction, KeyEqualFunction >::Insert(), BlockPool::IntIncBlockPinCount(), BlockPool::MapExternalBlock(), SizeNode< ValueType >::OnPreOpFile(), RebalanceNode< ValueType >::OnPreOpFile(), CacheNode< ValueType >::OnPreOpFile(), PrefixSumNode< ValueType, SumFunction, Inclusive >::OnPreOpFile(), CollapseNode< ValueType >::OnPreOpFile(), AllGatherNode< ValueType >::OnPreOpFile(), ZipWithIndexNode< ValueType, ZipFunction >::OnPreOpFile(), BaseWindowNode< ValueType, Input, WindowFunction, PartialWindowFunction >::OnPreOpFile(), ZipNode< ValueType, ZipFunction, Pad, UnequalCheck, NoRebalance, kNumInputs >::OnPreOpFile(), SortNode< ValueType, CompareFunction, SortAlgorithm, Stable >::OnPreOpFile(), ConcatNode< ValueType >::OnPreOpFile(), ZipWindowNode< ValueType, ZipFunction_, Pad_, UnequalCheck, UseStdArray, kNumInputs_ >::OnPreOpFile(), BlockPool::OnReadComplete(), BlockPool::OnWriteComplete(), AsyncReadBuffer::operator()(), AsyncWriteBuffer::operator()(), AsyncReadByteBlock::operator()(), AsyncWriteBlock::operator()(), BlockPool::PinBlock(), SampleNode< ValueType >::PushData(), BlockPool::ReleaseInternalMemory(), BlockPool::RequestInternalMemory(), AsyncReadBuffer::~AsyncReadBuffer(), AsyncReadByteBlock::~AsyncReadByteBlock(), AsyncRequest::~AsyncRequest(), AsyncWriteBlock::~AsyncWriteBlock(), AsyncWriteBuffer::~AsyncWriteBuffer(), and BlockPool::~BlockPool().

◆ sLOG

#define sLOG   sLOGC(debug)

Default logging method: output if the local debug variable is true.

Definition at line 34 of file logger.hpp.

Referenced by ReservoirSamplingGrow< SampleIndexPair >::add(), BlockWriter< BlockSink >::AllocateBlock(), WriteBinaryNode< ValueType >::SysFileSink::AppendPinnedBlock(), Group::BroadcastBinomialTree(), CatStreamData::Close(), ReducePrePhaseEmitter< TableItem, VolatileKey, BlockWriter >::CloseAll(), Group::ConstructLocalRealTCPMesh(), examples::suffix_sorting::ConstructWaveletTree(), ConstructWaveletTree(), Dispatcher::Dispatch(), Dispatcher::DispatchOne(), Sampling< RNG >::do_sample(), RebalanceNode< ValueType >::Execute(), SampleNode< ValueType >::Execute(), ZipWithIndexNode< ValueType, ZipFunction >::Execute(), OverlapWindowNode< ValueType, Input, WindowFunction, PartialWindowFunction >::Execute(), ConcatNode< ValueType >::Execute(), DisjointWindowNode< ValueType, Input, WindowFunction, PartialWindowFunction >::Execute(), thrill::vfs::FillFilePattern(), DuplicateDetection::FindNonDuplicates(), ReduceByHashPostPhase< TableItem, Key, ValueType, KeyExtractor, ReduceFunction, thrill::api::ReduceNode::Emitter, VolatileKey, ReduceConfig, thrill::core::ReduceByHash, KeyEqualFunction >::Flush(), BlockWriter< BlockSink >::Flush(), BlockQueue::GetBlockSource(), BlockReader< CatBlockSource >::GetItemBatch(), File::GetReaderAt(), ReduceProbingHashTable< TableItem, Key, Value, KeyExtractor, ReduceFunction, Emitter, VolatileKey, ReduceConfig_, IndexFunction, KeyEqualFunction >::GrowPartition(), Sampling< RNG >::hash_sample(), ReduceBucketHashTable< TableItem, Key, Value, KeyExtractor, ReduceFunction, Emitter, VolatileKey, ReduceConfig, IndexFunction, KeyEqualFunction >::Initialize(), ReadLinesNode::InputLineIteratorCompressed::InputLineIteratorCompressed(), ReadLinesNode::InputLineIteratorUncompressed::InputLineIteratorUncompressed(), Multiplexer::IntReleaseCatStream(), Multiplexer::IntReleaseMixStream(), LocationDetection< thrill::api::JoinNode::HashCount >::LocationDetection(), CatStreamData::loopback_queue(), ZipNode< ValueType, ZipFunction, Pad, UnequalCheck, NoRebalance, kNumInputs >::MainOp(), ZipWindowNode< ValueType, ZipFunction_, Pad_, UnequalCheck, UseStdArray, kNumInputs_ >::MainOp(), SortNode< ValueType, CompareFunction, SortAlgorithm, Stable >::MainOp(), Multiplexer::OnCatStreamBlock(), Multiplexer::OnMixStreamBlock(), Multiplexer::OnMultiplexerHeader(), SortNode< ValueType, CompareFunction, SortAlgorithm, Stable >::OnPreOpFile(), MixStreamData::OnStreamBlock(), CatStreamData::OnStreamBlock(), MixStreamData::OnStreamBlockOrdered(), CatStreamData::OnStreamBlockOrdered(), WriteBinaryNode< ValueType >::OpenNextFile(), ByteBlock::Deleter::operator()(), Group::PrefixSumDoubling(), Group::PrefixSumHypercube(), ReduceNode< ValueType, KeyExtractor, ReduceFunction, ReduceConfig, KeyHashFunction, KeyEqualFunction, VolatileKey, UseDuplicateDetection >::ProcessChannel(), ReduceToIndexNode< ValueType, KeyExtractor, ReduceFunction, ReduceConfig, VolatileKey, SkipPreReducePhase >::ProcessChannel(), GroupToIndexNode< ValueType, KeyExtractor, GroupFunction >::PushData(), SampleNode< ValueType >::PushData(), MergeNode< ValueType, Comparator, kNumInputs >::PushData(), OverlapWindowNode< ValueType, Input, WindowFunction, PartialWindowFunction >::PushData(), DisjointWindowNode< ValueType, Input, WindowFunction, PartialWindowFunction >::PushData(), BlockWriter< BlockSink >::PutSafe(), ReadBinaryNode< ValueType >::ReadBinaryNode(), ReadLinesNode::ReadLinesNode(), Group::Reduce(), ReducePrePhase< TableItem, Key, Value, KeyExtractor, ReduceFunction, VolatileKey, BlockWriter, ReduceConfig_, IndexFunction, KeyEqualFunction, HashFunction, false >::ReducePrePhase(), Group::Send(), ReduceBucketHashTable< TableItem, Key, Value, KeyExtractor, ReduceFunction, Emitter, VolatileKey, ReduceConfig, IndexFunction, KeyEqualFunction >::SpillPartition(), WriteBinaryNode< ValueType >::StopPreOp(), WriteLinesNode< ValueType >::StopPreOp(), thrill::vfs::SysGlob(), thrill::vfs::SysOpenReadStream(), thrill::vfs::SysOpenWriteStream(), SocketAddress::ToStringHost(), WriteBinaryNode< ValueType >::WriteBinaryNode(), WriteLinesNode< ValueType >::WriteLinesNode(), and WriteLinesOneNode< ValueType >::WriteLinesOneNode().

◆ sLOG0

#define sLOG0   sLOGC(false)

Override default output: never or always output log.

Definition at line 37 of file logger.hpp.

Referenced by ReservoirSamplingGrow< SampleIndexPair >::add(), Dispatcher::DispatchOne(), BlockReader< CatBlockSource >::NextBlock(), and thrill::common::qsort_three_pivots().

◆ sLOG1

◆ sLOGC