/tmp/folly-2023.03.27.00-1-x86_64.3DjVGq/ └── usr/ ├── include/ │   └── folly/ │   ├── AtomicHashArray.h │   ├── AtomicHashArray-inl.h │   ├── AtomicHashMap.h │   ├── AtomicHashMap-inl.h │   ├── AtomicIntrusiveLinkedList.h │   ├── AtomicLinkedList.h │   ├── AtomicUnorderedMap.h │   ├── base64.h │   ├── Benchmark.h │   ├── BenchmarkUtil.h │   ├── Bits.h │   ├── CancellationToken.h │   ├── CancellationToken-inl.h │   ├── chrono/ │   │   ├── Conv.h │   │   └── Hardware.h │   ├── Chrono.h │   ├── ClockGettimeWrappers.h │   ├── compression/ │   │   ├── CompressionContextPool.h │   │   ├── CompressionContextPoolSingletons.h │   │   ├── CompressionCoreLocalContextPool.h │   │   ├── Compression.h │   │   ├── Utils.h │   │   ├── Zlib.h │   │   └── Zstd.h │   ├── concurrency/ │   │   ├── AtomicSharedPtr.h │   │   ├── CacheLocality.h │   │   ├── ConcurrentHashMap.h │   │   ├── CoreCachedSharedPtr.h │   │   ├── DeadlockDetector.h │   │   ├── detail/ │   │   │   ├── AtomicSharedPtr-detail.h │   │   │   └── ConcurrentHashMap-detail.h │   │   ├── DynamicBoundedQueue.h │   │   ├── PriorityUnboundedQueueSet.h │   │   ├── ThreadCachedSynchronized.h │   │   └── UnboundedQueue.h │   ├── ConcurrentBitSet.h │   ├── ConcurrentLazy.h │   ├── ConcurrentSkipList.h │   ├── ConcurrentSkipList-inl.h │   ├── ConstexprMath.h │   ├── ConstructorCallbackList.h │   ├── container/ │   │   ├── Access.h │   │   ├── Array.h │   │   ├── BitIterator.h │   │   ├── detail/ │   │   │   ├── BitIteratorDetail.h │   │   │   ├── F14Defaults.h │   │   │   ├── F14IntrinsicsAvailability.h │   │   │   ├── F14MapFallback.h │   │   │   ├── F14Mask.h │   │   │   ├── F14Policy.h │   │   │   ├── F14SetFallback.h │   │   │   ├── F14Table.h │   │   │   └── Util.h │   │   ├── Enumerate.h │   │   ├── EvictingCacheMap.h │   │   ├── F14Map-fwd.h │   │   ├── F14Map.h │   │   ├── F14Set-fwd.h │   │   ├── F14Set.h │   │   ├── Foreach.h │   │   ├── Foreach-inl.h │   │   ├── heap_vector_types.h │   │   ├── HeterogeneousAccess-fwd.h │   │   ├── HeterogeneousAccess.h │   │   ├── Iterator.h │   │   ├── Merge.h │   │   ├── SparseByteSet.h │   │   ├── test/ │   │   │   ├── F14TestUtil.h │   │   │   └── TrackingTypes.h │   │   ├── View.h │   │   └── WeightedEvictingCacheMap.h │   ├── Conv.h │   ├── CPortability.h │   ├── CppAttributes.h │   ├── CpuId.h │   ├── DefaultKeepAliveExecutor.h │   ├── Demangle.h │   ├── detail/ │   │   ├── AsyncTrace.h │   │   ├── AtomicHashUtils.h │   │   ├── AtomicUnorderedMapUtils.h │   │   ├── base64_detail/ │   │   │   ├── Base64Api.h │   │   │   ├── Base64Common.h │   │   │   ├── Base64Constants.h │   │   │   ├── Base64HiddenConstants.h │   │   │   ├── Base64Scalar.h │   │   │   ├── Base64Simd.h │   │   │   ├── Base64_SSE4_2.h │   │   │   ├── Base64_SSE4_2_Platform.h │   │   │   └── Base64SWAR.h │   │   ├── DiscriminatedPtrDetail.h │   │   ├── FileUtilDetail.h │   │   ├── FileUtilVectorDetail.h │   │   ├── FingerprintPolynomial.h │   │   ├── Futex.h │   │   ├── Futex-inl.h │   │   ├── GroupVarintDetail.h │   │   ├── IPAddress.h │   │   ├── IPAddressSource.h │   │   ├── Iterators.h │   │   ├── MemoryIdler.h │   │   ├── MPMCPipelineDetail.h │   │   ├── PolyDetail.h │   │   ├── RangeCommon.h │   │   ├── RangeSse42.h │   │   ├── SimdForEach.h │   │   ├── Singleton.h │   │   ├── SlowFingerprint.h │   │   ├── SocketFastOpen.h │   │   ├── SplitStringSimd.h │   │   ├── SplitStringSimdImpl.h │   │   ├── Sse.h │   │   ├── StaticSingletonManager.h │   │   ├── ThreadLocalDetail.h │   │   ├── TurnSequencer.h │   │   ├── TypeList.h │   │   └── UniqueInstance.h │   ├── DiscriminatedPtr.h │   ├── DynamicConverter.h │   ├── dynamic.h │   ├── dynamic-inl.h │   ├── Exception.h │   ├── ExceptionString.h │   ├── ExceptionWrapper.h │   ├── ExceptionWrapper-inl.h │   ├── Executor.h │   ├── executors/ │   │   ├── Async.h │   │   ├── Codel.h │   │   ├── CPUThreadPoolExecutor.h │   │   ├── DrivableExecutor.h │   │   ├── EDFThreadPoolExecutor.h │   │   ├── ExecutorWithPriority.h │   │   ├── ExecutorWithPriority-inl.h │   │   ├── FiberIOExecutor.h │   │   ├── FutureExecutor.h │   │   ├── GlobalExecutor.h │   │   ├── GlobalThreadPoolList.h │   │   ├── InlineExecutor.h │   │   ├── IOExecutor.h │   │   ├── IOObjectCache.h │   │   ├── IOThreadPoolDeadlockDetectorObserver.h │   │   ├── IOThreadPoolExecutor.h │   │   ├── ManualExecutor.h │   │   ├── MeteredExecutor.h │   │   ├── MeteredExecutor-inl.h │   │   ├── QueuedImmediateExecutor.h │   │   ├── QueueObserver.h │   │   ├── ScheduledExecutor.h │   │   ├── SequencedExecutor.h │   │   ├── SerialExecutor.h │   │   ├── SerializedExecutor.h │   │   ├── SoftRealTimeExecutor.h │   │   ├── StrandExecutor.h │   │   ├── task_queue/ │   │   │   ├── BlockingQueue.h │   │   │   ├── LifoSemMPMCQueue.h │   │   │   ├── PriorityLifoSemMPMCQueue.h │   │   │   ├── PriorityUnboundedBlockingQueue.h │   │   │   └── UnboundedBlockingQueue.h │   │   ├── ThreadedExecutor.h │   │   ├── thread_factory/ │   │   │   ├── InitThreadFactory.h │   │   │   ├── NamedThreadFactory.h │   │   │   ├── PriorityThreadFactory.h │   │   │   └── ThreadFactory.h │   │   ├── ThreadPoolExecutor.h │   │   ├── TimedDrivableExecutor.h │   │   └── TimekeeperScheduledExecutor.h │   ├── Expected.h │   ├── experimental/ │   │   ├── AtomicReadMostlyMainPtr.h │   │   ├── AutoTimer.h │   │   ├── Bits.h │   │   ├── BitVectorCoding.h │   │   ├── bser/ │   │   │   └── Bser.h │   │   ├── channels/ │   │   │   ├── ChannelCallbackHandle.h │   │   │   ├── Channel-fwd.h │   │   │   ├── Channel.h │   │   │   ├── Channel-inl.h │   │   │   ├── ChannelProcessor.h │   │   │   ├── ChannelProcessor-inl.h │   │   │   ├── ConsumeChannel.h │   │   │   ├── ConsumeChannel-inl.h │   │   │   ├── detail/ │   │   │   │   ├── AtomicQueue.h │   │   │   │   ├── ChannelBridge.h │   │   │   │   ├── FunctionTraits.h │   │   │   │   ├── IntrusivePtr.h │   │   │   │   ├── MultiplexerTraits.h │   │   │   │   ├── PointerVariant.h │   │   │   │   └── Utility.h │   │   │   ├── FanoutChannel.h │   │   │   ├── FanoutChannel-inl.h │   │   │   ├── FanoutSender.h │   │   │   ├── FanoutSender-inl.h │   │   │   ├── MergeChannel.h │   │   │   ├── MergeChannel-inl.h │   │   │   ├── Merge.h │   │   │   ├── Merge-inl.h │   │   │   ├── MultiplexChannel.h │   │   │   ├── MultiplexChannel-inl.h │   │   │   ├── OnClosedException.h │   │   │   ├── Producer.h │   │   │   ├── Producer-inl.h │   │   │   ├── ProxyChannel.h │   │   │   ├── ProxyChannel-inl.h │   │   │   ├── RateLimiter.h │   │   │   ├── Transform.h │   │   │   └── Transform-inl.h │   │   ├── Cleanup.h │   │   ├── CodingDetail.h │   │   ├── Coinflip.h │   │   ├── coro/ │   │   │   ├── Accumulate.h │   │   │   ├── Accumulate-inl.h │   │   │   ├── AsyncGenerator.h │   │   │   ├── AsyncPipe.h │   │   │   ├── AsyncScope.h │   │   │   ├── AsyncStack.h │   │   │   ├── Baton.h │   │   │   ├── BlockingWait.h │   │   │   ├── BoundedQueue.h │   │   │   ├── Collect.h │   │   │   ├── Collect-inl.h │   │   │   ├── Concat.h │   │   │   ├── Concat-inl.h │   │   │   ├── Coroutine.h │   │   │   ├── CurrentExecutor.h │   │   │   ├── DetachOnCancel.h │   │   │   ├── detail/ │   │   │   │   ├── Barrier.h │   │   │   │   ├── BarrierTask.h │   │   │   │   ├── CurrentAsyncFrame.h │   │   │   │   ├── Helpers.h │   │   │   │   ├── InlineTask.h │   │   │   │   ├── Malloc.h │   │   │   │   ├── ManualLifetime.h │   │   │   │   └── Traits.h │   │   │   ├── Filter.h │   │   │   ├── Filter-inl.h │   │   │   ├── FutureUtil.h │   │   │   ├── Generator.h │   │   │   ├── GmockHelpers.h │   │   │   ├── GtestHelpers.h │   │   │   ├── Invoke.h │   │   │   ├── Merge.h │   │   │   ├── Merge-inl.h │   │   │   ├── Mutex.h │   │   │   ├── Promise.h │   │   │   ├── Result.h │   │   │   ├── Retry.h │   │   │   ├── RustAdaptors.h │   │   │   ├── ScopeExit.h │   │   │   ├── SharedLock.h │   │   │   ├── SharedMutex.h │   │   │   ├── SharedPromise.h │   │   │   ├── Sleep.h │   │   │   ├── Sleep-inl.h │   │   │   ├── SmallUnboundedQueue.h │   │   │   ├── Task.h │   │   │   ├── TimedWait.h │   │   │   ├── Timeout.h │   │   │   ├── Timeout-inl.h │   │   │   ├── Traits.h │   │   │   ├── Transform.h │   │   │   ├── Transform-inl.h │   │   │   ├── UnboundedQueue.h │   │   │   ├── ViaIfAsync.h │   │   │   ├── WithAsyncStack.h │   │   │   └── WithCancellation.h │   │   ├── crypto/ │   │   │   ├── Blake2xb.h │   │   │   ├── detail/ │   │   │   │   └── LtHashInternal.h │   │   │   ├── LtHash.h │   │   │   └── LtHash-inl.h │   │   ├── DynamicParser.h │   │   ├── DynamicParser-inl.h │   │   ├── EliasFanoCoding.h │   │   ├── EnvUtil.h │   │   ├── EventCount.h │   │   ├── exception_tracer/ │   │   │   ├── ExceptionAbi.h │   │   │   ├── ExceptionCounterLib.h │   │   │   ├── ExceptionTracer.h │   │   │   ├── ExceptionTracerLib.h │   │   │   ├── SmartExceptionTracer.h │   │   │   ├── SmartExceptionTracerSingleton.h │   │   │   └── StackTrace.h │   │   ├── ExecutionObserver.h │   │   ├── flat_combining/ │   │   │   └── FlatCombining.h │   │   ├── FlatCombiningPriorityQueue.h │   │   ├── FunctionScheduler.h │   │   ├── FutureDAG.h │   │   ├── Instructions.h │   │   ├── io/ │   │   │   ├── AsyncBase.h │   │   │   ├── AsyncIO.h │   │   │   ├── AsyncIoUringSocketFactory.h │   │   │   ├── AsyncIoUringSocket.h │   │   │   ├── FsUtil.h │   │   │   ├── HugePages.h │   │   │   ├── IoUringBackend.h │   │   │   ├── IoUringBase.h │   │   │   ├── IoUringEventBaseLocal.h │   │   │   ├── IoUringEvent.h │   │   │   ├── IoUring.h │   │   │   └── SimpleAsyncIO.h │   │   ├── JemallocHugePageAllocator.h │   │   ├── JemallocNodumpAllocator.h │   │   ├── JSONSchema.h │   │   ├── LockFreeRingBuffer.h │   │   ├── NestedCommandLineApp.h │   │   ├── observer/ │   │   │   ├── detail/ │   │   │   │   ├── Core.h │   │   │   │   ├── GraphCycleDetector.h │   │   │   │   └── ObserverManager.h │   │   │   ├── Observable.h │   │   │   ├── Observable-inl.h │   │   │   ├── Observer.h │   │   │   ├── Observer-inl.h │   │   │   ├── Observer-pre.h │   │   │   ├── SimpleObservable.h │   │   │   ├── SimpleObservable-inl.h │   │   │   ├── WithJitter.h │   │   │   └── WithJitter-inl.h │   │   ├── PrimaryPtr.h │   │   ├── ProgramOptions.h │   │   ├── QuotientMultiSet.h │   │   ├── QuotientMultiSet-inl.h │   │   ├── ReadMostlySharedPtr.h │   │   ├── RelaxedConcurrentPriorityQueue.h │   │   ├── Select64.h │   │   ├── settings/ │   │   │   ├── detail/ │   │   │   │   └── SettingsImpl.h │   │   │   ├── Settings.h │   │   │   └── SettingsMetadata.h │   │   ├── SingletonRelaxedCounter.h │   │   ├── SingleWriterFixedHashMap.h │   │   ├── StampedPtr.h │   │   ├── StringKeyedCommon.h │   │   ├── StringKeyedMap.h │   │   ├── StringKeyedSet.h │   │   ├── StringKeyedUnorderedMap.h │   │   ├── StringKeyedUnorderedSet.h │   │   ├── STTimerFDTimeoutManager.h │   │   ├── symbolizer/ │   │   │   ├── detail/ │   │   │   │   └── Debug.h │   │   │   ├── Dwarf.h │   │   │   ├── DwarfImpl.h │   │   │   ├── DwarfLineNumberVM.h │   │   │   ├── DwarfSection.h │   │   │   ├── DwarfUtil.h │   │   │   ├── ElfCache.h │   │   │   ├── Elf.h │   │   │   ├── Elf-inl.h │   │   │   ├── LineReader.h │   │   │   ├── SignalHandler.h │   │   │   ├── StackTrace.h │   │   │   ├── SymbolizedFrame.h │   │   │   ├── SymbolizePrinter.h │   │   │   └── Symbolizer.h │   │   ├── TestUtil.h │   │   ├── ThreadedRepeatingFunctionRunner.h │   │   ├── ThreadWheelTimekeeperHighRes.h │   │   ├── TimerFD.h │   │   ├── TimerFDTimeoutManager.h │   │   ├── TLRefCount.h │   │   └── TupleOps.h │   ├── ext/ │   │   └── test_ext.h │   ├── external/ │   │   └── farmhash/ │   │   └── farmhash.h │   ├── FBString.h │   ├── FBVector.h │   ├── fibers/ │   │   ├── AddTasks.h │   │   ├── AddTasks-inl.h │   │   ├── async/ │   │   │   ├── Async.h │   │   │   ├── AsyncStack.h │   │   │   ├── Baton.h │   │   │   ├── Collect.h │   │   │   ├── Collect-inl.h │   │   │   ├── FiberManager.h │   │   │   ├── Future.h │   │   │   ├── Promise.h │   │   │   ├── Task.h │   │   │   └── WaitUtils.h │   │   ├── AtomicBatchDispatcher.h │   │   ├── AtomicBatchDispatcher-inl.h │   │   ├── BatchDispatcher.h │   │   ├── BatchSemaphore.h │   │   ├── Baton.h │   │   ├── Baton-inl.h │   │   ├── BoostContextCompatibility.h │   │   ├── CallOnce.h │   │   ├── detail/ │   │   │   └── AtomicBatchDispatcher.h │   │   ├── EventBaseLoopController.h │   │   ├── EventBaseLoopController-inl.h │   │   ├── ExecutorBasedLoopController.h │   │   ├── ExecutorLoopController.h │   │   ├── ExecutorLoopController-inl.h │   │   ├── Fiber.h │   │   ├── Fiber-inl.h │   │   ├── FiberManager.h │   │   ├── FiberManager-inl.h │   │   ├── FiberManagerInternal.h │   │   ├── FiberManagerInternal-inl.h │   │   ├── FiberManagerMap.h │   │   ├── FiberManagerMap-inl.h │   │   ├── ForEach.h │   │   ├── ForEach-inl.h │   │   ├── GenericBaton.h │   │   ├── GuardPageAllocator.h │   │   ├── LoopController.h │   │   ├── Promise.h │   │   ├── Promise-inl.h │   │   ├── SemaphoreBase.h │   │   ├── Semaphore.h │   │   ├── SimpleLoopController.h │   │   ├── TimedMutex.h │   │   ├── TimedMutex-inl.h │   │   ├── traits.h │   │   ├── WhenN.h │   │   └── WhenN-inl.h │   ├── File.h │   ├── FileUtil.h │   ├── Fingerprint.h │   ├── FixedString.h │   ├── folly-config.h │   ├── FollyMemcpy.h │   ├── FollyMemset.h │   ├── FormatArg.h │   ├── Format.h │   ├── Format-inl.h │   ├── FormatTraits.h │   ├── functional/ │   │   ├── ApplyTuple.h │   │   ├── Invoke.h │   │   └── Partial.h │   ├── Function.h │   ├── futures/ │   │   ├── Barrier.h │   │   ├── detail/ │   │   │   ├── Core.h │   │   │   └── Types.h │   │   ├── Future.h │   │   ├── Future-inl.h │   │   ├── Future-pre.h │   │   ├── FutureSplitter.h │   │   ├── ManualTimekeeper.h │   │   ├── Portability.h │   │   ├── Promise.h │   │   ├── Promise-inl.h │   │   ├── Retrying.h │   │   ├── SharedPromise.h │   │   ├── SharedPromise-inl.h │   │   ├── ThreadWheelTimekeeper.h │   │   └── WTCallback.h │   ├── gen/ │   │   ├── Base.h │   │   ├── Base-inl.h │   │   ├── Combine.h │   │   ├── Combine-inl.h │   │   ├── Core.h │   │   ├── Core-inl.h │   │   ├── File.h │   │   ├── File-inl.h │   │   ├── IStream.h │   │   ├── Parallel.h │   │   ├── Parallel-inl.h │   │   ├── ParallelMap.h │   │   ├── ParallelMap-inl.h │   │   ├── String.h │   │   └── String-inl.h │   ├── GLog.h │   ├── GroupVarint.h │   ├── hash/ │   │   ├── Checksum.h │   │   ├── detail/ │   │   │   └── ChecksumDetail.h │   │   ├── FarmHash.h │   │   ├── Hash.h │   │   ├── SpookyHashV1.h │   │   └── SpookyHashV2.h │   ├── Hash.h │   ├── Indestructible.h │   ├── IndexedMemPool.h │   ├── init/ │   │   ├── Init.h │   │   └── Phase.h │   ├── IntrusiveList.h │   ├── io/ │   │   ├── async/ │   │   │   ├── AsyncPipe.h │   │   │   ├── AsyncServerSocket.h │   │   │   ├── AsyncSignalHandler.h │   │   │   ├── AsyncSocketBase.h │   │   │   ├── AsyncSocketException.h │   │   │   ├── AsyncSocket.h │   │   │   ├── AsyncSocketTransport.h │   │   │   ├── AsyncSSLSocket.h │   │   │   ├── AsyncTimeout.h │   │   │   ├── AsyncTransportCertificate.h │   │   │   ├── AsyncTransport.h │   │   │   ├── AsyncUDPServerSocket.h │   │   │   ├── AsyncUDPSocket.h │   │   │   ├── AtomicNotificationQueue.h │   │   │   ├── AtomicNotificationQueue-inl.h │   │   │   ├── CertificateIdentityVerifier.h │   │   │   ├── DecoratedAsyncTransportWrapper.h │   │   │   ├── DelayedDestructionBase.h │   │   │   ├── DelayedDestruction.h │   │   │   ├── DestructorCheck.h │   │   │   ├── EventBaseAtomicNotificationQueue.h │   │   │   ├── EventBaseAtomicNotificationQueue-inl.h │   │   │   ├── EventBaseBackendBase.h │   │   │   ├── EventBase.h │   │   │   ├── EventBaseLocal.h │   │   │   ├── EventBaseManager.h │   │   │   ├── EventBaseThread.h │   │   │   ├── EventHandler.h │   │   │   ├── EventUtil.h │   │   │   ├── HHWheelTimer-fwd.h │   │   │   ├── HHWheelTimer.h │   │   │   ├── NotificationQueue.h │   │   │   ├── PasswordInFile.h │   │   │   ├── Request.h │   │   │   ├── ScopedEventBaseThread.h │   │   │   ├── ssl/ │   │   │   │   ├── BasicTransportCertificate.h │   │   │   │   ├── OpenSSLTransportCertificate.h │   │   │   │   ├── OpenSSLUtils.h │   │   │   │   ├── SSLErrors.h │   │   │   │   └── TLSDefinitions.h │   │   │   ├── SSLContext.h │   │   │   ├── SSLOptions.h │   │   │   ├── TerminateCancellationToken.h │   │   │   ├── test/ │   │   │   │   ├── AsyncSocketTest2.h │   │   │   │   ├── AsyncSocketTest.h │   │   │   │   ├── AsyncSSLSocketTest.h │   │   │   │   ├── BlockingSocket.h │   │   │   │   ├── MockAsyncServerSocket.h │   │   │   │   ├── MockAsyncSocket.h │   │   │   │   ├── MockAsyncSSLSocket.h │   │   │   │   ├── MockAsyncTransport.h │   │   │   │   ├── MockAsyncUDPSocket.h │   │   │   │   ├── MockTimeoutManager.h │   │   │   │   ├── ScopedBoundPort.h │   │   │   │   ├── SocketPair.h │   │   │   │   ├── TestSSLServer.h │   │   │   │   ├── TimeUtil.h │   │   │   │   ├── UndelayedDestruction.h │   │   │   │   └── Util.h │   │   │   ├── TimeoutManager.h │   │   │   ├── VirtualEventBase.h │   │   │   └── WriteChainAsyncTransportWrapper.h │   │   ├── coro/ │   │   │   ├── ServerSocket.h │   │   │   └── Transport.h │   │   ├── Cursor.h │   │   ├── Cursor-inl.h │   │   ├── GlobalShutdownSocketSet.h │   │   ├── IOBuf.h │   │   ├── IOBufIovecBuilder.h │   │   ├── IOBufQueue.h │   │   ├── RecordIO.h │   │   ├── RecordIO-inl.h │   │   ├── ShutdownSocketSet.h │   │   ├── SocketOptionMap.h │   │   └── TypedIOBuf.h │   ├── IPAddressException.h │   ├── IPAddress.h │   ├── IPAddressV4.h │   ├── IPAddressV6.h │   ├── json.h │   ├── json_patch.h │   ├── json_pointer.h │   ├── lang/ │   │   ├── Access.h │   │   ├── Aligned.h │   │   ├── Align.h │   │   ├── Assume.h │   │   ├── Badge.h │   │   ├── Bits.h │   │   ├── Builtin.h │   │   ├── Byte.h │   │   ├── CArray.h │   │   ├── Cast.h │   │   ├── CheckedMath.h │   │   ├── CString.h │   │   ├── CustomizationPoint.h │   │   ├── Exception.h │   │   ├── Extern.h │   │   ├── Hint.h │   │   ├── Hint-inl.h │   │   ├── Keep.h │   │   ├── Launder.h │   │   ├── New.h │   │   ├── Ordering.h │   │   ├── Pretty.h │   │   ├── PropagateConst.h │   │   ├── RValueReferenceWrapper.h │   │   ├── SafeAssert.h │   │   ├── StaticConst.h │   │   ├── Thunk.h │   │   ├── ToAscii.h │   │   ├── TypeInfo.h │   │   └── UncaughtExceptions.h │   ├── Lazy.h │   ├── Likely.h │   ├── logging/ │   │   ├── AsyncFileWriter.h │   │   ├── AsyncLogWriter.h │   │   ├── BridgeFromGoogleLogging.h │   │   ├── CustomLogFormatter.h │   │   ├── FileHandlerFactory.h │   │   ├── FileWriterFactory.h │   │   ├── GlogStyleFormatter.h │   │   ├── ImmediateFileWriter.h │   │   ├── Init.h │   │   ├── LogCategoryConfig.h │   │   ├── LogCategory.h │   │   ├── LogConfig.h │   │   ├── LogConfigParser.h │   │   ├── LogFormatter.h │   │   ├── LoggerDB.h │   │   ├── Logger.h │   │   ├── LogHandlerConfig.h │   │   ├── LogHandlerFactory.h │   │   ├── LogHandler.h │   │   ├── LogLevel.h │   │   ├── LogMessage.h │   │   ├── LogName.h │   │   ├── LogStream.h │   │   ├── LogStreamProcessor.h │   │   ├── LogWriter.h │   │   ├── ObjectToString.h │   │   ├── RateLimiter.h │   │   ├── StandardLogHandlerFactory.h │   │   ├── StandardLogHandler.h │   │   ├── StreamHandlerFactory.h │   │   └── xlog.h │   ├── MacAddress.h │   ├── MapUtil.h │   ├── Math.h │   ├── memory/ │   │   ├── Arena.h │   │   ├── Arena-inl.h │   │   ├── detail/ │   │   │   └── MallocImpl.h │   │   ├── EnableSharedFromThis.h │   │   ├── MallctlHelper.h │   │   ├── Malloc.h │   │   ├── MemoryResource.h │   │   ├── not_null.h │   │   ├── not_null-inl.h │   │   ├── ReentrantAllocator.h │   │   ├── SanitizeAddress.h │   │   ├── SanitizeLeak.h │   │   ├── ThreadCachedArena.h │   │   └── UninitializedMemoryHacks.h │   ├── Memory.h │   ├── MicroLock.h │   ├── MicroSpinLock.h │   ├── MoveWrapper.h │   ├── MPMCPipeline.h │   ├── MPMCQueue.h │   ├── net/ │   │   ├── detail/ │   │   │   └── SocketFileDescriptorMap.h │   │   ├── NetOpsDispatcher.h │   │   ├── NetOps.h │   │   ├── NetworkSocket.h │   │   ├── TcpInfoDispatcher.h │   │   ├── TcpInfo.h │   │   └── TcpInfoTypes.h │   ├── ObserverContainer.h │   ├── Optional.h │   ├── Overload.h │   ├── PackedSyncPtr.h │   ├── Padded.h │   ├── poly/ │   │   ├── Nullable.h │   │   └── Regular.h │   ├── PolyException.h │   ├── Poly.h │   ├── Poly-inl.h │   ├── portability/ │   │   ├── Asm.h │   │   ├── Atomic.h │   │   ├── Builtins.h │   │   ├── Config.h │   │   ├── Constexpr.h │   │   ├── Dirent.h │   │   ├── Event.h │   │   ├── Fcntl.h │   │   ├── Filesystem.h │   │   ├── FmtCompile.h │   │   ├── GFlags.h │   │   ├── GMock.h │   │   ├── GTest.h │   │   ├── IOVec.h │   │   ├── Libgen.h │   │   ├── Libunwind.h │   │   ├── Malloc.h │   │   ├── Math.h │   │   ├── Memory.h │   │   ├── OpenSSL.h │   │   ├── PThread.h │   │   ├── Sched.h │   │   ├── Sockets.h │   │   ├── Stdio.h │   │   ├── Stdlib.h │   │   ├── String.h │   │   ├── SysFile.h │   │   ├── Syslog.h │   │   ├── SysMembarrier.h │   │   ├── SysMman.h │   │   ├── SysResource.h │   │   ├── SysStat.h │   │   ├── SysSyscall.h │   │   ├── SysTime.h │   │   ├── SysTypes.h │   │   ├── SysUio.h │   │   ├── Time.h │   │   ├── Unistd.h │   │   └── Windows.h │   ├── Portability.h │   ├── Preprocessor.h │   ├── ProducerConsumerQueue.h │   ├── python/ │   │   ├── async_generator.h │   │   ├── AsyncioExecutor.h │   │   ├── coro.h │   │   ├── error.h │   │   ├── executor.h │   │   ├── futures.h │   │   ├── import.h │   │   └── iobuf.h │   ├── Random.h │   ├── Random-inl.h │   ├── Range.h │   ├── Replaceable.h │   ├── RWSpinLock.h │   ├── ScopeGuard.h │   ├── SharedMutex.h │   ├── Singleton.h │   ├── Singleton-inl.h │   ├── SingletonThreadLocal.h │   ├── small_vector.h │   ├── SocketAddress.h │   ├── sorted_vector_types.h │   ├── SpinLock.h │   ├── ssl/ │   │   ├── detail/ │   │   │   ├── OpenSSLSession.h │   │   │   └── OpenSSLThreading.h │   │   ├── Init.h │   │   ├── OpenSSLCertUtils.h │   │   ├── OpenSSLHash.h │   │   ├── OpenSSLLockTypes.h │   │   ├── OpenSSLPtrTypes.h │   │   ├── OpenSSLTicketHandler.h │   │   ├── OpenSSLVersionFinder.h │   │   ├── SSLSession.h │   │   └── SSLSessionManager.h │   ├── stats/ │   │   ├── BucketedTimeSeries.h │   │   ├── BucketedTimeSeries-inl.h │   │   ├── detail/ │   │   │   ├── Bucket.h │   │   │   ├── BufferedStat.h │   │   │   ├── BufferedStat-inl.h │   │   │   ├── DoubleRadixSort.h │   │   │   ├── SlidingWindow.h │   │   │   └── SlidingWindow-inl.h │   │   ├── DigestBuilder.h │   │   ├── DigestBuilder-inl.h │   │   ├── Histogram.h │   │   ├── Histogram-inl.h │   │   ├── MultiLevelTimeSeries.h │   │   ├── MultiLevelTimeSeries-inl.h │   │   ├── QuantileEstimator.h │   │   ├── QuantileEstimator-inl.h │   │   ├── QuantileHistogram.h │   │   ├── QuantileHistogram-inl.h │   │   ├── StreamingStats.h │   │   ├── TDigest.h │   │   ├── TimeseriesHistogram.h │   │   └── TimeseriesHistogram-inl.h │   ├── stop_watch.h │   ├── String.h │   ├── String-inl.h │   ├── Subprocess.h │   ├── synchronization/ │   │   ├── AsymmetricThreadFence.h │   │   ├── AtomicNotification.h │   │   ├── AtomicNotification-inl.h │   │   ├── AtomicRef.h │   │   ├── AtomicStruct.h │   │   ├── AtomicUtil.h │   │   ├── AtomicUtil-inl.h │   │   ├── Baton.h │   │   ├── CallOnce.h │   │   ├── DelayedInit.h │   │   ├── detail/ │   │   │   ├── AtomicUtils.h │   │   │   ├── Hardware.h │   │   │   ├── HazptrUtils.h │   │   │   ├── InlineFunctionRef.h │   │   │   ├── Sleeper.h │   │   │   ├── Spin.h │   │   │   ├── ThreadCachedLists.h │   │   │   ├── ThreadCachedReaders.h │   │   │   └── ThreadCachedTag.h │   │   ├── DistributedMutex.h │   │   ├── DistributedMutex-inl.h │   │   ├── example/ │   │   │   ├── HazptrLockFreeLIFO.h │   │   │   ├── HazptrSWMRSet.h │   │   │   └── HazptrWideCAS.h │   │   ├── HazptrDomain.h │   │   ├── Hazptr-fwd.h │   │   ├── Hazptr.h │   │   ├── HazptrHolder.h │   │   ├── HazptrObj.h │   │   ├── HazptrObjLinked.h │   │   ├── HazptrRec.h │   │   ├── HazptrThreadPoolExecutor.h │   │   ├── HazptrThrLocal.h │   │   ├── Latch.h │   │   ├── LifoSem.h │   │   ├── Lock.h │   │   ├── MicroSpinLock.h │   │   ├── NativeSemaphore.h │   │   ├── ParkingLot.h │   │   ├── PicoSpinLock.h │   │   ├── Rcu.h │   │   ├── RelaxedAtomic.h │   │   ├── RWSpinLock.h │   │   ├── SanitizeThread.h │   │   ├── SaturatingSemaphore.h │   │   ├── SmallLocks.h │   │   ├── test/ │   │   │   └── Semaphore.h │   │   ├── ThrottledLifoSem.h │   │   ├── Utility.h │   │   └── WaitOptions.h │   ├── Synchronized.h │   ├── SynchronizedPtr.h │   ├── system/ │   │   ├── AtFork.h │   │   ├── HardwareConcurrency.h │   │   ├── MemoryMapping.h │   │   ├── Pid.h │   │   ├── Shell.h │   │   ├── ThreadId.h │   │   └── ThreadName.h │   ├── test/ │   │   ├── DeterministicSchedule.h │   │   ├── JsonTestUtil.h │   │   └── TestUtils.h │   ├── ThreadCachedInt.h │   ├── ThreadLocal.h │   ├── TimeoutQueue.h │   ├── TokenBucket.h │   ├── tracing/ │   │   ├── AsyncStack.h │   │   ├── AsyncStack-inl.h │   │   ├── ScopedTraceSection.h │   │   ├── StaticTracepoint-ELFx86.h │   │   └── StaticTracepoint.h │   ├── Traits.h │   ├── Try.h │   ├── Try-inl.h │   ├── Unicode.h │   ├── Unit.h │   ├── Uri.h │   ├── Uri-inl.h │   ├── UTF8String.h │   ├── Utility.h │   ├── Varint.h │   └── VirtualExecutor.h └── lib/ ├── cmake/ │   └── folly/ │   ├── folly-config.cmake │   ├── folly-targets.cmake │   └── folly-targets-relwithdebinfo.cmake ├── libfolly.a ├── libfollybenchmark.a ├── libfolly_exception_counter.a ├── libfolly_exception_tracer.a ├── libfolly_exception_tracer_base.a ├── libfolly_test_util.a └── pkgconfig/ └── libfolly.pc 75 directories, 846 files