Skip to content

Instantly share code, notes, and snippets.

@ryantm
Created August 4, 2019 05:15
Show Gist options
  • Star 0 You must be signed in to star a gist
  • Fork 0 You must be signed in to fork a gist
  • Save ryantm/8ab8a707778e34b03e1273734c6dbef8 to your computer and use it in GitHub Desktop.
Save ryantm/8ab8a707778e34b03e1273734c6dbef8 to your computer and use it in GitHub Desktop.
/nix/store/2y546872arcc4hxhy36jfjcfylc9xlvm-folly-2019.07.22.00
├── include
│   └── folly
│   ├── AtomicBitSet.h
│   ├── AtomicHashArray.h
│   ├── AtomicHashArray-inl.h
│   ├── AtomicHashMap.h
│   ├── AtomicHashMap-inl.h
│   ├── AtomicIntrusiveLinkedList.h
│   ├── AtomicLinkedList.h
│   ├── AtomicUnorderedMap.h
│   ├── Benchmark.h
│   ├── Bits.h
│   ├── CachelinePadded.h
│   ├── CancellationToken.h
│   ├── CancellationToken-inl.h
│   ├── chrono
│   │   ├── Conv.h
│   │   └── Hardware.h
│   ├── Chrono.h
│   ├── ClockGettimeWrappers.h
│   ├── compression
│   │   ├── Compression.h
│   │   ├── Counters.h
│   │   ├── Utils.h
│   │   ├── Zlib.h
│   │   └── Zstd.h
│   ├── concurrency
│   │   ├── AtomicSharedPtr.h
│   │   ├── CacheLocality.h
│   │   ├── ConcurrentHashMap.h
│   │   ├── CoreCachedSharedPtr.h
│   │   ├── detail
│   │   │   ├── AtomicSharedPtr-detail.h
│   │   │   └── ConcurrentHashMap-detail.h
│   │   ├── DynamicBoundedQueue.h
│   │   ├── PriorityUnboundedQueueSet.h
│   │   └── UnboundedQueue.h
│   ├── ConcurrentSkipList.h
│   ├── ConcurrentSkipList-inl.h
│   ├── ConstexprMath.h
│   ├── container
│   │   ├── Access.h
│   │   ├── Array.h
│   │   ├── BitIterator.h
│   │   ├── detail
│   │   │   ├── BitIteratorDetail.h
│   │   │   ├── F14Defaults.h
│   │   │   ├── F14IntrinsicsAvailability.h
│   │   │   ├── F14Mask.h
│   │   │   ├── F14Policy.h
│   │   │   └── F14Table.h
│   │   ├── Enumerate.h
│   │   ├── EvictingCacheMap.h
│   │   ├── F14Map-fwd.h
│   │   ├── F14Map.h
│   │   ├── F14Set-fwd.h
│   │   ├── F14Set.h
│   │   ├── Foreach.h
│   │   ├── Foreach-inl.h
│   │   ├── HeterogeneousAccess-fwd.h
│   │   ├── HeterogeneousAccess.h
│   │   ├── Iterator.h
│   │   ├── Merge.h
│   │   └── SparseByteSet.h
│   ├── Conv.h
│   ├── CPortability.h
│   ├── CppAttributes.h
│   ├── CpuId.h
│   ├── DefaultKeepAliveExecutor.h
│   ├── Demangle.h
│   ├── detail
│   │   ├── AtFork.h
│   │   ├── AtomicHashUtils.h
│   │   ├── AtomicUnorderedMapUtils.h
│   │   ├── Demangle.h
│   │   ├── DiscriminatedPtrDetail.h
│   │   ├── FileUtilDetail.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
│   │   ├── Singleton.h
│   │   ├── SingletonStackTrace.h
│   │   ├── SlowFingerprint.h
│   │   ├── SocketFastOpen.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
│   │   ├── FiberIOExecutor.h
│   │   ├── FutureExecutor.h
│   │   ├── GlobalExecutor.h
│   │   ├── GlobalThreadPoolList.h
│   │   ├── InlineExecutor.h
│   │   ├── IOExecutor.h
│   │   ├── IOObjectCache.h
│   │   ├── IOThreadPoolExecutor.h
│   │   ├── ManualExecutor.h
│   │   ├── QueuedImmediateExecutor.h
│   │   ├── ScheduledExecutor.h
│   │   ├── SequencedExecutor.h
│   │   ├── SerialExecutor.h
│   │   ├── SoftRealTimeExecutor.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
│   │   ├── CodingDetail.h
│   │   ├── coro
│   │   │   ├── AsyncGenerator.h
│   │   │   ├── Baton.h
│   │   │   ├── BlockingWait.h
│   │   │   ├── Collect.h
│   │   │   ├── Collect-inl.h
│   │   │   ├── CurrentExecutor.h
│   │   │   ├── detail
│   │   │   │   ├── Barrier.h
│   │   │   │   ├── BarrierTask.h
│   │   │   │   ├── Helpers.h
│   │   │   │   ├── InlineTask.h
│   │   │   │   ├── ManualLifetime.h
│   │   │   │   └── Traits.h
│   │   │   ├── Generator.h
│   │   │   ├── Mutex.h
│   │   │   ├── SharedLock.h
│   │   │   ├── SharedMutex.h
│   │   │   ├── Task.h
│   │   │   ├── TimedWait.h
│   │   │   ├── Traits.h
│   │   │   ├── Utils.h
│   │   │   ├── ViaIfAsync.h
│   │   │   └── Wait.h
│   │   ├── DynamicParser.h
│   │   ├── DynamicParser-inl.h
│   │   ├── EliasFanoCoding.h
│   │   ├── EnvUtil.h
│   │   ├── EventCount.h
│   │   ├── ExecutionObserver.h
│   │   ├── flat_combining
│   │   │   └── FlatCombining.h
│   │   ├── FlatCombiningPriorityQueue.h
│   │   ├── FunctionScheduler.h
│   │   ├── FutureDAG.h
│   │   ├── Instructions.h
│   │   ├── io
│   │   │   ├── FsUtil.h
│   │   │   └── HugePages.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
│   │   ├── ProgramOptions.h
│   │   ├── ReadMostlySharedPtr.h
│   │   ├── RelaxedConcurrentPriorityQueue.h
│   │   ├── Select64.h
│   │   ├── settings
│   │   │   ├── detail
│   │   │   │   └── SettingsImpl.h
│   │   │   ├── Settings.h
│   │   │   └── SettingsMetadata.h
│   │   ├── SingletonRelaxedCounter.h
│   │   ├── StampedPtr.h
│   │   ├── StringKeyedCommon.h
│   │   ├── StringKeyedMap.h
│   │   ├── StringKeyedSet.h
│   │   ├── StringKeyedUnorderedMap.h
│   │   ├── StringKeyedUnorderedSet.h
│   │   ├── STTimerFDTimeoutManager.h
│   │   ├── TestUtil.h
│   │   ├── ThreadedRepeatingFunctionRunner.h
│   │   ├── TimerFD.h
│   │   ├── TimerFDTimeoutManager.h
│   │   ├── TLRefCount.h
│   │   └── TupleOps.h
│   ├── external
│   │   └── farmhash
│   │   └── farmhash.h
│   ├── FBString.h
│   ├── FBVector.h
│   ├── fibers
│   │   ├── AddTasks.h
│   │   ├── AddTasks-inl.h
│   │   ├── AtomicBatchDispatcher.h
│   │   ├── AtomicBatchDispatcher-inl.h
│   │   ├── BatchDispatcher.h
│   │   ├── Baton.h
│   │   ├── Baton-inl.h
│   │   ├── BoostContextCompatibility.h
│   │   ├── CallOnce.h
│   │   ├── detail
│   │   │   └── AtomicBatchDispatcher.h
│   │   ├── EventBaseLoopController.h
│   │   ├── EventBaseLoopController-inl.h
│   │   ├── ExecutorLoopController.h
│   │   ├── ExecutorLoopController-inl.h
│   │   ├── Fiber.h
│   │   ├── Fiber-inl.h
│   │   ├── FiberManager.h
│   │   ├── FiberManager-inl.h
│   │   ├── FiberManagerInternal.h
│   │   ├── FiberManagerInternal-inl.h
│   │   ├── FiberManagerMap.h
│   │   ├── ForEach.h
│   │   ├── ForEach-inl.h
│   │   ├── GenericBaton.h
│   │   ├── GuardPageAllocator.h
│   │   ├── LoopController.h
│   │   ├── Promise.h
│   │   ├── Promise-inl.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
│   ├── 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
│   │   ├── Portability.h
│   │   ├── Promise.h
│   │   ├── Promise-inl.h
│   │   ├── Retrying.h
│   │   ├── SharedPromise.h
│   │   ├── SharedPromise-inl.h
│   │   └── ThreadWheelTimekeeper.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
│   ├── IntrusiveList.h
│   ├── io
│   │   ├── async
│   │   │   ├── AsyncPipe.h
│   │   │   ├── AsyncServerSocket.h
│   │   │   ├── AsyncSignalHandler.h
│   │   │   ├── AsyncSocketBase.h
│   │   │   ├── AsyncSocketException.h
│   │   │   ├── AsyncSocket.h
│   │   │   ├── AsyncSSLSocket.h
│   │   │   ├── AsyncTimeout.h
│   │   │   ├── AsyncTransportCertificate.h
│   │   │   ├── AsyncTransport.h
│   │   │   ├── AsyncUDPServerSocket.h
│   │   │   ├── AsyncUDPSocket.h
│   │   │   ├── DecoratedAsyncTransportWrapper.h
│   │   │   ├── DelayedDestructionBase.h
│   │   │   ├── DelayedDestruction.h
│   │   │   ├── DestructorCheck.h
│   │   │   ├── EventBase.h
│   │   │   ├── EventBaseLocal.h
│   │   │   ├── EventBaseManager.h
│   │   │   ├── EventBaseThread.h
│   │   │   ├── EventFDWrapper.h
│   │   │   ├── EventHandler.h
│   │   │   ├── EventUtil.h
│   │   │   ├── HHWheelTimer-fwd.h
│   │   │   ├── HHWheelTimer.h
│   │   │   ├── NotificationQueue.h
│   │   │   ├── PasswordInFile.h
│   │   │   ├── Request.h
│   │   │   ├── ScopedEventBaseThread.h
│   │   │   ├── ssl
│   │   │   │   ├── BasicTransportCertificate.h
│   │   │   │   ├── OpenSSLUtils.h
│   │   │   │   ├── SSLErrors.h
│   │   │   │   └── TLSDefinitions.h
│   │   │   ├── SSLContext.h
│   │   │   ├── SSLOptions.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
│   │   ├── Cursor.h
│   │   ├── Cursor-inl.h
│   │   ├── GlobalShutdownSocketSet.h
│   │   ├── IOBuf.h
│   │   ├── IOBufQueue.h
│   │   ├── RecordIO.h
│   │   ├── RecordIO-inl.h
│   │   ├── ShutdownSocketSet.h
│   │   └── TypedIOBuf.h
│   ├── IPAddressException.h
│   ├── IPAddress.h
│   ├── IPAddressV4.h
│   ├── IPAddressV6.h
│   ├── json.h
│   ├── json_patch.h
│   ├── json_pointer.h
│   ├── lang
│   │   ├── Align.h
│   │   ├── Assume.h
│   │   ├── Bits.h
│   │   ├── CheckedMath.h
│   │   ├── ColdClass.h
│   │   ├── CustomizationPoint.h
│   │   ├── Exception.h
│   │   ├── Launder.h
│   │   ├── Ordering.h
│   │   ├── Pretty.h
│   │   ├── PropagateConst.h
│   │   ├── RValueReferenceWrapper.h
│   │   ├── SafeAssert.h
│   │   ├── StaticConst.h
│   │   ├── TypeInfo.h
│   │   └── UncaughtExceptions.h
│   ├── Lazy.h
│   ├── Likely.h
│   ├── LockTraitsBoost.h
│   ├── LockTraits.h
│   ├── logging
│   │   ├── AsyncFileWriter.h
│   │   ├── AsyncLogWriter.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
│   │   ├── SanitizeLeak.h
│   │   ├── ThreadCachedArena.h
│   │   └── UninitializedMemoryHacks.h
│   ├── Memory.h
│   ├── MicroLock.h
│   ├── MicroSpinLock.h
│   ├── MoveWrapper.h
│   ├── MPMCPipeline.h
│   ├── MPMCQueue.h
│   ├── net
│   │   ├── detail
│   │   │   └── SocketFileDescriptorMap.h
│   │   ├── NetOps.h
│   │   └── NetworkSocket.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
│   │   ├── GFlags.h
│   │   ├── GMock.h
│   │   ├── GTest.h
│   │   ├── IOVec.h
│   │   ├── Libgen.h
│   │   ├── Malloc.h
│   │   ├── Math.h
│   │   ├── Memory.h
│   │   ├── OpenSSL.h
│   │   ├── PThread.h
│   │   ├── Sched.h
│   │   ├── Semaphore.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
│   ├── PriorityMPMCQueue.h
│   ├── ProducerConsumerQueue.h
│   ├── python
│   │   ├── AsyncioExecutor.h
│   │   ├── coro.h
│   │   ├── futures.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
│   │   │   ├── OpenSSLThreading.h
│   │   │   └── SSLSessionImpl.h
│   │   ├── Init.h
│   │   ├── OpenSSLCertUtils.h
│   │   ├── OpenSSLHash.h
│   │   ├── OpenSSLLockTypes.h
│   │   ├── OpenSSLPtrTypes.h
│   │   ├── OpenSSLVersionFinder.h
│   │   └── SSLSession.h
│   ├── stats
│   │   ├── BucketedTimeSeries-defs.h
│   │   ├── BucketedTimeSeries.h
│   │   ├── detail
│   │   │   ├── Bucket.h
│   │   │   ├── BufferedStat-defs.h
│   │   │   ├── BufferedStat.h
│   │   │   ├── BufferedStatTDigest.h
│   │   │   ├── DigestBuilder-defs.h
│   │   │   ├── DigestBuilder.h
│   │   │   ├── DoubleRadixSort.h
│   │   │   ├── SlidingWindow-defs.h
│   │   │   └── SlidingWindow.h
│   │   ├── Histogram-defs.h
│   │   ├── Histogram.h
│   │   ├── MultiLevelTimeSeries-defs.h
│   │   ├── MultiLevelTimeSeries.h
│   │   ├── QuantileEstimator-defs.h
│   │   ├── QuantileEstimator.h
│   │   ├── TDigest.h
│   │   ├── TimeseriesHistogram-defs.h
│   │   └── TimeseriesHistogram.h
│   ├── stop_watch.h
│   ├── String.h
│   ├── String-inl.h
│   ├── Subprocess.h
│   ├── synchronization
│   │   ├── AsymmetricMemoryBarrier.h
│   │   ├── AtomicNotification.h
│   │   ├── AtomicNotification-inl.h
│   │   ├── AtomicStruct.h
│   │   ├── AtomicUtil.h
│   │   ├── AtomicUtil-inl.h
│   │   ├── Baton.h
│   │   ├── CallOnce.h
│   │   ├── detail
│   │   │   ├── AtomicUtils.h
│   │   │   ├── HazptrUtils.h
│   │   │   ├── InlineFunctionRef.h
│   │   │   ├── ProxyLockable.h
│   │   │   ├── ProxyLockable-inl.h
│   │   │   ├── Sleeper.h
│   │   │   ├── Spin.h
│   │   │   ├── ThreadCachedInts.h
│   │   │   └── ThreadCachedLists.h
│   │   ├── DistributedMutex.h
│   │   ├── DistributedMutex-inl.h
│   │   ├── DistributedMutexSpecializations.h
│   │   ├── example
│   │   │   ├── HazptrLockFreeLIFO.h
│   │   │   ├── HazptrSWMRSet.h
│   │   │   └── HazptrWideCAS.h
│   │   ├── HazptrDomain.h
│   │   ├── Hazptr-fwd.h
│   │   ├── Hazptr.h
│   │   ├── HazptrHolder.h
│   │   ├── HazptrObj.h
│   │   ├── HazptrObjLinked.h
│   │   ├── HazptrRec.h
│   │   ├── HazptrThrLocal.h
│   │   ├── LifoSem.h
│   │   ├── MicroSpinLock.h
│   │   ├── ParkingLot.h
│   │   ├── PicoSpinLock.h
│   │   ├── Rcu.h
│   │   ├── Rcu-inl.h
│   │   ├── RWSpinLock.h
│   │   ├── SanitizeThread.h
│   │   ├── SaturatingSemaphore.h
│   │   ├── SmallLocks.h
│   │   ├── Tearable.h
│   │   ├── test
│   │   │   └── Semaphore.h
│   │   ├── Utility.h
│   │   └── WaitOptions.h
│   ├── Synchronized.h
│   ├── SynchronizedPtr.h
│   ├── system
│   │   ├── MemoryMapping.h
│   │   ├── Shell.h
│   │   ├── ThreadId.h
│   │   └── ThreadName.h
│   ├── test
│   │   ├── DeterministicSchedule.h
│   │   ├── JsonTestUtil.h
│   │   └── TestUtils.h
│   ├── ThreadCachedInt.h
│   ├── ThreadLocal.h
│   ├── TimeoutQueue.h
│   ├── TokenBucket.h
│   ├── tracing
│   │   ├── 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-release.cmake
├── libfolly.a
├── libfollybenchmark.a
├── libfolly_test_util.a
└── pkgconfig
└── libfolly.pc
61 directories, 625 files
Sign up for free to join this conversation on GitHub. Already have an account? Sign in to comment