- Cache(String) - Constructor for class com.facebook.buck.event.ActionGraphEvent.Cache
-
- CACHE_CHECK_RESOURCE_AMOUNTS - Static variable in class com.facebook.buck.core.build.engine.impl.CachingBuildEngine
-
- CACHE_MODE - Static variable in class com.facebook.buck.artifact_cache.DirArtifactCacheEvent
-
- CACHE_MODE - Static variable in class com.facebook.buck.artifact_cache.HttpArtifactCacheEvent
-
- CACHE_MODE - Static variable in class com.facebook.buck.artifact_cache.SQLiteArtifactCacheEvent
-
- CACHE_RATE_STATS_UPDATE_EVENT - Static variable in interface com.facebook.buck.event.external.events.BuckEventExternalInterface
-
- CACHE_TIME_MS - Static variable in class com.facebook.buck.slb.ServerHealthManager
-
- cacheBundlesAndPackages() - Method in class com.facebook.buck.apple.AppleConfig
-
- CacheCommand - Class in com.facebook.buck.cli
-
A command for inspecting the artifact cache.
- CacheCommand() - Constructor for class com.facebook.buck.cli.CacheCommand
-
- CacheCountersSummary - Class in com.facebook.buck.artifact_cache
-
Utility class to help outputting the information to the machine-readable log.
- CacheCountersSummary() - Constructor for class com.facebook.buck.artifact_cache.CacheCountersSummary
-
- CacheCountersSummaryEvent - Class in com.facebook.buck.artifact_cache
-
- CacheDecorator - Interface in com.facebook.buck.artifact_cache
-
A Cache that wraps another cache and performs additional things, e.g.
- CacheDeleteCommand - Class in com.facebook.buck.cli
-
A command for deleting artifacts from cache.
- CacheDeleteCommand() - Constructor for class com.facebook.buck.cli.CacheDeleteCommand
-
- CacheDeleteResult - Class in com.facebook.buck.artifact_cache
-
Result of delete from cache command.
- CacheDeleteResult() - Constructor for class com.facebook.buck.artifact_cache.CacheDeleteResult
-
- cacheError() - Method in class com.facebook.buck.artifact_cache.CacheResult
-
- cacheMode() - Method in class com.facebook.buck.artifact_cache.CacheResult
-
- CacheRateStatsKeeper - Class in com.facebook.buck.event.listener.stats.cache
-
Measure CACHE HIT % based on total cache misses and the theoretical total number of build rules.
- CacheRateStatsKeeper() - Constructor for class com.facebook.buck.event.listener.stats.cache.CacheRateStatsKeeper
-
- CacheRateStatsKeeper.CacheRateStatsUpdateEvent - Class in com.facebook.buck.event.listener.stats.cache
-
- CacheRateStatsListener - Class in com.facebook.buck.event.listener
-
Posts rate-limited cache rate update events for the WebSocket to consume.
- CacheRateStatsListener(BuckEventBus) - Constructor for class com.facebook.buck.event.listener.CacheRateStatsListener
-
- cacheRateStatsUpdate(CacheRateStatsKeeper.CacheRateStatsUpdateEvent) - Method in class com.facebook.buck.httpserver.WebServerBuckEventListener
-
- CacheRateStatsUpdateEvent(int, int, int, int, int) - Constructor for class com.facebook.buck.event.listener.stats.cache.CacheRateStatsKeeper.CacheRateStatsUpdateEvent
-
- CacheRateStatsUpdateExternalEventInterface - Interface in com.facebook.buck.event.external.events
-
Sent to update the WebSocket clients about cache misses and errors.
- CacheReadMode - Enum in com.facebook.buck.artifact_cache.config
-
Describes whether the cache allows stores.
- CacheResult - Class in com.facebook.buck.artifact_cache
-
- CacheResult() - Constructor for class com.facebook.buck.artifact_cache.CacheResult
-
- cacheResult() - Method in class com.facebook.buck.artifact_cache.RuleKeyCacheResult
-
- CacheResultType - Enum in com.facebook.buck.artifact_cache
-
- cacheSource() - Method in class com.facebook.buck.artifact_cache.CacheResult
-
- CacheStats - Class in com.facebook.buck.util.cache
-
Class containing various cache statistics
- CacheStats() - Constructor for class com.facebook.buck.util.cache.CacheStats
-
- CacheStats.Builder - Class in com.facebook.buck.util.cache
-
- CacheStatsEvent - Class in com.facebook.buck.event
-
BuckEvent for passing cache stats through the event bus
- CacheStatsEvent(String, CacheStats) - Constructor for class com.facebook.buck.event.CacheStatsEvent
-
- CacheStatsTracker - Interface in com.facebook.buck.util.cache
-
Class that tracks cache statistics, including timings.
- CacheStatsTracker.CacheRequest - Interface in com.facebook.buck.util.cache
-
Class that keeps record and timings of a single cache request
- cacheWasEmpty - Variable in class com.facebook.buck.event.ActionGraphEvent.Cache.Miss
-
- CachingBuildEngine - Class in com.facebook.buck.core.build.engine.impl
-
A build engine used to build a
BuildRule
which also caches the results.
- CachingBuildEngine(CachingBuildEngineDelegate, Optional<BuildRuleStrategy>, WeightedListeningExecutorService, BuildType, DepFiles, long, Optional<Long>, BuildRuleResolver, BuildEngineActionToBuildRuleResolver, TargetConfigurationSerializer, BuildInfoStoreManager, ResourceAwareSchedulingInfo, boolean, RuleKeyFactories) - Constructor for class com.facebook.buck.core.build.engine.impl.CachingBuildEngine
-
- CachingBuildEngine.DefaultBuildRuleBuilderDelegate - Class in com.facebook.buck.core.build.engine.impl
-
- CachingBuildEngineBuckConfig - Class in com.facebook.buck.core.build.engine.config
-
- CachingBuildEngineBuckConfig() - Constructor for class com.facebook.buck.core.build.engine.config.CachingBuildEngineBuckConfig
-
- CachingBuildEngineDelegate - Interface in com.facebook.buck.core.build.engine.delegate
-
- CachingGlobber - Class in com.facebook.buck.skylark.io.impl
-
Globber
implementation that caches expanded paths from previous invocations and reuses
them in case the glob with same
GlobSpec
is requested again.
- CachingPlatformResolver - Class in com.facebook.buck.core.rules.platform
-
An implementation of
PlatformResolver
that caches platforms created by a given delegate.
- CachingPlatformResolver(PlatformResolver) - Constructor for class com.facebook.buck.core.rules.platform.CachingPlatformResolver
-
- CachingQueryEvaluator<ENV_NODE_TYPE> - Class in com.facebook.buck.query
-
- CachingQueryEvaluator() - Constructor for class com.facebook.buck.query.CachingQueryEvaluator
-
- calculate(BuckEventBus, BuildRule) - Method in class com.facebook.buck.core.rulekey.calculator.ParallelRuleKeyCalculator
-
- CalculateAbi - Interface in com.facebook.buck.jvm.core
-
Tag interface for rules that calculate ABIs for Java code.
- CalculateClassAbi - Class in com.facebook.buck.jvm.java
-
Calculates Class ABI.
- CalculateClassAbi(BuildTarget, ProjectFilesystem, SourcePathRuleFinder, SourcePath, AbiGenerationMode) - Constructor for class com.facebook.buck.jvm.java.CalculateClassAbi
-
- CalculateClassAbiStep - Class in com.facebook.buck.jvm.java
-
- CalculateClassAbiStep(ProjectFilesystem, Path, Path, AbiGenerationMode) - Constructor for class com.facebook.buck.jvm.java.CalculateClassAbiStep
-
- calculateClassHashes(ExecutionContext, ProjectFilesystem, Path) - Static method in class com.facebook.buck.jvm.java.AccumulateClassNamesStep
-
- calculateDepFileRuleKey(Optional<ImmutableList<String>>, boolean) - Method in class com.facebook.buck.core.build.engine.cache.manager.DependencyFileRuleKeyManager
-
- calculateInputBasedRuleKey() - Method in class com.facebook.buck.core.build.engine.cache.manager.InputBasedRuleKeyManager
-
- calculateManifestKey(BuckEventBus) - Method in class com.facebook.buck.core.build.engine.cache.manager.ManifestRuleKeyManager
-
- calculateManifestKey(SupportsDependencyFileRuleKey, BuckEventBus) - Method in class com.facebook.buck.rules.keys.RuleKeyFactories
-
- calculateMaxLen() - Method in class com.facebook.buck.support.cli.args.CmdLineParserWithPrintInformation
-
- calculateOutputSizeAndWriteMetadata(FileHashLoader, ImmutableSortedSet<Path>, Predicate<Long>) - Method in class com.facebook.buck.core.build.engine.buildinfo.DefaultOnDiskBuildInfo
-
- calculateOutputSizeAndWriteMetadata(FileHashLoader, ImmutableSortedSet<Path>, Predicate<Long>) - Method in interface com.facebook.buck.core.build.engine.buildinfo.OnDiskBuildInfo
-
- calculatePythonPlatformFlavorFromSection(String) - Method in class com.facebook.buck.features.python.PythonBuckConfig
-
- CalculateSourceAbi - Class in com.facebook.buck.jvm.java
-
Source Abi calculation.
- CalculateSourceAbi(BuildTarget, ProjectFilesystem, JarBuildStepsFactory, SourcePathRuleFinder) - Constructor for class com.facebook.buck.jvm.java.CalculateSourceAbi
-
- CalculateSourceAbi.SourceAbiBuildable - Class in com.facebook.buck.jvm.java
-
Buildable implementation.
- CalculateSourceAbiFromLibraryTarget - Class in com.facebook.buck.jvm.java
-
Calculates a Source ABI by copying the source ABI output from the library rule into a JAR.
- CalculateSourceAbiFromLibraryTarget(SourcePath, BuildTarget, ProjectFilesystem, SourcePathRuleFinder) - Constructor for class com.facebook.buck.jvm.java.CalculateSourceAbiFromLibraryTarget
-
- call() - Method in class com.facebook.buck.cli.bootstrapper.ConsoleHandler
-
- call() - Method in class com.facebook.buck.cli.bootstrapper.LogFileHandler
-
- call() - Method in class com.facebook.buck.cli.bootstrapper.MemoryHandler
-
- call() - Method in interface com.facebook.buck.core.build.engine.cache.manager.BuildCacheArtifactFetcher.OnOutputsWillChange
-
- call(Object[], FuncallExpression, Environment) - Method in class com.facebook.buck.core.rules.providers.impl.UserDefinedProvider
-
- call(List<Object>, Map<String, Object>, FuncallExpression, Environment) - Method in class com.facebook.buck.core.starlark.compatible.BuckStarlarkFunction
-
- call(Object[], FuncallExpression, Environment) - Method in class com.facebook.buck.core.starlark.rule.SkylarkUserDefinedRule
-
- call() - Method in class com.facebook.buck.jvm.java.abi.source.FrontendOnlyJavacTask
-
- call() - Method in class com.facebook.buck.jvm.java.plugin.adapter.BuckJavacTaskProxyImpl
-
- call() - Method in class com.facebook.buck.util.InputStreamConsumer
-
- call(Object, ProcessExecutorParams, ImmutableMap<String, String>) - Method in interface com.facebook.buck.util.ProcessRegistry.ProcessRegisterCallback
-
- callback(int) - Method in class com.facebook.buck.util.sqlite.RetryBusyHandler
-
- callOnEachResource(Consumer<R>) - Method in class com.facebook.buck.util.concurrent.ResourcePool
-
- CanaryFactory - Class in com.facebook.buck.android.dalvik
-
Helper to create a "canary" class for the secondary DEX.
- canBeAggregated(IjProjectConfig) - Method in enum com.facebook.buck.features.project.intellij.model.IjModuleType
-
- canBorrow() - Method in class com.facebook.buck.io.file.BorrowablePath
-
- canBuild(BuildRule) - Method in interface com.facebook.buck.core.rules.build.strategy.BuildRuleStrategy
-
A rule will be built by the custom strategy only if canBuild() returns true.
- canBuild(BuildRule) - Method in class com.facebook.buck.rules.modern.builders.HybridLocalStrategy
-
- canBuild(BuildRule) - Method in class com.facebook.buck.rules.modern.builders.LocalFallbackStrategy
-
- canBuild(BuildRule) - Method in class com.facebook.buck.rules.modern.builders.RemoteExecutionStrategy
-
- cancel(Throwable) - Method in interface com.facebook.buck.core.rules.build.strategy.BuildRuleStrategy.StrategyBuildResult
-
Indicates that the caller is no longer interested in the result and the strategy is free to
cancel pending work.
- cancel() - Method in interface com.facebook.buck.remoteexecution.RemoteExecutionServiceClient.ExecutionHandle
-
- cancel(Throwable) - Method in class com.facebook.buck.rules.modern.builders.RemoteRuleContext
-
Call when action has been cancelled.
- canceled(BuildRule, Throwable) - Static method in class com.facebook.buck.core.build.engine.BuildResult
-
- cancelIfNotComplete(Throwable) - Method in interface com.facebook.buck.core.rules.build.strategy.BuildRuleStrategy.StrategyBuildResult
-
Tries to cancel the execution if work has not yet past the point of no return.
- canExecuteRemotely(T) - Method in class com.facebook.buck.shell.AbstractGenruleDescription
-
- canHandleException(Throwable) - Method in class com.facebook.buck.support.exceptions.handler.ExceptionHandler
-
- canMergeWith(IjFolder) - Method in class com.facebook.buck.features.project.intellij.model.folders.IjFolder
-
- canMergeWith(IjFolder) - Method in class com.facebook.buck.features.project.intellij.model.folders.ResourceFolder
-
- canMergeWith(IjFolder) - Method in class com.facebook.buck.features.project.intellij.model.folders.SelfMergingOnlyFolder
-
- CannotInferException - Exception in com.facebook.buck.jvm.java.abi.source.api
-
- CannotInferException(String, Element) - Constructor for exception com.facebook.buck.jvm.java.abi.source.api.CannotInferException
-
- CannotInferException(String, TypeMirror) - Constructor for exception com.facebook.buck.jvm.java.abi.source.api.CannotInferException
-
- CanonicalCellName - Class in com.facebook.buck.core.cell.name
-
Provides a canonical identifier for a
Cell
.
- CanonicalCellName() - Constructor for class com.facebook.buck.core.cell.name.CanonicalCellName
-
- canPutEntry(FileLike) - Method in class com.facebook.buck.android.dalvik.DalvikAwareOutputStreamHelper
-
- canStartSimulator(String) - Method in class com.facebook.buck.apple.simulator.AppleSimulatorController
-
- canWrapBinaryBuildRule(BuildRule) - Static method in class com.facebook.buck.apple.AppleDebuggableBinary
-
Indicates whether its possible to wrap given _binary_ rule.
- Capability - Enum in com.facebook.buck.io.watchman
-
Various
capabilities
supported by different versions of Watchman.
- capitalize(String) - Static method in class com.facebook.buck.util.string.MoreStrings
-
- CapturingPrintStream - Class in com.facebook.buck.util
-
- CapturingPrintStream() - Constructor for class com.facebook.buck.util.CapturingPrintStream
-
- CasBlobDownloadEvent - Class in com.facebook.buck.remoteexecution.event
-
Started/Finished event pairs for CAS blob downloads .
- CasBlobDownloadEvent(EventKey) - Constructor for class com.facebook.buck.remoteexecution.event.CasBlobDownloadEvent
-
- CasBlobDownloadEvent.Finished - Class in com.facebook.buck.remoteexecution.event
-
Download to the CAS has finished.
- CasBlobDownloadEvent.Started - Class in com.facebook.buck.remoteexecution.event
-
Download to the CAS has started.
- CasBlobUploader - Interface in com.facebook.buck.remoteexecution
-
Interface used to upload inputs/outputs to the CAS.
- CasBlobUploader.UploadResult - Class in com.facebook.buck.remoteexecution
-
Result (status/error message) of an upload.
- CasBlobUploadEvent - Class in com.facebook.buck.remoteexecution.event
-
Started/Finished event pairs for CAS blob uploads .
- CasBlobUploadEvent(EventKey) - Constructor for class com.facebook.buck.remoteexecution.event.CasBlobUploadEvent
-
- CasBlobUploadEvent.Finished - Class in com.facebook.buck.remoteexecution.event
-
Upload to the CAS has finished.
- CasBlobUploadEvent.Started - Class in com.facebook.buck.remoteexecution.event
-
Upload to the CAS has started.
- cast(Class<U>) - Method in interface com.facebook.buck.core.model.targetgraph.TargetNode
-
- castArg(TargetNode<?>, Class<V>) - Static method in class com.facebook.buck.core.model.targetgraph.impl.TargetNodes
-
Type safe checked cast of the constructor arg.
- category - Variable in class com.facebook.buck.core.rules.impl.SymlinkTree
-
- cc - Variable in enum com.facebook.buck.android.toolchain.ndk.NdkCompilerType
-
- CcFlagsMacro - Interface in com.facebook.buck.rules.macros
-
$(cflags)
macro type.
- CcMacro - Interface in com.facebook.buck.rules.macros
-
$(cc)
macro type.
- cCompiler - Variable in class com.facebook.buck.features.ocaml.OcamlCCompileStep.Args
-
- cDepInput - Variable in class com.facebook.buck.features.ocaml.OcamlLinkStep
-
- cDepInput - Variable in class com.facebook.buck.features.ocaml.OcamlNativePluginStep
-
- Cell - Interface in com.facebook.buck.core.cell
-
Represents a single checkout of a code base.
- CellConfig - Class in com.facebook.buck.core.cell
-
Hierarcical configuration of cell/section/key/value quadruples.
- CellConfig() - Constructor for class com.facebook.buck.core.cell.CellConfig
-
- CellConfig.Builder - Class in com.facebook.buck.core.cell
-
- CellMappingsFactory - Class in com.facebook.buck.core.cell.impl
-
- CellName - Class in com.facebook.buck.core.cell
-
Describes a cell name relative to another cell.
- CellName() - Constructor for class com.facebook.buck.core.cell.CellName
-
- CellNameResolver - Interface in com.facebook.buck.core.cell.nameresolver
-
- cellNameResolverForCell(CanonicalCellName) - Method in class com.facebook.buck.core.cell.DefaultCellNameResolverProvider
-
- cellNameResolverForCell(CanonicalCellName) - Method in interface com.facebook.buck.core.cell.nameresolver.CellNameResolverProvider
-
- CellNameResolverProvider - Interface in com.facebook.buck.core.cell.nameresolver
-
- CellPathResolver - Interface in com.facebook.buck.core.cell
-
- CellPathResolverView - Class in com.facebook.buck.core.cell
-
View of a subset of cells of a cell path resolver.
- CellPathResolverView(CellPathResolver, CellNameResolver, ImmutableSet<String>, Path) - Constructor for class com.facebook.buck.core.cell.CellPathResolverView
-
- CellProvider - Class in com.facebook.buck.core.cell
-
- CellProvider(NewCellPathResolver, Function<CellProvider, CacheLoader<AbsPath, Cell>>, Function<CellProvider, Cell>) - Constructor for class com.facebook.buck.core.cell.CellProvider
-
Create a cell provider with a specific cell loader, and optionally a special factory function
for the root cell.
- CellRelativePath - Class in com.facebook.buck.core.model
-
- CellRelativePath() - Constructor for class com.facebook.buck.core.model.CellRelativePath
-
- Cells - Class in com.facebook.buck.core.cell
-
Access all cells.
- Cells(Cell) - Constructor for class com.facebook.buck.core.cell.Cells
-
- certificate - Variable in class com.facebook.buck.android.AppBuilderBase.PrivateKeyAndCertificate
-
- CertificateInfo(X509Certificate, ImmutableList<X509Certificate>) - Constructor for class com.facebook.buck.artifact_cache.ClientCertificateHandler.CertificateInfo
-
Create a new CertificateInfo instance
- cFlags - Variable in class com.facebook.buck.features.ocaml.OcamlCCompileStep.Args
-
- CGoCompileStep - Class in com.facebook.buck.features.go
-
- CGoCompileStep(AbsPath, ImmutableMap<String, String>, ImmutableList<String>, ImmutableList<String>, ImmutableList<String>, ImmutableList<String>, ImmutableList<Path>, GoPlatform, Path) - Constructor for class com.facebook.buck.features.go.CGoCompileStep
-
- CGoGenerateImportStep - Class in com.facebook.buck.features.go
-
- CGoGenerateImportStep(AbsPath, ImmutableList<String>, GoPlatform, Supplier<String>, Path, Path) - Constructor for class com.facebook.buck.features.go.CGoGenerateImportStep
-
- CGoGenImport - Class in com.facebook.buck.features.go
-
- CGoGenImport(BuildTarget, ProjectFilesystem, SourcePathRuleFinder, Tool, GoPlatform, SourcePath, SourcePath) - Constructor for class com.facebook.buck.features.go.CGoGenImport
-
- CGoGenSource - Class in com.facebook.buck.features.go
-
- CGoGenSource(BuildTarget, ProjectFilesystem, SourcePathRuleFinder, Preprocessor, ImmutableSet<SourcePath>, HeaderSymlinkTree, Tool, ImmutableList<String>, PreprocessorFlags, Preprocessor, GoPlatform) - Constructor for class com.facebook.buck.features.go.CGoGenSource
-
- CGoLibrary - Class in com.facebook.buck.features.go
-
The CGoLibrary represents cgo build process which outputs the linkable object that is appended to
the native go compiled program (via pack tool).
- CgoLibraryDescription - Class in com.facebook.buck.features.go
-
- CgoLibraryDescription(GoBuckConfig, CxxBuckConfig, ToolchainProvider) - Constructor for class com.facebook.buck.features.go.CgoLibraryDescription
-
- CgoLibraryDescriptionArg - Class in com.facebook.buck.features.go
-
Immutable implementation of CgoLibraryDescription.AbstractCgoLibraryDescriptionArg
.
- CgoLibraryDescriptionArg.Builder - Class in com.facebook.buck.features.go
-
- Change() - Constructor for class com.facebook.buck.io.watchman.WatchmanMultiplePathEvent.Change
-
- changedFiles(String) - Method in class com.facebook.buck.util.versioncontrol.DelegatingVersionControlCmdLineInterface
-
- changedFiles(String) - Method in class com.facebook.buck.util.versioncontrol.HgCmdLineInterface
-
- changedFiles(String) - Method in class com.facebook.buck.util.versioncontrol.NoOpCmdLineInterface
-
- changedFiles(String) - Method in interface com.facebook.buck.util.versioncontrol.VersionControlCmdLineInterface
-
- characters(char[], int, int) - Method in class com.facebook.buck.util.xml.PositionalXmlHandler
-
- check() - Method in class com.facebook.buck.android.exopackage.ExopackageInfo
-
- check() - Method in class com.facebook.buck.apple.GroupedSource
-
- check() - Method in class com.facebook.buck.artifact_cache.CacheResult
-
- check() - Method in interface com.facebook.buck.core.build.engine.manifest.ManifestStoreResult
-
- check() - Method in class com.facebook.buck.core.graph.transformation.model.ComposedKey
-
- check() - Method in interface com.facebook.buck.core.model.Flavor
-
- check() - Method in class com.facebook.buck.core.model.InternalFlavor
-
- check() - Method in class com.facebook.buck.core.model.RuleBasedTargetConfiguration
-
- check() - Method in class com.facebook.buck.core.model.RuleType
-
- check() - Method in class com.facebook.buck.core.model.targetgraph.impl.TargetNodeImpl
-
- check() - Method in class com.facebook.buck.core.model.UserFlavor
-
- check() - Method in class com.facebook.buck.core.parser.buildtargetpattern.BuildTargetPattern
-
Validate that target name is only present when necessary
- check() - Method in class com.facebook.buck.core.rules.knowntypes.KnownNativeRuleTypes
-
- check() - Method in class com.facebook.buck.core.sourcepath.ArchiveMemberSourcePath
-
- check() - Method in class com.facebook.buck.core.test.rule.CoercedTestRunnerSpec
-
- check() - Method in class com.facebook.buck.core.test.rule.TestRunnerSpec
-
- check() - Method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkTargetMode
-
- check() - Method in class com.facebook.buck.io.BuildCellRelativePath
-
Check the path is relative.
- check() - Method in class com.facebook.buck.parser.manifest.BuildPackagePathToBuildFileManifestKey
-
- check() - Method in class com.facebook.buck.parser.targetnode.BuildPackagePathToUnconfiguredTargetNodePackageKey
-
- check() - Method in class com.facebook.buck.parser.targetnode.BuildTargetToUnconfiguredTargetNodeKey
-
- check() - Method in class com.facebook.buck.parser.targetnode.UnconfiguredTargetNodeToUnconfiguredTargetNodeWithDepsKey
-
- check() - Method in class com.facebook.buck.rules.coercer.FrameworkPath
-
- check() - Method in class com.facebook.buck.rules.coercer.SourceSet
-
- check() - Method in class com.facebook.buck.rules.coercer.SourceSortedSet
-
- check() - Method in class com.facebook.buck.rules.coercer.SourceWithFlagsList
-
- check() - Method in class com.facebook.buck.rules.keys.DependencyFileEntry
-
- check(BuildRule) - Method in class com.facebook.buck.rules.modern.tools.IsolationChecker
-
Serializes an object.
- check() - Method in class com.facebook.buck.util.PatternAndMessage
-
- check() - Method in class com.facebook.buck.zip.ZipScrubberStep
-
- checkAccess(Path, AccessMode...) - Method in class com.facebook.buck.core.filesystems.BuckFileSystemProvider
-
- checkArchive(boolean, String) - Static method in class com.facebook.buck.cxx.toolchain.objectfile.ObjectFileScrubbers
-
- checkArgument(boolean, Object) - Static method in class com.facebook.buck.core.exceptions.UserVerify
-
Verifies that argument is true.
- checkArgument(boolean, String, Object...) - Static method in class com.facebook.buck.core.exceptions.UserVerify
-
Verifies that argument is true.
- checkBaseName(String, String) - Static method in class com.facebook.buck.core.parser.buildtargetparser.BaseNameParser
-
Check base name is valid (e.
- checkBuckOut() - Method in class com.facebook.buck.io.filesystem.BuckPaths
-
- checkComponents() - Method in class com.facebook.buck.core.cell.CellName
-
- checkDependencyConsistency() - Method in class com.facebook.buck.features.project.intellij.model.IjModule
-
- checkDuplicateSources(SourcePathResolverAdapter) - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
Checks that there are no files that appear both in srcs and platform_srcs
- checkForSourceOnlyAbiCompatibility() - Method in enum com.facebook.buck.jvm.java.abi.AbiGenerationMode
-
- checkGTestTestList() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- checkHeadersUsage() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
- checkHeadersUsage() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
- checkInputBasedCaches() - Method in class com.facebook.buck.core.build.engine.cache.manager.InputBasedRuleKeyManager
-
- checkMatchingDepfile() - Method in class com.facebook.buck.core.build.engine.cache.manager.DependencyFileRuleKeyManager
-
- checkModularUsage() - Method in interface com.facebook.buck.apple.AppleNativeTargetDescriptionArg
-
- checkOutputAssignableTo(TypeToken<S>) - Method in interface com.facebook.buck.rules.coercer.TypeCoercer
-
Runtime checked cast.
- checkPathExistsAndResolve(String, String) - Method in class com.facebook.buck.core.config.BuckConfig
-
- checkPrefixAndPrecompiledHeaderArgs() - Method in class com.facebook.buck.cxx.CxxSourceRuleFactory
-
- checkRuleIsBuiltForCorrectTarget(BuildTarget, BuildRule) - Method in class com.facebook.buck.core.rules.resolver.impl.AbstractActionGraphBuilder
-
- checkTargetSupportsMultiarch(BuildTarget) - Static method in class com.facebook.buck.apple.MultiarchFileInfos
-
Assert that target supports multiple architectures.
- checkUnconfiguredAssignableTo(TypeToken<S>) - Method in interface com.facebook.buck.rules.coercer.TypeCoercer
-
Runtime checked cast.
- checkVisibility(ObeysVisibility) - Method in interface com.facebook.buck.rules.visibility.VisibilityPattern
-
- child(DependencyStack.Element) - Method in class com.facebook.buck.core.exceptions.DependencyStack
-
Cons
- child(String) - Method in class com.facebook.buck.core.exceptions.DependencyStack
-
Cons
- ChromeTraceBuckConfig - Class in com.facebook.buck.event.chrome_trace
-
- ChromeTraceBuildListener - Class in com.facebook.buck.event.listener
-
Logs events to a json file formatted to be viewed in Chrome Trace View (chrome://tracing).
- ChromeTraceBuildListener(ProjectFilesystem, InvocationInfo, Clock, ChromeTraceBuckConfig, TaskManagerCommandScope, Optional<RemoteExecutionStatsProvider>, CriticalPathEventListener) - Constructor for class com.facebook.buck.event.listener.ChromeTraceBuildListener
-
- ChromeTraceEvent - Class in com.facebook.buck.event.chrome_trace
-
Json format for Chrome Trace events that can be viewed in chrome://tracing.
- ChromeTraceEvent(String, String, ChromeTraceEvent.Phase, long, long, long, long, ImmutableMap<String, ? extends Object>) - Constructor for class com.facebook.buck.event.chrome_trace.ChromeTraceEvent
-
- ChromeTraceEvent.Phase - Enum in com.facebook.buck.event.chrome_trace
-
- ChromeTraceParser - Class in com.facebook.buck.util.trace
-
- ChromeTraceParser(ProjectFilesystem) - Constructor for class com.facebook.buck.util.trace.ChromeTraceParser
-
- ChromeTraceParser.ChromeTraceEventMatcher<T> - Interface in com.facebook.buck.util.trace
-
Extracts data of interest if it finds a Chrome trace event of the type it is looking for.
- ChromeTraceWriter - Class in com.facebook.buck.event.chrome_trace
-
Type-safe utility to write Chrome trace events to files.
- ChromeTraceWriter(OutputStream) - Constructor for class com.facebook.buck.event.chrome_trace.ChromeTraceWriter
-
Create a writer backed by specified output stream.
- ChromeTraceWriter(JsonGenerator) - Constructor for class com.facebook.buck.event.chrome_trace.ChromeTraceWriter
-
Create a writer backed by specified json generator.
- CHUNK_RES_TABLE_PACKAGE - Static variable in class com.facebook.buck.android.resources.ResChunk
-
- CHUNK_RES_TABLE_TYPE - Static variable in class com.facebook.buck.android.resources.ResChunk
-
- CHUNK_RES_TABLE_TYPE_SPEC - Static variable in class com.facebook.buck.android.resources.ResChunk
-
- CHUNK_RESOURCE_TABLE - Static variable in class com.facebook.buck.android.resources.ResChunk
-
- CHUNK_STRING_POOL - Static variable in class com.facebook.buck.android.resources.ResChunk
-
- CHUNK_XML_REF_MAP - Static variable in class com.facebook.buck.android.resources.ResChunk
-
- CHUNK_XML_TREE - Static variable in class com.facebook.buck.android.resources.ResChunk
-
- ChunkAccumulator - Class in com.facebook.buck.util
-
Accumulates
String
chunks, keeping only the most recent to stay under a given maximum
size.
- ChunkAccumulator(Charset, long) - Constructor for class com.facebook.buck.util.ChunkAccumulator
-
- chunkArgs(Iterable<String>, int) - Static method in class com.facebook.buck.android.exopackage.RealAndroidDevice
-
Breaks a list of strings into groups whose total size is within some limit.
- ClangClCompiler - Class in com.facebook.buck.cxx.toolchain
-
Subclass of WindowsCompiler with overrides specific for clang-cl.
- ClangClCompiler(Tool) - Constructor for class com.facebook.buck.cxx.toolchain.ClangClCompiler
-
- ClangClPreprocessor - Class in com.facebook.buck.cxx.toolchain
-
Preprocessor implementation for compilations using clang-cl.
- ClangClPreprocessor(Tool) - Constructor for class com.facebook.buck.cxx.toolchain.ClangClPreprocessor
-
- ClangCompiler - Class in com.facebook.buck.cxx.toolchain
-
- ClangCompiler(Tool, ToolType, boolean) - Constructor for class com.facebook.buck.cxx.toolchain.ClangCompiler
-
- ClangCompiler(Tool, ToolType, boolean, boolean) - Constructor for class com.facebook.buck.cxx.toolchain.ClangCompiler
-
- ClangPreprocessor - Class in com.facebook.buck.cxx.toolchain
-
Preprocessor implementation for the Clang toolchain.
- ClangPreprocessor(Tool) - Constructor for class com.facebook.buck.cxx.toolchain.ClangPreprocessor
-
- ClangWindowsArchiver - Class in com.facebook.buck.cxx.toolchain
-
Archiver implementation for the Clang for Windows toolchain.
- ClangWindowsArchiver(Tool) - Constructor for class com.facebook.buck.cxx.toolchain.ClangWindowsArchiver
-
- ClangWindowsCompiler - Class in com.facebook.buck.cxx.toolchain
-
Compiler implementation for the Clang for Windows toolchain.
- ClangWindowsCompiler(Tool, ToolType, boolean) - Constructor for class com.facebook.buck.cxx.toolchain.ClangWindowsCompiler
-
- ClangWindowsPreprocessor - Class in com.facebook.buck.cxx.toolchain
-
Preprocessor implementation for the Clang toolchain.
- ClangWindowsPreprocessor(Tool) - Constructor for class com.facebook.buck.cxx.toolchain.ClangWindowsPreprocessor
-
- CLASS_ABI_FLAVOR - Static variable in class com.facebook.buck.jvm.core.JavaAbis
-
- CLASS_SECTION_HEADER - Static variable in class com.facebook.buck.android.WriteAppModuleMetadataStep
-
- ClassBasedComputationIdentifier<ResultType extends ComputeResult> - Class in com.facebook.buck.core.graph.transformation.model
-
- CLASSIFIER_SOURCES - Static variable in class com.facebook.buck.maven.aether.AetherUtil
-
- ClassInfo<T extends AddsToRuleKey> - Interface in com.facebook.buck.rules.modern
-
ClassInfo is used by ModernBuildRule to extract information from an AddsToRuleKey instance.
- ClassLoaderBootstrapper - Class in com.facebook.buck.cli.bootstrapper
-
This class sets up a separate ClassLoader for most of Buck's implementation, leaving only the
bare minimum bootstrapping classes (and a few classes for compatibility with library code that is
not ClassLoader-aware) in the system ClassLoader.
- ClassLoaderCache - Class in com.facebook.buck.util
-
Maintain a cache mapping class paths to class loaders that load from these class paths.
- ClassLoaderCache() - Constructor for class com.facebook.buck.util.ClassLoaderCache
-
- ClassNameFilter - Class in com.facebook.buck.android
-
Filter for internal class names.
- CLASSPATH_FILE_PROPERTY - Static variable in class com.facebook.buck.jvm.java.runner.FileClassPathRunner
-
- ClasspathAbiMacro - Class in com.facebook.buck.rules.macros
-
- ClasspathAbiMacro() - Constructor for class com.facebook.buck.rules.macros.ClasspathAbiMacro
-
- ClasspathAbiMacroExpander - Class in com.facebook.buck.rules.macros
-
Used to expand the macro $(classpath_abi //some:target) to the transitive abi's jars
path of that target, expanding all paths to be absolute.
- ClasspathAbiMacroExpander() - Constructor for class com.facebook.buck.rules.macros.ClasspathAbiMacroExpander
-
- ClasspathChecker - Class in com.facebook.buck.jvm.java
-
- ClasspathChecker() - Constructor for class com.facebook.buck.jvm.java.ClasspathChecker
-
- ClasspathFunction - Class in com.facebook.buck.rules.query
-
A classpath(expression [, depth]) expression that calculates targets in the classpath of the
given library or libraries.
- ClasspathFunction() - Constructor for class com.facebook.buck.rules.query.ClasspathFunction
-
- ClasspathMacro - Class in com.facebook.buck.rules.macros
-
- ClasspathMacro() - Constructor for class com.facebook.buck.rules.macros.ClasspathMacro
-
- ClasspathMacroExpander - Class in com.facebook.buck.rules.macros
-
Used to expand the macro $(classpath //some:target) to the transitive classpath of
that target, expanding all paths to be absolute.
- ClasspathMacroExpander() - Constructor for class com.facebook.buck.rules.macros.ClasspathMacroExpander
-
- ClasspathTraversal - Class in com.facebook.buck.jvm.java.classes
-
Traversal strategy for traversing a set of paths that themselves are traversed.
- ClasspathTraversal(Collection<Path>, ProjectFilesystem) - Constructor for class com.facebook.buck.jvm.java.classes.ClasspathTraversal
-
- ClasspathTraverser - Interface in com.facebook.buck.jvm.java.classes
-
- ClassUsageFileWriter - Interface in com.facebook.buck.jvm.java
-
- clean(BuckConfig, Path, Path, boolean, boolean) - Method in class com.facebook.buck.features.project.intellij.IJProjectCleaner
-
- clean(List<Diagnostic<? extends JavaFileObject>>) - Static method in class com.facebook.buck.jvm.java.DiagnosticCleaner
-
- clean(Path) - Method in class com.facebook.buck.util.DirectoryCleaner
-
- CleanBuildShutdownException - Exception in com.facebook.buck.util
-
* Exception sent to BuildEngine to shut it down cleanly, i.e.
- CleanBuildShutdownException(String) - Constructor for exception com.facebook.buck.util.CleanBuildShutdownException
-
- CleanCommand - Class in com.facebook.buck.cli
-
- CleanCommand() - Constructor for class com.facebook.buck.cli.CleanCommand
-
- CleanCommandBuckConfig - Class in com.facebook.buck.cli
-
Configuration options used by buck clean
command.
- CleanCommandBuckConfig() - Constructor for class com.facebook.buck.cli.CleanCommandBuckConfig
-
- cleanup(SimplePerfEvent.Scope) - Method in class com.facebook.buck.rules.keys.EventPostingRuleKeyCacheScope
-
Additional cleanup.
- clear() - Method in class com.facebook.buck.util.concurrent.LinkedBlockingStack
-
- clearCurrentThreadTracingInterfaceFromJsr199Javac() - Static method in class com.facebook.buck.event.api.BuckTracing
-
Used by Buck to disconnect this class from its tracing mechanism.
- clearLine() - Method in class com.facebook.buck.util.Ansi
-
Clears the line the cursor is currently on.
- clearPendingLogLines() - Method in class com.facebook.buck.event.listener.RenderingConsole
-
- clearToTheEndOfLine() - Method in class com.facebook.buck.util.Ansi
-
Clears from the cursor to the end of line.
- CliConfig - Class in com.facebook.buck.support.cli.config
-
- CliConfig() - Constructor for class com.facebook.buck.support.cli.config.CliConfig
-
- ClientCertificateHandler - Class in com.facebook.buck.artifact_cache
-
Holder and certificate parser for HTTPS client certificates.
- ClientCertificateHandler(HandshakeCertificates, Optional<HostnameVerifier>) - Constructor for class com.facebook.buck.artifact_cache.ClientCertificateHandler
-
- ClientCertificateHandler.CertificateInfo - Class in com.facebook.buck.artifact_cache
-
Holds response of parseCertificateChain
- ClientSideSlb - Class in com.facebook.buck.slb
-
- ClientSideSlb(ClientSideSlbConfig, OkHttpClient.Builder) - Constructor for class com.facebook.buck.slb.ClientSideSlb
-
- ClientSideSlb.ServerPing - Class in com.facebook.buck.slb
-
- clock - Variable in class com.facebook.buck.event.listener.AbstractConsoleEventBusListener
-
- Clock - Interface in com.facebook.buck.util.timing
-
- ClockDuration - Class in com.facebook.buck.util.timing
-
Represents a difference between two time points obtained by
Clock
.
- ClockDuration(long, long, long) - Constructor for class com.facebook.buck.util.timing.ClockDuration
-
- clone() - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- cloneWith(BuckConfig) - Method in interface com.facebook.buck.artifact_cache.ArtifactCacheFactory
-
- cloneWith(BuckConfig) - Method in class com.facebook.buck.artifact_cache.ArtifactCaches
-
- cloneWith(BuckConfig) - Method in class com.facebook.buck.artifact_cache.NoopArtifactCache.NoopArtifactCacheFactory
-
- cloneWith(BuckConfig) - Method in class com.facebook.buck.artifact_cache.SingletonArtifactCacheFactory
-
- cloneWithOutputStreams(PrintStream, PrintStream) - Method in class com.facebook.buck.util.ContextualProcessExecutor
-
- cloneWithOutputStreams(PrintStream, PrintStream) - Method in class com.facebook.buck.util.DefaultProcessExecutor
-
- cloneWithOutputStreams(PrintStream, PrintStream) - Method in interface com.facebook.buck.util.ProcessExecutor
-
Makes a clone of this process executor with the stdout and stderr streams overridden.
- close() - Method in class com.facebook.buck.android.AdbHelper
-
- close() - Method in class com.facebook.buck.android.dalvik.DalvikAwareOutputStreamHelper
-
- close() - Method in class com.facebook.buck.android.resources.ResourcesZipBuilder
-
- close() - Method in class com.facebook.buck.artifact_cache.AbstractNetworkCache
-
- close() - Method in interface com.facebook.buck.artifact_cache.ArtifactCache
-
- close() - Method in class com.facebook.buck.artifact_cache.ArtifactCaches
-
- close() - Method in class com.facebook.buck.artifact_cache.DirArtifactCache
-
- close() - Method in class com.facebook.buck.artifact_cache.FullyReadOnCloseInputStream
-
- close() - Method in class com.facebook.buck.artifact_cache.LoggingArtifactCacheDecorator
-
- close() - Method in class com.facebook.buck.artifact_cache.MultiArtifactCache
-
- close() - Method in class com.facebook.buck.artifact_cache.NoopArtifactCache
-
- close() - Method in class com.facebook.buck.artifact_cache.RetryingCacheDecorator
-
- close() - Method in class com.facebook.buck.artifact_cache.SQLiteArtifactCache
-
- close() - Method in class com.facebook.buck.artifact_cache.ThriftArtifactCacheProtocol.Response
-
- close() - Method in class com.facebook.buck.artifact_cache.TwoLevelArtifactCacheDecorator
-
- close() - Method in class com.facebook.buck.cli.bootstrapper.CompressingFileHandler
-
- close() - Method in class com.facebook.buck.cli.bootstrapper.ConsoleHandler
-
- close() - Method in class com.facebook.buck.cli.bootstrapper.LogFileHandler
-
- close() - Method in class com.facebook.buck.cli.bootstrapper.MemoryHandler
-
- close() - Method in class com.facebook.buck.cli.CommandThreadManager
-
- close() - Method in class com.facebook.buck.command.Build
-
- close() - Method in interface com.facebook.buck.core.build.engine.buildinfo.BuildInfoStore
-
- close() - Method in class com.facebook.buck.core.build.engine.buildinfo.SQLiteBuildInfoStore
-
- close() - Method in class com.facebook.buck.core.build.engine.cache.manager.BuildInfoStoreManager
-
- close() - Method in class com.facebook.buck.core.build.engine.impl.CachingBuildEngine
-
- close() - Method in class com.facebook.buck.core.build.execution.context.ExecutionContext
-
- close() - Method in class com.facebook.buck.core.filesystems.BuckFileSystem
-
- close() - Method in interface com.facebook.buck.core.graph.transformation.executor.DepsAwareExecutor
-
Shuts down the executor workers immediately.
- close() - Method in class com.facebook.buck.core.graph.transformation.executor.impl.JavaExecutorBackedDefaultDepsAwareExecutor
-
- close() - Method in interface com.facebook.buck.core.graph.transformation.GraphTransformationEngine
-
Shuts down the engine and rejects any future computations
- close() - Method in class com.facebook.buck.core.graph.transformation.impl.DefaultGraphTransformationEngine
-
- close() - Method in interface com.facebook.buck.core.rules.build.strategy.BuildRuleStrategy
-
- close() - Method in interface com.facebook.buck.core.rules.pipeline.RulePipelineState
-
Called after the pipeline is done (either through success or failure partway through) to
release resources.
- close() - Method in class com.facebook.buck.counters.CounterRegistryImpl
-
- close() - Method in class com.facebook.buck.event.api.BuckTracing.TraceSection
-
- close() - Method in interface com.facebook.buck.event.BuckEventListener
-
Cleanup, output any trace data collected to the backing store.
- close() - Method in class com.facebook.buck.event.chrome_trace.ChromeTraceWriter
-
Close the underlying json generator.
- close() - Method in class com.facebook.buck.event.DefaultBuckEventBus
-
- close() - Method in class com.facebook.buck.event.listener.AbstractConsoleEventBusListener
-
- close() - Method in class com.facebook.buck.event.listener.BuckEventOrderer
-
- close() - Method in class com.facebook.buck.event.listener.ChromeTraceBuildListener
-
- close() - Method in class com.facebook.buck.event.listener.FileSerializationOutputRuleDepsListener
-
- close() - Method in class com.facebook.buck.event.listener.HttpArtifactCacheEventListener
-
- close() - Method in class com.facebook.buck.event.listener.JavaUtilsLoggingBuildListener
-
- close() - Method in class com.facebook.buck.event.listener.LoggingBuildListener
-
- close() - Method in class com.facebook.buck.event.listener.LogUploaderListener
-
- close() - Method in class com.facebook.buck.event.listener.MachineReadableLoggerListener
-
- close() - Method in class com.facebook.buck.event.listener.RenderingConsole
-
Shuts down rendering.
- close() - Method in class com.facebook.buck.event.listener.RuleKeyDiagnosticsListener
-
- close() - Method in class com.facebook.buck.event.listener.RuleKeyLoggerListener
-
- close() - Method in class com.facebook.buck.event.listener.SuperConsoleEventBusListener
-
- close() - Method in class com.facebook.buck.event.listener.util.ProgressEstimator
-
- close() - Method in interface com.facebook.buck.event.SimplePerfEvent.Scope
-
- close() - Method in class com.facebook.buck.httpserver.WebServerBuckEventListener
-
- close() - Method in class com.facebook.buck.io.unixsocket.UnixDomainSocket
-
- close() - Method in interface com.facebook.buck.io.watchman.WatchmanClient
-
- close() - Method in class com.facebook.buck.io.windowspipe.WindowsNamedPipe
-
- close() - Method in class com.facebook.buck.jvm.java.abi.JarBuilderStubJarWriter
-
- close() - Method in interface com.facebook.buck.jvm.java.Javac.Invocation
-
- close() - Method in class com.facebook.buck.jvm.java.JavacEventSinkScopedSimplePerfEvent
-
- close() - Method in class com.facebook.buck.jvm.java.JavacPipelineState
-
- close() - Method in class com.facebook.buck.jvm.java.PluginFactory
-
- close() - Method in class com.facebook.buck.jvm.java.tracing.TranslatingJavacPhaseTracer
-
- close() - Method in class com.facebook.buck.log.AsyncLogHandler
-
- close() - Method in class com.facebook.buck.log.ConsoleHandler
-
- close() - Method in interface com.facebook.buck.log.ConsoleHandlerState.Writer
-
- close() - Method in interface com.facebook.buck.log.GlobalStateManager.LoggerIsMappedToThreadScope
-
- close() - Method in class com.facebook.buck.log.LogFileHandler
-
- close() - Method in class com.facebook.buck.log.LogFileHandlerDispatcher
-
- close() - Method in class com.facebook.buck.log.memory.MemoryHandler
-
- close() - Method in class com.facebook.buck.log.ReferenceCountedWriter
-
- close() - Method in class com.facebook.buck.log.thrift.ThriftRuleKeyLogger
-
Close the output stream
- close() - Method in interface com.facebook.buck.parser.api.FileParser
-
- close() - Method in class com.facebook.buck.parser.api.ForwardingProjectBuildFileParserDecorator
-
- close() - Method in class com.facebook.buck.parser.BuildTargetRawNodeParsePipeline
-
- close() - Method in class com.facebook.buck.parser.ConcurrentProjectBuildFileParser
-
- close() - Method in class com.facebook.buck.parser.decorators.EventReportingProjectBuildFileParser
-
- close() - Method in class com.facebook.buck.parser.GenericFileParsePipeline
-
- close() - Method in class com.facebook.buck.parser.HybridProjectBuildFileParser
-
- close() - Method in class com.facebook.buck.parser.PerBuildState
-
- close() - Method in class com.facebook.buck.parser.PythonDslProjectBuildFileParser
-
- close() - Method in class com.facebook.buck.parser.TargetSpecResolver
-
- close() - Method in class com.facebook.buck.parser.UnconfiguredTargetNodePipeline
-
- close() - Method in class com.facebook.buck.parser.UnconfiguredTargetNodeToTargetNodeParsePipeline
-
- close() - Method in class com.facebook.buck.remoteexecution.grpc.GrpcRemoteExecutionClients
-
- close() - Method in class com.facebook.buck.remoteexecution.grpc.server.GrpcServer
-
- close() - Method in class com.facebook.buck.remoteexecution.util.OutOfProcessIsolatedExecutionClients
-
- close() - Method in class com.facebook.buck.rules.keys.DefaultRuleKeyScopedHasher.DefaultContainerScope
-
Hashes the container iff non-empty (i.e.
- close() - Method in class com.facebook.buck.rules.keys.EventPostingRuleKeyCacheScope
-
- close() - Method in interface com.facebook.buck.rules.keys.RuleKeyCacheScope
-
- close() - Method in class com.facebook.buck.rules.modern.builders.HybridLocalStrategy
-
- close() - Method in class com.facebook.buck.rules.modern.builders.LocalFallbackStrategy
-
- close() - Method in class com.facebook.buck.rules.modern.builders.RemoteExecutionStrategy
-
- close() - Method in class com.facebook.buck.slb.ClientSideSlb
-
- close() - Method in interface com.facebook.buck.slb.HttpLoadBalancer
-
- close() - Method in interface com.facebook.buck.slb.HttpService
-
- close() - Method in class com.facebook.buck.slb.HybridThriftOverHttpServiceImpl
-
- close() - Method in class com.facebook.buck.slb.LoadBalancedHttpResponse
-
- close() - Method in class com.facebook.buck.slb.LoadBalancedService
-
- close() - Method in class com.facebook.buck.slb.OkHttpResponseWrapper
-
- close() - Method in class com.facebook.buck.slb.RetryingHttpService
-
- close() - Method in class com.facebook.buck.slb.SingleUriService
-
- close() - Method in class com.facebook.buck.slb.ThriftOverHttpServiceImpl
-
- close() - Method in class com.facebook.buck.support.bgtasks.TaskManagerCommandScope
-
- close() - Method in class com.facebook.buck.support.state.BuckGlobalState
-
- close() - Method in class com.facebook.buck.util.AbstractCloseableMemoizedSupplier
-
- close() - Method in class com.facebook.buck.util.AbstractCloseableWrapper
-
- close() - Method in class com.facebook.buck.util.ClassLoaderCache
-
- close() - Method in class com.facebook.buck.util.CloseableHolder
-
- close() - Method in interface com.facebook.buck.util.concurrent.AssertScopeExclusiveAccess.Scope
-
- close() - Method in class com.facebook.buck.util.concurrent.AutoCloseableLock
-
- close() - Method in class com.facebook.buck.util.concurrent.ResourcePool
-
- close() - Method in class com.facebook.buck.util.hash.HasherOutputStream
-
- close() - Method in class com.facebook.buck.util.LineFetcher
-
- close() - Method in class com.facebook.buck.util.NamedTemporaryDirectory
-
- close() - Method in class com.facebook.buck.util.NamedTemporaryFile
-
- close() - Method in class com.facebook.buck.util.network.offline.OfflineScribeLogger
-
- close() - Method in class com.facebook.buck.util.network.ThriftScribeLogger
-
- close() - Method in class com.facebook.buck.util.perf.PerfStatsTracking
-
- close() - Method in class com.facebook.buck.util.perf.ProcessTracker
-
- close() - Method in interface com.facebook.buck.util.Scope
-
- close() - Method in class com.facebook.buck.util.TeeOutputStream
-
- close() - Method in class com.facebook.buck.util.zip.CustomZipOutputStream
-
- close() - Method in class com.facebook.buck.util.zip.DeterministicZipBuilder
-
- close() - Method in interface com.facebook.buck.util.zip.JarEntryContainer
-
- close() - Method in class com.facebook.buck.worker.WorkerProcess
-
- close() - Method in interface com.facebook.buck.worker.WorkerProcessPool
-
- close() - Method in class com.facebook.buck.worker.WorkerProcessPoolAsync
-
- close() - Method in class com.facebook.buck.worker.WorkerProcessPoolSync.BorrowedWorkerProcess
-
Returns ownership of the borrowed worker process back to the pool it was retrieved from.
- close() - Method in class com.facebook.buck.worker.WorkerProcessPoolSync
-
- close() - Method in interface com.facebook.buck.worker.WorkerProcessProtocol.CommandSender
-
Instructs the CommandReceiver to shut itself down.
- close() - Method in class com.facebook.buck.worker.WorkerProcessProtocolZero.CommandSender
-
- CloseableHolder<T extends Closeable> - Class in com.facebook.buck.util
-
CloseableHolder is used to pass ownership of a Closeable.
- CloseableHolder(T) - Constructor for class com.facebook.buck.util.CloseableHolder
-
- CloseableMemoizedSupplier<T> - Class in com.facebook.buck.util
-
Convenience wrapper class to attach closeable functionality to suppliers of resources to be
closed.
- CloseableWrapper<T> - Class in com.facebook.buck.util
-
Convenience wrapper class to attach closeable functionality to non-closeable class so it can be
used with try-with-resources to make sure resources are always released and proper exception
suppression is used.
- closeEntry() - Method in class com.facebook.buck.util.zip.CustomZipOutputStream
-
- CloseHandle(WinNT.HANDLE) - Method in interface com.facebook.buck.io.windowspipe.WindowsNamedPipeLibrary
-
- closeLogFile() - Static method in class com.facebook.buck.event.listener.JavaUtilsLoggingBuildListener
-
- closeStdin(boolean) - Method in interface com.facebook.buck.util.ListeningProcessExecutor.LaunchedProcess
-
Closes the stdin of the process.
- cmd - Variable in class com.facebook.buck.shell.GenruleBuildable
-
The shell command to run to generate the output file.
- cmdExe - Variable in class com.facebook.buck.shell.GenruleBuildable
-
The cmd shell command to generate the output file.
- CmdLineParserWithPrintInformation - Class in com.facebook.buck.support.cli.args
-
An implementation of CmdLineParser
that can provide some information that can be used to
print help in more flexible form than CmdLineParser
.
- CmdLineParserWithPrintInformation(Object) - Constructor for class com.facebook.buck.support.cli.args.CmdLineParserWithPrintInformation
-
- CODE_SIGN_ENTITLEMENTS - Static variable in class com.facebook.buck.apple.AppleBundle
-
- coderResult - Variable in class com.facebook.buck.util.charset.NulTerminatedCharsetDecoder.Result
-
- CodeSignIdentity - Class in com.facebook.buck.apple.toolchain
-
Represents a identity used in code signing.
- CodeSignIdentity() - Constructor for class com.facebook.buck.apple.toolchain.CodeSignIdentity
-
- CodeSignIdentityStore - Interface in com.facebook.buck.apple.toolchain
-
A collection of code sign identities.
- CodeSignIdentityStoreFactory - Class in com.facebook.buck.apple.toolchain.impl
-
- CodeSignIdentityStoreFactory() - Constructor for class com.facebook.buck.apple.toolchain.impl.CodeSignIdentityStoreFactory
-
- coerce(TestRunnerSpec, StringWithMacrosConverter) - Static method in class com.facebook.buck.core.test.rule.coercer.TestRunnerSpecCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, ImmutableList<String>) - Method in class com.facebook.buck.rules.coercer.AbsoluteOutputMacroTypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, Object) - Method in class com.facebook.buck.rules.coercer.BuildConfigFieldsTypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, ImmutableList<String>) - Method in class com.facebook.buck.rules.coercer.BuildTargetMacroTypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, UnconfiguredBuildTarget) - Method in class com.facebook.buck.rules.coercer.BuildTargetTypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, UnconfiguredBuildTargetWithOutputs) - Method in class com.facebook.buck.rules.coercer.BuildTargetWithOutputsTypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, ImmutableList<String>) - Method in class com.facebook.buck.rules.coercer.CxxGenruleFilterAndTargetsMacroTypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, Object) - Method in class com.facebook.buck.rules.coercer.CxxLinkGroupMappingCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, Object) - Method in class com.facebook.buck.rules.coercer.CxxLinkGroupMappingTargetCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, Object) - Method in class com.facebook.buck.rules.coercer.CxxLinkGroupMappingTargetTraversalCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, Either<LU, RU>) - Method in class com.facebook.buck.rules.coercer.EitherTypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, ImmutableList<String>) - Method in class com.facebook.buck.rules.coercer.EnvMacroTypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, Object) - Method in class com.facebook.buck.rules.coercer.FrameworkPathTypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, Object) - Method in class com.facebook.buck.rules.coercer.ImmutableTypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, T) - Method in class com.facebook.buck.rules.coercer.LeafUnconfiguredOnlyCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, ImmutableList<U>) - Method in class com.facebook.buck.rules.coercer.ListTypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, Object) - Method in class com.facebook.buck.rules.coercer.ManifestEntriesTypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, ImmutableMap<KU, VU>) - Method in class com.facebook.buck.rules.coercer.MapTypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, Object) - Method in class com.facebook.buck.rules.coercer.NeededCoverageSpecTypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, Optional<U>) - Method in class com.facebook.buck.rules.coercer.OptionalTypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, ImmutableList<String>) - Method in class com.facebook.buck.rules.coercer.OutputMacroTypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, Pair<FU, SU>) - Method in class com.facebook.buck.rules.coercer.PairTypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, Object) - Method in class com.facebook.buck.rules.coercer.PatternMatchedCollectionTypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, Object) - Method in class com.facebook.buck.rules.coercer.QueryCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, ImmutableSet<U>) - Method in class com.facebook.buck.rules.coercer.SetTypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, ImmutableSortedMap<KU, VU>) - Method in class com.facebook.buck.rules.coercer.SortedMapTypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, ImmutableList<U>) - Method in class com.facebook.buck.rules.coercer.SortedSetTypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, UnconfiguredSourcePath) - Method in class com.facebook.buck.rules.coercer.SourcePathTypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, Object) - Method in class com.facebook.buck.rules.coercer.SourceSetTypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, Object) - Method in class com.facebook.buck.rules.coercer.SourceSortedSetTypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, Object) - Method in class com.facebook.buck.rules.coercer.SourceWithFlagsListTypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, Object) - Method in class com.facebook.buck.rules.coercer.SourceWithFlagsTypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, Object) - Method in class com.facebook.buck.rules.coercer.StringWithMacrosTypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, Object) - Method in class com.facebook.buck.rules.coercer.TestRunnerSpecCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, U) - Method in interface com.facebook.buck.rules.coercer.TypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, Object) - Method in class com.facebook.buck.rules.coercer.VersionMatchedCollectionTypeCoercer
-
- coerce(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, ImmutableList<String>) - Method in class com.facebook.buck.rules.coercer.ZeroArgMacroTypeCoercer
-
- coerceBoth(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, Object) - Method in interface com.facebook.buck.rules.coercer.TypeCoercer
-
- CoercedTestRunnerSpec - Class in com.facebook.buck.core.test.rule
-
The freeform JSON test protocol specification.
- CoercedTestRunnerSpec() - Constructor for class com.facebook.buck.core.test.rule.CoercedTestRunnerSpec
-
- CoerceFailedException - Exception in com.facebook.buck.rules.coercer
-
- CoerceFailedException(String) - Constructor for exception com.facebook.buck.rules.coercer.CoerceFailedException
-
- CoerceFailedException(String, Throwable) - Constructor for exception com.facebook.buck.rules.coercer.CoerceFailedException
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.BuildTargetTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.BuildTargetWithOutputsTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.ConstraintTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.CxxLinkGroupMappingCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.CxxLinkGroupMappingTargetCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.EitherTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.EnumTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.FlavorTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.FrameworkPathTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.IdentityTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.ImmutableTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.LeafTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.ListTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.LogLevelTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.MapTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.NeededCoverageSpecTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.NumberTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.OptionalTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.PairTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.PathTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.PatternMatchedCollectionTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.PatternTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.QueryCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.SetTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.SortedMapTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.SortedSetTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.SourcePathTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.SourceSetTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.SourceSortedSetTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.SourceWithFlagsListTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.SourceWithFlagsTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.StringWithMacrosTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.TestRunnerSpecCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in interface com.facebook.buck.rules.coercer.TypeCoercer
-
Coerce to a value for unconfigured graph.
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.UnconfiguredBuildTargetTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.UnconfiguredBuildTargetWithOutputsTypeCoercer
-
- coerceToUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, Object) - Method in class com.facebook.buck.rules.coercer.VersionMatchedCollectionTypeCoercer
-
- collect() - Method in class com.facebook.buck.core.exceptions.DependencyStack
-
Collect the stack elements, top first
- collect(Set<Path>, Path) - Method in class com.facebook.buck.remoteexecution.util.OutputsCollector
-
Returns the collected output information.
- collectAndSubmitResult() - Method in class com.facebook.buck.doctor.AbstractReport
-
- collectCxxPreprocessorInput(BuildTarget, CxxPlatform, ActionGraphBuilder, Iterable<BuildRule>, ImmutableMultimap<CxxSource.Type, ? extends Arg>, ImmutableList<HeaderSymlinkTree>, ImmutableSet<FrameworkPath>, Iterable<CxxPreprocessorInput>, ImmutableSortedSet<SourcePath>, ImmutableSortedSet<String>, ProjectFilesystem) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- collectDirectAssetCatalogs(TargetGraph, TargetNode<?>) - Static method in class com.facebook.buck.apple.AppleBuildRules
-
- collectDirectResources(TargetGraph, TargetNode<?>) - Static method in class com.facebook.buck.apple.AppleResources
-
- CollectedOutputs(ImmutableList<Protocol.OutputFile>, ImmutableList<Protocol.OutputDirectory>, ImmutableSet<UploadDataSupplier>) - Constructor for class com.facebook.buck.remoteexecution.util.OutputsCollector.CollectedOutputs
-
- collectInitializationErrors(List<Throwable>) - Method in class com.facebook.buck.testrunner.BuckBlockJUnit4ClassRunner
-
Override default init error collector so that class without any test methods will pass
- CollectionTypeCoercer<D extends com.google.common.collect.ImmutableCollection<U>,C extends com.google.common.collect.ImmutableCollection<T>,U,T> - Class in com.facebook.buck.rules.coercer
-
Base class for ImmutableCollection
subclasses coercers.
- collectNodesWithExportInfo() - Method in class com.facebook.buck.cxx.toolchain.objectfile.MachoExportTrieNode
-
Performs a depth-first traversal of the trie and collects all nodes which have non-null export
info.
- collectRecursiveAssetCatalogs(XCodeDescriptions, TargetGraph, Optional<AppleDependenciesCache>, Iterable<TargetNode<T>>, AppleBuildRules.RecursiveDependenciesMode, Predicate<BuildTarget>) - Static method in class com.facebook.buck.apple.AppleBuildRules
-
Collect recursive asset catalogs
- collectRecursiveResources(XCodeDescriptions, TargetGraph, Optional<AppleDependenciesCache>, TargetNode<?>, AppleBuildRules.RecursiveDependenciesMode) - Static method in class com.facebook.buck.apple.AppleResources
-
Collect resources from recursive dependencies.
- collectRecursiveWrapperResources(XCodeDescriptions, TargetGraph, Optional<AppleDependenciesCache>, Iterable<TargetNode<T>>, AppleBuildRules.RecursiveDependenciesMode) - Static method in class com.facebook.buck.apple.AppleBuildRules
-
Collect recursive wrapper resources
- collectResourceDirsAndFiles(XCodeDescriptions, TargetGraph, BuildRuleResolver, Optional<AppleDependenciesCache>, TargetNode<T>, AppleCxxPlatform, AppleBuildRules.RecursiveDependenciesMode, Predicate<BuildTarget>) - Static method in class com.facebook.buck.apple.AppleResources
-
Collect resource dirs and files
- collectStringsFilterAdjacentDupes() - Method in class com.facebook.buck.core.exceptions.DependencyStack
-
Collect the stack elements, top first, converting all elements to strings, and filtering out
adjacent duplicates.
- collectTargetPatterns(Collection<String>) - Method in class com.facebook.buck.query.QueryExpression
-
Collects all target patterns that are referenced anywhere within this query expression and adds
them to the given collection, which must be mutable.
- collectTransitiveBuildRuleTargets(XCodeDescriptions, TargetGraph, Optional<AppleDependenciesCache>, ImmutableSet<Class<? extends BaseDescription<?>>>, Collection<TargetNode<?>>, AppleBuildRules.RecursiveDependenciesMode) - Static method in class com.facebook.buck.apple.AppleBuildRules
-
Collects transitive target nodes of type included in descriptionClasses
- collectTransitiveBuildRuleTargetsWithTransform(XCodeDescriptions, TargetGraph, Optional<AppleDependenciesCache>, ImmutableSet<Class<? extends BaseDescription<?>>>, Collection<TargetNode<?>>, AppleBuildRules.RecursiveDependenciesMode, Function<TargetNode<?>, T>, Predicate<BuildTarget>) - Static method in class com.facebook.buck.apple.AppleBuildRules
-
Collect the transitive target node dependencies using some RecursiveDependenciesMode.
- collectTransitiveBuildTargetArg(XCodeDescriptions, TargetGraph, Optional<AppleDependenciesCache>, ImmutableSet<Class<? extends BaseDescription<?>>>, Collection<TargetNode<?>>, AppleBuildRules.RecursiveDependenciesMode, Predicate<BuildTarget>) - Static method in class com.facebook.buck.apple.AppleBuildRules
-
- com.facebook.buck.android - package com.facebook.buck.android
-
- com.facebook.buck.android.aapt - package com.facebook.buck.android.aapt
-
- com.facebook.buck.android.agent - package com.facebook.buck.android.agent
-
- com.facebook.buck.android.agent.util - package com.facebook.buck.android.agent.util
-
- com.facebook.buck.android.apkmodule - package com.facebook.buck.android.apkmodule
-
- com.facebook.buck.android.dalvik - package com.facebook.buck.android.dalvik
-
- com.facebook.buck.android.dalvik.firstorder - package com.facebook.buck.android.dalvik.firstorder
-
- com.facebook.buck.android.device - package com.facebook.buck.android.device
-
- com.facebook.buck.android.exopackage - package com.facebook.buck.android.exopackage
-
- com.facebook.buck.android.packageable - package com.facebook.buck.android.packageable
-
- com.facebook.buck.android.redex - package com.facebook.buck.android.redex
-
- com.facebook.buck.android.relinker - package com.facebook.buck.android.relinker
-
- com.facebook.buck.android.resources - package com.facebook.buck.android.resources
-
- com.facebook.buck.android.toolchain - package com.facebook.buck.android.toolchain
-
- com.facebook.buck.android.toolchain.common - package com.facebook.buck.android.toolchain.common
-
- com.facebook.buck.android.toolchain.impl - package com.facebook.buck.android.toolchain.impl
-
- com.facebook.buck.android.toolchain.ndk - package com.facebook.buck.android.toolchain.ndk
-
- com.facebook.buck.android.toolchain.ndk.impl - package com.facebook.buck.android.toolchain.ndk.impl
-
- com.facebook.buck.android.toolchain.platform - package com.facebook.buck.android.toolchain.platform
-
- com.facebook.buck.apple - package com.facebook.buck.apple
-
- com.facebook.buck.apple.clang - package com.facebook.buck.apple.clang
-
- com.facebook.buck.apple.device - package com.facebook.buck.apple.device
-
- com.facebook.buck.apple.platform_type - package com.facebook.buck.apple.platform_type
-
- com.facebook.buck.apple.simulator - package com.facebook.buck.apple.simulator
-
- com.facebook.buck.apple.toolchain - package com.facebook.buck.apple.toolchain
-
- com.facebook.buck.apple.toolchain.impl - package com.facebook.buck.apple.toolchain.impl
-
- com.facebook.buck.apple.xcode - package com.facebook.buck.apple.xcode
-
- com.facebook.buck.apple.xcode.xcodeproj - package com.facebook.buck.apple.xcode.xcodeproj
-
- com.facebook.buck.artifact_cache - package com.facebook.buck.artifact_cache
-
- com.facebook.buck.artifact_cache.config - package com.facebook.buck.artifact_cache.config
-
- com.facebook.buck.cli - package com.facebook.buck.cli
-
- com.facebook.buck.cli.bootstrapper - package com.facebook.buck.cli.bootstrapper
-
- com.facebook.buck.command - package com.facebook.buck.command
-
- com.facebook.buck.command.config - package com.facebook.buck.command.config
-
- com.facebook.buck.core.artifact - package com.facebook.buck.core.artifact
-
- com.facebook.buck.core.artifact.converter - package com.facebook.buck.core.artifact.converter
-
- com.facebook.buck.core.build.action - package com.facebook.buck.core.build.action
-
- com.facebook.buck.core.build.action.resolver - package com.facebook.buck.core.build.action.resolver
-
- com.facebook.buck.core.build.buildable.context - package com.facebook.buck.core.build.buildable.context
-
- com.facebook.buck.core.build.context - package com.facebook.buck.core.build.context
-
- com.facebook.buck.core.build.engine - package com.facebook.buck.core.build.engine
-
- com.facebook.buck.core.build.engine.buildinfo - package com.facebook.buck.core.build.engine.buildinfo
-
- com.facebook.buck.core.build.engine.cache.manager - package com.facebook.buck.core.build.engine.cache.manager
-
- com.facebook.buck.core.build.engine.config - package com.facebook.buck.core.build.engine.config
-
- com.facebook.buck.core.build.engine.delegate - package com.facebook.buck.core.build.engine.delegate
-
- com.facebook.buck.core.build.engine.impl - package com.facebook.buck.core.build.engine.impl
-
- com.facebook.buck.core.build.engine.manifest - package com.facebook.buck.core.build.engine.manifest
-
- com.facebook.buck.core.build.engine.type - package com.facebook.buck.core.build.engine.type
-
- com.facebook.buck.core.build.event - package com.facebook.buck.core.build.event
-
- com.facebook.buck.core.build.execution.context - package com.facebook.buck.core.build.execution.context
-
- com.facebook.buck.core.build.stats - package com.facebook.buck.core.build.stats
-
- com.facebook.buck.core.cell - package com.facebook.buck.core.cell
-
- com.facebook.buck.core.cell.exception - package com.facebook.buck.core.cell.exception
-
- com.facebook.buck.core.cell.impl - package com.facebook.buck.core.cell.impl
-
- com.facebook.buck.core.cell.name - package com.facebook.buck.core.cell.name
-
- com.facebook.buck.core.cell.nameresolver - package com.facebook.buck.core.cell.nameresolver
-
- com.facebook.buck.core.config - package com.facebook.buck.core.config
-
- com.facebook.buck.core.description - package com.facebook.buck.core.description
-
- com.facebook.buck.core.description.arg - package com.facebook.buck.core.description.arg
-
- com.facebook.buck.core.description.attr - package com.facebook.buck.core.description.attr
-
- com.facebook.buck.core.description.impl - package com.facebook.buck.core.description.impl
-
- com.facebook.buck.core.description.metadata - package com.facebook.buck.core.description.metadata
-
- com.facebook.buck.core.exceptions - package com.facebook.buck.core.exceptions
-
- com.facebook.buck.core.exceptions.config - package com.facebook.buck.core.exceptions.config
-
- com.facebook.buck.core.files - package com.facebook.buck.core.files
-
- com.facebook.buck.core.filesystems - package com.facebook.buck.core.filesystems
-
- com.facebook.buck.core.graph.transformation - package com.facebook.buck.core.graph.transformation
-
- com.facebook.buck.core.graph.transformation.composition - package com.facebook.buck.core.graph.transformation.composition
-
- com.facebook.buck.core.graph.transformation.executor - package com.facebook.buck.core.graph.transformation.executor
-
- com.facebook.buck.core.graph.transformation.executor.config - package com.facebook.buck.core.graph.transformation.executor.config
-
- com.facebook.buck.core.graph.transformation.executor.factory - package com.facebook.buck.core.graph.transformation.executor.factory
-
- com.facebook.buck.core.graph.transformation.executor.impl - package com.facebook.buck.core.graph.transformation.executor.impl
-
- com.facebook.buck.core.graph.transformation.impl - package com.facebook.buck.core.graph.transformation.impl
-
- com.facebook.buck.core.graph.transformation.model - package com.facebook.buck.core.graph.transformation.model
-
- com.facebook.buck.core.io - package com.facebook.buck.core.io
-
- com.facebook.buck.core.linkgroup - package com.facebook.buck.core.linkgroup
-
- com.facebook.buck.core.macros - package com.facebook.buck.core.macros
-
- com.facebook.buck.core.model - package com.facebook.buck.core.model
-
- com.facebook.buck.core.model.actiongraph - package com.facebook.buck.core.model.actiongraph
-
- com.facebook.buck.core.model.actiongraph.computation - package com.facebook.buck.core.model.actiongraph.computation
-
- com.facebook.buck.core.model.graph - package com.facebook.buck.core.model.graph
-
- com.facebook.buck.core.model.impl - package com.facebook.buck.core.model.impl
-
- com.facebook.buck.core.model.platform - package com.facebook.buck.core.model.platform
-
- com.facebook.buck.core.model.platform.impl - package com.facebook.buck.core.model.platform.impl
-
- com.facebook.buck.core.model.targetgraph - package com.facebook.buck.core.model.targetgraph
-
- com.facebook.buck.core.model.targetgraph.impl - package com.facebook.buck.core.model.targetgraph.impl
-
- com.facebook.buck.core.model.targetgraph.raw - package com.facebook.buck.core.model.targetgraph.raw
-
- com.facebook.buck.core.model.tc.factory - package com.facebook.buck.core.model.tc.factory
-
- com.facebook.buck.core.module - package com.facebook.buck.core.module
-
- com.facebook.buck.core.module.annotationprocessor - package com.facebook.buck.core.module.annotationprocessor
-
- com.facebook.buck.core.module.impl - package com.facebook.buck.core.module.impl
-
- com.facebook.buck.core.parser - package com.facebook.buck.core.parser
-
- com.facebook.buck.core.parser.buildtargetparser - package com.facebook.buck.core.parser.buildtargetparser
-
- com.facebook.buck.core.parser.buildtargetpattern - package com.facebook.buck.core.parser.buildtargetpattern
-
- com.facebook.buck.core.path - package com.facebook.buck.core.path
-
- com.facebook.buck.core.plugin - package com.facebook.buck.core.plugin
-
- com.facebook.buck.core.plugin.impl - package com.facebook.buck.core.plugin.impl
-
- com.facebook.buck.core.resources - package com.facebook.buck.core.resources
-
- com.facebook.buck.core.rulekey - package com.facebook.buck.core.rulekey
-
- com.facebook.buck.core.rulekey.calculator - package com.facebook.buck.core.rulekey.calculator
-
- com.facebook.buck.core.rulekey.config - package com.facebook.buck.core.rulekey.config
-
- com.facebook.buck.core.rules - package com.facebook.buck.core.rules
-
- com.facebook.buck.core.rules.actions - package com.facebook.buck.core.rules.actions
-
- com.facebook.buck.core.rules.actions.lib - package com.facebook.buck.core.rules.actions.lib
-
- com.facebook.buck.core.rules.actions.lib.args - package com.facebook.buck.core.rules.actions.lib.args
-
- com.facebook.buck.core.rules.analysis - package com.facebook.buck.core.rules.analysis
-
- com.facebook.buck.core.rules.analysis.action - package com.facebook.buck.core.rules.analysis.action
-
- com.facebook.buck.core.rules.analysis.cache - package com.facebook.buck.core.rules.analysis.cache
-
- com.facebook.buck.core.rules.analysis.computation - package com.facebook.buck.core.rules.analysis.computation
-
- com.facebook.buck.core.rules.analysis.config - package com.facebook.buck.core.rules.analysis.config
-
- com.facebook.buck.core.rules.analysis.context - package com.facebook.buck.core.rules.analysis.context
-
- com.facebook.buck.core.rules.analysis.impl - package com.facebook.buck.core.rules.analysis.impl
-
- com.facebook.buck.core.rules.attr - package com.facebook.buck.core.rules.attr
-
- com.facebook.buck.core.rules.build.strategy - package com.facebook.buck.core.rules.build.strategy
-
- com.facebook.buck.core.rules.common - package com.facebook.buck.core.rules.common
-
- com.facebook.buck.core.rules.config - package com.facebook.buck.core.rules.config
-
- com.facebook.buck.core.rules.config.impl - package com.facebook.buck.core.rules.config.impl
-
- com.facebook.buck.core.rules.config.registry - package com.facebook.buck.core.rules.config.registry
-
- com.facebook.buck.core.rules.config.registry.impl - package com.facebook.buck.core.rules.config.registry.impl
-
- com.facebook.buck.core.rules.configsetting - package com.facebook.buck.core.rules.configsetting
-
- com.facebook.buck.core.rules.impl - package com.facebook.buck.core.rules.impl
-
- com.facebook.buck.core.rules.knowntypes - package com.facebook.buck.core.rules.knowntypes
-
- com.facebook.buck.core.rules.knowntypes.provider - package com.facebook.buck.core.rules.knowntypes.provider
-
- com.facebook.buck.core.rules.modern - package com.facebook.buck.core.rules.modern
-
- com.facebook.buck.core.rules.modern.annotations - package com.facebook.buck.core.rules.modern.annotations
-
- com.facebook.buck.core.rules.pipeline - package com.facebook.buck.core.rules.pipeline
-
- com.facebook.buck.core.rules.platform - package com.facebook.buck.core.rules.platform
-
- com.facebook.buck.core.rules.providers - package com.facebook.buck.core.rules.providers
-
- com.facebook.buck.core.rules.providers.annotations - package com.facebook.buck.core.rules.providers.annotations
-
- com.facebook.buck.core.rules.providers.collect - package com.facebook.buck.core.rules.providers.collect
-
- com.facebook.buck.core.rules.providers.collect.impl - package com.facebook.buck.core.rules.providers.collect.impl
-
- com.facebook.buck.core.rules.providers.impl - package com.facebook.buck.core.rules.providers.impl
-
- com.facebook.buck.core.rules.providers.lib - package com.facebook.buck.core.rules.providers.lib
-
- com.facebook.buck.core.rules.resolver.impl - package com.facebook.buck.core.rules.resolver.impl
-
- com.facebook.buck.core.rules.schedule - package com.facebook.buck.core.rules.schedule
-
- com.facebook.buck.core.rules.tool - package com.facebook.buck.core.rules.tool
-
- com.facebook.buck.core.rules.transformer - package com.facebook.buck.core.rules.transformer
-
- com.facebook.buck.core.rules.transformer.impl - package com.facebook.buck.core.rules.transformer.impl
-
- com.facebook.buck.core.select - package com.facebook.buck.core.select
-
- com.facebook.buck.core.select.impl - package com.facebook.buck.core.select.impl
-
- com.facebook.buck.core.sourcepath - package com.facebook.buck.core.sourcepath
-
- com.facebook.buck.core.sourcepath.resolver - package com.facebook.buck.core.sourcepath.resolver
-
- com.facebook.buck.core.sourcepath.resolver.impl - package com.facebook.buck.core.sourcepath.resolver.impl
-
- com.facebook.buck.core.starlark.coercer - package com.facebook.buck.core.starlark.coercer
-
- com.facebook.buck.core.starlark.compatible - package com.facebook.buck.core.starlark.compatible
-
- com.facebook.buck.core.starlark.eventhandler - package com.facebook.buck.core.starlark.eventhandler
-
- com.facebook.buck.core.starlark.knowntypes - package com.facebook.buck.core.starlark.knowntypes
-
- com.facebook.buck.core.starlark.rule - package com.facebook.buck.core.starlark.rule
-
- com.facebook.buck.core.starlark.rule.args - package com.facebook.buck.core.starlark.rule.args
-
- com.facebook.buck.core.starlark.rule.artifact - package com.facebook.buck.core.starlark.rule.artifact
-
- com.facebook.buck.core.starlark.rule.attr - package com.facebook.buck.core.starlark.rule.attr
-
- com.facebook.buck.core.starlark.rule.attr.impl - package com.facebook.buck.core.starlark.rule.attr.impl
-
- com.facebook.buck.core.starlark.rule.data - package com.facebook.buck.core.starlark.rule.data
-
- com.facebook.buck.core.starlark.rule.names - package com.facebook.buck.core.starlark.rule.names
-
- com.facebook.buck.core.test.event - package com.facebook.buck.core.test.event
-
- com.facebook.buck.core.test.rule - package com.facebook.buck.core.test.rule
-
- com.facebook.buck.core.test.rule.coercer - package com.facebook.buck.core.test.rule.coercer
-
- com.facebook.buck.core.test.rule.impl - package com.facebook.buck.core.test.rule.impl
-
- com.facebook.buck.core.toolchain - package com.facebook.buck.core.toolchain
-
- com.facebook.buck.core.toolchain.impl - package com.facebook.buck.core.toolchain.impl
-
- com.facebook.buck.core.toolchain.rule - package com.facebook.buck.core.toolchain.rule
-
- com.facebook.buck.core.toolchain.tool - package com.facebook.buck.core.toolchain.tool
-
- com.facebook.buck.core.toolchain.tool.impl - package com.facebook.buck.core.toolchain.tool.impl
-
- com.facebook.buck.core.toolchain.toolprovider - package com.facebook.buck.core.toolchain.toolprovider
-
- com.facebook.buck.core.toolchain.toolprovider.impl - package com.facebook.buck.core.toolchain.toolprovider.impl
-
- com.facebook.buck.core.util - package com.facebook.buck.core.util
-
- com.facebook.buck.core.util.graph - package com.facebook.buck.core.util.graph
-
- com.facebook.buck.core.util.immutables - package com.facebook.buck.core.util.immutables
-
- com.facebook.buck.core.util.log - package com.facebook.buck.core.util.log
-
- com.facebook.buck.core.util.log.appendablelogrecord - package com.facebook.buck.core.util.log.appendablelogrecord
-
- com.facebook.buck.counters - package com.facebook.buck.counters
-
- com.facebook.buck.cxx - package com.facebook.buck.cxx
-
- com.facebook.buck.cxx.config - package com.facebook.buck.cxx.config
-
- com.facebook.buck.cxx.toolchain - package com.facebook.buck.cxx.toolchain
-
- com.facebook.buck.cxx.toolchain.elf - package com.facebook.buck.cxx.toolchain.elf
-
- com.facebook.buck.cxx.toolchain.impl - package com.facebook.buck.cxx.toolchain.impl
-
- com.facebook.buck.cxx.toolchain.linker - package com.facebook.buck.cxx.toolchain.linker
-
- com.facebook.buck.cxx.toolchain.linker.impl - package com.facebook.buck.cxx.toolchain.linker.impl
-
- com.facebook.buck.cxx.toolchain.nativelink - package com.facebook.buck.cxx.toolchain.nativelink
-
- com.facebook.buck.cxx.toolchain.objectfile - package com.facebook.buck.cxx.toolchain.objectfile
-
- com.facebook.buck.doctor - package com.facebook.buck.doctor
-
- com.facebook.buck.doctor.config - package com.facebook.buck.doctor.config
-
- com.facebook.buck.edenfs - package com.facebook.buck.edenfs
-
- com.facebook.buck.event - package com.facebook.buck.event
-
- com.facebook.buck.event.api - package com.facebook.buck.event.api
-
- com.facebook.buck.event.chrome_trace - package com.facebook.buck.event.chrome_trace
-
- com.facebook.buck.event.external.elements - package com.facebook.buck.event.external.elements
-
- com.facebook.buck.event.external.events - package com.facebook.buck.event.external.events
-
- com.facebook.buck.event.listener - package com.facebook.buck.event.listener
-
- com.facebook.buck.event.listener.interfaces - package com.facebook.buck.event.listener.interfaces
-
- com.facebook.buck.event.listener.stats.cache - package com.facebook.buck.event.listener.stats.cache
-
- com.facebook.buck.event.listener.stats.parse - package com.facebook.buck.event.listener.stats.parse
-
- com.facebook.buck.event.listener.util - package com.facebook.buck.event.listener.util
-
- com.facebook.buck.features.apple.common - package com.facebook.buck.features.apple.common
-
- com.facebook.buck.features.apple.project - package com.facebook.buck.features.apple.project
-
Classes pertaining to the generation of Xcode projects and workspaces.
- com.facebook.buck.features.apple.projectV2 - package com.facebook.buck.features.apple.projectV2
-
- com.facebook.buck.features.d - package com.facebook.buck.features.d
-
- com.facebook.buck.features.dotnet - package com.facebook.buck.features.dotnet
-
- com.facebook.buck.features.filebundler - package com.facebook.buck.features.filebundler
-
- com.facebook.buck.features.filegroup - package com.facebook.buck.features.filegroup
-
- com.facebook.buck.features.go - package com.facebook.buck.features.go
-
- com.facebook.buck.features.gwt - package com.facebook.buck.features.gwt
-
- com.facebook.buck.features.halide - package com.facebook.buck.features.halide
-
- com.facebook.buck.features.haskell - package com.facebook.buck.features.haskell
-
- com.facebook.buck.features.js - package com.facebook.buck.features.js
-
- com.facebook.buck.features.lua - package com.facebook.buck.features.lua
-
- com.facebook.buck.features.ocaml - package com.facebook.buck.features.ocaml
-
- com.facebook.buck.features.project.intellij - package com.facebook.buck.features.project.intellij
-
- com.facebook.buck.features.project.intellij.aggregation - package com.facebook.buck.features.project.intellij.aggregation
-
- com.facebook.buck.features.project.intellij.lang.android - package com.facebook.buck.features.project.intellij.lang.android
-
- com.facebook.buck.features.project.intellij.lang.cxx - package com.facebook.buck.features.project.intellij.lang.cxx
-
- com.facebook.buck.features.project.intellij.lang.groovy - package com.facebook.buck.features.project.intellij.lang.groovy
-
- com.facebook.buck.features.project.intellij.lang.java - package com.facebook.buck.features.project.intellij.lang.java
-
- com.facebook.buck.features.project.intellij.lang.kotlin - package com.facebook.buck.features.project.intellij.lang.kotlin
-
- com.facebook.buck.features.project.intellij.lang.python - package com.facebook.buck.features.project.intellij.lang.python
-
- com.facebook.buck.features.project.intellij.lang.scala - package com.facebook.buck.features.project.intellij.lang.scala
-
- com.facebook.buck.features.project.intellij.model - package com.facebook.buck.features.project.intellij.model
-
- com.facebook.buck.features.project.intellij.model.folders - package com.facebook.buck.features.project.intellij.model.folders
-
- com.facebook.buck.features.python - package com.facebook.buck.features.python
-
- com.facebook.buck.features.python.toolchain - package com.facebook.buck.features.python.toolchain
-
- com.facebook.buck.features.python.toolchain.impl - package com.facebook.buck.features.python.toolchain.impl
-
- com.facebook.buck.features.rust - package com.facebook.buck.features.rust
-
- com.facebook.buck.features.zip.rules - package com.facebook.buck.features.zip.rules
-
- com.facebook.buck.file - package com.facebook.buck.file
-
- com.facebook.buck.file.downloader - package com.facebook.buck.file.downloader
-
- com.facebook.buck.file.downloader.impl - package com.facebook.buck.file.downloader.impl
-
- com.facebook.buck.frontend - package com.facebook.buck.frontend
-
- com.facebook.buck.httpserver - package com.facebook.buck.httpserver
-
- com.facebook.buck.infer - package com.facebook.buck.infer
-
- com.facebook.buck.infer.toolchain - package com.facebook.buck.infer.toolchain
-
- com.facebook.buck.io - package com.facebook.buck.io
-
- com.facebook.buck.io.file - package com.facebook.buck.io.file
-
- com.facebook.buck.io.filesystem - package com.facebook.buck.io.filesystem
-
- com.facebook.buck.io.filesystem.impl - package com.facebook.buck.io.filesystem.impl
-
- com.facebook.buck.io.filesystem.skylark - package com.facebook.buck.io.filesystem.skylark
-
- com.facebook.buck.io.pathformat - package com.facebook.buck.io.pathformat
-
- com.facebook.buck.io.unixsocket - package com.facebook.buck.io.unixsocket
-
- com.facebook.buck.io.watchman - package com.facebook.buck.io.watchman
-
- com.facebook.buck.io.windowsfs - package com.facebook.buck.io.windowsfs
-
- com.facebook.buck.io.windowspipe - package com.facebook.buck.io.windowspipe
-
- com.facebook.buck.json - package com.facebook.buck.json
-
- com.facebook.buck.jvm.common - package com.facebook.buck.jvm.common
-
- com.facebook.buck.jvm.core - package com.facebook.buck.jvm.core
-
- com.facebook.buck.jvm.groovy - package com.facebook.buck.jvm.groovy
-
- com.facebook.buck.jvm.java - package com.facebook.buck.jvm.java
-
- com.facebook.buck.jvm.java.abi - package com.facebook.buck.jvm.java.abi
-
- com.facebook.buck.jvm.java.abi.source - package com.facebook.buck.jvm.java.abi.source
-
Enables generation of ABI jars using only the Java source code of a single target, without
requiring access to the source or ABI of dependencies.
- com.facebook.buck.jvm.java.abi.source.api - package com.facebook.buck.jvm.java.abi.source.api
-
- com.facebook.buck.jvm.java.classes - package com.facebook.buck.jvm.java.classes
-
- com.facebook.buck.jvm.java.coverage - package com.facebook.buck.jvm.java.coverage
-
- com.facebook.buck.jvm.java.javax - package com.facebook.buck.jvm.java.javax
-
- com.facebook.buck.jvm.java.lang.model - package com.facebook.buck.jvm.java.lang.model
-
- com.facebook.buck.jvm.java.plugin - package com.facebook.buck.jvm.java.plugin
-
- com.facebook.buck.jvm.java.plugin.adapter - package com.facebook.buck.jvm.java.plugin.adapter
-
- com.facebook.buck.jvm.java.plugin.api - package com.facebook.buck.jvm.java.plugin.api
-
- com.facebook.buck.jvm.java.rules - package com.facebook.buck.jvm.java.rules
-
- com.facebook.buck.jvm.java.runner - package com.facebook.buck.jvm.java.runner
-
- com.facebook.buck.jvm.java.toolchain - package com.facebook.buck.jvm.java.toolchain
-
- com.facebook.buck.jvm.java.toolchain.impl - package com.facebook.buck.jvm.java.toolchain.impl
-
- com.facebook.buck.jvm.java.tracing - package com.facebook.buck.jvm.java.tracing
-
- com.facebook.buck.jvm.java.version - package com.facebook.buck.jvm.java.version
-
- com.facebook.buck.jvm.kotlin - package com.facebook.buck.jvm.kotlin
-
- com.facebook.buck.jvm.scala - package com.facebook.buck.jvm.scala
-
- com.facebook.buck.log - package com.facebook.buck.log
-
- com.facebook.buck.log.memory - package com.facebook.buck.log.memory
-
- com.facebook.buck.log.thrift - package com.facebook.buck.log.thrift
-
- com.facebook.buck.log.views - package com.facebook.buck.log.views
-
- com.facebook.buck.logd - package com.facebook.buck.logd
-
- com.facebook.buck.logd.client - package com.facebook.buck.logd.client
-
- com.facebook.buck.logd.server - package com.facebook.buck.logd.server
-
- com.facebook.buck.maven - package com.facebook.buck.maven
-
- com.facebook.buck.maven.aether - package com.facebook.buck.maven.aether
-
- com.facebook.buck.parser - package com.facebook.buck.parser
-
- com.facebook.buck.parser.api - package com.facebook.buck.parser.api
-
- com.facebook.buck.parser.cache - package com.facebook.buck.parser.cache
-
- com.facebook.buck.parser.cache.json - package com.facebook.buck.parser.cache.json
-
- com.facebook.buck.parser.config - package com.facebook.buck.parser.config
-
- com.facebook.buck.parser.decorators - package com.facebook.buck.parser.decorators
-
- com.facebook.buck.parser.detector - package com.facebook.buck.parser.detector
-
- com.facebook.buck.parser.events - package com.facebook.buck.parser.events
-
- com.facebook.buck.parser.exceptions - package com.facebook.buck.parser.exceptions
-
- com.facebook.buck.parser.function - package com.facebook.buck.parser.function
-
- com.facebook.buck.parser.implicit - package com.facebook.buck.parser.implicit
-
- com.facebook.buck.parser.manifest - package com.facebook.buck.parser.manifest
-
- com.facebook.buck.parser.options - package com.facebook.buck.parser.options
-
- com.facebook.buck.parser.spec - package com.facebook.buck.parser.spec
-
- com.facebook.buck.parser.syntax - package com.facebook.buck.parser.syntax
-
- com.facebook.buck.parser.targetnode - package com.facebook.buck.parser.targetnode
-
- com.facebook.buck.parser.temporarytargetuniquenesschecker - package com.facebook.buck.parser.temporarytargetuniquenesschecker
-
- com.facebook.buck.query - package com.facebook.buck.query
-
- com.facebook.buck.remoteexecution - package com.facebook.buck.remoteexecution
-
- com.facebook.buck.remoteexecution.config - package com.facebook.buck.remoteexecution.config
-
- com.facebook.buck.remoteexecution.event - package com.facebook.buck.remoteexecution.event
-
- com.facebook.buck.remoteexecution.event.listener - package com.facebook.buck.remoteexecution.event.listener
-
- com.facebook.buck.remoteexecution.event.listener.model - package com.facebook.buck.remoteexecution.event.listener.model
-
- com.facebook.buck.remoteexecution.factory - package com.facebook.buck.remoteexecution.factory
-
- com.facebook.buck.remoteexecution.grpc - package com.facebook.buck.remoteexecution.grpc
-
- com.facebook.buck.remoteexecution.grpc.retry - package com.facebook.buck.remoteexecution.grpc.retry
-
- com.facebook.buck.remoteexecution.grpc.server - package com.facebook.buck.remoteexecution.grpc.server
-
- com.facebook.buck.remoteexecution.interfaces - package com.facebook.buck.remoteexecution.interfaces
-
- com.facebook.buck.remoteexecution.util - package com.facebook.buck.remoteexecution.util
-
- com.facebook.buck.rules.args - package com.facebook.buck.rules.args
-
- com.facebook.buck.rules.coercer - package com.facebook.buck.rules.coercer
-
- com.facebook.buck.rules.coercer.concat - package com.facebook.buck.rules.coercer.concat
-
- com.facebook.buck.rules.keys - package com.facebook.buck.rules.keys
-
- com.facebook.buck.rules.keys.config - package com.facebook.buck.rules.keys.config
-
- com.facebook.buck.rules.keys.config.impl - package com.facebook.buck.rules.keys.config.impl
-
- com.facebook.buck.rules.keys.hasher - package com.facebook.buck.rules.keys.hasher
-
- com.facebook.buck.rules.macros - package com.facebook.buck.rules.macros
-
- com.facebook.buck.rules.modern - package com.facebook.buck.rules.modern
-
- com.facebook.buck.rules.modern.builders - package com.facebook.buck.rules.modern.builders
-
- com.facebook.buck.rules.modern.config - package com.facebook.buck.rules.modern.config
-
- com.facebook.buck.rules.modern.impl - package com.facebook.buck.rules.modern.impl
-
- com.facebook.buck.rules.modern.tools - package com.facebook.buck.rules.modern.tools
-
- com.facebook.buck.rules.query - package com.facebook.buck.rules.query
-
- com.facebook.buck.rules.tool.config - package com.facebook.buck.rules.tool.config
-
- com.facebook.buck.rules.visibility - package com.facebook.buck.rules.visibility
-
- com.facebook.buck.rules.visibility.parser - package com.facebook.buck.rules.visibility.parser
-
- com.facebook.buck.sandbox - package com.facebook.buck.sandbox
-
- com.facebook.buck.sandbox.darwin - package com.facebook.buck.sandbox.darwin
-
- com.facebook.buck.sandbox.impl - package com.facebook.buck.sandbox.impl
-
- com.facebook.buck.shell - package com.facebook.buck.shell
-
- com.facebook.buck.shell.programrunner - package com.facebook.buck.shell.programrunner
-
- com.facebook.buck.skylark.function - package com.facebook.buck.skylark.function
-
- com.facebook.buck.skylark.function.attr - package com.facebook.buck.skylark.function.attr
-
- com.facebook.buck.skylark.io - package com.facebook.buck.skylark.io
-
- com.facebook.buck.skylark.io.impl - package com.facebook.buck.skylark.io.impl
-
- com.facebook.buck.skylark.packages - package com.facebook.buck.skylark.packages
-
- com.facebook.buck.skylark.parser - package com.facebook.buck.skylark.parser
-
- com.facebook.buck.skylark.parser.context - package com.facebook.buck.skylark.parser.context
-
- com.facebook.buck.slb - package com.facebook.buck.slb
-
- com.facebook.buck.step - package com.facebook.buck.step
-
- com.facebook.buck.step.fs - package com.facebook.buck.step.fs
-
- com.facebook.buck.step.impl - package com.facebook.buck.step.impl
-
- com.facebook.buck.support.bgtasks - package com.facebook.buck.support.bgtasks
-
- com.facebook.buck.support.build.report - package com.facebook.buck.support.build.report
-
- com.facebook.buck.support.cli.args - package com.facebook.buck.support.cli.args
-
- com.facebook.buck.support.cli.config - package com.facebook.buck.support.cli.config
-
- com.facebook.buck.support.exceptions.handler - package com.facebook.buck.support.exceptions.handler
-
- com.facebook.buck.support.fix - package com.facebook.buck.support.fix
-
- com.facebook.buck.support.jvm - package com.facebook.buck.support.jvm
-
- com.facebook.buck.support.log - package com.facebook.buck.support.log
-
- com.facebook.buck.support.state - package com.facebook.buck.support.state
-
- com.facebook.buck.swift - package com.facebook.buck.swift
-
- com.facebook.buck.swift.toolchain - package com.facebook.buck.swift.toolchain
-
- com.facebook.buck.swift.toolchain.impl - package com.facebook.buck.swift.toolchain.impl
-
- com.facebook.buck.test - package com.facebook.buck.test
-
- com.facebook.buck.test.config - package com.facebook.buck.test.config
-
- com.facebook.buck.test.external - package com.facebook.buck.test.external
-
- com.facebook.buck.test.result.type - package com.facebook.buck.test.result.type
-
- com.facebook.buck.test.selectors - package com.facebook.buck.test.selectors
-
- com.facebook.buck.testrunner - package com.facebook.buck.testrunner
-
- com.facebook.buck.unarchive - package com.facebook.buck.unarchive
-
- com.facebook.buck.util - package com.facebook.buck.util
-
- com.facebook.buck.util.bser - package com.facebook.buck.util.bser
-
- com.facebook.buck.util.cache - package com.facebook.buck.util.cache
-
- com.facebook.buck.util.cache.impl - package com.facebook.buck.util.cache.impl
-
- com.facebook.buck.util.charset - package com.facebook.buck.util.charset
-
- com.facebook.buck.util.collect - package com.facebook.buck.util.collect
-
- com.facebook.buck.util.concurrent - package com.facebook.buck.util.concurrent
-
- com.facebook.buck.util.config - package com.facebook.buck.util.config
-
- com.facebook.buck.util.console - package com.facebook.buck.util.console
-
- com.facebook.buck.util.env - package com.facebook.buck.util.env
-
- com.facebook.buck.util.environment - package com.facebook.buck.util.environment
-
- com.facebook.buck.util.filesystem - package com.facebook.buck.util.filesystem
-
- com.facebook.buck.util.function - package com.facebook.buck.util.function
-
- com.facebook.buck.util.hash - package com.facebook.buck.util.hash
-
- com.facebook.buck.util.hashing - package com.facebook.buck.util.hashing
-
- com.facebook.buck.util.i18n - package com.facebook.buck.util.i18n
-
- com.facebook.buck.util.json - package com.facebook.buck.util.json
-
- com.facebook.buck.util.liteinfersupport - package com.facebook.buck.util.liteinfersupport
-
- com.facebook.buck.util.network - package com.facebook.buck.util.network
-
- com.facebook.buck.util.network.hostname - package com.facebook.buck.util.network.hostname
-
- com.facebook.buck.util.network.offline - package com.facebook.buck.util.network.offline
-
- com.facebook.buck.util.perf - package com.facebook.buck.util.perf
-
- com.facebook.buck.util.randomizedtrial - package com.facebook.buck.util.randomizedtrial
-
- com.facebook.buck.util.sha1 - package com.facebook.buck.util.sha1
-
- com.facebook.buck.util.shutdown - package com.facebook.buck.util.shutdown
-
- com.facebook.buck.util.sqlite - package com.facebook.buck.util.sqlite
-
- com.facebook.buck.util.stream - package com.facebook.buck.util.stream
-
- com.facebook.buck.util.string - package com.facebook.buck.util.string
-
- com.facebook.buck.util.timing - package com.facebook.buck.util.timing
-
- com.facebook.buck.util.trace - package com.facebook.buck.util.trace
-
- com.facebook.buck.util.trace.uploader - package com.facebook.buck.util.trace.uploader
-
- com.facebook.buck.util.trace.uploader.launcher - package com.facebook.buck.util.trace.uploader.launcher
-
- com.facebook.buck.util.trace.uploader.types - package com.facebook.buck.util.trace.uploader.types
-
- com.facebook.buck.util.types - package com.facebook.buck.util.types
-
- com.facebook.buck.util.unarchive - package com.facebook.buck.util.unarchive
-
- com.facebook.buck.util.unit - package com.facebook.buck.util.unit
-
- com.facebook.buck.util.versioncontrol - package com.facebook.buck.util.versioncontrol
-
- com.facebook.buck.util.xml - package com.facebook.buck.util.xml
-
- com.facebook.buck.util.zip - package com.facebook.buck.util.zip
-
- com.facebook.buck.util.zip.collect - package com.facebook.buck.util.zip.collect
-
- com.facebook.buck.versions - package com.facebook.buck.versions
-
- com.facebook.buck.worker - package com.facebook.buck.worker
-
- com.facebook.buck.zip - package com.facebook.buck.zip
-
- COM_SUN_TOOLS_JAVAC_API_JAVAC_TOOL - Static variable in class com.facebook.buck.jvm.java.ExternalJavacProvider
-
- combine(Set<String>, String, Set<String>) - Static method in class com.facebook.buck.io.file.FileFinder
-
Combines prefixes, base, and suffixes to create a set of file names.
- combinedFutures(ListenableFuture<U>, ListenableFuture<V>, ListeningExecutorService) - Static method in class com.facebook.buck.util.concurrent.MoreFutures
-
Combine the and listenable futures, returning a listenable
future that wraps the result of these futures as a
Pair
.
- CombinedPlatformResolver - Class in com.facebook.buck.core.rules.platform
-
- CombinedPlatformResolver(ConfigurationRuleResolver, RuleBasedPlatformResolver, RuleBasedMultiPlatformResolver) - Constructor for class com.facebook.buck.core.rules.platform.CombinedPlatformResolver
-
- combineInputs(IjFolder, IjFolder) - Static method in class com.facebook.buck.features.project.intellij.model.folders.IjFolder
-
- command - Variable in exception com.facebook.buck.android.AdbHelper.CommandFailedException
-
- Command - Interface in com.facebook.buck.cli
-
- command - Variable in class com.facebook.buck.httpserver.TracesHandlerDelegate.TraceAttrs
-
- command - Variable in class com.facebook.buck.util.ProcessExecutor.LaunchedProcessImpl
-
- command - Variable in class com.facebook.buck.util.ProcessExecutor.Result
-
- COMMAND - Static variable in class com.facebook.buck.util.trace.ChromeTraceParser
-
Tries to extract the command that was used to trigger the invocation of Buck that generated the
trace.
- COMMAND_ARGS_FILE_HELP - Static variable in class com.facebook.buck.support.cli.args.GlobalCliOptions
-
- COMMAND_ARGS_FILE_LONG_ARG - Static variable in class com.facebook.buck.support.cli.args.GlobalCliOptions
-
- CommandAlias - Class in com.facebook.buck.shell
-
A
BinaryBuildRule
that wraps other build rules, and can optionally add extra arguments,
environment variables, or run different tools per host
Platform
.
- CommandAlias(BuildTarget, ProjectFilesystem, Optional<BuildRule>, ImmutableSortedMap<Platform, BuildRule>, ImmutableList<Arg>, ImmutableSortedMap<String, Arg>, Platform) - Constructor for class com.facebook.buck.shell.CommandAlias
-
- CommandAlias.UnsupportedPlatformException - Exception in com.facebook.buck.shell
-
Specific runtime exception type that is thrown when trying to run a tool via
CommandAlias
on a platform that has not been provided.
- CommandAliasDescription - Class in com.facebook.buck.shell
-
- CommandAliasDescription(Platform) - Constructor for class com.facebook.buck.shell.CommandAliasDescription
-
- CommandAliasDescriptionArg - Class in com.facebook.buck.shell
-
Immutable implementation of CommandAliasDescription.AbstractCommandAliasDescriptionArg
.
- CommandAliasDescriptionArg.Builder - Class in com.facebook.buck.shell
-
- commandArgsFile - Variable in class com.facebook.buck.cli.AbstractCommand
-
- commandArgsFile - Variable in class com.facebook.buck.cli.AbstractContainerCommand
-
- CommandEvent - Class in com.facebook.buck.event
-
Events tracking the start and stop of a buck command.
- CommandEvent.Finished - Class in com.facebook.buck.event
-
- CommandEvent.Interrupted - Class in com.facebook.buck.event
-
- CommandEvent.Started - Class in com.facebook.buck.event
-
- CommandFailedException(String, int, String) - Constructor for exception com.facebook.buck.android.AdbHelper.CommandFailedException
-
- commandFinished - Variable in class com.facebook.buck.event.listener.AbstractConsoleEventBusListener
-
- commandFinished(CommandEvent.Finished) - Method in class com.facebook.buck.event.listener.AbstractConsoleEventBusListener
-
- commandFinished(CommandEvent.Finished) - Method in class com.facebook.buck.event.listener.ChromeTraceBuildListener
-
- commandFinished(CommandEvent.Finished) - Method in class com.facebook.buck.event.listener.CriticalPathEventListener
-
- commandFinished(CommandEvent.Finished) - Method in class com.facebook.buck.event.listener.FileSerializationOutputRuleDepsListener
-
- commandFinished(CommandEvent.Finished) - Method in class com.facebook.buck.event.listener.LogUploaderListener
-
- commandFinished(CommandEvent.Finished) - Method in class com.facebook.buck.event.listener.MachineReadableLoggerListener
-
- commandFinished(CommandEvent.Finished) - Method in class com.facebook.buck.event.listener.SimpleConsoleEventBusListener
-
- CommandHelper - Class in com.facebook.buck.cli
-
Utility class with print methods
- CommandIdToIsDaemonMapper - Interface in com.facebook.buck.log
-
- CommandIdToIsRemoteExecutionMapper - Interface in com.facebook.buck.log
-
This tracks where a given command was run with remote execution.
- commandIdToIsRunningAsDaemon(String) - Method in interface com.facebook.buck.log.CommandIdToIsDaemonMapper
-
- commandIdToIsRunningAsRemoteExecution(String) - Method in interface com.facebook.buck.log.CommandIdToIsRemoteExecutionMapper
-
- commandIdToIsSuperConsoleEnabled(String) - Method in interface com.facebook.buck.log.CommandIdToIsSuperConsoleEnabledMapper
-
- CommandIdToIsSuperConsoleEnabledMapper - Interface in com.facebook.buck.log
-
- commandInterrupted(CommandEvent.Interrupted) - Method in class com.facebook.buck.event.listener.LogUploaderListener
-
- commandInterrupted(CommandEvent.Interrupted) - Method in class com.facebook.buck.event.listener.MachineReadableLoggerListener
-
- CommandLine - Interface in com.facebook.buck.core.rules.actions.lib.args
-
Information needed to execute a command line program.
- CommandLineArgException - Exception in com.facebook.buck.core.rules.actions.lib.args
-
- CommandLineArgException(Object) - Constructor for exception com.facebook.buck.core.rules.actions.lib.args.CommandLineArgException
-
- CommandLineArgException(String, Object) - Constructor for exception com.facebook.buck.core.rules.actions.lib.args.CommandLineArgException
-
- CommandLineArgs - Interface in com.facebook.buck.core.rules.actions.lib.args
-
Container for a list of objects that can be stringified into command line arguments for an action
that executes a program.
- CommandLineArgs.ArgAndFormatString - Interface in com.facebook.buck.core.rules.actions.lib.args
-
- CommandLineArgsApi - Interface in com.facebook.buck.core.rules.actions.lib.args
-
- CommandLineArgsBuilder - Class in com.facebook.buck.core.starlark.rule.args
-
- CommandLineArgsBuilder() - Constructor for class com.facebook.buck.core.starlark.rule.args.CommandLineArgsBuilder
-
- CommandLineArgsBuilderApi - Interface in com.facebook.buck.core.starlark.rule.args
-
Struct for creating more efficient and validated lists of arguments to pass to actions' command
lines.
- CommandLineArgsFactory - Class in com.facebook.buck.core.rules.actions.lib.args
-
Factory class that returns more efficient implementations of
CommandLineArgs
depending on
what type of arguments are available (e.g.
- CommandLineArgsFactory() - Constructor for class com.facebook.buck.core.rules.actions.lib.args.CommandLineArgsFactory
-
- CommandLineArgStringifier - Class in com.facebook.buck.core.rules.actions.lib.args
-
Helper methods to convert / validate objects that are command line arguments for actions
- CommandLineBuilder - Interface in com.facebook.buck.core.rules.actions.lib.args
-
- CommandLineException - Exception in com.facebook.buck.util
-
Exception that is raised when user-supplied command line contains incompatible parameters or in
general cannot be executed
- CommandLineException(String, Object...) - Constructor for exception com.facebook.buck.util.CommandLineException
-
- CommandLineException(String) - Constructor for exception com.facebook.buck.util.CommandLineException
-
- CommandLineException(ExceptionWithHumanReadableMessage) - Constructor for exception com.facebook.buck.util.CommandLineException
-
- CommandLineException(Throwable, String) - Constructor for exception com.facebook.buck.util.CommandLineException
-
- CommandLineException(Throwable, String, Object...) - Constructor for exception com.facebook.buck.util.CommandLineException
-
- CommandLineTargetNodeSpecParser - Class in com.facebook.buck.cli
-
- CommandLineTargetNodeSpecParser(Cell, Path, BuckConfig, BuildTargetMatcherTargetNodeParser) - Constructor for class com.facebook.buck.cli.CommandLineTargetNodeSpecParser
-
- CommandMode - Enum in com.facebook.buck.util.environment
-
- CommandResponse(int, int) - Constructor for class com.facebook.buck.worker.WorkerProcessProtocol.CommandResponse
-
- CommandRunnerParams - Class in com.facebook.buck.cli
-
- CommandRunnerParams() - Constructor for class com.facebook.buck.cli.CommandRunnerParams
-
- CommandSender(OutputStream, InputStream, Path, Runnable, Supplier<Boolean>) - Constructor for class com.facebook.buck.worker.WorkerProcessProtocolZero.CommandSender
-
- CommandSplitter - Class in com.facebook.buck.util
-
Splits an argument list into a list of command invocations whose total length will not exceed the
specified limit if possible.
- CommandSplitter(List<String>, int) - Constructor for class com.facebook.buck.util.CommandSplitter
-
- CommandSplitter(List<String>) - Constructor for class com.facebook.buck.util.CommandSplitter
-
- commandStarted(CommandEvent.Started) - Method in class com.facebook.buck.event.listener.ChromeTraceBuildListener
-
- commandStartedEvent(CommandEvent.Started) - Method in class com.facebook.buck.event.listener.AbstractConsoleEventBusListener
-
- CommandString(Optional<String>, Optional<String>, Optional<String>) - Constructor for class com.facebook.buck.shell.AbstractGenruleStep.CommandString
-
- CommandThreadFactory - Class in com.facebook.buck.util.concurrent
-
A ThreadFactory which associates created threads with the same command associated with the thread
which creates the CommandThreadFactory.
- CommandThreadFactory(String, CommonThreadFactoryState, int) - Constructor for class com.facebook.buck.util.concurrent.CommandThreadFactory
-
- CommandThreadFactory(String, CommonThreadFactoryState) - Constructor for class com.facebook.buck.util.concurrent.CommandThreadFactory
-
- CommandThreadFactory(ThreadFactory, CommonThreadFactoryState) - Constructor for class com.facebook.buck.util.concurrent.CommandThreadFactory
-
- CommandThreadFactory(ThreadFactory, CommonThreadFactoryState, OptionalInt) - Constructor for class com.facebook.buck.util.concurrent.CommandThreadFactory
-
- CommandThreadManager - Class in com.facebook.buck.cli
-
Encapsulates a group of threads which operate a
ListeningExecutorService
, providing an
AutoCloseable
interface which waits for and kills the threads on close.
- CommandThreadManager(String, ListeningMultiSemaphore, ResourceAmounts, int, long, TimeUnit) - Constructor for class com.facebook.buck.cli.CommandThreadManager
-
- CommandThreadManager(String, ListeningMultiSemaphore, ResourceAmounts, int) - Constructor for class com.facebook.buck.cli.CommandThreadManager
-
- CommandThreadManager(String, ConcurrencyLimit, long, TimeUnit) - Constructor for class com.facebook.buck.cli.CommandThreadManager
-
- CommandThreadManager(String, ConcurrencyLimit) - Constructor for class com.facebook.buck.cli.CommandThreadManager
-
- CommandTool - Class in com.facebook.buck.core.toolchain.tool.impl
-
- CommandTool.Builder - Class in com.facebook.buck.core.toolchain.tool.impl
-
- CommandWithPluginManager - Class in com.facebook.buck.cli
-
An implementation of
Command
that allows keeping
PluginManager
.
- CommandWithPluginManager() - Constructor for class com.facebook.buck.cli.CommandWithPluginManager
-
- COMMON_MODIFICATION_TIME_STAMP - Static variable in class com.facebook.buck.util.ObjectFileCommonModificationDate
-
01 Feb 1985 00:00:00 (12:00:00 AM).
- CommonFastVersionControlStats - Interface in com.facebook.buck.util.versioncontrol
-
- CommonGroups - Enum in com.facebook.buck.util.randomizedtrial
-
- CommonSlowVersionControlStats - Interface in com.facebook.buck.util.versioncontrol
-
- commonSuffixLength(Path, Path) - Static method in class com.facebook.buck.io.file.MorePaths
-
- CommonThreadFactoryState - Interface in com.facebook.buck.util.concurrent
-
- CommonThreadStateRenderer - Class in com.facebook.buck.event.listener
-
Renders the per thread information line during build phase on super console
- CommonThreadStateRenderer(Ansi, Function<Long, String>, long, int, ImmutableMap<Long, ThreadRenderingInformation>) - Constructor for class com.facebook.buck.event.listener.CommonThreadStateRenderer
-
- compact() - Method in class com.facebook.buck.cxx.toolchain.elf.ElfVerDef
-
- compact() - Method in class com.facebook.buck.cxx.toolchain.elf.ElfVerNeed
-
- ComparableToolchain - Interface in com.facebook.buck.core.toolchain
-
Interface that indicates that changes in a toolchain cause restarting Daemon
.
- comparator() - Static method in interface com.facebook.buck.core.filesystems.AbsPath
-
- compare(Config, Config) - Static method in class com.facebook.buck.command.config.ConfigDifference
-
Compares all values in two sets of configs
- compare(ImmutableMap<String, ImmutableMap<String, String>>, ImmutableMap<String, ImmutableMap<String, String>>) - Static method in class com.facebook.buck.command.config.ConfigDifference
-
Compares sets of config options, and returns the difference as a map of 'section.key' strings
to pairs containing the different values.
- compare(QueryTarget, QueryTarget) - Static method in interface com.facebook.buck.core.model.QueryTarget
-
- compare(Optional<T>, Optional<T>) - Static method in class com.facebook.buck.core.util.Optionals
-
- compare(Path, Path) - Method in class com.facebook.buck.features.project.intellij.lang.java.ParsingJavaPackageFinder.PathComponentCountOrder
-
- compare(String, String) - Method in class com.facebook.buck.util.VersionStringComparator
-
- CompareAbis - Class in com.facebook.buck.jvm.java
-
- CompareAbis(BuildTarget, ProjectFilesystem, BuildRuleParams, SourcePath, SourcePath, JavaBuckConfig.SourceAbiVerificationMode) - Constructor for class com.facebook.buck.jvm.java.CompareAbis
-
- compareClasses(SourcePath) - Method in interface com.facebook.buck.core.sourcepath.SourcePath
-
- compareForCaching(BuckConfig, BuckConfig) - Static method in class com.facebook.buck.command.config.ConfigDifference
-
Compares only the config options that invalidate global state
- comparePaths(DirectoryCleaner.PathStats, DirectoryCleaner.PathStats) - Method in interface com.facebook.buck.util.DirectoryCleaner.PathSelector
-
Returns the preferred sorting order to delete paths.
- compareStrings(String, String) - Static method in class com.facebook.buck.util.string.MoreStrings
-
Compare two strings lexicographically.
- compareTo(RDotTxtEntry) - Method in class com.facebook.buck.android.aapt.RDotTxtEntry
-
A collection of Resources should be sorted such that Resources of the same type should be
grouped together, and should be alphabetized within that group.
- compareTo(APKModule) - Method in class com.facebook.buck.android.apkmodule.APKModule
-
- compareTo(SourcePathWithAppleBundleDestination) - Method in class com.facebook.buck.apple.SourcePathWithAppleBundleDestination
-
- compareTo(ApplePlatform) - Method in class com.facebook.buck.apple.toolchain.ApplePlatform
-
- compareTo(SourceTreePath) - Method in class com.facebook.buck.apple.xcode.xcodeproj.SourceTreePath
-
- compareTo(OutputArtifact) - Method in class com.facebook.buck.core.artifact.OutputArtifact
-
- compareTo(CanonicalCellName) - Method in class com.facebook.buck.core.cell.name.CanonicalCellName
-
- compareTo(Path) - Method in class com.facebook.buck.core.filesystems.BuckUnixPath
-
- compareTo(CxxLinkGroupMapping) - Method in class com.facebook.buck.core.linkgroup.CxxLinkGroupMapping
-
- compareTo(CxxLinkGroupMappingTarget) - Method in class com.facebook.buck.core.linkgroup.CxxLinkGroupMappingTarget
-
- compareTo(BaseName) - Method in class com.facebook.buck.core.model.BaseName
-
- compareTo(BuildId) - Method in class com.facebook.buck.core.model.BuildId
-
- compareTo(BuildTarget) - Method in class com.facebook.buck.core.model.BuildTarget
-
- compareTo(BuildTargetWithOutputs) - Method in class com.facebook.buck.core.model.BuildTargetWithOutputs
-
- compareTo(CellRelativePath) - Method in class com.facebook.buck.core.model.CellRelativePath
-
- compareTo(Flavor) - Method in interface com.facebook.buck.core.model.Flavor
-
- compareTo(FlavorSet) - Method in class com.facebook.buck.core.model.FlavorSet
-
- compareTo(OutputLabel) - Method in class com.facebook.buck.core.model.OutputLabel
-
- compareTo(TargetConfiguration) - Method in class com.facebook.buck.core.model.TargetConfiguration
-
- compareTo(TargetNode<?>) - Method in class com.facebook.buck.core.model.targetgraph.impl.TargetNodeImpl
-
- compareTo(MergedTargetNode) - Method in class com.facebook.buck.core.model.targetgraph.MergedTargetNode
-
- compareTo(UnconfiguredBuildTarget) - Method in class com.facebook.buck.core.model.UnconfiguredBuildTarget
-
- compareTo(UnconfiguredBuildTargetWithOutputs) - Method in class com.facebook.buck.core.model.UnconfiguredBuildTargetWithOutputs
-
- compareTo(UnflavoredBuildTarget) - Method in class com.facebook.buck.core.model.UnflavoredBuildTarget
-
- compareTo(ForwardRelativePath) - Method in class com.facebook.buck.core.path.ForwardRelativePath
-
- compareTo(BuildRule) - Method in interface com.facebook.buck.core.rules.BuildRule
-
- compareTo(SourcePath) - Method in class com.facebook.buck.core.sourcepath.ArchiveMemberSourcePath
-
- compareTo(SourcePath) - Method in class com.facebook.buck.core.sourcepath.DefaultBuildTargetSourcePath
-
- compareTo(SourcePath) - Method in class com.facebook.buck.core.sourcepath.ExplicitBuildTargetSourcePath
-
- compareTo(SourcePath) - Method in class com.facebook.buck.core.sourcepath.ForwardingBuildTargetSourcePath
-
- compareTo(SourcePath) - Method in class com.facebook.buck.core.sourcepath.PathSourcePath
-
- compareTo(SourceWithFlags) - Method in class com.facebook.buck.core.sourcepath.SourceWithFlags
-
- compareTo(IjDependencyListBuilder.DependencyEntry) - Method in class com.facebook.buck.features.project.intellij.IjDependencyListBuilder.DependencyEntry
-
- compareTo(ContentRoot) - Method in class com.facebook.buck.features.project.intellij.model.ContentRoot
-
- compareTo(IjFolder) - Method in class com.facebook.buck.features.project.intellij.model.folders.IjFolder
-
- compareTo(IjSourceFolder) - Method in class com.facebook.buck.features.project.intellij.model.folders.IjSourceFolder
-
- compareTo(ModuleIndexEntry) - Method in class com.facebook.buck.features.project.intellij.model.ModuleIndexEntry
-
- compareTo(FrameworkPath) - Method in class com.facebook.buck.rules.coercer.FrameworkPath
-
- compareTo(BuildRule) - Method in class com.facebook.buck.rules.modern.ModernBuildRule
-
- COMPILATION_DATABASE - Static variable in class com.facebook.buck.cxx.CxxCompilationDatabase
-
- CompilationUnitTreeProxy - Interface in com.facebook.buck.jvm.java.plugin.api
-
CompilationUnitTree
is included with the compiler and is thus not
directly accessible from within Buck's class loader.
- CompilationUnitTreeProxyImpl - Class in com.facebook.buck.jvm.java.plugin.adapter
-
- CompilationUnitTreeProxyImpl(CompilationUnitTree) - Constructor for class com.facebook.buck.jvm.java.plugin.adapter.CompilationUnitTreeProxyImpl
-
- compile(BuildTarget, ProjectFilesystem, SourcePathRuleFinder, CompilerDelegate, String, SourcePath, CxxSource.Type, DebugPathSanitizer) - Static method in class com.facebook.buck.cxx.CxxPreprocessAndCompile
-
- compile(String) - Static method in class com.facebook.buck.cxx.toolchain.FasterPattern
-
Compile a pattern.
- COMPILE_DEPS - Static variable in class com.facebook.buck.apple.AppleTestDescription
-
- COMPILE_FORCE_CACHE - Static variable in class com.facebook.buck.swift.SwiftBuckConfig
-
- CompileAgainstLibraryType - Enum in com.facebook.buck.jvm.java
-
Expresses what kind of library a given JvmLibrary should compile against.
- COMPILED_TESTS_LIBRARY_FLAVOR - Static variable in class com.facebook.buck.jvm.java.JavaTest
-
- Compiler - Interface in com.facebook.buck.cxx.toolchain
-
Interface for a c/c++ compiler.
- compiler() - Method in class com.facebook.buck.features.dotnet.DotnetLegacyToolchainInfo
-
- compiler() - Method in class com.facebook.buck.features.dotnet.ImmutableDotnetLegacyToolchainInfo
-
- COMPILER_ERROR_EVENT - Static variable in interface com.facebook.buck.event.external.events.CompilerErrorEventExternalInterface
-
- COMPILER_FLAGS_NAME - Static variable in class com.facebook.buck.swift.SwiftBuckConfig
-
- CompilerErrorEvent - Class in com.facebook.buck.event
-
- compilerErrorEvent(CompilerErrorEvent) - Method in class com.facebook.buck.httpserver.WebServerBuckEventListener
-
- CompilerErrorEvent.CompilerType - Enum in com.facebook.buck.event
-
- CompilerErrorEventExternalInterface - Interface in com.facebook.buck.event.external.events
-
Describes a compiler error thrown by buck.
- CompilerOutputPaths - Class in com.facebook.buck.jvm.java
-
Provides access to the various output paths for a java library.
- CompilerOutputPaths() - Constructor for class com.facebook.buck.jvm.java.CompilerOutputPaths
-
- CompilerParameters - Class in com.facebook.buck.jvm.java
-
- CompilerParameters() - Constructor for class com.facebook.buck.jvm.java.CompilerParameters
-
- CompilerParameters.Builder - Class in com.facebook.buck.jvm.java
-
- CompilerPluginDurationEvent - Class in com.facebook.buck.event
-
Base class for events being reported by plugins to in-process compilers such as JSR199 javac.
- CompilerPluginDurationEvent(EventKey, BuildTarget, String, String, ImmutableMap<String, String>) - Constructor for class com.facebook.buck.event.CompilerPluginDurationEvent
-
- CompilerPluginDurationEvent.Finished - Class in com.facebook.buck.event
-
- CompilerPluginDurationEvent.Started - Class in com.facebook.buck.event
-
- compilerPluginDurationEventFinished(CompilerPluginDurationEvent.Finished) - Method in class com.facebook.buck.event.listener.ChromeTraceBuildListener
-
- compilerPluginDurationEventStarted(CompilerPluginDurationEvent.Started) - Method in class com.facebook.buck.event.listener.ChromeTraceBuildListener
-
- CompilerProvider - Class in com.facebook.buck.cxx.toolchain
-
- CompilerProvider(ToolProvider, CxxToolProvider.Type, ToolType, boolean) - Constructor for class com.facebook.buck.cxx.toolchain.CompilerProvider
-
- CompilerProvider(ToolProvider, Supplier<CxxToolProvider.Type>, ToolType, boolean) - Constructor for class com.facebook.buck.cxx.toolchain.CompilerProvider
-
- CompilerProvider(ToolProvider, Supplier<CxxToolProvider.Type>, ToolType, boolean, boolean) - Constructor for class com.facebook.buck.cxx.toolchain.CompilerProvider
-
- CompileStringsStep - Class in com.facebook.buck.android
-
This
Step
takes a list of string resource files (strings.xml), groups them by locales,
and for each locale generates a file with all the string resources for that locale.
- CompileStringsStep(ProjectFilesystem, ImmutableList<Path>, Path, Function<String, Path>) - Constructor for class com.facebook.buck.android.CompileStringsStep
-
Note: The ordering of files in the input list determines which resource value ends up in the
output .fbstr file, in the event of multiple xml files of a locale sharing the same string
resource name - file that appears first in the list wins.
- compileTimeJar - Variable in class com.facebook.buck.jvm.java.JarBuildStepsFactory.JavaDependencyInfo
-
- CompileToJarStepFactory - Class in com.facebook.buck.jvm.java
-
Provides a base implementation for post compile steps.
- CompileToJarStepFactory() - Constructor for class com.facebook.buck.jvm.java.CompileToJarStepFactory
-
- complete(PerfTimesStats) - Static method in class com.facebook.buck.event.listener.PerfTimesEventListener.PerfTimesEvent
-
- complete(T) - Method in class com.facebook.buck.util.concurrent.WorkThreadTrackingTask
-
- completed(T) - Static method in class com.facebook.buck.util.concurrent.WorkThreadTrackingTask
-
- CompletedTypeKind - Enum in com.facebook.buck.jvm.java.abi.source
-
- ComposedComputation<BaseKey extends ComputeKey<?>,Result2 extends ComputeResult> - Interface in com.facebook.buck.core.graph.transformation.composition
-
- ComposedComputationIdentifier<ResultType extends ComputeResult> - Class in com.facebook.buck.core.graph.transformation.model
-
- ComposedKey<KeyType1 extends ComputeKey<?>,ResultType2 extends ComputeResult> - Class in com.facebook.buck.core.graph.transformation.model
-
- ComposedKey() - Constructor for class com.facebook.buck.core.graph.transformation.model.ComposedKey
-
- ComposedResult<KeyType extends ComputeKey<ResultType>,ResultType extends ComputeResult> - Class in com.facebook.buck.core.graph.transformation.model
-
- ComposedResult() - Constructor for class com.facebook.buck.core.graph.transformation.model.ComposedResult
-
- composeLeft(Class<Result2>, ComposedComputation<KeyBase, Result1>, KeyComposer<Key1, Result1, Key2>) - Static method in class com.facebook.buck.core.graph.transformation.composition.Composition
-
- Composer<Key1,Result1> - Interface in com.facebook.buck.core.graph.transformation.composition
-
- composeRight(Class<Result2>, GraphComputation<Key1, Result1>, KeyComposer<Key1, Result1, KeyIntermediate>) - Static method in class com.facebook.buck.core.graph.transformation.composition.Composition
-
- CompositeArg - Class in com.facebook.buck.rules.args
-
CompositeArg holds a list of args and appends them all to the command-line.
- CompositeArg() - Constructor for class com.facebook.buck.rules.args.CompositeArg
-
- Composition - Class in com.facebook.buck.core.graph.transformation.composition
-
- Composition() - Constructor for class com.facebook.buck.core.graph.transformation.composition.Composition
-
- compressedSize - Variable in class com.facebook.buck.event.ArtifactCompressionEvent.Finished
-
- CompressingFileHandler - Class in com.facebook.buck.cli.bootstrapper
-
- CompressingFileHandler() - Constructor for class com.facebook.buck.cli.bootstrapper.CompressingFileHandler
-
- CompressingFileHandler - Class in com.facebook.buck.log
-
- CompressingFileHandler() - Constructor for class com.facebook.buck.log.CompressingFileHandler
-
- CompressionAlgorithm - Enum in com.facebook.buck.android
-
Assets in the apks (e.g.
- CompressionType - Enum in com.facebook.buck.util.trace.uploader.types
-
Whether and when to upload logs.
- ComputationEnvironment - Interface in com.facebook.buck.core.graph.transformation
-
- ComputationIdentifier<ResultType extends ComputeResult> - Interface in com.facebook.buck.core.graph.transformation.model
-
- compute(KeyType) - Method in interface com.facebook.buck.core.graph.transformation.GraphTransformationEngine
-
Asynchronously computes the result for the given key
- compute(KeyType) - Method in class com.facebook.buck.core.graph.transformation.impl.DefaultGraphTransformationEngine
-
- compute() - Method in class com.facebook.buck.util.concurrent.WorkThreadTrackingTask
-
- computeAll(Set<KeyType>) - Method in interface com.facebook.buck.core.graph.transformation.GraphTransformationEngine
-
Asynchronously computes the result for multiple keys
- computeAll(Set<KeyType>) - Method in class com.facebook.buck.core.graph.transformation.impl.DefaultGraphTransformationEngine
-
- computeAllIfAbsent(ImmutableMap<BuildTarget, Function<BuildTarget, BuildRule>>) - Method in interface com.facebook.buck.core.rules.ActionGraphBuilder
-
- computeAllIfAbsent(ImmutableMap<BuildTarget, Function<BuildTarget, BuildRule>>) - Method in class com.facebook.buck.core.rules.resolver.impl.AbstractActionGraphBuilder
-
- computeAllIfAbsent(ImmutableMap<BuildTarget, Function<BuildTarget, BuildRule>>) - Method in class com.facebook.buck.core.rules.resolver.impl.MultiThreadedActionGraphBuilder
-
- computeAllUnchecked(Set<KeyType>) - Method in interface com.facebook.buck.core.graph.transformation.GraphTransformationEngine
-
Synchronously computes the result for multiple keys
- computeAllUnchecked(Set<KeyType>) - Method in class com.facebook.buck.core.graph.transformation.impl.DefaultGraphTransformationEngine
-
- computeBundleName(ImmutableSortedSet<Flavor>, Supplier<String>) - Method in interface com.facebook.buck.features.js.HasBundleName
-
Computes the bundle name as configured, or falls back to a default name.
- computeClosure(UsedResourcesFinder.ApkContentProvider, Iterable<String>, Iterable<Integer>) - Static method in class com.facebook.buck.android.resources.UsedResourcesFinder
-
- computeDigest(Protocol.Directory) - Method in class com.facebook.buck.remoteexecution.grpc.GrpcProtocol
-
- computeDigest(byte[]) - Method in class com.facebook.buck.remoteexecution.grpc.GrpcProtocol
-
- computeDigest(Protocol.Directory) - Method in interface com.facebook.buck.remoteexecution.interfaces.Protocol
-
- computeDigest(byte[]) - Method in interface com.facebook.buck.remoteexecution.interfaces.Protocol
-
- computeIfAbsent(BuildTarget, Function<BuildTarget, BuildRule>) - Method in interface com.facebook.buck.core.rules.ActionGraphBuilder
-
Retrieve the BuildRule
for the given BuildTarget
.
- computeIfAbsent(BuildTarget, Function<BuildTarget, BuildRule>) - Method in class com.facebook.buck.core.rules.resolver.impl.MultiThreadedActionGraphBuilder
-
- computeIfAbsent(BuildTarget, Function<BuildTarget, BuildRule>) - Method in class com.facebook.buck.core.rules.resolver.impl.RuleAnalysisCompatibleDelegatingActionGraphBuilder
-
- computeInput(ActionGraphBuilder, Linker.LinkableDepType, boolean, TargetConfiguration) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableInfo.Delegate
-
- computeInputs(ThrowingConsumer<SourcePath, E>) - Method in interface com.facebook.buck.core.rules.modern.HasCustomInputsLogic
-
- computeInputs(ThrowingConsumer<SourcePath, E>) - Method in class com.facebook.buck.core.toolchain.tool.impl.VersionedTool
-
- ComputeKey<ResultType extends ComputeResult> - Interface in com.facebook.buck.core.graph.transformation.model
-
- computeMd5Hash(ByteSource) - Static method in class com.facebook.buck.artifact_cache.ThriftArtifactCacheProtocol
-
- computePrimaryApkClosure(UsedResourcesFinder.ApkContentProvider) - Static method in class com.facebook.buck.android.resources.UsedResourcesFinder
-
- COMPUTER_NAME_FORMAT__ComputerNameDnsDomain - Static variable in interface com.facebook.buck.util.network.hostname.HostnameFetchingWin32Library
-
- COMPUTER_NAME_FORMAT__ComputerNameDnsFullyQualified - Static variable in interface com.facebook.buck.util.network.hostname.HostnameFetchingWin32Library
-
- COMPUTER_NAME_FORMAT__ComputerNameDnsHostname - Static variable in interface com.facebook.buck.util.network.hostname.HostnameFetchingWin32Library
-
- COMPUTER_NAME_FORMAT__ComputerNameNetBIOS - Static variable in interface com.facebook.buck.util.network.hostname.HostnameFetchingWin32Library
-
- COMPUTER_NAME_FORMAT__ComputerNamePhysicalDnsDomain - Static variable in interface com.facebook.buck.util.network.hostname.HostnameFetchingWin32Library
-
- COMPUTER_NAME_FORMAT__ComputerNamePhysicalDnsFullyQualified - Static variable in interface com.facebook.buck.util.network.hostname.HostnameFetchingWin32Library
-
- COMPUTER_NAME_FORMAT__ComputerNamePhysicalDnsHostname - Static variable in interface com.facebook.buck.util.network.hostname.HostnameFetchingWin32Library
-
- COMPUTER_NAME_FORMAT__ComputerNamePhysicalNetBIOS - Static variable in interface com.facebook.buck.util.network.hostname.HostnameFetchingWin32Library
-
- ComputeResult - Interface in com.facebook.buck.core.graph.transformation.model
-
- computeSha1(Path) - Method in class com.facebook.buck.edenfs.EdenProjectFilesystemDelegate
-
- computeSha1(Path) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- computeSha1(Path) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystemDelegate
-
- computeSha1(Path) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
- computeSha1(Path) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystemDelegate
-
- computeSha256(Path) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- computeSha256(Path) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
- computeSharedLibrariesToBundles(ImmutableSet<TargetNode<?>>, TargetGraph) - Static method in class com.facebook.buck.features.apple.project.ProjectGenerator
-
Generate a mapping from libraries to the framework bundles that include them.
- computeSharedLibrariesToBundles(ImmutableSet<TargetNode<?>>, TargetGraph) - Static method in class com.facebook.buck.features.apple.projectV2.XcodeNativeTargetGenerator
-
Generate a mapping from libraries to the framework bundles that include them.
- computeTransitiveCxxToPreprocessorInputMap(CxxPlatform, CxxPreprocessorDep, boolean, ActionGraphBuilder) - Static method in class com.facebook.buck.cxx.TransitiveCxxPreprocessorInputCache
-
- computeUnchecked(KeyType) - Method in interface com.facebook.buck.core.graph.transformation.GraphTransformationEngine
-
Synchronously computes the given key
- computeUnchecked(KeyType) - Method in class com.facebook.buck.core.graph.transformation.impl.DefaultGraphTransformationEngine
-
- concat(Iterable<CxxDeps>) - Static method in class com.facebook.buck.cxx.CxxDeps
-
- concat(CxxDeps...) - Static method in class com.facebook.buck.cxx.CxxDeps
-
- concat(Iterable<CxxPreprocessorInput>) - Static method in class com.facebook.buck.cxx.CxxPreprocessorInput
-
- concat(CxxToolFlags...) - Static method in class com.facebook.buck.cxx.CxxToolFlags
-
Concatenate multiple flags in a pairwise manner.
- concat(Iterable<NativeLinkableInput>) - Static method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableInput
-
- concat(Iterable<T>) - Method in interface com.facebook.buck.rules.coercer.concat.Concatable
-
- concat(Iterable<ImmutableList<T>>) - Method in class com.facebook.buck.rules.coercer.concat.ImmutableListConcatable
-
- concat(Iterable<Object>) - Method in class com.facebook.buck.rules.coercer.concat.SingleElementJsonTypeConcatenatingCoercer
-
- concat(Iterable<ImmutableList<T>>) - Method in class com.facebook.buck.rules.coercer.ListTypeCoercer
-
- concat(Iterable<ImmutableMap<K, V>>) - Method in class com.facebook.buck.rules.coercer.MapTypeCoercer
-
- concat(Iterable<Optional<T>>) - Method in class com.facebook.buck.rules.coercer.OptionalTypeCoercer
-
- concat(Iterable<PatternMatchedCollection<T>>) - Static method in class com.facebook.buck.rules.coercer.PatternMatchedCollection
-
- concat(Iterable<PatternMatchedCollection<T>>) - Method in class com.facebook.buck.rules.coercer.PatternMatchedCollectionTypeCoercer
-
- concat(Iterable<ImmutableSortedSet<T>>) - Method in class com.facebook.buck.rules.coercer.SortedSetConcatable
-
- concat(Iterable<ImmutableSortedSet<T>>) - Method in class com.facebook.buck.rules.coercer.SortedSetTypeCoercer
-
- concat(Iterable<SourceSet>) - Static method in class com.facebook.buck.rules.coercer.SourceSet
-
Concatenates elements of the given lists into a single list.
- concat(Iterable<SourceSet>) - Method in class com.facebook.buck.rules.coercer.SourceSetConcatable
-
- concat(Iterable<SourceSortedSet>) - Static method in class com.facebook.buck.rules.coercer.SourceSortedSet
-
Concatenates elements of the given lists into a single list.
- concat(Iterable<SourceSortedSet>) - Method in class com.facebook.buck.rules.coercer.SourceSortedSetConcatable
-
- concat(Iterable<String>) - Method in class com.facebook.buck.rules.coercer.StringTypeCoercer
-
- concat(Iterable<StringWithMacros>) - Method in class com.facebook.buck.rules.coercer.StringWithMacrosTypeCoercer
-
- concat(Iterable<T>) - Method in interface com.facebook.buck.rules.coercer.TypeCoercer
-
Implementation of concatenation for this type.
- concat(Stream<? extends T>) - Method in interface com.facebook.buck.util.stream.RichStream
-
- Concatable<T> - Interface in com.facebook.buck.rules.coercer.concat
-
Indicates that a class provides concatenation operation (which can either perform concatenation
or indicate that the type doesn't support concatenation).
- concatenateFiles(Path, Iterable<Path>) - Static method in class com.facebook.buck.io.file.MostFiles
-
Concatenates the contents of one or more files.
- ConcatStep - Class in com.facebook.buck.android
-
Takes in a list of files and outputs a concatenation of them in the same directory.
- ConcatStep(ProjectFilesystem, ImmutableList<Path>, Path) - Constructor for class com.facebook.buck.android.ConcatStep
-
Use this constructor if the files to concatenate are known at the time of step creation.
- ConcatStep(ProjectFilesystem, ImmutableList.Builder<Path>, Path) - Constructor for class com.facebook.buck.android.ConcatStep
-
Use this constructor if the files to concatenate are not known at the time of step creation.
- ConcurrencyLimit - Class in com.facebook.buck.util.concurrent
-
Amalgamation of parameters that control how many jobs we can run at once.
- ConcurrencyLimit(int, ResourceAllocationFairness, int, ResourceAmounts, ResourceAmounts) - Constructor for class com.facebook.buck.util.concurrent.ConcurrencyLimit
-
- CONCURRENT_ACTION_COMPUTATIONS_KEY - Static variable in class com.facebook.buck.remoteexecution.config.RemoteExecutionConfig
-
Number of actions to compute at a time.
- CONCURRENT_EXECUTIONS_KEY - Static variable in class com.facebook.buck.remoteexecution.config.RemoteExecutionConfig
-
Limit on the number of outstanding execution requests.
- CONCURRENT_PENDING_UPLOADS_KEY - Static variable in class com.facebook.buck.remoteexecution.config.RemoteExecutionConfig
-
Number of pending uploads at a time.
- CONCURRENT_RESULT_HANDLING_KEY - Static variable in class com.facebook.buck.remoteexecution.config.RemoteExecutionConfig
-
Number of results to concurrently handle at a time.
- ConcurrentProjectBuildFileParser - Class in com.facebook.buck.parser
-
- ConcurrentProjectBuildFileParser(Supplier<ProjectBuildFileParser>) - Constructor for class com.facebook.buck.parser.ConcurrentProjectBuildFileParser
-
- ConditionalStep - Class in com.facebook.buck.step
-
Step
that is run conditionally based on
Supplier<Boolean> shouldRunStep
.
- ConditionalStep(Supplier<Boolean>, Step) - Constructor for class com.facebook.buck.step.ConditionalStep
-
- Config - Class in com.facebook.buck.util.config
-
Structured representation of data read from a stack of .ini
files, where each file can
override values defined by the previous ones.
- Config() - Constructor for class com.facebook.buck.util.config.Config
-
Convenience constructor to create an empty config.
- Config(RawConfig) - Constructor for class com.facebook.buck.util.config.Config
-
- Config(RawConfig, ImmutableMap<Path, RawConfig>) - Constructor for class com.facebook.buck.util.config.Config
-
- CONFIG_FILE_LONG_ARG - Static variable in class com.facebook.buck.support.cli.args.GlobalCliOptions
-
- CONFIG_JSON_FILE_NAME - Static variable in class com.facebook.buck.util.BuckConstant
-
- CONFIG_LONG_ARG - Static variable in class com.facebook.buck.support.cli.args.GlobalCliOptions
-
- ConfigBasedUnresolvedRustPlatform - Class in com.facebook.buck.features.rust
-
- ConfigDifference - Class in com.facebook.buck.command.config
-
Helper methods for calculating and logging the config differences that cause state invalidation
- ConfigDifference() - Constructor for class com.facebook.buck.command.config.ConfigDifference
-
- ConfigDifference.ConfigChange - Interface in com.facebook.buck.command.config
-
A single changed config value
- ConfigIgnoredByDaemon - Class in com.facebook.buck.command.config
-
A view of a config that excludes configuration options that do not invalidate global state.
- ConfigIgnoredByDaemon() - Constructor for class com.facebook.buck.command.config.ConfigIgnoredByDaemon
-
- ConfigRuleKeyConfigurationFactory - Class in com.facebook.buck.rules.keys.config.impl
-
- ConfigRuleKeyConfigurationFactory() - Constructor for class com.facebook.buck.rules.keys.config.impl.ConfigRuleKeyConfigurationFactory
-
- CONFIGS - Static variable in class com.facebook.buck.parser.MetaRules
-
- Configs - Class in com.facebook.buck.util.config
-
Utility functions for working with
Config
s.
- ConfigSettingArg - Class in com.facebook.buck.core.rules.configsetting
-
Immutable implementation of ConfigSettingDescription.AbstractConfigSettingArg
.
- ConfigSettingArg.Builder - Class in com.facebook.buck.core.rules.configsetting
-
- ConfigSettingDescription - Class in com.facebook.buck.core.rules.configsetting
-
A description for config_setting
.
- ConfigSettingDescription() - Constructor for class com.facebook.buck.core.rules.configsetting.ConfigSettingDescription
-
- ConfigSettingRule - Class in com.facebook.buck.core.rules.configsetting
-
config_setting
rule.
- ConfigSettingRule(BuildTarget, ImmutableMap<String, String>, ImmutableSet<ConstraintValueRule>) - Constructor for class com.facebook.buck.core.rules.configsetting.ConfigSettingRule
-
- ConfigSettingRuleDescriptionProvider - Class in com.facebook.buck.core.rules.configsetting
-
- ConfigSettingRuleDescriptionProvider() - Constructor for class com.facebook.buck.core.rules.configsetting.ConfigSettingRuleDescriptionProvider
-
- ConfigSettingSelectable - Class in com.facebook.buck.core.rules.configsetting
-
- ConfigSettingSelectable(BuildTarget, ImmutableMap<String, String>, ImmutableSet<ConstraintValue>) - Constructor for class com.facebook.buck.core.rules.configsetting.ConfigSettingSelectable
-
- ConfigSettingSelectableConfigurationContext - Interface in com.facebook.buck.core.rules.configsetting
-
- CONFIGURATION - Static variable in class com.facebook.buck.core.build.engine.buildinfo.BuildInfo.MetadataKey
-
Key for
OnDiskBuildInfo
to store the build target configuration of the owning build
rule.
- ConfigurationBuildTargets - Class in com.facebook.buck.core.model
-
- ConfigurationForConfigurationTargets - Class in com.facebook.buck.core.model
-
- ConfigurationRule - Interface in com.facebook.buck.core.rules.config
-
A rule that can be used to configure a build graph.
- ConfigurationRuleArg - Interface in com.facebook.buck.core.rules.config
-
Marker for constructor args of configuration rules
- ConfigurationRuleDescription<T extends ConfigurationRuleArg,R extends ConfigurationRule> - Interface in com.facebook.buck.core.rules.config
-
This class describe a configuration rule - a rule that can be used during configuration of a
target graph.
- ConfigurationRuleDescriptionProvider - Interface in com.facebook.buck.core.rules.config
-
- ConfigurationRuleRegistry - Interface in com.facebook.buck.core.rules.config.registry
-
Provides centralized access to various configuration rules.
- ConfigurationRuleRegistryFactory - Class in com.facebook.buck.core.rules.config.registry.impl
-
- ConfigurationRuleResolver - Interface in com.facebook.buck.core.rules.config
-
- ConfigurationRuleSelectableResolver - Class in com.facebook.buck.core.rules.config.impl
-
- ConfigurationRuleSelectableResolver(ConfigurationRuleResolver) - Constructor for class com.facebook.buck.core.rules.config.impl.ConfigurationRuleSelectableResolver
-
- configure(long, long, long, long, BuildId) - Method in class com.facebook.buck.artifact_cache.HttpArtifactCacheEvent.Finished
-
- configure(long, long, long, long, BuildId) - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.BeginningBuildRuleEvent
-
- configure(long, long, long, long, BuildId) - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.EndingBuildRuleEvent
-
- configure(TargetConfiguration) - Method in class com.facebook.buck.core.model.UnconfiguredBuildTarget
-
- configure(TargetConfiguration) - Method in class com.facebook.buck.core.model.UnconfiguredBuildTargetWithOutputs
-
Apply the configuration.
- configure(long, long, long, long, BuildId) - Method in class com.facebook.buck.event.AbstractBuckEvent
-
Method to configure an event before posting it to the
BuckEventBus
.
- configure(long, long, long, long, BuildId) - Method in interface com.facebook.buck.event.BuckEvent
-
- configure(WebSocketServletFactory) - Method in class com.facebook.buck.httpserver.StreamingWebSocketServlet
-
- configure(JvmLibraryArg, JavacOptions, ActionGraphBuilder, BuildRuleResolver, TargetConfiguration, ToolchainProvider) - Method in class com.facebook.buck.jvm.groovy.GroovyConfiguredCompilerFactory
-
- configure(JvmLibraryArg, JavacOptions, ActionGraphBuilder, BuildRuleResolver, TargetConfiguration, ToolchainProvider) - Method in class com.facebook.buck.jvm.java.ConfiguredCompilerFactory
-
- configure(JvmLibraryArg, JavacOptions, ActionGraphBuilder, BuildRuleResolver, TargetConfiguration, ToolchainProvider) - Method in class com.facebook.buck.jvm.java.JavaConfiguredCompilerFactory
-
- configure(JvmLibraryArg, JavacOptions, ActionGraphBuilder, BuildRuleResolver, TargetConfiguration, ToolchainProvider) - Method in class com.facebook.buck.jvm.kotlin.KotlinConfiguredCompilerFactory
-
- configure(JvmLibraryArg, JavacOptions, ActionGraphBuilder, BuildRuleResolver, TargetConfiguration, ToolchainProvider) - Method in class com.facebook.buck.jvm.scala.ScalaConfiguredCompilerFactory
-
- ConfiguredCompilerFactory - Class in com.facebook.buck.jvm.java
-
- ConfiguredCompilerFactory() - Constructor for class com.facebook.buck.jvm.java.ConfiguredCompilerFactory
-
- configureParser(Object, SubCommand) - Method in class com.facebook.buck.cli.AdditionalOptionsSubCommandHandler
-
- ConfigView<T> - Interface in com.facebook.buck.core.config
-
A view of a particular config class.
- ConfigViewCache<T> - Class in com.facebook.buck.core.config
-
A cache for views of some Config.
- ConfigViewCache(T, Class<T>) - Constructor for class com.facebook.buck.core.config.ConfigViewCache
-
- confirm(String) - Method in class com.facebook.buck.doctor.UserInput
-
- CONNECT_TIMEOUT_MS - Static variable in class com.facebook.buck.android.agent.AgentMain
-
- console - Variable in class com.facebook.buck.event.listener.AbstractConsoleEventBusListener
-
- Console - Class in com.facebook.buck.util
-
- Console(Verbosity, PrintStream, PrintStream, Ansi) - Constructor for class com.facebook.buck.util.Console
-
- CONSOLE_EVENT - Static variable in interface com.facebook.buck.event.external.events.ConsoleEventExternalInterface
-
- ConsoleBuckEventListener - Class in com.facebook.buck.util.console
-
BuckEventListener that subscribes to
ConsoleEvent
, format and print them into the
Console
- ConsoleBuckEventListener(Console) - Constructor for class com.facebook.buck.util.console.ConsoleBuckEventListener
-
- ConsoleEvent - Class in com.facebook.buck.event
-
Event for messages.
- ConsoleEvent(Level, boolean, String) - Constructor for class com.facebook.buck.event.ConsoleEvent
-
- consoleEvent(ConsoleEvent) - Method in class com.facebook.buck.httpserver.WebServerBuckEventListener
-
- ConsoleEventExternalInterface - Interface in com.facebook.buck.event.external.events
-
Describes a console event thrown by buck.
- ConsoleEventHandler - Class in com.facebook.buck.core.starlark.eventhandler
-
A simple class that posts log events from skylark as
ConsoleEvent
the provided event bus
- ConsoleEventHandler(BuckEventBus, Set<EventKind>, ImmutableSet<String>, HumanReadableExceptionAugmentor) - Constructor for class com.facebook.buck.core.starlark.eventhandler.ConsoleEventHandler
-
- ConsoleHandler - Class in com.facebook.buck.cli.bootstrapper
-
- ConsoleHandler() - Constructor for class com.facebook.buck.cli.bootstrapper.ConsoleHandler
-
- ConsoleHandler - Class in com.facebook.buck.log
-
Implementation of Handler which writes to the console (System.err by default).
- ConsoleHandler() - Constructor for class com.facebook.buck.log.ConsoleHandler
-
- ConsoleHandlerState - Interface in com.facebook.buck.log
-
How the ConsoleHandler is supposed to behave for a particular thread.
- ConsoleHandlerState.Writer - Interface in com.facebook.buck.log
-
- ConsoleUtils - Class in com.facebook.buck.util.console
-
Utility methods to work with Console/ConsoleEvents
- constant(long) - Static method in class com.facebook.buck.remoteexecution.grpc.retry.Backoff
-
- ConstantJavacProvider - Class in com.facebook.buck.jvm.java
-
- ConstantJavacProvider(Javac) - Constructor for class com.facebook.buck.jvm.java.ConstantJavacProvider
-
- Constants() - Constructor for class com.facebook.buck.jvm.java.tracing.JavacPhaseEvent.Constants
-
- Constants() - Constructor for class com.facebook.buck.util.Libc.Constants
-
- ConstantToolProvider - Class in com.facebook.buck.core.toolchain.toolprovider.impl
-
- ConstantToolProvider(Tool) - Constructor for class com.facebook.buck.core.toolchain.toolprovider.impl.ConstantToolProvider
-
- Constraint - Interface in com.facebook.buck.versions
-
Represents a version constraint applied to a dependency.
- ConstraintBasedAndroidNativeTargetConfigurationMatcher - Class in com.facebook.buck.android
-
Matcher that uses constraints to figure out whether platform in target configuration matches the
CPU type.
- ConstraintBasedAndroidNativeTargetConfigurationMatcher(ConfigurationRuleRegistry, ImmutableMap<TargetCpuType, NamedPlatform>) - Constructor for class com.facebook.buck.android.ConstraintBasedAndroidNativeTargetConfigurationMatcher
-
- ConstraintBasedAndroidPackageableFilter - Class in com.facebook.buck.android.packageable
-
Performs filtering using a single configuration for non-native targets and a set of allowed
constraint values for native targets.
- ConstraintBasedAndroidPackageableFilter(TargetConfiguration) - Constructor for class com.facebook.buck.android.packageable.ConstraintBasedAndroidPackageableFilter
-
- ConstraintBasedPlatform - Class in com.facebook.buck.core.model.platform.impl
-
An implementation of a
Platform
that has a fixed set of constraints.
- ConstraintBasedPlatform(BuildTarget, ImmutableSet<ConstraintValue>) - Constructor for class com.facebook.buck.core.model.platform.impl.ConstraintBasedPlatform
-
- ConstraintResolver - Interface in com.facebook.buck.core.model.platform
-
- ConstraintRulesDescriptionProvider - Class in com.facebook.buck.core.rules.platform
-
- ConstraintRulesDescriptionProvider() - Constructor for class com.facebook.buck.core.rules.platform.ConstraintRulesDescriptionProvider
-
- ConstraintSetting - Class in com.facebook.buck.core.model.platform
-
Represents a group of constraints defined using constraint_setting
.
- ConstraintSetting() - Constructor for class com.facebook.buck.core.model.platform.ConstraintSetting
-
- ConstraintSettingArg - Class in com.facebook.buck.core.rules.platform
-
Immutable implementation of ConstraintSettingDescription.AbstractConstraintSettingArg
.
- ConstraintSettingArg.Builder - Class in com.facebook.buck.core.rules.platform
-
- ConstraintSettingDescription - Class in com.facebook.buck.core.rules.platform
-
A description for constraint_setting
.
- ConstraintSettingDescription() - Constructor for class com.facebook.buck.core.rules.platform.ConstraintSettingDescription
-
- ConstraintSettingRule - Class in com.facebook.buck.core.rules.platform
-
A configuration rule that represents config_setting
target.
- ConstraintSettingRule(BuildTarget) - Constructor for class com.facebook.buck.core.rules.platform.ConstraintSettingRule
-
- ConstraintTypeCoercer - Class in com.facebook.buck.rules.coercer
-
- ConstraintTypeCoercer() - Constructor for class com.facebook.buck.rules.coercer.ConstraintTypeCoercer
-
- ConstraintValue - Class in com.facebook.buck.core.model.platform
-
Represents a constraint defined using constraint_value
.
- ConstraintValue() - Constructor for class com.facebook.buck.core.model.platform.ConstraintValue
-
- ConstraintValueArg - Class in com.facebook.buck.core.rules.platform
-
Immutable implementation of ConstraintValueDescription.AbstractConstraintValueArg
.
- ConstraintValueArg.Builder - Class in com.facebook.buck.core.rules.platform
-
- ConstraintValueDescription - Class in com.facebook.buck.core.rules.platform
-
A description for constraint_value
.
- ConstraintValueDescription() - Constructor for class com.facebook.buck.core.rules.platform.ConstraintValueDescription
-
- ConstraintValueRule - Class in com.facebook.buck.core.rules.platform
-
constraint_value
rule.
- ConstraintValueRule(BuildTarget, ConstraintSettingRule) - Constructor for class com.facebook.buck.core.rules.platform.ConstraintValueRule
-
- ConstraintValueUtil - Class in com.facebook.buck.core.model.platform
-
Utilities to work with AbstractConstraintValue
- construct(int, Map<Integer, SortedSet<Integer>>) - Static method in class com.facebook.buck.android.resources.BringToFrontMapper
-
Constructs a ReferenceMapper that will reassign ids and adjust offsets such that for each key
in idsByType, the ids in idsByType will be reassigned to the first n ids of that type.
- ConstructorArg - Interface in com.facebook.buck.core.description.arg
-
Marker interface for all rule args including configuration rules.
- ConstructorArgMarshaller - Interface in com.facebook.buck.rules.coercer
-
- ConsumeAllOptionsHandler - Class in com.facebook.buck.cli
-
- ConsumeAllOptionsHandler(CmdLineParser, OptionDef, Setter<? super String>) - Constructor for class com.facebook.buck.cli.ConsumeAllOptionsHandler
-
- ConsumingTraverser<N> - Class in com.facebook.buck.core.util.graph
-
- ConsumingTraverser() - Constructor for class com.facebook.buck.core.util.graph.ConsumingTraverser
-
- contacts() - Method in class com.facebook.buck.core.rules.providers.lib.ImmutableTestInfo
-
- contacts() - Method in class com.facebook.buck.core.rules.providers.lib.TestInfo
-
- CONTAINER - Static variable in class com.facebook.buck.rules.keys.hasher.RuleKeyHasherTypes
-
- containerScope(RuleKeyHasher.Container) - Method in class com.facebook.buck.rules.keys.DefaultRuleKeyScopedHasher
-
Hashes the container iff non-empty (i.e.
- containerScope(RuleKeyHasher.Container) - Method in class com.facebook.buck.rules.keys.NoopRuleKeyScopedHasher
-
- containerScope(RuleKeyHasher.Container) - Method in interface com.facebook.buck.rules.keys.RuleKeyScopedHasher
-
- containerSubType(RuleKeyHasher.Container) - Static method in class com.facebook.buck.rules.keys.hasher.RuleKeyHasherTypes
-
- contains(String, ArtifactCacheMode) - Static method in class com.facebook.buck.artifact_cache.CacheResult
-
- contains(Flavor) - Method in class com.facebook.buck.core.model.FlavorDomain
-
- contains(Flavor) - Method in class com.facebook.buck.core.model.FlavorSet
-
Does this set contain given flavor?
- contains(Provider<T>) - Method in class com.facebook.buck.core.rules.providers.collect.impl.LegacyProviderInfoCollectionImpl
-
- contains(Provider<T>) - Method in class com.facebook.buck.core.rules.providers.collect.impl.ProviderInfoCollectionImpl
-
- contains(Provider<T>) - Method in interface com.facebook.buck.core.rules.providers.collect.ProviderInfoCollection
-
- contains(Object) - Method in class com.facebook.buck.util.concurrent.LinkedBlockingStack
-
- containsAll(FlavorSet) - Method in class com.facebook.buck.core.model.FlavorSet
-
Does this set contain all given flavors?
- containsAll(Collection<Flavor>) - Method in class com.facebook.buck.core.model.FlavorSet
-
Does this set contain all given flavors?
- containsAll(Collection<?>) - Method in class com.facebook.buck.util.concurrent.LinkedBlockingStack
-
- containsAnsiEscapeCodes() - Method in class com.facebook.buck.event.ConsoleEvent
-
- containsAnyOf(Set<Flavor>) - Method in class com.facebook.buck.core.model.FlavorDomain
-
- containsAnyOf(FlavorSet) - Method in class com.facebook.buck.core.model.FlavorDomain
-
- containsClassPath(String) - Method in class com.facebook.buck.test.selectors.PatternTestSelector
-
- containsClassPath(String) - Method in class com.facebook.buck.test.selectors.SimpleTestSelector
-
- containsClassPath(String) - Method in interface com.facebook.buck.test.selectors.TestSelector
-
- containsDigest(Protocol.Digest) - Method in interface com.facebook.buck.remoteexecution.ContentAddressedStorageClient
-
- containsDigest(Protocol.Digest) - Method in class com.facebook.buck.remoteexecution.grpc.GrpcContentAddressableStorageClient
-
- containsDigest(Protocol.Digest) - Method in class com.facebook.buck.remoteexecution.util.LocalContentAddressedStorage
-
- containsDigest(Protocol.Digest) - Method in class com.facebook.buck.remoteexecution.util.MultiThreadedBlobUploader
-
- containsEdge(T, T) - Method in class com.facebook.buck.core.util.graph.MutableDirectedGraph
-
- containsEntry(FileLike) - Method in class com.facebook.buck.android.dalvik.DalvikAwareOutputStreamHelper
-
- containsFlavor(Flavor) - Static method in class com.facebook.buck.apple.Flavors
-
- containsFlavors(FlavorDomain<?>) - Static method in class com.facebook.buck.apple.Flavors
-
- containsKey(Object, Location, StarlarkContext) - Method in class com.facebook.buck.core.rules.providers.collect.impl.LegacyProviderInfoCollectionImpl
-
- containsKey(Object, Location, StarlarkContext) - Method in class com.facebook.buck.core.rules.providers.collect.impl.ProviderInfoCollectionImpl
-
- containsKey(Object, Location, StarlarkContext) - Method in class com.facebook.buck.core.starlark.rule.data.SkylarkDependency
-
- containsNode(T) - Method in class com.facebook.buck.core.util.graph.MutableDirectedGraph
-
- containsValuesLessThan(ResourceAmounts) - Method in class com.facebook.buck.util.concurrent.ResourceAmounts
-
- CONTENT_ESCAPER - Static variable in class com.facebook.buck.testrunner.TestXmlEscaper
-
- CONTENT_UNESCAPER - Static variable in class com.facebook.buck.test.TestXmlUnescaper
-
- ContentAddressedStorageClient - Interface in com.facebook.buck.remoteexecution
-
This is a simple ContentAddressedStorageClient interface used for remote execution.
- ContentAddressedStorageClient.FileMaterializer - Interface in com.facebook.buck.remoteexecution
-
Interface for filesystem operations required for materialization.
- ContentAgnosticRuleKeyFactory - Class in com.facebook.buck.rules.keys
-
A factory for generating
RuleKey
s that only take into the account the path of a file and
not the contents(hash) of the file.
- ContentAgnosticRuleKeyFactory(RuleKeyFieldLoader, SourcePathRuleFinder, Optional<ThriftRuleKeyLogger>) - Constructor for class com.facebook.buck.rules.keys.ContentAgnosticRuleKeyFactory
-
- ContentAgnosticRuleKeyFactory.Builder<RULE_KEY> - Class in com.facebook.buck.rules.keys
-
- contentLength() - Method in interface com.facebook.buck.slb.HttpResponse
-
- contentLength() - Method in class com.facebook.buck.slb.LoadBalancedHttpResponse
-
- contentLength() - Method in class com.facebook.buck.slb.OkHttpResponseWrapper
-
- ContentRoot - Class in com.facebook.buck.features.project.intellij.model
-
- ContentRoot() - Constructor for class com.facebook.buck.features.project.intellij.model.ContentRoot
-
- Context(ImmutableMap<SupportsDependencyFileRuleKey, DependencyFileRuleKeyFactory.RuleKeyAndInputs>, ActionGraphBuilder, ImmutableMap<BuildRule, ImmutableSet<SourcePath>>) - Constructor for class com.facebook.buck.cli.PerfManifestCommand.Context
-
- ContextualProcessExecutor - Class in com.facebook.buck.util
-
- ContextualProcessExecutor(ProcessExecutor, ImmutableMap<String, String>) - Constructor for class com.facebook.buck.util.ContextualProcessExecutor
-
- convert(ProjectFilesystem, SourcePath) - Static method in class com.facebook.buck.core.artifact.BuildTargetSourcePathToArtifactConverter
-
- convert(UnconfiguredBuildTarget) - Static method in class com.facebook.buck.core.model.ConfigurationBuildTargets
-
- convert(Optional<UnconfiguredBuildTarget>) - Static method in class com.facebook.buck.core.model.ConfigurationBuildTargets
-
- convert(ImmutableSet<UnconfiguredBuildTarget>) - Static method in class com.facebook.buck.core.model.ConfigurationBuildTargets
-
- convert(String, Function<? super T, U>) - Method in class com.facebook.buck.core.model.FlavorDomain
-
Provides a convenience for converting from one domain to another.
- convert(StringWithMacros) - Method in class com.facebook.buck.rules.macros.StringWithMacrosConverter
-
- convertAppleHeadersToPrivateCxxHeaders(BuildTarget, Function<SourcePath, Path>, Path, CxxLibraryDescription.CommonArg) - Static method in class com.facebook.buck.apple.AppleDescriptions
-
- convertAppleHeadersToPublicCxxHeaders(BuildTarget, Function<SourcePath, Path>, Path, CxxLibraryDescription.CommonArg) - Static method in class com.facebook.buck.apple.AppleDescriptions
-
- convertArgumentsToBuildTargets(CommandRunnerParams, List<String>) - Method in class com.facebook.buck.cli.AbstractCommand
-
Converts target arguments to fully qualified form (including resolving aliases, resolving the
implicit package target, etc).
- convertErrorToSoftError(ListenableFuture<CacheResult>, RuleKey) - Method in class com.facebook.buck.core.build.engine.cache.manager.BuildCacheArtifactFetcher
-
Converts a failed ListenableFuture<CacheResult>
to a CacheResult
error.
- convertHeadersToPrivateCxxHeaders(BuildTarget, Function<SourcePath, Path>, Path, SourceSortedSet, SourceSortedSet) - Static method in class com.facebook.buck.apple.AppleDescriptions
-
- convertHeadersToPublicCxxHeaders(BuildTarget, Function<SourcePath, Path>, Path, SourceSortedSet) - Static method in class com.facebook.buck.apple.AppleDescriptions
-
- convertLanguageLevelToIjFormat(String) - Static method in class com.facebook.buck.features.project.intellij.JavaLanguageLevelHelper
-
- convertMultimapToMapOfLists(ImmutableMultimap<K, V>) - Static method in class com.facebook.buck.util.MoreMaps
-
- convertToAllCapsIfNeeded(String) - Method in class com.facebook.buck.event.listener.AbstractConsoleEventBusListener
-
- convertToPojo(Object) - Method in class com.facebook.buck.parser.api.BuildFileManifestPojoizer
-
Recursively convert parser-created objects into equivalent POJO objects.
- convertValue(Map<String, Object>, Class<T>) - Static method in class com.facebook.buck.util.json.ObjectMappers
-
- convertValues(ImmutableMap<T, UnconfiguredBuildTarget>) - Static method in class com.facebook.buck.core.model.ConfigurationBuildTargets
-
- convertValues(ImmutableSortedMap<T, UnconfiguredBuildTarget>) - Static method in class com.facebook.buck.core.model.ConfigurationBuildTargets
-
- copy() - Method in class com.facebook.buck.android.resources.StringPool
-
- copy(Artifact, Artifact, CopySourceMode) - Method in class com.facebook.buck.core.artifact.ArtifactFilesystem
-
- copy(Path, Path, CopyOption...) - Method in class com.facebook.buck.core.filesystems.BuckFileSystemProvider
-
- copy(ProjectFilesystem, BuildCellRelativePathFactory, ImmutableList.Builder<Step>, Path, ImmutableSortedSet<SourcePath>, SourcePathResolverAdapter) - Method in class com.facebook.buck.features.filebundler.FileBundler
-
- copy(ProjectFilesystem, BuildCellRelativePathFactory, ImmutableList.Builder<Step>, Path, Iterable<SourcePath>, SourcePathResolverAdapter, PatternsMatcher) - Method in class com.facebook.buck.features.filebundler.FileBundler
-
- copy(Path, Path, CopySourceMode) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- copy(Path, Path, CopySourceMode) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
- COPY_STDLIB_TO_FRAMEWORKS - Static variable in class com.facebook.buck.swift.SwiftBuckConfig
-
- CopyAction - Class in com.facebook.buck.core.rules.actions.lib
-
- CopyAction(ActionRegistry, Artifact, OutputArtifact, CopySourceMode) - Constructor for class com.facebook.buck.core.rules.actions.lib.CopyAction
-
- copyAppendingExtraDeps(Supplier<? extends Iterable<? extends BuildRule>>) - Method in class com.facebook.buck.core.rules.BuildRuleParams
-
- copyAppendingExtraDeps(Iterable<? extends BuildRule>) - Method in class com.facebook.buck.core.rules.BuildRuleParams
-
- copyAppendingExtraDeps(BuildRule...) - Method in class com.facebook.buck.core.rules.BuildRuleParams
-
- copyDir(ProjectFilesystem, Path, Path, Predicate<Path>) - Method in class com.facebook.buck.util.DefaultFilteredDirectoryCopier
-
- copyDir(ProjectFilesystem, Path, Path, Predicate<Path>) - Method in interface com.facebook.buck.util.FilteredDirectoryCopier
-
Creates a filtered copy of a directory.
- copyDirs(ProjectFilesystem, Map<Path, Path>, Predicate<Path>) - Method in class com.facebook.buck.util.DefaultFilteredDirectoryCopier
-
- copyDirs(ProjectFilesystem, Map<Path, Path>, Predicate<Path>) - Method in interface com.facebook.buck.util.FilteredDirectoryCopier
-
Copies multiple directories while filtering out individual files which fail a predicate.
- copyFile(Artifact, Object, Location) - Method in class com.facebook.buck.core.starlark.rule.SkylarkRuleContextActions
-
- copyFile(Artifact, Object, Location) - Method in interface com.facebook.buck.core.starlark.rule.SkylarkRuleContextActionsApi
-
- copyFile(Path, Path) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- copyFile(Path, Path) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
- CopyFilePhaseDestinationSpec - Interface in com.facebook.buck.apple.xcode.xcodeproj
-
- copyFolder(Path, Path) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- copyFolder(Path, Path) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
- CopyingFileBundler - Class in com.facebook.buck.features.filebundler
-
- CopyingFileBundler(ProjectFilesystem, BuildTarget) - Constructor for class com.facebook.buck.features.filebundler.CopyingFileBundler
-
- CopyInXcode - Class in com.facebook.buck.features.apple.common
-
- CopyInXcode() - Constructor for class com.facebook.buck.features.apple.common.CopyInXcode
-
- CopyInXcode.DestinationBase - Enum in com.facebook.buck.features.apple.common
-
- CopyInXcode.SourceType - Enum in com.facebook.buck.features.apple.common
-
- CopyNativeLibraries - Class in com.facebook.buck.android
-
A
BuildRule
that gathers shared objects generated by
ndk_library
and
prebuilt_native_library
rules into a directory.
- CopyNativeLibraries(BuildTarget, ProjectFilesystem, SourcePathRuleFinder, ImmutableSet<CopyNativeLibraries.StrippedObjectDescription>, ImmutableSet<CopyNativeLibraries.StrippedObjectDescription>, ImmutableSet<SourcePath>, ImmutableSet<SourcePath>, ImmutableSet<TargetCpuType>, String) - Constructor for class com.facebook.buck.android.CopyNativeLibraries
-
- CopyNativeLibraries.StrippedObjectDescription - Class in com.facebook.buck.android
-
- copyNodeWithFlavors(TargetNode<T>, ImmutableSet<Flavor>) - Method in class com.facebook.buck.core.model.targetgraph.impl.TargetNodeFactory
-
- copyNodeWithFlavors(TargetNode<T>, ImmutableSet<Flavor>) - Method in interface com.facebook.buck.core.model.targetgraph.NodeCopier
-
- copyOf(Iterable<? extends Flavor>) - Static method in class com.facebook.buck.core.model.FlavorSet
-
Constructor.
- copyOf(ImmutableSortedSet<Flavor>) - Static method in class com.facebook.buck.core.model.FlavorSet
-
Constructor.
- copyOf(Iterable<Arg>, Iterable<Arg>) - Static method in class com.facebook.buck.cxx.CxxToolFlags
-
Directly construct an instance from the given members.
- copyPlatformWithFlavorAndConfig(CxxPlatform, Platform, CxxBuckConfig, Flavor) - Static method in class com.facebook.buck.cxx.toolchain.impl.CxxPlatforms
-
Creates a CxxPlatform with a defined flavor for a CxxBuckConfig with default values provided
from another default CxxPlatform
- copyRecursively(Path, Path) - Static method in class com.facebook.buck.io.file.MostFiles
-
Recursively copies all files under fromPath
to toPath
.
- copyRecursively(Path, Path, Function<Path, Path>) - Static method in class com.facebook.buck.io.file.MostFiles
-
Recursively copies all files under fromPath
to toPath
.
- copyRecursively(Path, Path, Function<Path, Path>, Function<Path, Boolean>) - Static method in class com.facebook.buck.io.file.MostFiles
-
- CopyResourcesStep - Class in com.facebook.buck.jvm.java
-
- CopyResourcesStep(ProjectFilesystem, BuildContext, BuildTarget, ResourcesParameters, Path) - Constructor for class com.facebook.buck.jvm.java.CopyResourcesStep
-
- CopySourceMode - Enum in com.facebook.buck.io.filesystem
-
Controls the behavior of how the source should be treated when copying.
- CopyStep - Class in com.facebook.buck.step.fs
-
- CopyStep.DirectoryMode - Enum in com.facebook.buck.step.fs
-
When copying a directory, this specifies whether only the contents of the directory should be
copied, or if the directory itself should be included.
- copyToOutputStream(Path, OutputStream) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
Copies a file to an output stream.
- copyToOutputStream(Path, OutputStream) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
Copies a file to an output stream.
- copyToPath(InputStream, Path, CopyOption...) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- copyToPath(InputStream, Path, CopyOption...) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
- copyToZip(ZipEntrySourceCollection, Path) - Method in class com.facebook.buck.util.zip.collect.ZipEntrySourceCollectionWriter
-
Creates a zip archive in a given file by copying all entries listed in the collection.
- CopyToZipStep - Class in com.facebook.buck.features.zip.rules
-
A
Step
that copies a set of files and entries from given zip files to a zip file.
- CopyToZipStep(ProjectFilesystem, Path, ImmutableMap<Path, Path>, ImmutableList<Path>, ImmutableSet<Pattern>, OnDuplicateEntry) - Constructor for class com.facebook.buck.features.zip.rules.CopyToZipStep
-
- copyWithFlavors(ImmutableSet<Flavor>) - Method in class com.facebook.buck.core.model.targetgraph.impl.TargetNodeImpl
-
- copyWithFlavors(ImmutableSet<Flavor>) - Method in interface com.facebook.buck.core.model.targetgraph.TargetNode
-
- copyWithFlavors(FlavorSet) - Method in interface com.facebook.buck.core.model.targetgraph.TargetNode
-
- copyWithNewIdValue(String) - Method in class com.facebook.buck.android.aapt.RDotTxtEntry
-
- copyWithNewParent(String) - Method in class com.facebook.buck.android.aapt.RDotTxtEntry
-
- CORE_DATA_MODEL_DESCRIPTION_CLASSES - Static variable in class com.facebook.buck.apple.AppleBuildRules
-
- CORE_WLAN_INSTANCE - Static variable in class com.facebook.buck.util.environment.MacWifiSsidFinder
-
- CoreDataModel - Class in com.facebook.buck.apple
-
- CoreDataModelDescription - Class in com.facebook.buck.apple
-
Description for a core_data_model rule, which identifies a model file for use with Apple's Core
Data.
- CoreDataModelDescription() - Constructor for class com.facebook.buck.apple.CoreDataModelDescription
-
- CoreDataResource - Class in com.facebook.buck.features.apple.projectV2
-
Represents a core data resource from disk.
- CoreDataResource(Path, Optional<CoreDataResource.VersionInformation>) - Constructor for class com.facebook.buck.features.apple.projectV2.CoreDataResource
-
- CoreDataResource.VersionInformation - Class in com.facebook.buck.features.apple.projectV2
-
Details the version information for a core data file.
- CorruptArtifactException(String, String) - Constructor for exception com.facebook.buck.remoteexecution.util.MultiThreadedBlobUploader.CorruptArtifactException
-
- Counter - Class in com.facebook.buck.counters
-
- Counter(String, String, ImmutableMap<String, String>) - Constructor for class com.facebook.buck.counters.Counter
-
- COUNTER_CATEGORY - Static variable in class com.facebook.buck.event.listener.LoadBalancerEventsListener
-
- CounterBuckConfig - Class in com.facebook.buck.counters
-
- CounterBuckConfig() - Constructor for class com.facebook.buck.counters.CounterBuckConfig
-
- CounterRegistry - Interface in com.facebook.buck.counters
-
- CounterRegistry.AsyncCounterRegistrationEvent - Class in com.facebook.buck.counters
-
- CounterRegistryImpl - Class in com.facebook.buck.counters
-
- CounterRegistryImpl(ScheduledExecutorService, BuckEventBus) - Constructor for class com.facebook.buck.counters.CounterRegistryImpl
-
- CounterRegistryImpl(ScheduledExecutorService, BuckEventBus, long, long) - Constructor for class com.facebook.buck.counters.CounterRegistryImpl
-
- CounterSnapshot - Class in com.facebook.buck.counters
-
- CounterSnapshot() - Constructor for class com.facebook.buck.counters.CounterSnapshot
-
- CounterSnapshot.Builder - Class in com.facebook.buck.counters
-
- CountersSnapshotEvent - Class in com.facebook.buck.counters
-
- CountersSnapshotEvent(Iterable<CounterSnapshot>) - Constructor for class com.facebook.buck.counters.CountersSnapshotEvent
-
- CountingRuleKeyHasher<HASH> - Class in com.facebook.buck.rules.keys.hasher
-
A delegating
RuleKeyHasher
that counts the number of values put in it.
- CountingRuleKeyHasher(RuleKeyHasher<HASH>) - Constructor for class com.facebook.buck.rules.keys.hasher.CountingRuleKeyHasher
-
- CoverageReportFormat - Enum in com.facebook.buck.test
-
- CoverageReportFormatsHandler(CmdLineParser, OptionDef, Setter<CoverageReportFormat>) - Constructor for class com.facebook.buck.cli.TestCommand.CoverageReportFormatsHandler
-
- CppFlagsMacro - Class in com.facebook.buck.rules.macros
-
$(cppflags ...)
macro type.
- CppFlagsMacro() - Constructor for class com.facebook.buck.rules.macros.CppFlagsMacro
-
- CrateType - Enum in com.facebook.buck.features.rust
-
Describe the kinds of crates rustc can generate.
- create(ToolchainProvider, ProjectFilesystem, ActionGraphBuilder, CellPathResolver, BuildTarget, BuildRuleParams, AndroidBinaryGraphEnhancer, DexSplitMode, EnumSet<ExopackageMode>, FilterResourcesSteps.ResourceFilter, Supplier<ImmutableSet<JavaLibrary>>, AndroidBinaryDescriptionArg, JavaOptions) - Method in class com.facebook.buck.android.AndroidBinaryFactory
-
- create(ToolchainProvider, JavaBuckConfig, AndroidBuckConfig, CxxBuckConfig, DxConfig, ProGuardConfig, CellPathResolver, TargetGraph, BuildTarget, DependencyStack, ProjectFilesystem, BuildRuleParams, ActionGraphBuilder, FilterResourcesSteps.ResourceFilter, DexSplitMode, EnumSet<ExopackageMode>, Supplier<ImmutableSet<JavaLibrary>>, AndroidGraphEnhancerArgs, boolean, JavaOptions, JavacFactory, ConfigurationRuleRegistry) - Method in class com.facebook.buck.android.AndroidBinaryGraphEnhancerFactory
-
- create(ToolchainProvider, ProjectFilesystem, ActionGraphBuilder, CellPathResolver, BuildTarget, BuildRuleParams, AndroidBinaryGraphEnhancer, DexSplitMode, EnumSet<ExopackageMode>, FilterResourcesSteps.ResourceFilter, AndroidBundleDescriptionArg, JavaOptions) - Method in class com.facebook.buck.android.AndroidBundleFactory
-
- create(String, String) - Static method in class com.facebook.buck.android.dalvik.CanaryFactory
-
Adds a "canary" class to a secondary dex that can be safely loaded on any system.
- create(AndroidPlatformTarget, ImmutableList<String>, ProjectFilesystem, Optional<Path>, String, Optional<String>, Set<Path>, ProGuardObfuscateStep.SdkProguardType, int, Optional<List<String>>, Map<Path, Path>, ImmutableSet<Path>, Path, BuildableContext, BuildContext, boolean, ImmutableList.Builder<Step>) - Static method in class com.facebook.buck.android.ProGuardObfuscateStep
-
Create steps that write out ProGuard's command line arguments to a text file and then run
ProGuard using those arguments.
- create(Iterable<String>) - Static method in class com.facebook.buck.android.resources.StringPool
-
- create(FlavorDomain<UnresolvedAppleCxxPlatform>, BuildTarget) - Static method in class com.facebook.buck.apple.MultiarchFileInfos
-
Inspect the given build target and return information about it if its a fat binary.
- create(PluginManager) - Static method in class com.facebook.buck.apple.XCodeDescriptionsFactory
-
- create(Cells, Cell, Closer, CommandRunnerParams) - Static method in class com.facebook.buck.cli.GraphEngineFactory
-
Create new Graph Engine instance.
- create(ProcessExecutor, PluginManager, SandboxExecutionStrategyFactory, ImmutableList<ConfigurationRuleDescription<?, ?>>) - Method in interface com.facebook.buck.cli.MainRunner.KnownRuleTypesFactoryFactory
-
- create(AbsPath, Config) - Static method in class com.facebook.buck.core.cell.impl.CellMappingsFactory
-
- create(AbsPath, Map<String, AbsPath>, CellNameResolver, NewCellPathResolver) - Static method in class com.facebook.buck.core.cell.impl.DefaultCellPathResolver
-
- create(AbsPath, Config) - Static method in class com.facebook.buck.core.cell.impl.DefaultCellPathResolver
-
Creates a DefaultCellPathResolver using the mappings in the provided
Config
.
- create(ProjectFilesystem, BuckConfig, CellConfig, ImmutableMap<CellName, AbsPath>, CellPathResolver, BuckModuleManager, ToolchainProviderFactory, ProjectFilesystemFactory, UnconfiguredBuildTargetViewFactory) - Static method in class com.facebook.buck.core.cell.impl.LocalCellProviderFactory
-
Create a cell provider at a given root.
- create(ImmutableSortedSet<AbsPath>, CellProvider, NewCellPathResolver, CellPathResolver, ProjectFilesystem, BuckModuleManager, PluginManager, BuckConfig, ImmutableMap<String, String>, ProcessExecutor, ExecutableFinder) - Static method in class com.facebook.buck.core.cell.impl.RootCellFactory
-
- create(Class<? extends BaseDescription<?>>) - Static method in class com.facebook.buck.core.description.impl.RuleTypeFactory
-
Create a rule type from a rule implementation class
- create(DepsAwareExecutorType, int) - Static method in class com.facebook.buck.core.graph.transformation.executor.factory.DepsAwareExecutorFactory
-
- create(BuckEventBus, CellProvider, ImmutableMap<ExecutorPool, ListeningExecutorService>, CloseableMemoizedSupplier<DepsAwareExecutor<? super ComputeResult, ?>>, BuckConfig) - Static method in class com.facebook.buck.core.model.actiongraph.computation.ActionGraphFactory
-
- create(Function<TargetNodeToBuildRuleTransformer, ActionGraphBuilder>) - Method in interface com.facebook.buck.core.model.actiongraph.computation.ActionGraphFactoryDelegate.ActionGraphBuilderDecorator
-
- create(TargetNodeToBuildRuleTransformer, TargetGraph, ActionGraphFactory.ActionGraphCreationLifecycleListener, ActionGraphFactoryDelegate.ActionGraphBuilderDecorator) - Method in interface com.facebook.buck.core.model.actiongraph.computation.ActionGraphFactoryDelegate
-
- create(TargetNodeToBuildRuleTransformer, TargetGraph, ActionGraphFactory.ActionGraphCreationLifecycleListener, ActionGraphFactoryDelegate.ActionGraphBuilderDecorator) - Method in class com.facebook.buck.core.model.actiongraph.computation.ParallelActionGraphFactory
-
- create(String) - Method in class com.facebook.buck.core.model.tc.factory.TargetConfigurationFactory
-
Create a target configuration by absolute buck target name
- create(String, CellNameResolver) - Method in class com.facebook.buck.core.parser.buildtargetparser.ParsingUnconfiguredBuildTargetViewFactory
-
- create(String, CellNameResolver) - Method in interface com.facebook.buck.core.parser.buildtargetparser.UnconfiguredBuildTargetViewFactory
-
- create(Cell) - Method in class com.facebook.buck.core.rules.knowntypes.DefaultKnownNativeRuleTypesFactory
-
- create(Cell) - Method in interface com.facebook.buck.core.rules.knowntypes.KnownNativeRuleTypesFactory
-
- create(CellNameResolver, ForwardRelativePath, ListWithSelects) - Method in class com.facebook.buck.core.select.impl.SelectorListFactory
-
Create
SelectorList
using the given elements to create Selectors.
- create(BuckConfig, ProjectFilesystem, RuleKeyConfiguration) - Method in class com.facebook.buck.core.toolchain.impl.DefaultToolchainProviderFactory
-
- create(BuckConfig, ProjectFilesystem, RuleKeyConfiguration) - Method in interface com.facebook.buck.core.toolchain.ToolchainProviderFactory
-
- create(Path, Path, Iterable<Arg>, Path, ImmutableList<Arg>, Linker, CanonicalCellName, Path, SourcePathResolverAdapter) - Static method in class com.facebook.buck.cxx.CxxPrepareForLinkStep
-
- create(BuildTarget, ProjectFilesystem, Path, ImmutableMap<Path, SourcePath>) - Static method in class com.facebook.buck.cxx.HeaderSymlinkTreeWithHeaderMap
-
- create(BuildTarget, ProjectFilesystem, Path, ImmutableMap<Path, SourcePath>, ModuleMapMode) - Static method in class com.facebook.buck.cxx.toolchain.HeaderSymlinkTreeWithModuleMap
-
- create(BuildTarget, String, CompilerErrorEvent.CompilerType, ImmutableSet<String>) - Static method in class com.facebook.buck.event.CompilerErrorEvent
-
- create(Level, String) - Static method in class com.facebook.buck.event.ConsoleEvent
-
- create(Level, String, Object...) - Static method in class com.facebook.buck.event.ConsoleEvent
-
- create(Throwable, String, Object...) - Static method in class com.facebook.buck.event.ThrowableConsoleEvent
-
Deprecated.
- create(BuildRuleParams, BuildTarget, ProjectFilesystem, ActionGraphBuilder, CellPathResolver, CxxBuckConfig, GoPlatform, CgoLibraryDescriptionArg, Iterable<BuildTarget>, Tool) - Static method in class com.facebook.buck.features.go.CGoLibrary
-
- create(BuildTarget, ProjectFilesystem, SourcePathRuleFinder, Optional<Arg>, WorkerTool, SourcePath, Optional<String>, Optional<Path>) - Static method in class com.facebook.buck.features.js.JsFile
-
Creates JS file dev rule implementation
- create(BuildTarget, ProjectFilesystem, SourcePathRuleFinder, Optional<Arg>, WorkerTool, BuildTargetSourcePath) - Static method in class com.facebook.buck.features.js.JsFile
-
Creates JS file release rule implementation
- create(ProjectFilesystem, ImmutableMap<String, String>, ImmutableList<String>, ImmutableList<String>, ImmutableList<Arg>, Optional<String>, Path, Path, ImmutableList<Arg>, ImmutableList<Arg>, ImmutableList<Path>, boolean, boolean, SourcePathResolverAdapter) - Static method in class com.facebook.buck.features.ocaml.OcamlLinkStep
-
Factory method for OcamlLinkStep.
- create(BuckConfig, AggregationMode, String, String, String, boolean, boolean, boolean, boolean, boolean, boolean, ImmutableSet<String>, ImmutableSet<String>) - Static method in class com.facebook.buck.features.project.intellij.IjProjectBuckConfig
-
- create(Path, boolean, ImmutableSortedSet<Path>) - Method in interface com.facebook.buck.features.project.intellij.model.folders.IJFolderFactory
-
- create(Path, Path, ImmutableSortedSet<Path>) - Method in interface com.facebook.buck.features.project.intellij.model.folders.ResourceFolderFactory
-
- create(BuildTarget, ProjectFilesystem, ActionGraphBuilder, JavacOptions, Optional<ExtraClasspathProvider>, UnresolvedInferPlatform, InferConfig) - Static method in class com.facebook.buck.infer.InferNullsafe
-
Builds
InferNullsafe
rule with a properly setup dependency on base library.
- create() - Method in class com.facebook.buck.io.file.LazyPath
-
- create(JavaFileManager) - Method in interface com.facebook.buck.jvm.java.abi.source.api.SourceOnlyAbiRuleInfoFactory
-
- create() - Method in class com.facebook.buck.jvm.java.coverage.ReportGenerator
-
Create the report.
- create(SourcePathRuleFinder, JvmLibraryArg, TargetConfiguration) - Method in class com.facebook.buck.jvm.java.JavacFactory
-
Returns either the defautl javac or one created from the provided args.
- create(JavacOptions, BuildTarget, BuildRuleResolver, JvmLibraryArg) - Static method in class com.facebook.buck.jvm.java.JavacOptionsFactory
-
- create(JavaLibrary, BuildTarget, ProjectFilesystem, BuildRuleParams, Optional<String>, Optional<SourcePath>) - Static method in class com.facebook.buck.jvm.java.MavenUberJar
-
Will traverse transitive dependencies of rootRule
, separating those that do and don't
have maven coordinates.
- create(BuildTarget, ProjectFilesystem, BuildRuleParams, ImmutableSortedSet<SourcePath>, Optional<String>, Optional<SourcePath>) - Static method in class com.facebook.buck.jvm.java.MavenUberJar.SourceJar
-
- create(ProjectFilesystem, SourcePathRuleFinder, ImmutableCollection<SourcePath>, Optional<Path>) - Static method in class com.facebook.buck.jvm.java.ResourcesParameters
-
- create(JavaCompiler) - Method in interface com.facebook.buck.jvm.java.StandardJavaFileManagerFactory
-
- create(Path) - Static method in class com.facebook.buck.log.thrift.ThriftRuleKeyLogger
-
Create an instance of a logger that writes to the given file name
- create(Cell, Path, UnconfiguredBuildTarget, DependencyStack, Map<String, Object>, Package) - Method in class com.facebook.buck.parser.DefaultUnconfiguredTargetNodeFactory
-
- create(Cell, Path, PackageMetadata, Optional<Package>) - Static method in class com.facebook.buck.parser.PackageFactory
-
Create a
Package
from the
rawPackage
- create(TypeCoercerFactory, ConstructorArgMarshaller, KnownRuleTypesProvider, ParserPythonInterpreterProvider, DaemonicParserState, TargetSpecResolver, Watchman, BuckEventBus, UnconfiguredBuildTargetViewFactory, TargetConfiguration, boolean) - Static method in class com.facebook.buck.parser.ParserFactory
-
Creates an instance of
Parser
.
- create(ParsingContext, DaemonicParserState) - Method in class com.facebook.buck.parser.PerBuildStateFactory
-
- create(ParsingContext, DaemonicParserState, AtomicLong) - Method in class com.facebook.buck.parser.PerBuildStateFactory
-
- create(boolean) - Static method in interface com.facebook.buck.parser.temporarytargetuniquenesschecker.TemporaryUnconfiguredTargetToTargetUniquenessChecker
-
Create a uniqueness checker, deny or no-op depending on hashed buck-out disabled or enabled.
- create(Cell, Path, UnconfiguredBuildTarget, DependencyStack, Map<String, Object>, Package) - Method in interface com.facebook.buck.parser.UnconfiguredTargetNodeFactory
-
- create(BuckEventBus, MetadataProvider) - Method in class com.facebook.buck.remoteexecution.factory.RemoteExecutionClientsFactory
-
Creates the RemoteExecutionClients based on the held configs.
- create(Protocol, BuckEventBus) - Static method in class com.facebook.buck.remoteexecution.util.OutOfProcessIsolatedExecutionClients
-
Returns a RemoteExecution implementation that uses a local CAS and a separate local temporary
directory for execution.
- create(Function<? super String, String>, String) - Static method in class com.facebook.buck.rules.args.SanitizedArg
-
Create a SanitizedArg by applying the given sanitizer function to an arg string.
- create(BuckConfig, BuckModuleManager) - Static method in class com.facebook.buck.rules.keys.config.impl.ConfigRuleKeyConfigurationFactory
-
- create(TrackableRuleKeyCache<V>) - Static method in class com.facebook.buck.rules.keys.RuleKeyCacheRecycler
-
- create(ValueCreator<E>) - Method in class com.facebook.buck.rules.modern.impl.BuildTargetTypeInfo
-
- create(ValueCreator<E>) - Method in class com.facebook.buck.rules.modern.impl.DynamicTypeInfo
-
- create(ValueCreator<E>) - Method in class com.facebook.buck.rules.modern.impl.EitherValueTypeInfo
-
- create(ValueCreator<E>) - Method in class com.facebook.buck.rules.modern.impl.EnumValueTypeInfo
-
- create(ValueCreator<E>) - Method in class com.facebook.buck.rules.modern.impl.HashCodeValueTypeInfo
-
- create(ValueCreator<E>) - Method in class com.facebook.buck.rules.modern.impl.ImmutableMapValueTypeInfo
-
- create(ValueCreator<E>) - Method in class com.facebook.buck.rules.modern.impl.ImmutableSetValueTypeInfo
-
- create(ValueCreator<E>) - Method in class com.facebook.buck.rules.modern.impl.ImmutableSortedMapValueTypeInfo
-
- create(ValueCreator<E>) - Method in class com.facebook.buck.rules.modern.impl.NonHashableSourcePathContainerValueTypeInfo
-
- create(ValueCreator<E>) - Method in class com.facebook.buck.rules.modern.impl.NullableValueTypeInfo
-
- create(ValueCreator<E>) - Method in class com.facebook.buck.rules.modern.impl.OutputLabelValueTypeInfo
-
- create(ValueCreator<E>) - Method in class com.facebook.buck.rules.modern.impl.PatternValueTypeInfo
-
- create(ValueCreator<E>) - Method in class com.facebook.buck.rules.modern.impl.SourcePathValueTypeInfo
-
- create(ValueCreator<E>) - Method in class com.facebook.buck.rules.modern.impl.SupplierValueTypeInfo
-
- create(ValueCreator<E>) - Method in class com.facebook.buck.rules.modern.impl.TargetConfigurationTypeInfo
-
- create(ValueCreator<E>) - Method in class com.facebook.buck.rules.modern.impl.ToolchainTypeInfo
-
- create(ValueCreator<E>) - Method in class com.facebook.buck.rules.modern.impl.UnconfiguredBuildTargetTypeInfo
-
- create(ValueCreator<E>) - Method in class com.facebook.buck.rules.modern.impl.ValueTypeInfos.ExcludedValueTypeInfo
-
- create(ValueCreator<E>) - Method in interface com.facebook.buck.rules.modern.ValueTypeInfo
-
- create(ProcessExecutor, BuckConfig) - Method in class com.facebook.buck.sandbox.impl.PlatformSandboxExecutionStrategyFactory
-
- create(ProcessExecutor, BuckConfig) - Method in interface com.facebook.buck.sandbox.SandboxExecutionStrategyFactory
-
- create(Path) - Method in interface com.facebook.buck.skylark.io.GlobberFactory
-
- create(Path) - Method in class com.facebook.buck.skylark.io.impl.HybridGlobberFactory
-
- create(Path) - Static method in class com.facebook.buck.skylark.io.impl.NativeGlobber
-
- create(WatchmanClient, SyncCookieState, String, String) - Static method in class com.facebook.buck.skylark.io.impl.WatchmanGlobber
-
- create(ExceptionHandler<? extends Throwable, ExitCode>...) - Static method in class com.facebook.buck.support.exceptions.handler.ExceptionHandlerRegistryFactory
-
Overriding is defined such that the order of the existing handlers are unaltered.
- create() - Static method in class com.facebook.buck.support.exceptions.handler.ExceptionHandlerRegistryFactory
-
- create(Cells, KnownRuleTypesProvider, Watchman, Optional<WebServer>, UnconfiguredBuildTargetViewFactory, TargetConfigurationSerializer, Clock) - Static method in class com.facebook.buck.support.state.BuckGlobalStateFactory
-
- create(ProjectFilesystem, Collection<Path>, Path) - Static method in class com.facebook.buck.util.zip.Zip
-
Takes a sequence of paths relative to the project root and writes a zip file to out
with the contents and structure that matches that of the specified paths.
- CREATE_PROCESS_ESCAPER - Static variable in class com.facebook.buck.util.Escaper
-
CreateProcess (Windows) quoting Function
which can be
passed to Iterables.transform()
.
- createActionGraph(TargetNodeToBuildRuleTransformer, TargetGraph, IncrementalActionGraphMode, ActionGraphFactory.ActionGraphCreationLifecycleListener) - Method in class com.facebook.buck.core.model.actiongraph.computation.ActionGraphFactory
-
- createAggregationModule(Path, ImmutableSet<TargetNode<?>>) - Method in interface com.facebook.buck.features.project.intellij.aggregation.AggregationModuleFactory
-
- createAggregationModule(Path, ImmutableSet<TargetNode<?>>) - Method in class com.facebook.buck.features.project.intellij.aggregation.DefaultAggregationModuleFactory
-
- createAndRegister(EventBus, TrackableRuleKeyCache<V>, ImmutableSet<ProjectFilesystem>) - Static method in class com.facebook.buck.rules.keys.RuleKeyCacheRecycler
-
- createAndroidGenPath(ProjectFilesystem, IjProjectConfig, Path) - Static method in class com.facebook.buck.features.project.intellij.IjAndroidHelper
-
- createAnsi(Optional<String>) - Method in class com.facebook.buck.support.cli.config.CliConfig
-
Create an Ansi object appropriate for the current output.
- createAnsiHighlightingHandler(boolean, PrintStream, Ansi) - Static method in class com.facebook.buck.util.InputStreamConsumer
-
- createBinaryBuildRule(BuildTarget, ProjectFilesystem, BuildRuleParams, ActionGraphBuilder, RustBuckConfig, RustPlatform, Optional<String>, Optional<String>, ImmutableSortedSet<String>, ImmutableSortedMap<String, Arg>, Iterator<Arg>, Iterator<Arg>, Linker.LinkableDepType, boolean, ImmutableSortedSet<SourcePath>, ImmutableSortedMap<SourcePath, String>, Optional<String>, ImmutableSet<String>, CrateType, Iterable<BuildRule>, ImmutableMap<String, BuildTarget>) - Static method in class com.facebook.buck.features.rust.RustCompileUtils
-
- createBoolean() - Method in interface com.facebook.buck.rules.modern.ValueCreator
-
- createBuckOutFileHashCache(ProjectFilesystem, FileHashCacheMode) - Static method in class com.facebook.buck.util.cache.impl.DefaultFileHashCache
-
- createBuckOutProjectFilesystem() - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- createBuckOutProjectFilesystem() - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
- createBuildConfiguration(String) - Method in class com.facebook.buck.apple.xcode.AbstractPBXObjectFactory
-
- createBuildConfiguration(String) - Method in class com.facebook.buck.apple.xcode.PBXObjectGIDFactory
-
- createBuilderArgs() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- createBuildFile(PBXReference) - Method in class com.facebook.buck.apple.xcode.AbstractPBXObjectFactory
-
- createBuildFile(PBXReference) - Method in class com.facebook.buck.apple.xcode.PBXObjectGIDFactory
-
- createBuildInfoRecorder(BuildTarget, ProjectFilesystem, BuildInfoStore) - Method in class com.facebook.buck.core.build.engine.BuildEngineBuildContext
-
- createBuildOutputSymLinksEnabled() - Method in class com.facebook.buck.command.config.BuildBuckConfig
-
Whether to create symlinks of build output in buck-out/last.
- createBuildResult(BuildRuleSuccessType, Optional<String>) - Method in interface com.facebook.buck.core.build.engine.BuildStrategyContext
-
- createBuildResult(BuildRuleSuccessType, Optional<String>) - Method in class com.facebook.buck.core.build.engine.DelegatingBuildStrategyContext
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, AndroidAarDescriptionArg) - Method in class com.facebook.buck.android.AndroidAarDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, AndroidAppModularityDescriptionArg) - Method in class com.facebook.buck.android.AndroidAppModularityDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, AndroidBinaryDescriptionArg) - Method in class com.facebook.buck.android.AndroidBinaryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, AndroidBuildConfigDescriptionArg) - Method in class com.facebook.buck.android.AndroidBuildConfigDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, AndroidBundleDescriptionArg) - Method in class com.facebook.buck.android.AndroidBundleDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, AndroidInstrumentationApkDescriptionArg) - Method in class com.facebook.buck.android.AndroidInstrumentationApkDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, AndroidInstrumentationTestDescriptionArg) - Method in class com.facebook.buck.android.AndroidInstrumentationTestDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, AndroidLibraryDescriptionArg) - Method in class com.facebook.buck.android.AndroidLibraryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, AndroidManifestDescriptionArg) - Method in class com.facebook.buck.android.AndroidManifestDescription
-
- createBuildRule(BuildTarget, ProjectFilesystem, BuildRuleResolver, ImmutableSortedSet<BuildTarget>, SourcePath) - Method in class com.facebook.buck.android.AndroidManifestFactory
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, AndroidPrebuiltAarDescriptionArg) - Method in class com.facebook.buck.android.AndroidPrebuiltAarDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, AndroidResourceDescriptionArg) - Method in class com.facebook.buck.android.AndroidResourceDescription
-
- createBuildRule(BuildTarget, ProjectFilesystem, BuildRuleParams, ActionGraphBuilder, ApkGenruleDescriptionArg, Optional<Arg>, Optional<Arg>, Optional<Arg>) - Method in class com.facebook.buck.android.ApkGenruleDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, GenAidlDescriptionArg) - Method in class com.facebook.buck.android.GenAidlDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, NdkLibraryDescriptionArg) - Method in class com.facebook.buck.android.NdkLibraryDescription
-
Deprecated.
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, NdkToolchainDescriptionArg) - Method in class com.facebook.buck.android.NdkToolchainDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, PrebuiltNativeLibraryDescriptionArg) - Method in class com.facebook.buck.android.PrebuiltNativeLibraryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, RobolectricTestDescriptionArg) - Method in class com.facebook.buck.android.RobolectricTestDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, AppleAssetCatalogDescriptionArg) - Method in class com.facebook.buck.apple.AppleAssetCatalogDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, AppleBinaryDescriptionArg) - Method in class com.facebook.buck.apple.AppleBinaryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, AppleBundleDescriptionArg) - Method in class com.facebook.buck.apple.AppleBundleDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, AppleLibraryDescriptionArg) - Method in class com.facebook.buck.apple.AppleLibraryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, ApplePackageDescriptionArg) - Method in class com.facebook.buck.apple.ApplePackageDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, AppleResourceDescriptionArg) - Method in class com.facebook.buck.apple.AppleResourceDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, AppleTestDescriptionArg) - Method in class com.facebook.buck.apple.AppleTestDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, AppleToolchainDescriptionArg) - Method in class com.facebook.buck.apple.AppleToolchainDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, AppleToolchainSetDescriptionArg) - Method in class com.facebook.buck.apple.AppleToolchainSetDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, AppleWrapperResourceArg) - Method in class com.facebook.buck.apple.CoreDataModelDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, PrebuiltAppleFrameworkDescriptionArg) - Method in class com.facebook.buck.apple.PrebuiltAppleFrameworkDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, AppleWrapperResourceArg) - Method in class com.facebook.buck.apple.SceneKitAssetsDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, XcodeScriptDescriptionArg) - Method in class com.facebook.buck.apple.XcodePostbuildScriptDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, XcodeScriptDescriptionArg) - Method in class com.facebook.buck.apple.XcodePrebuildScriptDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, T) - Method in interface com.facebook.buck.core.rules.DescriptionWithTargetGraph
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, ExternalTestRunnerDescriptionArg) - Method in class com.facebook.buck.core.test.rule.impl.ExternalTestRunnerDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, CxxBinaryDescriptionArg) - Method in class com.facebook.buck.cxx.CxxBinaryDescription
-
- createBuildRule(TargetGraph, BuildTarget, ProjectFilesystem, ActionGraphBuilder, CellPathResolver, CxxBinaryDescriptionArg, ImmutableSortedSet<BuildTarget>) - Method in class com.facebook.buck.cxx.CxxBinaryFactory
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, CxxGenruleDescriptionArg) - Method in class com.facebook.buck.cxx.CxxGenruleDescription
-
- createBuildRule(BuildTarget, ProjectFilesystem, BuildRuleParams, ActionGraphBuilder, CxxGenruleDescriptionArg, Optional<Arg>, Optional<Arg>, Optional<Arg>) - Method in class com.facebook.buck.cxx.CxxGenruleDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, CxxLibraryDescriptionArg) - Method in class com.facebook.buck.cxx.CxxLibraryDescription
-
- createBuildRule(TargetGraph, BuildTarget, ProjectFilesystem, BuildRuleParams, ActionGraphBuilder, CellPathResolver, CxxLibraryDescriptionArg, Optional<Linker.LinkableDepType>, Optional<SourcePath>, ImmutableSet<BuildTarget>, ImmutableSortedSet<BuildTarget>, CxxLibraryDescription.TransitiveCxxPreprocessorInputFunction, CxxLibraryDescriptionDelegate) - Method in class com.facebook.buck.cxx.CxxLibraryFactory
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, CxxPrecompiledHeaderDescriptionArg) - Method in class com.facebook.buck.cxx.CxxPrecompiledHeaderDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, CxxTestDescriptionArg) - Method in class com.facebook.buck.cxx.CxxTestDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, CxxToolchainDescriptionArg) - Method in class com.facebook.buck.cxx.CxxToolchainDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, PrebuiltCxxLibraryDescriptionArg) - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, PrebuiltCxxLibraryGroupDescriptionArg) - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, XcodeWorkspaceConfigDescriptionArg) - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, DBinaryDescriptionArg) - Method in class com.facebook.buck.features.d.DBinaryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, DLibraryDescriptionArg) - Method in class com.facebook.buck.features.d.DLibraryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, DTestDescriptionArg) - Method in class com.facebook.buck.features.d.DTestDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, CsharpLibraryDescriptionArg) - Method in class com.facebook.buck.features.dotnet.CsharpLibraryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, PrebuiltDotnetLibraryDescriptionArg) - Method in class com.facebook.buck.features.dotnet.PrebuiltDotnetLibraryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, FileGroupDescriptionArg) - Method in class com.facebook.buck.features.filegroup.FilegroupDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, CgoLibraryDescriptionArg) - Method in class com.facebook.buck.features.go.CgoLibraryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, GoBinaryDescriptionArg) - Method in class com.facebook.buck.features.go.GoBinaryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, GoLibraryDescriptionArg) - Method in class com.facebook.buck.features.go.GoLibraryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, GoTestDescriptionArg) - Method in class com.facebook.buck.features.go.GoTestDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, GoTestRunnerDescriptionArg) - Method in class com.facebook.buck.features.go.GoTestRunnerDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, PrebuiltGoLibraryDescriptionArg) - Method in class com.facebook.buck.features.go.PrebuiltGoLibraryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, GwtBinaryDescriptionArg) - Method in class com.facebook.buck.features.gwt.GwtBinaryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, HalideLibraryDescriptionArg) - Method in class com.facebook.buck.features.halide.HalideLibraryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, HaskellBinaryDescriptionArg) - Method in class com.facebook.buck.features.haskell.HaskellBinaryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, HaskellGhciDescriptionArg) - Method in class com.facebook.buck.features.haskell.HaskellGhciDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, HaskellHaddockDescriptionArg) - Method in class com.facebook.buck.features.haskell.HaskellHaddockDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, HaskellLibraryDescriptionArg) - Method in class com.facebook.buck.features.haskell.HaskellLibraryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, HaskellPrebuiltLibraryDescriptionArg) - Method in class com.facebook.buck.features.haskell.HaskellPrebuiltLibraryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, JsBundleDescriptionArg) - Method in class com.facebook.buck.features.js.JsBundleDescription
-
- createBuildRule(BuildTarget, ProjectFilesystem, BuildRuleParams, ActionGraphBuilder, JsBundleGenruleDescriptionArg, Optional<Arg>, Optional<Arg>, Optional<Arg>) - Method in class com.facebook.buck.features.js.JsBundleGenruleDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, JsLibraryDescriptionArg) - Method in class com.facebook.buck.features.js.JsLibraryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, CxxLuaExtensionDescriptionArg) - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, LuaBinaryDescriptionArg) - Method in class com.facebook.buck.features.lua.LuaBinaryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, LuaLibraryDescriptionArg) - Method in class com.facebook.buck.features.lua.LuaLibraryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, OcamlBinaryDescriptionArg) - Method in class com.facebook.buck.features.ocaml.OcamlBinaryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, OcamlLibraryDescriptionArg) - Method in class com.facebook.buck.features.ocaml.OcamlLibraryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, PrebuiltOcamlLibraryDescriptionArg) - Method in class com.facebook.buck.features.ocaml.PrebuiltOcamlLibraryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, CxxPythonExtensionDescriptionArg) - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, PrebuiltPythonLibraryDescriptionArg) - Method in class com.facebook.buck.features.python.PrebuiltPythonLibraryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, PythonBinaryDescriptionArg) - Method in class com.facebook.buck.features.python.PythonBinaryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, PythonLibraryDescriptionArg) - Method in class com.facebook.buck.features.python.PythonLibraryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, PythonTestDescriptionArg) - Method in class com.facebook.buck.features.python.PythonTestDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, PythonTestRunnerDescriptionArg) - Method in class com.facebook.buck.features.python.PythonTestRunnerDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, PrebuiltRustLibraryDescriptionArg) - Method in class com.facebook.buck.features.rust.PrebuiltRustLibraryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, RustBinaryDescriptionArg) - Method in class com.facebook.buck.features.rust.RustBinaryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, RustLibraryDescriptionArg) - Method in class com.facebook.buck.features.rust.RustLibraryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, RustTestDescriptionArg) - Method in class com.facebook.buck.features.rust.RustTestDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, ZipFileDescriptionArg) - Method in class com.facebook.buck.features.zip.rules.ZipFileDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, HttpArchiveDescriptionArg) - Method in class com.facebook.buck.file.HttpArchiveDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, HttpFileDescriptionArg) - Method in class com.facebook.buck.file.HttpFileDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, RemoteFileDescriptionArg) - Method in class com.facebook.buck.file.RemoteFileDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, GroovyLibraryDescriptionArg) - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, GroovyTestDescriptionArg) - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescription
-
- createBuildRule(BuildTarget, ProjectFilesystem, BuildRuleParams, ActionGraphBuilder, JarGenruleDescriptionArg, Optional<Arg>, Optional<Arg>, Optional<Arg>) - Method in class com.facebook.buck.jvm.java.JarGenruleDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, JavaAnnotationProcessorDescriptionArg) - Method in class com.facebook.buck.jvm.java.JavaAnnotationProcessorDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, JavaBinaryDescriptionArg) - Method in class com.facebook.buck.jvm.java.JavaBinaryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, JavaLibraryDescriptionArg) - Method in class com.facebook.buck.jvm.java.JavaLibraryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, JavaPluginDescriptionArg) - Method in class com.facebook.buck.jvm.java.JavaPluginDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, JavaTestDescriptionArg) - Method in class com.facebook.buck.jvm.java.JavaTestDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, JavaTestRunnerDescriptionArg) - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, KeystoreDescriptionArg) - Method in class com.facebook.buck.jvm.java.KeystoreDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, PrebuiltJarDescriptionArg) - Method in class com.facebook.buck.jvm.java.PrebuiltJarDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, KotlinLibraryDescriptionArg) - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, KotlinTestDescriptionArg) - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, ScalaLibraryDescriptionArg) - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, ScalaTestDescriptionArg) - Method in class com.facebook.buck.jvm.scala.ScalaTestDescription
-
- createBuildRule(BuildTarget, ProjectFilesystem, BuildRuleParams, ActionGraphBuilder, T, Optional<Arg>, Optional<Arg>, Optional<Arg>) - Method in class com.facebook.buck.shell.AbstractGenruleDescription
-
- createBuildRule(BuildTarget, ProjectFilesystem, BuildRuleResolver, T, Optional<Arg>, Optional<Arg>, Optional<Arg>, Optional<String>, Optional<ImmutableMap<String, ImmutableSet<String>>>) - Method in class com.facebook.buck.shell.AbstractGenruleDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, T) - Method in class com.facebook.buck.shell.AbstractGenruleDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, CommandAliasDescriptionArg) - Method in class com.facebook.buck.shell.CommandAliasDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, ExportFileDescriptionArg) - Method in class com.facebook.buck.shell.ExportFileDescription
-
- createBuildRule(BuildTarget, ProjectFilesystem, BuildRuleParams, ActionGraphBuilder, GenruleDescriptionArg, Optional<Arg>, Optional<Arg>, Optional<Arg>) - Method in class com.facebook.buck.shell.GenruleDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, ShBinaryDescriptionArg) - Method in class com.facebook.buck.shell.ShBinaryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, ShTestDescriptionArg) - Method in class com.facebook.buck.shell.ShTestDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, TestSuiteDescriptionArg) - Method in class com.facebook.buck.shell.TestSuiteDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, WorkerToolDescriptionArg) - Method in class com.facebook.buck.shell.WorkerToolDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, SwiftLibraryDescriptionArg) - Method in class com.facebook.buck.swift.SwiftLibraryDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, SwiftToolchainDescriptionArg) - Method in class com.facebook.buck.swift.SwiftToolchainDescription
-
- createBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, VersionedAliasDescriptionArg) - Method in class com.facebook.buck.versions.VersionedAliasDescription
-
- createBuildRuleForCxxThinLtoBinary(BuildTarget, ProjectFilesystem, ActionGraphBuilder, CellPathResolver, CxxBuckConfig, CxxPlatform, CxxBinaryDescription.CommonArg, ImmutableSet<BuildTarget>, Optional<StripStyle>, Optional<LinkerMapMode>) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- createBuildRuleForTransitiveAssetCatalogDependencies(XCodeDescriptions, TargetGraph, BuildTarget, ProjectFilesystem, SourcePathRuleFinder, Optional<String>, ApplePlatform, String, Tool, AppleAssetCatalog.ValidationType, AppleAssetCatalogsCompilationOptions, Predicate<BuildTarget>) - Static method in class com.facebook.buck.apple.AppleDescriptions
-
- createBuildRulesForCoreDataDependencies(XCodeDescriptions, TargetGraph, BuildTarget, ProjectFilesystem, BuildRuleParams, String, AppleCxxPlatform, Predicate<BuildTarget>) - Static method in class com.facebook.buck.apple.AppleDescriptions
-
- createBuildRulesForCxxBinary(BuildTarget, ProjectFilesystem, ActionGraphBuilder, CellPathResolver, CxxBuckConfig, CxxPlatform, ImmutableMap<String, CxxSource>, ImmutableMap<Path, SourcePath>, SortedSet<BuildRule>, ImmutableSet<BuildTarget>, Optional<StripStyle>, Optional<LinkerMapMode>, Linker.LinkableDepType, Optional<LinkableListFilter>, CxxLinkOptions, ImmutableList<StringWithMacros>, PatternMatchedCollection<ImmutableList<StringWithMacros>>, ImmutableMap<CxxSource.Type, ImmutableList<StringWithMacros>>, ImmutableMap<CxxSource.Type, PatternMatchedCollection<ImmutableList<StringWithMacros>>>, ImmutableSortedSet<FrameworkPath>, ImmutableSortedSet<FrameworkPath>, ImmutableList<StringWithMacros>, ImmutableMap<CxxSource.Type, ImmutableList<StringWithMacros>>, PatternMatchedCollection<ImmutableList<StringWithMacros>>, ImmutableMap<CxxSource.Type, PatternMatchedCollection<ImmutableList<StringWithMacros>>>, Optional<SourcePath>, Optional<SourcePath>, ImmutableList<StringWithMacros>, ImmutableList<String>, PatternMatchedCollection<ImmutableList<StringWithMacros>>, Optional<Linker.CxxRuntimeType>, ImmutableSortedSet<SourcePath>, ImmutableSortedSet<String>, Optional<String>) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- createBuildRulesForCxxBinaryDescriptionArg(TargetGraph, BuildTarget, ProjectFilesystem, ActionGraphBuilder, CellPathResolver, CxxBuckConfig, CxxPlatform, CxxBinaryDescription.CommonArg, ImmutableSet<BuildTarget>, Optional<StripStyle>, Optional<LinkerMapMode>) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- createBuildRulesForSceneKitAssetsDependencies(XCodeDescriptions, TargetGraph, BuildTarget, ProjectFilesystem, BuildRuleParams, AppleCxxPlatform, Predicate<BuildTarget>) - Static method in class com.facebook.buck.apple.AppleDescriptions
-
- createBuildTargetForObjCGeneratedHeaderBuildRule(BuildTarget, HeaderVisibility, CxxPlatform) - Static method in class com.facebook.buck.apple.AppleLibraryDescriptionSwiftEnhancer
-
- createBuildTargetForSwiftCompile(BuildTarget, CxxPlatform) - Static method in class com.facebook.buck.apple.AppleLibraryDescriptionSwiftEnhancer
-
- createByte() - Method in interface com.facebook.buck.rules.modern.ValueCreator
-
- createCancelledResult(Throwable) - Method in interface com.facebook.buck.core.build.engine.BuildStrategyContext
-
- createCancelledResult(Throwable) - Method in class com.facebook.buck.core.build.engine.DelegatingBuildStrategyContext
-
- createCCompileBuildTarget(BuildTarget, String) - Static method in class com.facebook.buck.features.ocaml.OcamlBuildRulesGenerator
-
- createCellNameResolver(AbsPath, Config, NewCellPathResolver) - Static method in class com.facebook.buck.core.cell.impl.CellMappingsFactory
-
- createCharacter() - Method in interface com.facebook.buck.rules.modern.ValueCreator
-
- createClient() - Method in class com.facebook.buck.io.watchman.Watchman
-
- createClientSideSlb(Clock, BuckEventBus) - Method in class com.facebook.buck.slb.SlbBuckConfig
-
- createClientSideSlb(Clock, BuckEventBus, Optional<HandshakeCertificates>, Optional<HostnameVerifier>) - Method in class com.facebook.buck.slb.SlbBuckConfig
-
- createCommandLineArguments() - Method in class com.facebook.buck.sandbox.darwin.DarwinSandbox
-
Creates a list CL arguments that should be used to run a process in this sandbox
- createCommandLineArgumentsForDescription() - Method in class com.facebook.buck.sandbox.darwin.DarwinSandbox
-
Creates a list CL arguments that should be used to run a process in this sandbox
- createCommands(Path, ProjectFilesystem, String, AppleBundle, Path, Optional<? extends IdbRunTestsStep.StdoutReadingCallback>, TestSelectorList, Optional<Long>, Optional<Long>, Collection<Path>, Map<Path, Path>, Map<Path, Map<Path, Path>>, Optional<String>) - Static method in class com.facebook.buck.apple.IdbRunTestsStep
-
Function that created one idb step for each different test
- createCompanionBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, ActionGraphBuilder, CxxLibraryDescription.CommonArg, Optional<String>) - Method in class com.facebook.buck.swift.SwiftLibraryDescription
-
- createCompilationDatabase(BuildTarget, ProjectFilesystem, Iterable<CxxPreprocessAndCompile>) - Static method in class com.facebook.buck.cxx.CxxCompilationDatabase
-
- createCompilationDatabaseDependencies(BuildTarget, FlavorDomain<?>, ActionGraphBuilder, ImmutableSortedSet<BuildTarget>) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- createCompileBuildTarget(String) - Method in class com.facebook.buck.cxx.CxxSourceRuleFactory
-
- createCompileFlags(ActionGraphBuilder, ImmutableSet<BuildRule>, HaskellPlatform, Linker.LinkableDepType, boolean, ImmutableList<String>) - Static method in class com.facebook.buck.features.haskell.HaskellDescriptionUtils
-
Create common Haskell compile flags used by HaskellCompileRule or HaskellHaddockLibRule.
- createCompiler(JavacExecutionContext, SourcePathResolverAdapter) - Method in class com.facebook.buck.jvm.java.JarBackedJavac
-
- createCompiler(JavacExecutionContext, SourcePathResolverAdapter) - Method in class com.facebook.buck.jvm.java.JdkProvidedInMemoryJavac
-
- createCompiler(JavacExecutionContext, SourcePathResolverAdapter) - Method in class com.facebook.buck.jvm.java.Jsr199Javac
-
- createCompileStep(BuildContext, ProjectFilesystem, BuildTarget, CompilerParameters, ImmutableList.Builder<Step>, BuildableContext) - Method in class com.facebook.buck.jvm.java.CompileToJarStepFactory
-
- createCompileStep(BuildContext, ProjectFilesystem, BuildTarget, CompilerParameters, ImmutableList.Builder<Step>, BuildableContext) - Method in class com.facebook.buck.jvm.java.JavacToJarStepFactory
-
- createCompileStep(BuildContext, ProjectFilesystem, BuildTarget, CompilerParameters, ImmutableList.Builder<Step>, BuildableContext) - Method in class com.facebook.buck.jvm.kotlin.KotlincToJarStepFactory
-
- createCompileStep(BuildContext, ProjectFilesystem, BuildTarget, CompilerParameters, ImmutableList.Builder<Step>, BuildableContext) - Method in class com.facebook.buck.jvm.scala.ScalacToJarStepFactory
-
- createCompileToJarStep(BuildContext, ProjectFilesystem, BuildTarget, CompilerParameters, ResourcesParameters, ImmutableList<String>, JarParameters, JarParameters, ImmutableList.Builder<Step>, BuildableContext) - Method in class com.facebook.buck.jvm.java.CompileToJarStepFactory
-
- createCompileToJarStepImpl(ProjectFilesystem, BuildContext, BuildTarget, CompilerParameters, ImmutableList<String>, JarParameters, JarParameters, ImmutableList.Builder<Step>, BuildableContext) - Method in class com.facebook.buck.jvm.java.CompileToJarStepFactory
-
- createCompileToJarStepImpl(ProjectFilesystem, BuildContext, BuildTarget, CompilerParameters, ImmutableList<String>, JarParameters, JarParameters, ImmutableList.Builder<Step>, BuildableContext) - Method in class com.facebook.buck.jvm.java.JavacToJarStepFactory
-
- createConcurrent() - Static method in class com.facebook.buck.core.util.graph.MutableDirectedGraph
-
- createConfigFromFiles(Path, ImmutableList<Path>) - Static method in class com.facebook.buck.util.config.Configs
-
Generates a config by merging configs from specified locations on disk in order of the list
supplied.
- createConfigurationList() - Method in class com.facebook.buck.apple.xcode.AbstractPBXObjectFactory
-
- createConfigurationList() - Method in class com.facebook.buck.apple.xcode.PBXObjectGIDFactory
-
- createConfigurationRule(ConfigurationRuleResolver, BuildTarget, DependencyStack, AndroidPlatformArg) - Method in class com.facebook.buck.android.toolchain.platform.AndroidPlatformDescription
-
- createConfigurationRule(ConfigurationRuleResolver, BuildTarget, DependencyStack, T) - Method in interface com.facebook.buck.core.rules.config.ConfigurationRuleDescription
-
- createConfigurationRule(ConfigurationRuleResolver, BuildTarget, DependencyStack, ConfigSettingArg) - Method in class com.facebook.buck.core.rules.configsetting.ConfigSettingDescription
-
- createConfigurationRule(ConfigurationRuleResolver, BuildTarget, DependencyStack, ConstraintSettingArg) - Method in class com.facebook.buck.core.rules.platform.ConstraintSettingDescription
-
- createConfigurationRule(ConfigurationRuleResolver, BuildTarget, DependencyStack, ConstraintValueArg) - Method in class com.facebook.buck.core.rules.platform.ConstraintValueDescription
-
- createConfigurationRule(ConfigurationRuleResolver, BuildTarget, DependencyStack, PlatformArg) - Method in class com.facebook.buck.core.rules.platform.PlatformDescription
-
- createConnection(URI) - Method in class com.facebook.buck.file.downloader.impl.HttpDownloader
-
- createConsole() - Method in class com.facebook.buck.rules.modern.builders.IsolatedBuildableBuilder
-
- createConsoleLinesAtTime(long) - Method in interface com.facebook.buck.event.listener.interfaces.AdditionalConsoleLineProvider
-
Returns additional console lines representing the current state of running a command.
- createConsoleLinesAtTime(long) - Method in class com.facebook.buck.remoteexecution.event.listener.RemoteExecutionConsoleLineProvider
-
- createContainerItemProxy(PBXObject, String, PBXContainerItemProxy.ProxyType) - Method in class com.facebook.buck.apple.xcode.AbstractPBXObjectFactory
-
- createContainerItemProxy(PBXObject, String, PBXContainerItemProxy.ProxyType) - Method in class com.facebook.buck.apple.xcode.PBXObjectGIDFactory
-
- createCopyWith(Path) - Method in class com.facebook.buck.features.project.intellij.model.folders.IjFolder
-
Create a copy of this folder using the specified path.
- createCxxLinkableBuildRule(CellPathResolver, CxxBuckConfig, CxxPlatform, ProjectFilesystem, BuildRuleResolver, BuildTarget, Path, ImmutableMap<String, Path>, ImmutableList<Arg>, Linker.LinkableDepType, CxxLinkOptions, Optional<LinkOutputPostprocessor>) - Static method in class com.facebook.buck.cxx.CxxLinkableEnhancer
-
- createCxxLinkableBuildRule(CxxBuckConfig, CxxPlatform, ProjectFilesystem, ActionGraphBuilder, BuildTarget, Linker.LinkType, Optional<String>, Path, ImmutableList<String>, Linker.LinkableDepType, Optional<LinkableListFilter>, CxxLinkOptions, Iterable<? extends NativeLinkable>, Optional<Linker.CxxRuntimeType>, Optional<SourcePath>, ImmutableSet<BuildTarget>, ImmutableSet<BuildTarget>, NativeLinkableInput, Optional<LinkOutputPostprocessor>, CellPathResolver) - Static method in class com.facebook.buck.cxx.CxxLinkableEnhancer
-
Construct a
CxxLink
rule that builds a native linkable from top-level input objects and
a dependency tree of
NativeLinkableGroup
dependencies.
- createCxxLinkableSharedBuildRule(CxxBuckConfig, CxxPlatform, ProjectFilesystem, BuildRuleResolver, BuildTarget, Path, ImmutableMap<String, Path>, Optional<String>, ImmutableList<? extends Arg>, CellPathResolver) - Static method in class com.facebook.buck.cxx.CxxLinkableEnhancer
-
- createCxxLinkTarget(BuildTarget, Optional<LinkerMapMode>) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- createCxxStripRule(BuildTarget, ProjectFilesystem, ActionGraphBuilder, StripStyle, boolean, BuildRule, CxxPlatform, Optional<String>) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- createCxxThinLTOIndexBuildRule(CxxBuckConfig, CxxPlatform, ProjectFilesystem, ActionGraphBuilder, BuildTarget, Path, Linker.LinkableDepType, Optional<LinkableListFilter>, Iterable<? extends NativeLinkable>, Optional<Linker.CxxRuntimeType>, ImmutableSet<BuildTarget>, ImmutableSet<BuildTarget>, NativeLinkableInput) - Static method in class com.facebook.buck.cxx.CxxLinkableEnhancer
-
Generate build rule for the indexing step of an incremental ThinLTO build
- createDateUidGidScrubber(ObjectFileScrubbers.PaddingStyle) - Static method in class com.facebook.buck.cxx.toolchain.objectfile.ObjectFileScrubbers
-
- createDeclaredArtifact(Path, Location) - Method in class com.facebook.buck.core.artifact.BuildArtifactFactory
-
- createDeclaredArtifact(String, Location) - Method in class com.facebook.buck.core.artifact.BuildArtifactFactory
-
Simple wrapper that also validates that a raw string is indeed a valid path
- createDefaultBuckPaths(CanonicalCellName, Path, boolean) - Static method in class com.facebook.buck.io.filesystem.BuckPaths
-
- createDefaultConfig(Path) - Static method in class com.facebook.buck.util.config.Configs
-
Convienence constructor
- createDefaultConfig(Path, RawConfig) - Static method in class com.facebook.buck.util.config.Configs
-
Generates a Buck config by merging configs from specified locations on disk.
- createDefaultConfig(Path, ImmutableList<Path>, RawConfig) - Static method in class com.facebook.buck.util.config.Configs
-
Generates a config by merging configs from specified locations on disk in order of the list
supplied.
- createDefaultFileHashCache(ProjectFilesystem, FileHashCacheMode) - Static method in class com.facebook.buck.util.cache.impl.DefaultFileHashCache
-
- createDefaultHashCaches(ProjectFilesystem, FileHashCacheMode) - Static method in class com.facebook.buck.util.cache.impl.StackedFileHashCache
-
- createDefaultJavaPackageFinder(ProjectFilesystem, Iterable<String>) - Static method in class com.facebook.buck.jvm.java.DefaultJavaPackageFinder
-
- createDefaultJavaPackageFinder() - Method in class com.facebook.buck.jvm.java.JavaBuckConfig
-
- createDensityFilter(ProjectFilesystem, Set<ResourceFilters.Density>) - Static method in class com.facebook.buck.android.ResourceFilters
-
Given a set of target densities, returns a
Predicate
that fails for any non-drawable
resource of a different density.
- createDirectory(Path, FileAttribute<?>...) - Method in class com.facebook.buck.core.filesystems.BuckFileSystemProvider
-
- createDouble() - Method in interface com.facebook.buck.rules.modern.ValueCreator
-
- createDynamic() - Method in interface com.facebook.buck.rules.modern.ValueCreator
-
- createEdenMountForProjectRoot(Path, EdenClientPool) - Static method in class com.facebook.buck.edenfs.EdenMount
-
- createEmptyInitModule(BuildTarget, ProjectFilesystem, ActionGraphBuilder) - Static method in class com.facebook.buck.features.python.PythonBinaryDescription
-
- CreateEvent(WinBase.SECURITY_ATTRIBUTES, boolean, boolean, String) - Method in interface com.facebook.buck.io.windowspipe.WindowsNamedPipeLibrary
-
- createEvent(BuildRule, long) - Static method in class com.facebook.buck.remoteexecution.event.RemoteBuildRuleExecutionEvent
-
- createEventBus(Console) - Method in class com.facebook.buck.rules.modern.builders.IsolatedBuildableBuilder
-
- createExcludes(IjModule) - Method in class com.facebook.buck.features.project.intellij.IjProjectTemplateDataPreparer
-
- createExtensionFinder() - Method in class com.facebook.buck.core.plugin.impl.DefaultBuckPluginManager
-
- CreateFile(String, int, int, WinBase.SECURITY_ATTRIBUTES, int, int, WinNT.HANDLE) - Method in interface com.facebook.buck.io.windowspipe.WindowsNamedPipeLibrary
-
- createFileParser(BuckEventBus, Cell, Watchman, boolean) - Method in class com.facebook.buck.parser.DefaultProjectBuildFileParserFactory
-
- createFileParser(BuckEventBus, Cell, Watchman, boolean) - Method in interface com.facebook.buck.parser.FileParserFactory
-
Creates an instance of {link ProjectBuildFileParser} based on passed in options.
- createFileParser(BuckEventBus, Cell, Watchman, boolean) - Method in class com.facebook.buck.parser.PackageFileParserFactory
-
Callers are responsible for managing the life-cycle of the created
PackageFileParser
.
- createFileParser(BuckEventBus, Cell, Watchman, boolean) - Method in interface com.facebook.buck.parser.ProjectBuildFileParserFactory
-
- createFileReference(String, String, PBXReference.SourceTree, Optional<String>) - Method in class com.facebook.buck.apple.xcode.AbstractPBXObjectFactory
-
- createFileReference(String, String, PBXReference.SourceTree, Optional<String>) - Method in class com.facebook.buck.apple.xcode.PBXObjectGIDFactory
-
- createFileReference(String, AbstractPBXObjectFactory) - Method in class com.facebook.buck.apple.xcode.xcodeproj.SourceTreePath
-
- createFileReference(AbstractPBXObjectFactory) - Method in class com.facebook.buck.apple.xcode.xcodeproj.SourceTreePath
-
- createFilesystemTraversalBoundaryPathSet(ImmutableSet<IjModule>) - Method in class com.facebook.buck.features.project.intellij.IjProjectTemplateDataPreparer
-
- createFinished(LocalFallbackEvent.Result, LocalFallbackEvent.Result, long, Optional<String>, Status, RemoteExecutionActionEvent.State, OptionalInt, Optional<RemoteExecutionMetadata>) - Method in class com.facebook.buck.remoteexecution.event.LocalFallbackEvent.Started
-
- createFinishedEvent(ImmutableMap<String, Object>) - Method in interface com.facebook.buck.event.SimplePerfEvent.Started
-
Creates a new event which indicates the end of a performance event.
- createFinishedEvent() - Method in interface com.facebook.buck.event.SimplePerfEvent.Started
-
- createFinishedEvent(String, Object) - Method in interface com.facebook.buck.event.SimplePerfEvent.Started
-
- createFinishedEvent(String, Object, String, Object) - Method in interface com.facebook.buck.event.SimplePerfEvent.Started
-
- createFloat() - Method in interface com.facebook.buck.rules.modern.ValueCreator
-
- createFor(Lock) - Static method in class com.facebook.buck.util.concurrent.AutoCloseableLock
-
- createForBaseName(BaseName, String, CellNameResolver) - Method in class com.facebook.buck.core.parser.buildtargetparser.ParsingUnconfiguredBuildTargetViewFactory
-
- createForBaseName(BaseName, String, CellNameResolver) - Method in interface com.facebook.buck.core.parser.buildtargetparser.UnconfiguredBuildTargetViewFactory
-
- createForBuildFileParseError(Path, IOException) - Static method in exception com.facebook.buck.parser.exceptions.BuildFileParseException
-
- createForChildren(CellRelativePath) - Method in class com.facebook.buck.core.parser.buildtargetparser.BuildTargetMatcherParser
-
- createForChildren(CellRelativePath) - Method in class com.facebook.buck.parser.spec.BuildTargetMatcherTargetNodeParser
-
- createForDescendants(CellRelativePath) - Method in class com.facebook.buck.core.parser.buildtargetparser.BuildTargetMatcherParser
-
- createForDescendants(CellRelativePath) - Method in class com.facebook.buck.parser.spec.BuildTargetMatcherTargetNodeParser
-
- createForFailingStepWithExitCode(Step, ExecutionContext, StepExecutionResult) - Static method in exception com.facebook.buck.step.StepFailedException
-
Creates a StepFailedException based on a StepExecutionResult.
- createForFailingStepWithExitCode(Step, ExecutionContext, StepExecutionResult, RemoteExecutionMetadata) - Static method in exception com.facebook.buck.step.StepFailedException
-
Same as above but includes RE action metadata
- createForMessageWithAnsiEscapeCodes(Level, String) - Static method in class com.facebook.buck.event.ConsoleEvent
-
- createForMissingBuildRule(UnconfiguredBuildTarget, ImmutableList<UnconfiguredBuildTarget>, int, Function<Path, OptionalLong>, Path) - Static method in exception com.facebook.buck.parser.exceptions.NoSuchBuildTargetException
-
- createForPathRelativeToProjectRoot(ForwardRelativePath, String, CellNameResolver) - Method in class com.facebook.buck.core.parser.buildtargetparser.ParsingUnconfiguredBuildTargetViewFactory
-
- createForPathRelativeToProjectRoot(ForwardRelativePath, String, CellNameResolver) - Method in interface com.facebook.buck.core.parser.buildtargetparser.UnconfiguredBuildTargetViewFactory
-
- createForSingleton(UnconfiguredBuildTargetWithOutputs) - Method in class com.facebook.buck.core.parser.buildtargetparser.BuildTargetMatcherParser
-
- createForSingleton(UnconfiguredBuildTargetWithOutputs) - Method in class com.facebook.buck.parser.spec.BuildTargetMatcherTargetNodeParser
-
- createForType(Class<?>) - Static method in class com.facebook.buck.rules.coercer.concat.JsonTypeConcatenatingCoercerFactory
-
- createForUnknownParseError(String, Object...) - Static method in exception com.facebook.buck.parser.exceptions.BuildFileParseException
-
- createForward() - Method in interface com.facebook.buck.android.exopackage.AndroidDevice
-
- createForward() - Method in class com.facebook.buck.android.exopackage.RealAndroidDevice
-
- createFrameworksBuildPhase() - Method in class com.facebook.buck.apple.xcode.AbstractPBXObjectFactory
-
- createFrameworksBuildPhase() - Method in class com.facebook.buck.apple.xcode.PBXObjectGIDFactory
-
- createFrom(Collection<BuildRule>, Optional<UnsortedAndroidResourceDeps.Callback>) - Static method in class com.facebook.buck.android.UnsortedAndroidResourceDeps
-
Returns transitive android resource deps which are _not_ sorted topologically, only to be used
when the order of the resource rules does not matter, for instance, when graph enhancing
UberRDotJava, DummyRDotJava, AaptPackageResources where we only need the deps to correctly
order the execution of those buildables.
- createFromConfig(BuckConfig, ToolchainProvider, TargetConfiguration) - Static method in class com.facebook.buck.file.downloader.impl.StackedDownloader
-
- createFromObject(U, Object, ProjectFilesystem, BuildTarget, DependencyStack, ImmutableSet<BuildTarget>, ImmutableSortedSet<BuildTarget>, ImmutableSet<VisibilityPattern>, ImmutableSet<VisibilityPattern>) - Method in class com.facebook.buck.core.model.targetgraph.impl.TargetNodeFactory
-
This factory method lets the wildcard be bound, so the constructor can be casted to it.
- createFromPlugins(PluginManager) - Static method in class com.facebook.buck.core.rules.config.impl.PluginBasedKnownConfigurationDescriptionsFactory
-
Create rule descriptors using provided plugin manager
- createFromPropertiesFile(Path, Path, ProjectFilesystem) - Static method in class com.facebook.buck.android.KeystoreProperties
-
- createFromRawNode(Path, CanonicalCellName, Map<String, Object>, Path) - Static method in class com.facebook.buck.parser.UnflavoredBuildTargetFactory
-
- createFromStringList(CellPathResolver, String, Object, Path, Supplier<String>) - Static method in class com.facebook.buck.rules.visibility.parser.VisibilityPatterns
-
- createGenerator(OutputStream) - Static method in class com.facebook.buck.util.json.ObjectMappers
-
- createGlobManifest() - Method in class com.facebook.buck.skylark.io.impl.CachingGlobber
-
- createGroupsFromSourcePaths(Function<SourcePath, Path>, Iterable<SourceWithFlags>, Iterable<SourcePath>, Iterable<SourcePath>, Iterable<SourcePath>, Iterable<SourcePath>) - Static method in class com.facebook.buck.apple.RuleUtils
-
- createHalideCompilerBuildTarget(BuildTarget) - Static method in class com.facebook.buck.features.halide.HalideLibraryDescription
-
- createHeadersBuildPhase() - Method in class com.facebook.buck.apple.xcode.AbstractPBXObjectFactory
-
- createHeadersBuildPhase() - Method in class com.facebook.buck.apple.xcode.PBXObjectGIDFactory
-
- createHeaderSymlinkTree(BuildTarget, ProjectFilesystem, HeaderMode, ImmutableMap<Path, SourcePath>, HeaderVisibility, Flavor...) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- createHeaderSymlinkTree(BuildTarget, ProjectFilesystem, BuildRuleResolver, CxxPlatform, ImmutableMap<Path, SourcePath>, HeaderVisibility, boolean) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- createHeaderSymlinkTreeBuildRule(BuildTarget, ProjectFilesystem, Path, ImmutableMap<Path, SourcePath>, HeaderMode) - Static method in class com.facebook.buck.cxx.CxxPreprocessables
-
- createHeaderSymlinkTreeTarget(BuildTarget, HeaderVisibility, Flavor...) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- createImageDensityFilter(Collection<Path>, Set<ResourceFilters.Density>, boolean) - Static method in class com.facebook.buck.android.ResourceFilters
-
Given a list of paths of available drawables, and a target screen density, returns a Predicate
that fails for drawables of a different density, whenever
they can be safely removed.
- createInferCaptureBuildTarget(String) - Method in class com.facebook.buck.cxx.CxxSourceRuleFactory
-
- createInfo(Object...) - Method in class com.facebook.buck.core.rules.providers.impl.BuiltInProvider
-
Constructs the info.
- createInProcess(BuckEventBus, RemoteExecutionStrategyConfig) - Static method in class com.facebook.buck.remoteexecution.grpc.GrpcExecutionFactory
-
The in-process strategy starts up a grpc remote execution service in process and connects to it
directly.
- createInteger() - Method in interface com.facebook.buck.rules.modern.ValueCreator
-
- createJarFile(Path) - Method in class com.facebook.buck.util.zip.JarBuilder
-
- createJarStep(ProjectFilesystem, JarParameters, ImmutableList.Builder<Step>) - Method in class com.facebook.buck.jvm.java.CompileToJarStepFactory
-
- createJavaFileParser(JavacLanguageLevelOptions) - Static method in class com.facebook.buck.jvm.java.JavaFileParser
-
- createKeystoreProperties() - Method in class com.facebook.buck.android.AppBuilderBase
-
- createLibraryBuildRule(BuildRuleCreationContextWithTargetGraph, BuildTarget, BuildRuleParams, ActionGraphBuilder, A, Optional<Linker.LinkableDepType>, Optional<SourcePath>, ImmutableSet<BuildTarget>, ImmutableSortedSet<BuildTarget>, CxxLibraryDescription.TransitiveCxxPreprocessorInputFunction) - Method in class com.facebook.buck.apple.AppleLibraryDescription
-
- createLink(Path, Path) - Method in class com.facebook.buck.core.filesystems.BuckFileSystemProvider
-
- createLinkMap(BuildTarget, ProjectFilesystem, SourcePathRuleFinder, CxxLinkAndCompileRules) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- createLinkRule(BuildTarget, ProjectFilesystem, BuildRuleParams, ActionGraphBuilder, HaskellPlatform, Linker.LinkType, ImmutableList<Arg>, Iterable<Arg>, Iterable<? extends NativeLinkableGroup>, ImmutableSet<BuildTarget>, Linker.LinkableDepType, Path, Optional<String>, boolean) - Static method in class com.facebook.buck.features.haskell.HaskellDescriptionUtils
-
Create a Haskell link rule that links the given inputs to a executable or shared library and
pulls in transitive native linkable deps from the given dep roots.
- createList(ValueTypeInfo<T>) - Method in interface com.facebook.buck.rules.modern.ValueCreator
-
- createListener() - Method in class com.facebook.buck.httpserver.WebServer
-
- createLoadBalancedResponse(URI, HttpLoadBalancer, Call) - Static method in class com.facebook.buck.slb.LoadBalancedHttpResponse
-
- createLogFile(String, LogType) - Method in interface com.facebook.buck.logd.client.LogDaemonClient
-
Client calls this method to request LogD to create a log file in file-system and/or storage.
- createLogFile(String, LogType) - Method in class com.facebook.buck.logd.client.LogdClient
-
- createLong() - Method in interface com.facebook.buck.rules.modern.ValueCreator
-
- createMap(ValueTypeInfo<K>, ValueTypeInfo<V>) - Method in interface com.facebook.buck.rules.modern.ValueCreator
-
- createMetadata(BuildTarget, ActionGraphBuilder, CellPathResolver, AppleBinaryDescriptionArg, Optional<ImmutableMap<BuildTarget, Version>>, Class<U>) - Method in class com.facebook.buck.apple.AppleBinaryDescription
-
- createMetadata(BuildTarget, ActionGraphBuilder, CellPathResolver, AppleBundleDescriptionArg, Optional<ImmutableMap<BuildTarget, Version>>, Class<U>) - Method in class com.facebook.buck.apple.AppleBundleDescription
-
- createMetadata(BuildTarget, ActionGraphBuilder, CellPathResolver, AppleLibraryDescriptionArg, Optional<ImmutableMap<BuildTarget, Version>>, Class<U>) - Method in class com.facebook.buck.apple.AppleLibraryDescription
-
- createMetadata(BuildTarget, ActionGraphBuilder, CellPathResolver, AppleTestDescriptionArg, Optional<ImmutableMap<BuildTarget, Version>>, Class<U>) - Method in class com.facebook.buck.apple.AppleTestDescription
-
- createMetadata(BuildTarget, ActionGraphBuilder, CellPathResolver, PrebuiltAppleFrameworkDescriptionArg, Optional<ImmutableMap<BuildTarget, Version>>, Class<U>) - Method in class com.facebook.buck.apple.PrebuiltAppleFrameworkDescription
-
- createMetadata(BuildTarget, ActionGraphBuilder, CellPathResolver, T, Optional<ImmutableMap<BuildTarget, Version>>, Class<U>) - Method in interface com.facebook.buck.core.description.metadata.MetadataProvidingDescription
-
- createMetadata(BuildTarget, ActionGraphBuilder, CellPathResolver, CxxBinaryDescriptionArg, Optional<ImmutableMap<BuildTarget, Version>>, Class<U>) - Method in class com.facebook.buck.cxx.CxxBinaryDescription
-
- createMetadata(BuildTarget, ActionGraphBuilder, ImmutableSortedSet<BuildTarget>, Class<U>) - Method in class com.facebook.buck.cxx.CxxBinaryMetadataFactory
-
- createMetadata(BuildTarget, ActionGraphBuilder, CellPathResolver, CxxLibraryDescriptionArg, Optional<ImmutableMap<BuildTarget, Version>>, Class<U>) - Method in class com.facebook.buck.cxx.CxxLibraryDescription
-
- createMetadata(BuildTarget, ActionGraphBuilder, CellPathResolver, CxxLibraryDescriptionArg, Class<U>) - Method in class com.facebook.buck.cxx.CxxLibraryMetadataFactory
-
- createMetadata(BuildTarget, ActionGraphBuilder, CellPathResolver, CxxTestDescriptionArg, Optional<ImmutableMap<BuildTarget, Version>>, Class<U>) - Method in class com.facebook.buck.cxx.CxxTestDescription
-
- createMetadata(BuildTarget, ActionGraphBuilder, CellPathResolver, CgoLibraryDescriptionArg, Optional<ImmutableMap<BuildTarget, Version>>, Class<U>) - Method in class com.facebook.buck.features.go.CgoLibraryDescription
-
- createMetadata(BuildTarget, ActionGraphBuilder, CellPathResolver, GoLibraryDescriptionArg, Optional<ImmutableMap<BuildTarget, Version>>, Class<U>) - Method in class com.facebook.buck.features.go.GoLibraryDescription
-
- createMetadata(BuildTarget, ActionGraphBuilder, CellPathResolver, GoTestDescriptionArg, Optional<ImmutableMap<BuildTarget, Version>>, Class<U>) - Method in class com.facebook.buck.features.go.GoTestDescription
-
- createMetadata(BuildTarget, ActionGraphBuilder, CellPathResolver, PrebuiltGoLibraryDescriptionArg, Optional<ImmutableMap<BuildTarget, Version>>, Class<U>) - Method in class com.facebook.buck.features.go.PrebuiltGoLibraryDescription
-
- createMetadata(BuildTarget, ActionGraphBuilder, CellPathResolver, PythonLibraryDescriptionArg, Optional<ImmutableMap<BuildTarget, Version>>, Class<U>) - Method in class com.facebook.buck.features.python.PythonLibraryDescription
-
- createMLBytecodeCompileBuildTarget(BuildTarget, String) - Static method in class com.facebook.buck.features.ocaml.OcamlBuildRulesGenerator
-
- createMLNativeCompileBuildTarget(BuildTarget, String) - Static method in class com.facebook.buck.features.ocaml.OcamlBuildRulesGenerator
-
- createModule(Path, ImmutableSet<TargetNode>, Set<Path>) - Method in class com.facebook.buck.features.project.intellij.DefaultIjModuleFactory
-
- createModule(Path, ImmutableSet<TargetNode>, Set<Path>) - Method in interface com.facebook.buck.features.project.intellij.model.IjModuleFactory
-
Create an
IjModule
form the supplied parameters.
- createModuleMap(String, ModuleMapMode, UmbrellaHeaderModuleMap.SwiftMode, Set<Path>) - Static method in class com.facebook.buck.apple.clang.ModuleMapFactory
-
Creates a module map.
- createNativeLinkable(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.cxx.PrebuiltCxxLibrary
-
- createNativeTarget(String) - Method in class com.facebook.buck.apple.xcode.AbstractPBXObjectFactory
-
- createNativeTarget(String) - Method in class com.facebook.buck.apple.xcode.PBXObjectGIDFactory
-
- createNewFile(Path) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
Creates a new file relative to the project root.
- createNewFile(Path) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
Creates a new file relative to the project root.
- createNode(Map<Path, Protocol.FileNode>, Map<Path, Protocol.SymlinkNode>, Map<Path, Protocol.DirectoryNode>) - Method in class com.facebook.buck.remoteexecution.util.MerkleTreeNodeCache
-
Creates the full tree of nodes for the provided files, symlinks and empty directories and
returns the root node.
- createNoPayloadHandler(ThriftResponse) - Static method in class com.facebook.buck.slb.HybridThriftResponseHandler
-
Encodes a response without out-of-band payloads.
- createNoPayloadHandler(ThriftResponse, ThrowingConsumer<ThriftResponse, IOException>) - Static method in class com.facebook.buck.slb.HybridThriftResponseHandler
-
Encodes a response without out-of-band payloads.
- createNotNull(ValueCreator<E>) - Method in interface com.facebook.buck.rules.modern.ValueTypeInfo
-
- createNullable(ValueTypeInfo<T>) - Method in interface com.facebook.buck.rules.modern.ValueCreator
-
- createNullConsole() - Static method in class com.facebook.buck.util.Console
-
Returns a
Console
that simply discards written bytes.
- createObjCGeneratedHeaderBuildRule(BuildTarget, ProjectFilesystem, ActionGraphBuilder, CxxPlatform, HeaderVisibility) - Static method in class com.facebook.buck.apple.AppleLibraryDescriptionSwiftEnhancer
-
- createOcamlLinkTarget(BuildTarget) - Static method in class com.facebook.buck.features.ocaml.OcamlRuleBuilder
-
- createOkHttpClient() - Method in class com.facebook.buck.util.network.RemoteLogBuckConfig
-
- createOnDiskBuildInfoFor(BuildTarget, ProjectFilesystem, BuildInfoStore) - Method in class com.facebook.buck.core.build.engine.BuildEngineBuildContext
-
- createOptimizeBuildTarget(String) - Method in class com.facebook.buck.cxx.CxxSourceRuleFactory
-
- createOptional(ValueTypeInfo<T>) - Method in interface com.facebook.buck.rules.modern.ValueCreator
-
- createOrGetUnderlying(TreeBackedAnnotatedConstruct, AnnotatedConstruct, Class<A>) - Static method in class com.facebook.buck.jvm.java.abi.source.TreeBackedAnnotationFactory
-
- createOrThrow(CanonicalCellName, AbsPath, boolean) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystemFactory
-
- createOrThrow(CanonicalCellName, AbsPath, boolean) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystemFactory
-
- createOsRootDirectoriesCaches(ProjectFilesystemFactory, FileHashCacheMode) - Static method in class com.facebook.buck.util.cache.impl.DefaultFileHashCache
-
- createOutputPath() - Method in interface com.facebook.buck.rules.modern.ValueCreator
-
- createPackageLookupPathSet(IjModuleGraph) - Static method in class com.facebook.buck.features.project.intellij.IjProjectTemplateDataPreparer
-
- createPackagePaths(ImmutableSet<OutputArtifact>) - Method in class com.facebook.buck.core.artifact.ArtifactFilesystem
-
Create the package paths that actions will write into if it does not exist
- createParentDirs(String) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- createParentDirs(Path) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- createParentDirs(String) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
- createParentDirs(Path) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
- createParser(Path) - Static method in class com.facebook.buck.util.json.ObjectMappers
-
- createParser(String) - Static method in class com.facebook.buck.util.json.ObjectMappers
-
- createParser(byte[]) - Static method in class com.facebook.buck.util.json.ObjectMappers
-
- createParser(InputStream) - Static method in class com.facebook.buck.util.json.ObjectMappers
-
- createParser(Reader) - Static method in class com.facebook.buck.util.json.ObjectMappers
-
- createParsingContext(Cell, ListeningExecutorService) - Method in class com.facebook.buck.cli.AbstractCommand
-
- createParsingContext(Cell, ListeningExecutorService) - Method in class com.facebook.buck.cli.AbstractContainerCommand
-
- createParsingContext(Cell, ListeningExecutorService) - Method in interface com.facebook.buck.cli.Command
-
Creates a basic
ParsingContext
with some options populated from command's arguments.
- createPassthrough() - Static method in class com.facebook.buck.rules.modern.builders.ModernBuildRuleBuilderFactory
-
The passthrough strategy just forwards to executorRunner.runWithDefaultExecutor.
- createPath() - Method in interface com.facebook.buck.rules.modern.ValueCreator
-
- createPBXGroup(String, String, PBXReference.SourceTree) - Method in class com.facebook.buck.apple.xcode.AbstractPBXObjectFactory
-
- createPBXGroup(String, String, PBXReference.SourceTree) - Method in class com.facebook.buck.apple.xcode.PBXObjectGIDFactory
-
- createPipelinedCompileStep(BuildContext, ProjectFilesystem, JavacPipelineState, BuildTarget, ImmutableList.Builder<Step>) - Method in class com.facebook.buck.jvm.java.JavacToJarStepFactory
-
- createPipelinedCompileToJarStep(BuildContext, ProjectFilesystem, BuildTarget, JavacPipelineState, ResourcesParameters, ImmutableList<String>, ImmutableList.Builder<Step>, BuildableContext) - Method in class com.facebook.buck.jvm.java.JavacToJarStepFactory
-
- createPipelineState(BuildTarget, CompilerParameters, JarParameters, JarParameters) - Method in class com.facebook.buck.jvm.java.JavacToJarStepFactory
-
- createPipeWithPath(String) - Static method in class com.facebook.buck.io.windowspipe.WindowsNamedPipe
-
Creates a Windows named pipe bound to a path
- createPlatform(RuleBasedPlatformResolver, DependencyStack) - Method in class com.facebook.buck.android.toolchain.platform.AndroidMultiPlatformRule
-
- createPlatform(RuleBasedPlatformResolver, DependencyStack) - Method in interface com.facebook.buck.core.rules.platform.MultiPlatformRule
-
- createPluginDescriptorFinder() - Method in class com.facebook.buck.core.plugin.impl.DefaultBuckPluginManager
-
- createPluginLoader() - Method in class com.facebook.buck.core.plugin.impl.DefaultBuckPluginManager
-
- createPluginManager() - Static method in class com.facebook.buck.core.plugin.impl.BuckPluginManagerFactory
-
Creates a PluginManager
and loads plugins.
- createPluginRepository() - Method in class com.facebook.buck.core.plugin.impl.DefaultBuckPluginManager
-
- createProcessExecutor(PrintStream, PrintStream) - Method in class com.facebook.buck.util.PrintStreamProcessExecutorFactory
-
- createProcessExecutor(PrintStream, PrintStream) - Method in interface com.facebook.buck.util.ProcessExecutorFactory
-
- createProject(String) - Method in class com.facebook.buck.apple.xcode.AbstractPBXObjectFactory
-
- createProject(String) - Method in class com.facebook.buck.apple.xcode.PBXObjectGIDFactory
-
- createProjectFilesystem(CanonicalCellName, AbsPath, Config, Optional<EmbeddedCellBuckOutInfo>, boolean) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystemFactory
-
- createProjectFilesystem(CanonicalCellName, AbsPath, Config, boolean) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystemFactory
-
- createProjectFilesystem(CanonicalCellName, AbsPath, boolean) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystemFactory
-
- createProjectFilesystem(CanonicalCellName, AbsPath, Config, Optional<EmbeddedCellBuckOutInfo>, boolean) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystemFactory
-
- createProjectFilesystem(CanonicalCellName, AbsPath, Config, boolean) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystemFactory
-
- createProjectFilesystem(CanonicalCellName, AbsPath, boolean) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystemFactory
-
- createProviders(ProviderCreationContext, BuildTarget, T) - Method in interface com.facebook.buck.core.rules.LegacyProviderCompatibleDescription
-
- createProviders(ProviderCreationContext, BuildTarget, CsharpLibraryDescriptionArg) - Method in class com.facebook.buck.features.dotnet.CsharpLibraryDescription
-
- createProviders(ProviderCreationContext, BuildTarget, HttpArchiveDescriptionArg) - Method in class com.facebook.buck.file.HttpArchiveDescription
-
- createProviders(ProviderCreationContext, BuildTarget, HttpFileDescriptionArg) - Method in class com.facebook.buck.file.HttpFileDescription
-
- createReadableExceptionWithWhenSuffix(BuildTarget, BuildTarget, BuildFileParseException) - Static method in class com.facebook.buck.parser.ParserMessages
-
- createReadableExceptionWithWhenSuffix(BuildTarget, BuildTarget, BuildTargetException) - Static method in class com.facebook.buck.parser.ParserMessages
-
- createReadableExceptionWithWhenSuffix(BuildTarget, BuildTarget, HumanReadableException) - Static method in class com.facebook.buck.parser.ParserMessages
-
- createReconstructing(SourcePathRuleFinder, CellPathResolver, Cell) - Static method in class com.facebook.buck.rules.modern.builders.ModernBuildRuleBuilderFactory
-
The reconstructing strategy serializes and deserializes the build rule in memory and builds the
deserialized version.
- createReferencedFolderPathsSet(ImmutableSet<IjModule>) - Static method in class com.facebook.buck.features.project.intellij.IjProjectTemplateDataPreparer
-
- createRegistry(TargetGraph) - Static method in class com.facebook.buck.core.rules.config.registry.impl.ConfigurationRuleRegistryFactory
-
- createRegistry(BiFunction<BuildTarget, DependencyStack, TargetNode<?>>) - Static method in class com.facebook.buck.core.rules.config.registry.impl.ConfigurationRuleRegistryFactory
-
- createRelativeMap(Path, Iterable<SourcePath>) - Method in class com.facebook.buck.core.sourcepath.resolver.impl.AbstractSourcePathResolver
-
- createRelativeMap(Path, Iterable<SourcePath>) - Method in interface com.facebook.buck.core.sourcepath.resolver.SourcePathResolver
-
Creates a map where given source paths are resolved relatively to the given base path and
stored (as keys) with their absolute paths (as values).
- createRelativeMap(Path, Iterable<SourcePath>) - Method in class com.facebook.buck.core.sourcepath.resolver.SourcePathResolverAdapter
-
Returns a map where given
SourcePath
instances are resolved relatively to the given
base path and stored (as keys) with their absolute paths (as values).
- createRelativeSymlink(Path, Path, ProjectFilesystem) - Static method in class com.facebook.buck.io.MoreProjectFilesystems
-
Creates a symlink at projectFilesystem.getRootPath().resolve(pathToDesiredLinkUnderProjectRoot)
that points to
projectFilesystem.getRootPath().resolve(pathToExistingFileUnderProjectRoot)
using a
relative symlink.
- createRemote(String, int, String, int, int, boolean, boolean, Optional<Path>, Optional<Path>, Optional<Path>, RemoteExecutionStrategyConfig, MetadataProvider, BuckEventBus) - Static method in class com.facebook.buck.remoteexecution.grpc.GrpcExecutionFactory
-
The remote strategy connects to a remote grpc remote execution service.
- createRenderLinesAtTime(long) - Method in class com.facebook.buck.event.listener.SuperConsoleEventBusListener
-
Creates a list of lines to be rendered at a given time.
- createRequest(ThriftProtocol, BuckCacheRequest, ByteSource...) - Static method in class com.facebook.buck.artifact_cache.ThriftArtifactCacheProtocol
-
- createSandboxProgramRunner(SandboxProperties) - Method in class com.facebook.buck.sandbox.darwin.DarwinSandboxExecutionStrategy
-
- createSandboxProgramRunner(SandboxProperties) - Method in class com.facebook.buck.sandbox.NoSandboxExecutionStrategy
-
- createSandboxProgramRunner(SandboxProperties) - Method in interface com.facebook.buck.sandbox.SandboxExecutionStrategy
-
Creates a new
ProgramRunner
to run a specific program in a sandbox.
- createSelector(CellNameResolver, ForwardRelativePath, Map<String, ?>) - Method in class com.facebook.buck.core.select.impl.SelectorFactory
-
Creates a new Selector using the default error message when no conditions match.
- createSelector(CellNameResolver, ForwardRelativePath, Map<String, ?>, String) - Method in class com.facebook.buck.core.select.impl.SelectorFactory
-
Creates a
Selector
by converting a given map.
- createSet(ValueTypeInfo<T>) - Method in interface com.facebook.buck.rules.modern.ValueCreator
-
- createSharedInterfaceLibraryFromLibrary(BuildTarget, ProjectFilesystem, BuildRuleResolver, CxxPlatform, SourcePath) - Method in class com.facebook.buck.cxx.MachoDylibStubRuleFactory
-
- createSharedInterfaceLibraryFromLibrary(BuildTarget, ProjectFilesystem, BuildRuleResolver, CxxPlatform, SourcePath) - Method in interface com.facebook.buck.cxx.toolchain.SharedLibraryInterfaceFactory
-
- createSharedInterfaceLibraryFromLinkableInput(BuildTarget, ProjectFilesystem, BuildRuleResolver, String, Linker, ImmutableList<Arg>) - Method in class com.facebook.buck.cxx.MachoDylibStubRuleFactory
-
- createSharedInterfaceLibraryFromLinkableInput(BuildTarget, ProjectFilesystem, BuildRuleResolver, String, Linker, ImmutableList<Arg>) - Method in interface com.facebook.buck.cxx.toolchain.SharedLibraryInterfaceFactory
-
- createSharedLibraryBuildTarget(BuildTarget, Flavor, Linker.LinkType) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- createSharedLibrarySymlinkTree(BuildTarget, ProjectFilesystem, ActionGraphBuilder, CxxPlatform, Iterable<? extends BuildRule>, Function<? super BuildRule, Optional<Iterable<? extends BuildRule>>>) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
Build a
HeaderSymlinkTree
of all the shared libraries found via the top-level rule's
transitive dependencies.
- createSharedLibrarySymlinkTreeTarget(BuildTarget, Flavor) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- createShellScriptBuildPhase() - Method in class com.facebook.buck.apple.xcode.AbstractPBXObjectFactory
-
- createShellScriptBuildPhase() - Method in class com.facebook.buck.apple.xcode.PBXObjectGIDFactory
-
- createShort() - Method in interface com.facebook.buck.rules.modern.ValueCreator
-
- createSocketWithPath(Path) - Static method in class com.facebook.buck.io.unixsocket.UnixDomainSocket
-
Creates a Unix domain socket bound to a path.
- createSortedMap(ValueTypeInfo<K>, ValueTypeInfo<V>) - Method in interface com.facebook.buck.rules.modern.ValueCreator
-
- createSortedSet(ValueTypeInfo<T>) - Method in interface com.facebook.buck.rules.modern.ValueCreator
-
- createSourcePath() - Method in interface com.facebook.buck.rules.modern.ValueCreator
-
- createSourcesBuildPhase() - Method in class com.facebook.buck.apple.xcode.AbstractPBXObjectFactory
-
- createSourcesBuildPhase() - Method in class com.facebook.buck.apple.xcode.PBXObjectGIDFactory
-
- createSpecial(Class<T>, Object...) - Method in interface com.facebook.buck.rules.modern.ValueCreator
-
- createStackedFileHashCache(CommandRunnerParams) - Method in class com.facebook.buck.cli.AbstractPerfCommand
-
- createStarted(String) - Static method in class com.facebook.buck.remoteexecution.event.LocalFallbackEvent
-
- createStaticLibraryBuildTarget(BuildTarget, Flavor, PicType) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- createStaticLibraryBuildTarget(BuildTarget) - Static method in class com.facebook.buck.features.ocaml.OcamlRuleBuilder
-
- createStepForDummyRDotJava(ProjectFilesystem, SourcePathResolverAdapter, List<HasAndroidResourceDeps>, Path, boolean, Optional<String>, Optional<String>, boolean, boolean) - Static method in class com.facebook.buck.android.MergeAndroidResourcesStep
-
- createStepForUberRDotJava(ProjectFilesystem, SourcePathResolverAdapter, List<HasAndroidResourceDeps>, ImmutableList<Path>, Path, EnumSet<RDotTxtEntry.RType>, Optional<Path>, ImmutableList<Path>, Optional<String>) - Static method in class com.facebook.buck.android.MergeAndroidResourcesStep
-
- createSteps(ProjectFilesystem, AndroidSdkLocation, SourcePathResolverAdapter, RedexOptions, Path, Path, Supplier<KeystoreProperties>, Path, BuildableContext) - Static method in class com.facebook.buck.android.redex.ReDexStep
-
- createStolen(BuildTarget) - Static method in class com.facebook.buck.rules.modern.builders.HybridLocalEvent
-
- createStreamObserver(String) - Method in class com.facebook.buck.logd.client.DefaultStreamObserverFactory
-
- createStreamObserver(String) - Method in interface com.facebook.buck.logd.client.StreamObserverFactory
-
Creates a stream observer that observes and processes server responses corresponding with
provided log file path
- createString() - Method in interface com.facebook.buck.rules.modern.ValueCreator
-
- createSubCommand() - Method in class com.facebook.buck.features.apple.project.XCodeProjectSubCommandFactory
-
- createSubCommand() - Method in class com.facebook.buck.features.go.GoProjectSubCommandFactory
-
- createSubCommand() - Method in class com.facebook.buck.features.project.intellij.IntelliJProjectSubCommandFactory
-
- createSubCommand() - Method in interface com.facebook.buck.support.cli.args.PluginBasedSubCommandFactory
-
- createSubContext(PrintStream, PrintStream, Optional<Verbosity>) - Method in class com.facebook.buck.core.build.execution.context.ExecutionContext
-
- createSwiftBuildRule(BuildTarget, ProjectFilesystem, ActionGraphBuilder, CellPathResolver, AppleNativeTargetDescriptionArg, Optional<AppleLibrarySwiftDelegate>) - Method in class com.facebook.buck.apple.AppleLibraryDescription
-
- createSwiftCompileRule(BuildTarget, CellPathResolver, ActionGraphBuilder, AppleNativeTargetDescriptionArg, ProjectFilesystem, CxxPlatform, AppleCxxPlatform, SwiftBuckConfig, ImmutableSet<CxxPreprocessorInput>) - Static method in class com.facebook.buck.apple.AppleLibraryDescriptionSwiftEnhancer
-
- createSwiftCompileRule(CxxPlatform, SwiftPlatform, SwiftBuckConfig, BuildTarget, ActionGraphBuilder, CellPathResolver, ProjectFilesystem, SwiftLibraryDescriptionArg, Preprocessor, PreprocessorFlags, boolean, Optional<SwiftTargetTriple>) - Static method in class com.facebook.buck.swift.SwiftLibraryDescription
-
- createSymbolicLink(Path, Path, FileAttribute<?>...) - Method in class com.facebook.buck.core.filesystems.BuckFileSystemProvider
-
- createSymbolicLink(Path, Path, boolean) - Method in class com.facebook.buck.io.windowsfs.WindowsFS
-
Creates a symbolic link (using CreateSymbolicLink winapi call under the hood).
- CreateSymbolicLinkW(String, String, int) - Method in interface com.facebook.buck.io.windowsfs.WindowsFSLibrary
-
- createSymLink(WindowsFS, Path, Path) - Static method in class com.facebook.buck.io.file.MorePaths
-
Creates a symlink.
- createSymLink(Path, Path, boolean) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- createSymLink(Path, Path, boolean) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
- createSymLink(PathWrapper, Path, boolean) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
- createSymlinkTree(String, ExopackageInfo, SourcePathResolverAdapter, ProjectFilesystem, Path) - Static method in class com.facebook.buck.android.exopackage.ExopackageSymlinkTree
-
Create a symlink tree rooted at rootPath which contains a mirror of what should appear on the
device as a result of an exopackage installation.
- createTargetConfiguration() - Method in interface com.facebook.buck.rules.modern.ValueCreator
-
- createTargetDependency(PBXContainerItemProxy) - Method in class com.facebook.buck.apple.xcode.AbstractPBXObjectFactory
-
- createTargetDependency(PBXContainerItemProxy) - Method in class com.facebook.buck.apple.xcode.PBXObjectGIDFactory
-
- createTargetNode(Cell, Path, BuildTarget, DependencyStack, Map<String, Object>, Function<SimplePerfEvent.PerfEventId, SimplePerfEvent.Scope>) - Method in interface com.facebook.buck.parser.ParserTargetNodeFromAttrMapFactory
-
- createTargetNode(Cell, AbsPath, BuildTarget, DependencyStack, UnconfiguredTargetNode, Function<SimplePerfEvent.PerfEventId, SimplePerfEvent.Scope>) - Method in interface com.facebook.buck.parser.ParserTargetNodeFromUnconfiguredTargetNodeFactory
-
- createTargetNode(Cell, AbsPath, BuildTarget, DependencyStack, UnconfiguredTargetNode, Function<SimplePerfEvent.PerfEventId, SimplePerfEvent.Scope>) - Method in class com.facebook.buck.parser.UnconfiguredTargetNodeToTargetNodeFactory
-
- createTask(Callable<ResultType>) - Method in interface com.facebook.buck.core.graph.transformation.executor.DepsAwareExecutor
-
- createTask(Callable<T>) - Method in class com.facebook.buck.core.graph.transformation.executor.impl.JavaExecutorBackedDefaultDepsAwareExecutor
-
- createTask(Callable<T>) - Method in class com.facebook.buck.core.graph.transformation.executor.impl.ToposortBasedDepsAwareExecutor
-
- createTempFile(String, String, FileAttribute<?>...) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
Returns a relative path whose parent directory is guaranteed to exist.
- createTempFile(Path, String, String, FileAttribute<?>...) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- createTempFile(String, String, FileAttribute<?>...) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
Returns a relative path whose parent directory is guaranteed to exist.
- createTempFile(Path, String, String, FileAttribute<?>...) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
- createTest() - Method in class com.facebook.buck.testrunner.BuckBlockJUnit4ClassRunner
-
- createThrowingTask(Callable<ResultType>, ThrowingSupplier<ImmutableSet<TaskType>, Exception>, ThrowingSupplier<ImmutableSet<TaskType>, Exception>) - Method in interface com.facebook.buck.core.graph.transformation.executor.DepsAwareExecutor
-
- createThrowingTask(Callable<T>, ThrowingSupplier<ImmutableSet<DefaultDepsAwareTask<T>>, Exception>, ThrowingSupplier<ImmutableSet<DefaultDepsAwareTask<T>>, Exception>) - Method in class com.facebook.buck.core.graph.transformation.executor.impl.JavaExecutorBackedDefaultDepsAwareExecutor
-
- createThrowingTask(Callable<T>, ThrowingSupplier<ImmutableSet<ToposortBasedDepsAwareTask<T>>, Exception>, ThrowingSupplier<ImmutableSet<ToposortBasedDepsAwareTask<T>>, Exception>) - Method in class com.facebook.buck.core.graph.transformation.executor.impl.ToposortBasedDepsAwareExecutor
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.android.toolchain.impl.AdbToolchainFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.android.toolchain.impl.AndroidBuildToolsLocationFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.android.toolchain.impl.AndroidPlatformTargetFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.android.toolchain.impl.AndroidSdkLocationFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.android.toolchain.impl.DxToolchainFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.android.toolchain.ndk.impl.AndroidNdkFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.android.toolchain.ndk.impl.NdkCxxPlatformsProviderFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.apple.toolchain.impl.AppleCxxPlatformsProviderFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.apple.toolchain.impl.AppleDeveloperDirectoryForTestsProviderFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.apple.toolchain.impl.AppleDeveloperDirectoryProviderFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.apple.toolchain.impl.AppleSdkLocationFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.apple.toolchain.impl.AppleToolchainProviderFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.apple.toolchain.impl.CodeSignIdentityStoreFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.apple.toolchain.impl.ProvisioningProfileStoreFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in interface com.facebook.buck.core.toolchain.ToolchainFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.cxx.toolchain.impl.CxxPlatformsProviderFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.features.dotnet.DotnetToolchainSupplier.DotnetToolchainFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.features.go.GoToolchainFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.features.haskell.HaskellPlatformsProviderFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.features.lua.LuaPlatformsProviderFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.features.ocaml.OcamlToolchainFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.features.python.toolchain.impl.PexToolProviderFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.features.python.toolchain.impl.PythonInterpreterFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.features.python.toolchain.impl.PythonPlatformsProviderFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.features.rust.RustToolchainFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.file.downloader.impl.DownloaderFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.infer.toolchain.InferToolchainFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.jvm.java.toolchain.impl.JavacOptionsProviderFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.jvm.java.toolchain.impl.JavaCxxPlatformProviderFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.jvm.java.toolchain.impl.JavaOptionsProviderFactory
-
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.jvm.java.toolchain.impl.JavaToolchainFactory
-
Creates a java toolchain from the .buckconfig.
- createToolchain(ToolchainProvider, ToolchainCreationContext, TargetConfiguration) - Method in class com.facebook.buck.swift.toolchain.impl.SwiftPlatformsProviderFactory
-
- createUberCompilationDatabase(BuildTarget, ProjectFilesystem, ActionGraphBuilder) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- createUndefinedSymbolsFile(ProjectFilesystem, BuildRuleParams, ActionGraphBuilder, TargetConfiguration, BuildTarget, Iterable<? extends SourcePath>) - Method in class com.facebook.buck.cxx.toolchain.PosixNmSymbolNameTool
-
- createUndefinedSymbolsFile(ProjectFilesystem, BuildRuleParams, ActionGraphBuilder, TargetConfiguration, BuildTarget, Iterable<? extends SourcePath>) - Method in interface com.facebook.buck.cxx.toolchain.SymbolNameTool
-
Creates a
BuildRule
which extracts all undefined symbols from the given inputs.
- createUndefinedSymbolsLinkerArgs(ProjectFilesystem, BuildRuleParams, ActionGraphBuilder, BuildTarget, ImmutableList<? extends SourcePath>) - Method in class com.facebook.buck.cxx.toolchain.linker.impl.DarwinLinker
-
- createUndefinedSymbolsLinkerArgs(ProjectFilesystem, BuildRuleParams, ActionGraphBuilder, BuildTarget, ImmutableList<? extends SourcePath>) - Method in class com.facebook.buck.cxx.toolchain.linker.impl.GnuLinker
-
Write all undefined symbols given in symbolFiles
into a linker script wrapped in
`EXTERN` commands.
- createUndefinedSymbolsLinkerArgs(ProjectFilesystem, BuildRuleParams, ActionGraphBuilder, BuildTarget, ImmutableList<? extends SourcePath>) - Method in class com.facebook.buck.cxx.toolchain.linker.impl.WindowsLinker
-
- createUndefinedSymbolsLinkerArgs(ProjectFilesystem, BuildRuleParams, ActionGraphBuilder, BuildTarget, ImmutableList<? extends SourcePath>) - Method in interface com.facebook.buck.cxx.toolchain.linker.Linker
-
Generate a necessary linker arguments to propagate undefined symbols to a link command.
- createUpdateEvent(ImmutableMap<String, Object>) - Method in interface com.facebook.buck.event.SimplePerfEvent.Started
-
Creates a new event which indicates an update to the performance data being gathered.
- createUpdateEvent(String, Object) - Method in interface com.facebook.buck.event.SimplePerfEvent.Started
-
- createUpdateEvent(String, Object, String, Object) - Method in interface com.facebook.buck.event.SimplePerfEvent.Started
-
- createVariableExpansionFunction(Map<String, String>) - Static method in class com.facebook.buck.apple.InfoPlistSubstitution
-
- createVariantGroup(String, String, PBXReference.SourceTree) - Method in class com.facebook.buck.apple.xcode.AbstractPBXObjectFactory
-
- createVariantGroup(String, String, PBXReference.SourceTree) - Method in class com.facebook.buck.apple.xcode.PBXObjectGIDFactory
-
- createVerificationCommandLineArguments() - Static method in class com.facebook.buck.sandbox.darwin.DarwinSandbox
-
Creates a list of CL arguments to run a sandbox to verify that sandbox is functioning
- createVersionGroup(String, String, PBXReference.SourceTree) - Method in class com.facebook.buck.apple.xcode.AbstractPBXObjectFactory
-
- createVersionGroup(String, String, PBXReference.SourceTree) - Method in class com.facebook.buck.apple.xcode.PBXObjectGIDFactory
-
- createVersionGroup(AbstractPBXObjectFactory) - Method in class com.facebook.buck.apple.xcode.xcodeproj.SourceTreePath
-
- createVersionManager() - Method in class com.facebook.buck.core.plugin.impl.DefaultBuckPluginManager
-
- createWatchmanClient(Path, Console, Clock) - Static method in class com.facebook.buck.io.watchman.WatchmanFactory
-
- createWithEmptyBeansPermitted() - Static method in class com.facebook.buck.util.json.ObjectMappers
-
Creates an ObjectMapper
that allows to use objects without fields.
- createWithFileSystemCrawler(BuckEventBus, DepsAwareExecutor<? super ComputeResult, ?>, CellProvider, LoadingCache<Path, DirectoryListCache>, LoadingCache<Path, FileTreeCache>) - Static method in class com.facebook.buck.parser.TargetSpecResolver
-
- createWithoutPayloads(ThriftRequest) - Static method in class com.facebook.buck.slb.HybridThriftRequestHandler
-
Create request that sends no out-of-band payloads.
- createWithSuggestions(Flavored, UnconfiguredBuildTarget) - Static method in exception com.facebook.buck.parser.UnexpectedFlavorException
-
- createWithWatchmanCrawler(BuckEventBus, Watchman, DepsAwareExecutor<? super ComputeResult, ?>, CellProvider) - Static method in class com.facebook.buck.parser.TargetSpecResolver
-
- createWithWildcard(String, CellNameResolver) - Method in class com.facebook.buck.core.parser.buildtargetparser.ParsingUnconfiguredBuildTargetViewFactory
-
- createWithWildcard(String, CellNameResolver) - Method in interface com.facebook.buck.core.parser.buildtargetparser.UnconfiguredBuildTargetViewFactory
-
Given a target base name and a target name returns
UnconfiguredBuildTarget
with
optionally allowing the short name to be empty.
- createWorkerProcess(ProcessExecutorParams, ExecutionContext, Path) - Method in class com.facebook.buck.worker.WorkerProcessPoolFactory
-
- createXcodeProject(XcodeProjectWriteOptions, ListeningExecutorService) - Method in class com.facebook.buck.features.apple.projectV2.ProjectGenerator
-
Creates an xcode project.
- createXcodeProjects() - Method in class com.facebook.buck.features.apple.project.ProjectGenerator
-
- CriticalPathEventListener - Class in com.facebook.buck.event.listener
-
BuckEventListener
that is intended to build Critical path of the build (The longest by
time path )
- CriticalPathEventListener(Path) - Constructor for class com.facebook.buck.event.listener.CriticalPathEventListener
-
- CriticalPathReportableNode - Interface in com.facebook.buck.event.listener
-
Critical Path Reportable node that is used to store information into report table
- CsharpLibrary - Class in com.facebook.buck.features.dotnet
-
- CsharpLibrary(BuildTarget, ProjectFilesystem, BuildRuleParams, Tool, ImmutableSortedSet<SourcePath>, ImmutableList<Either<BuildRule, String>>, ImmutableMap<String, SourcePath>, FrameworkVersion, ImmutableList<String>, Path) - Constructor for class com.facebook.buck.features.dotnet.CsharpLibrary
-
- CsharpLibraryCompile - Class in com.facebook.buck.features.dotnet
-
- CsharpLibraryCompile(SourcePathResolverAdapter, Tool, Path, ImmutableSortedSet<Path>, ImmutableList<Either<Path, String>>, ImmutableListMultimap<Path, String>, FrameworkVersion, ImmutableList<String>) - Constructor for class com.facebook.buck.features.dotnet.CsharpLibraryCompile
-
- CsharpLibraryDescription - Class in com.facebook.buck.features.dotnet
-
- CsharpLibraryDescription() - Constructor for class com.facebook.buck.features.dotnet.CsharpLibraryDescription
-
- CsharpLibraryDescriptionArg - Class in com.facebook.buck.features.dotnet
-
Immutable implementation of CsharpLibraryDescription.AbstractCsharpLibraryDescriptionArg
.
- CsharpLibraryDescriptionArg.Builder - Class in com.facebook.buck.features.dotnet
-
- CURRENT_BUCK_BUILD_TYPE - Static variable in enum com.facebook.buck.util.environment.BuckBuildType
-
Check in runtime to see what current build type is.
- currentConfig() - Method in interface com.facebook.buck.support.build.report.FullBuildReport
-
- currentRevisionId() - Method in class com.facebook.buck.util.versioncontrol.HgCmdLineInterface
-
- currentRevisionId() - Method in class com.facebook.buck.util.versioncontrol.NoOpCmdLineInterface
-
- currentTimeMillis() - Method in interface com.facebook.buck.util.timing.Clock
-
- currentTimeMillis() - Method in class com.facebook.buck.util.timing.DefaultClock
-
- cursorPreviousLine(int) - Method in class com.facebook.buck.util.Ansi
-
Moves the cursor y
lines up.
- CustomBehaviorUtils - Class in com.facebook.buck.rules.modern
-
Utilities for dealing with CustomFieldBehavior and CustomClassBehavior.
- CustomBehaviorUtils() - Constructor for class com.facebook.buck.rules.modern.CustomBehaviorUtils
-
- CustomClassBehavior - Annotation Type in com.facebook.buck.core.rules.modern.annotations
-
- CustomClassBehaviorTag - Interface in com.facebook.buck.core.rules.modern.annotations
-
Root interface for any CustomClassBehavior values.
- CustomClassSerialization<T extends AddsToRuleKey> - Interface in com.facebook.buck.rules.modern
-
Allows a class to follow specify its serialization/deserialization in terms of calls to the
ValueVisitor/ValueCreator.
- CustomFieldBehavior - Annotation Type in com.facebook.buck.core.rulekey
-
- CustomFieldBehaviorTag - Interface in com.facebook.buck.core.rulekey
-
Root interface for any CustomFieldBehavior values.
- CustomFieldDeps<T> - Interface in com.facebook.buck.rules.modern
-
Allows custom derivation of the deps corresponding to a field.
- CustomFieldDepsTag - Interface in com.facebook.buck.core.rulekey
-
Tag to indicate custom field deps derivation.
- CustomFieldInputs<T> - Interface in com.facebook.buck.rules.modern
-
Allows custom derivation of the inputs corresponding to a field.
- CustomFieldInputsTag - Interface in com.facebook.buck.core.rulekey
-
Tag to indicate custom field inputs derivation.
- CustomFieldSerialization<T> - Interface in com.facebook.buck.rules.modern
-
Allows the serialization/deserialization of a specific field to be specified in terms of calls to
the ValueVisitor/Creator.
- CustomFieldSerializationTag - Interface in com.facebook.buck.core.rulekey
-
Tag to indicate custom field serialization.
- CustomJarOutputStream - Class in com.facebook.buck.util.zip
-
- CustomJarOutputStream(CustomZipOutputStream.Impl) - Constructor for class com.facebook.buck.util.zip.CustomJarOutputStream
-
- CustomOptionalProtoSerializer - Class in com.facebook.buck.util.json
-
Custom serializer for ProtoBuf classes as jackson is not able to serialize them.
- CustomOptionalProtoSerializer() - Constructor for class com.facebook.buck.util.json.CustomOptionalProtoSerializer
-
- CustomPrebuiltCxxLibrary(BuildTarget, ProjectFilesystem, BuildRuleParams, PrebuiltCxxLibraryGroupDescriptionArg) - Constructor for class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescription.CustomPrebuiltCxxLibrary
-
- customType - Variable in class com.facebook.buck.android.aapt.RDotTxtEntry
-
- CustomZipEntry - Class in com.facebook.buck.util.zip
-
- CustomZipEntry(ZipEntry) - Constructor for class com.facebook.buck.util.zip.CustomZipEntry
-
- CustomZipEntry(String) - Constructor for class com.facebook.buck.util.zip.CustomZipEntry
-
- CustomZipEntry(Path, boolean) - Constructor for class com.facebook.buck.util.zip.CustomZipEntry
-
- CustomZipEntry(Path) - Constructor for class com.facebook.buck.util.zip.CustomZipEntry
-
- CustomZipOutputStream - Class in com.facebook.buck.util.zip
-
- CustomZipOutputStream(CustomZipOutputStream.Impl) - Constructor for class com.facebook.buck.util.zip.CustomZipOutputStream
-
- CustomZipOutputStream.Impl - Interface in com.facebook.buck.util.zip
-
- cxx - Variable in enum com.facebook.buck.android.toolchain.ndk.NdkCompilerType
-
- CXX_LINK_BINARY_FLAVOR - Static variable in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- CXX_LINK_MAP_FLAVOR - Static variable in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- CXX_LINK_THININDEX_FLAVOR - Static variable in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- CxxBinary - Class in com.facebook.buck.cxx
-
- CxxBinary(BuildTarget, ProjectFilesystem, BuildRuleParams, CxxPlatform, BuildRule, Tool, Iterable<FrameworkPath>, Iterable<BuildTarget>, BuildTarget, boolean) - Constructor for class com.facebook.buck.cxx.CxxBinary
-
- CxxBinaryDescription - Class in com.facebook.buck.cxx
-
- CxxBinaryDescription(ToolchainProvider, CxxBinaryImplicitFlavors, CxxBinaryFactory, CxxBinaryMetadataFactory, CxxBinaryFlavored) - Constructor for class com.facebook.buck.cxx.CxxBinaryDescription
-
- CxxBinaryDescription.CommonArg - Interface in com.facebook.buck.cxx
-
- CxxBinaryDescriptionArg - Class in com.facebook.buck.cxx
-
Immutable implementation of CxxBinaryDescription.AbstractCxxBinaryDescriptionArg
.
- CxxBinaryDescriptionArg.Builder - Class in com.facebook.buck.cxx
-
- CxxBinaryFactory - Class in com.facebook.buck.cxx
-
- CxxBinaryFactory(ToolchainProvider, CxxBuckConfig, InferBuckConfig) - Constructor for class com.facebook.buck.cxx.CxxBinaryFactory
-
- CxxBinaryFlavored - Class in com.facebook.buck.cxx
-
- CxxBinaryFlavored(ToolchainProvider, CxxBuckConfig) - Constructor for class com.facebook.buck.cxx.CxxBinaryFlavored
-
- CxxBinaryImplicitFlavors - Class in com.facebook.buck.cxx
-
- CxxBinaryImplicitFlavors(ToolchainProvider, CxxBuckConfig) - Constructor for class com.facebook.buck.cxx.CxxBinaryImplicitFlavors
-
- CxxBinaryMetadataFactory - Class in com.facebook.buck.cxx
-
- CxxBinaryMetadataFactory(ToolchainProvider) - Constructor for class com.facebook.buck.cxx.CxxBinaryMetadataFactory
-
- CxxBuckConfig - Class in com.facebook.buck.cxx.config
-
Contains platform independent settings for C/C++ rules.
- CxxBuckConfig(BuckConfig) - Constructor for class com.facebook.buck.cxx.config.CxxBuckConfig
-
- CxxBuckConfig(BuckConfig, Flavor) - Constructor for class com.facebook.buck.cxx.config.CxxBuckConfig
-
- CxxCompilationDatabase - Class in com.facebook.buck.cxx
-
- CxxCompilationDatabaseEntry - Class in com.facebook.buck.cxx
-
- CxxCompilationDatabaseEntry() - Constructor for class com.facebook.buck.cxx.CxxCompilationDatabaseEntry
-
- cxxCompiler - Variable in class com.facebook.buck.features.ocaml.OcamlLinkStep
-
- cxxCompiler - Variable in class com.facebook.buck.features.ocaml.OcamlNativePluginStep
-
- CxxConstructorArg - Interface in com.facebook.buck.cxx
-
- CxxDeps - Class in com.facebook.buck.cxx
-
- CxxDeps() - Constructor for class com.facebook.buck.cxx.CxxDeps
-
- CxxDeps.Builder - Class in com.facebook.buck.cxx
-
- CxxDescriptionEnhancer - Class in com.facebook.buck.cxx
-
- CxxDescriptionsProvider - Class in com.facebook.buck.cxx
-
- CxxDescriptionsProvider() - Constructor for class com.facebook.buck.cxx.CxxDescriptionsProvider
-
- CxxFlags - Class in com.facebook.buck.cxx
-
- CxxFlags.TranslateMacrosArgsFunction - Class in com.facebook.buck.cxx
-
Function for translating cxx flag macros in list of Arg.
- CxxFlags.TranslateMacrosFunction - Class in com.facebook.buck.cxx
-
Function for translating cxx flag macros.
- CxxFlagsMacro - Interface in com.facebook.buck.rules.macros
-
$(cxxflags)
macro type.
- CxxFlavorSanitizer - Class in com.facebook.buck.cxx.toolchain
-
- CxxGenrule - Class in com.facebook.buck.cxx
-
Genrule with C++ aware macros.
- CxxGenrule(BuildTarget, ProjectFilesystem, BuildRuleParams, String) - Constructor for class com.facebook.buck.cxx.CxxGenrule
-
- CxxGenruleDescription - Class in com.facebook.buck.cxx
-
- CxxGenruleDescription(ToolchainProvider, BuckConfig, CxxBuckConfig, SandboxExecutionStrategy) - Constructor for class com.facebook.buck.cxx.CxxGenruleDescription
-
- CxxGenruleDescriptionArg - Class in com.facebook.buck.cxx
-
Immutable implementation of CxxGenruleDescription.AbstractCxxGenruleDescriptionArg
.
- CxxGenruleDescriptionArg.Builder - Class in com.facebook.buck.cxx
-
- CxxGenruleFilterAndTargetsMacro - Class in com.facebook.buck.rules.macros
-
Base class for cxx_genrule
flags-based macros.
- CxxGenruleFilterAndTargetsMacro() - Constructor for class com.facebook.buck.rules.macros.CxxGenruleFilterAndTargetsMacro
-
- CxxGenruleFilterAndTargetsMacroTypeCoercer<M extends CxxGenruleFilterAndTargetsMacro> - Class in com.facebook.buck.rules.coercer
-
Coercer for cxx_genrule
flag-based macros.
- CxxGenruleFilterAndTargetsMacroTypeCoercer(Optional<TypeCoercer<Pattern, Pattern>>, TypeCoercer<ImmutableList<UnconfiguredBuildTarget>, ImmutableList<BuildTarget>>, Class<M>, BiFunction<Optional<Pattern>, ImmutableList<BuildTarget>, M>) - Constructor for class com.facebook.buck.rules.coercer.CxxGenruleFilterAndTargetsMacroTypeCoercer
-
- CxxHeaders - Class in com.facebook.buck.cxx
-
Encapsulates headers from a single root location.
- CxxHeaders() - Constructor for class com.facebook.buck.cxx.CxxHeaders
-
- CxxHeadersDir - Class in com.facebook.buck.cxx
-
Wraps a header directory to add to the preprocessors search path.
- CxxHeadersDir() - Constructor for class com.facebook.buck.cxx.CxxHeadersDir
-
- CxxInferEnhancer - Class in com.facebook.buck.cxx
-
- CxxInferEnhancer.InferFlavors - Enum in com.facebook.buck.cxx
-
Flavors affixed to a library or binary rule to run infer.
- CxxIntermediateBuildProduct - Interface in com.facebook.buck.cxx
-
Interface marker for a type that emits intermediate products in a cxx build
- CxxLibraryDescription - Class in com.facebook.buck.cxx
-
- CxxLibraryDescription(CxxLibraryImplicitFlavors, CxxLibraryFlavored, CxxLibraryFactory, CxxLibraryMetadataFactory) - Constructor for class com.facebook.buck.cxx.CxxLibraryDescription
-
- CxxLibraryDescription.CommonArg - Interface in com.facebook.buck.cxx
-
- CxxLibraryDescription.MetadataType - Enum in com.facebook.buck.cxx
-
- CxxLibraryDescription.TransitiveCxxPreprocessorInputFunction - Interface in com.facebook.buck.cxx
-
This is a hack to allow fine grained control over how the transitive CxxPreprocessorInput
s are found.
- CxxLibraryDescription.Type - Enum in com.facebook.buck.cxx
-
- CxxLibraryDescriptionArg - Class in com.facebook.buck.cxx
-
Immutable implementation of CxxLibraryDescription.AbstractCxxLibraryDescriptionArg
.
- CxxLibraryDescriptionArg.Builder - Class in com.facebook.buck.cxx
-
- CxxLibraryDescriptionDelegate - Interface in com.facebook.buck.cxx
-
- CxxLibraryDescriptionDelegate.ConfiguredDelegate - Interface in com.facebook.buck.cxx
-
The delegate for a specific target and platform.
- CxxLibraryEnhancement(BuildTarget, ProjectFilesystem, BuildRuleParams, Optional<Boolean>, ImmutableSet<BuildTarget>, ActionGraphBuilder, CxxPlatform) - Constructor for class com.facebook.buck.jvm.java.JavaTestDescription.CxxLibraryEnhancement
-
- CxxLibraryFactory - Class in com.facebook.buck.cxx
-
- CxxLibraryFactory(ToolchainProvider, CxxBuckConfig, InferBuckConfig) - Constructor for class com.facebook.buck.cxx.CxxLibraryFactory
-
- CxxLibraryFlavored - Class in com.facebook.buck.cxx
-
- CxxLibraryFlavored(ToolchainProvider, CxxBuckConfig) - Constructor for class com.facebook.buck.cxx.CxxLibraryFlavored
-
- CxxLibraryGroup - Class in com.facebook.buck.cxx
-
An action graph representation of a C/C++ library from the target graph, providing the various
interfaces to make it consumable by C/C++ preprocessing and native linkable rules.
- CxxLibraryGroup(BuildTarget, ProjectFilesystem, BuildRuleParams, CxxDeps, CxxDeps, Predicate<CxxPlatform>, BiFunction<? super CxxPlatform, ActionGraphBuilder, Iterable<? extends Arg>>, BiFunction<? super CxxPlatform, ActionGraphBuilder, Iterable<? extends Arg>>, QuadFunction<? super CxxPlatform, ActionGraphBuilder, SourcePathResolverAdapter, Boolean, NativeLinkableInput>, Optional<Pattern>, ImmutableSet<FrameworkPath>, ImmutableSet<FrameworkPath>, NativeLinkableGroup.Linkage, boolean, Optional<String>, ImmutableSortedSet<BuildTarget>, boolean, boolean, boolean, boolean, CxxLibraryDescriptionDelegate) - Constructor for class com.facebook.buck.cxx.CxxLibraryGroup
-
- CxxLibraryImplicitFlavors - Class in com.facebook.buck.cxx
-
- CxxLibraryImplicitFlavors(ToolchainProvider, CxxBuckConfig) - Constructor for class com.facebook.buck.cxx.CxxLibraryImplicitFlavors
-
- CxxLibraryMetadataFactory - Class in com.facebook.buck.cxx
-
- CxxLibraryMetadataFactory(ToolchainProvider, ProjectFilesystem) - Constructor for class com.facebook.buck.cxx.CxxLibraryMetadataFactory
-
- CxxLibraryModuleRule - Class in com.facebook.buck.features.project.intellij.lang.cxx
-
- CxxLibraryModuleRule(ProjectFilesystem, IjModuleFactoryResolver, IjProjectConfig) - Constructor for class com.facebook.buck.features.project.intellij.lang.cxx.CxxLibraryModuleRule
-
- CxxLink - Class in com.facebook.buck.cxx
-
A BuildRule for linking c++ objects.
- CxxLink(BuildTarget, ProjectFilesystem, SourcePathRuleFinder, CellPathResolver, Linker, Path, ImmutableMap<String, Path>, ImmutableList<Arg>, Optional<LinkOutputPostprocessor>, Optional<RuleScheduleInfo>, boolean, boolean, boolean) - Constructor for class com.facebook.buck.cxx.CxxLink
-
- CxxLink.Impl - Class in com.facebook.buck.cxx
-
Buildable implementation of CxxLink.
- CxxLinkableEnhancer - Class in com.facebook.buck.cxx
-
- CxxLinkAndCompileRules - Class in com.facebook.buck.cxx
-
- CxxLinkGroupMapping - Class in com.facebook.buck.core.linkgroup
-
Represents a single mapping which specifies which targets belong to a link group.
- CxxLinkGroupMapping() - Constructor for class com.facebook.buck.core.linkgroup.CxxLinkGroupMapping
-
- CxxLinkGroupMappingCoercer - Class in com.facebook.buck.rules.coercer
-
- CxxLinkGroupMappingCoercer(TypeCoercer<String, String>, TypeCoercer<ImmutableList<Object>, ImmutableList<CxxLinkGroupMappingTarget>>) - Constructor for class com.facebook.buck.rules.coercer.CxxLinkGroupMappingCoercer
-
- CxxLinkGroupMappingTarget - Class in com.facebook.buck.core.linkgroup
-
Represents how a single build target should be mapped to a link group.
- CxxLinkGroupMappingTarget() - Constructor for class com.facebook.buck.core.linkgroup.CxxLinkGroupMappingTarget
-
- CxxLinkGroupMappingTarget.Traversal - Enum in com.facebook.buck.core.linkgroup
-
Defines how nodes should be included starting from the root as specified by the build target.
- CxxLinkGroupMappingTargetCoercer - Class in com.facebook.buck.rules.coercer
-
- CxxLinkGroupMappingTargetCoercer(TypeCoercer<UnconfiguredBuildTarget, BuildTarget>, TypeCoercer<Object, CxxLinkGroupMappingTarget.Traversal>, TypeCoercer<Pattern, Pattern>) - Constructor for class com.facebook.buck.rules.coercer.CxxLinkGroupMappingTargetCoercer
-
- CxxLinkGroupMappingTargetTraversalCoercer - Class in com.facebook.buck.rules.coercer
-
- CxxLinkGroupMappingTargetTraversalCoercer() - Constructor for class com.facebook.buck.rules.coercer.CxxLinkGroupMappingTargetTraversalCoercer
-
- CxxLinkOptions - Class in com.facebook.buck.cxx
-
- CxxLinkOptions() - Constructor for class com.facebook.buck.cxx.CxxLinkOptions
-
- CxxLocationMacroExpander - Class in com.facebook.buck.cxx
-
- CxxLocationMacroExpander(CxxPlatform) - Constructor for class com.facebook.buck.cxx.CxxLocationMacroExpander
-
- CxxLuaExtension - Class in com.facebook.buck.features.lua
-
- CxxLuaExtension(BuildTarget, ProjectFilesystem, BuildRuleParams) - Constructor for class com.facebook.buck.features.lua.CxxLuaExtension
-
- CxxLuaExtensionDescription - Class in com.facebook.buck.features.lua
-
- CxxLuaExtensionDescription(ToolchainProvider, CxxBuckConfig) - Constructor for class com.facebook.buck.features.lua.CxxLuaExtensionDescription
-
- CxxLuaExtensionDescriptionArg - Class in com.facebook.buck.features.lua
-
Immutable implementation of CxxLuaExtensionDescription.AbstractCxxLuaExtensionDescriptionArg
.
- CxxLuaExtensionDescriptionArg.Builder - Class in com.facebook.buck.features.lua
-
- CxxMacro - Interface in com.facebook.buck.rules.macros
-
$(cxx)
macro type.
- CxxPlatform - Interface in com.facebook.buck.cxx.toolchain
-
Interface describing a C/C++ toolchain and platform to build for.
- CxxPlatform.Builder - Class in com.facebook.buck.cxx.toolchain
-
- CxxPlatforms - Class in com.facebook.buck.cxx.toolchain.impl
-
- CxxPlatformsProvider - Class in com.facebook.buck.cxx.toolchain
-
- CxxPlatformsProvider() - Constructor for class com.facebook.buck.cxx.toolchain.CxxPlatformsProvider
-
- CxxPlatformsProviderFactory - Class in com.facebook.buck.cxx.toolchain.impl
-
- CxxPlatformsProviderFactory() - Constructor for class com.facebook.buck.cxx.toolchain.impl.CxxPlatformsProviderFactory
-
- CxxPlatformsSupplier - Interface in com.facebook.buck.cxx.toolchain
-
A toolchain that provides CXX platforms.
- CxxppFlagsMacro - Class in com.facebook.buck.rules.macros
-
$(cxxppflags ...)
macro type.
- CxxppFlagsMacro() - Constructor for class com.facebook.buck.rules.macros.CxxppFlagsMacro
-
- CxxPrecompiledHeaderDescription - Class in com.facebook.buck.cxx
-
- CxxPrecompiledHeaderDescription() - Constructor for class com.facebook.buck.cxx.CxxPrecompiledHeaderDescription
-
- CxxPrecompiledHeaderDescriptionArg - Class in com.facebook.buck.cxx
-
Immutable implementation of CxxPrecompiledHeaderDescription.AbstractCxxPrecompiledHeaderDescriptionArg
.
- CxxPrecompiledHeaderDescriptionArg.Builder - Class in com.facebook.buck.cxx
-
- CxxPrecompiledHeaderTemplate - Class in com.facebook.buck.cxx
-
Represents a precompilable header file, along with dependencies.
- CxxPrefixHeader - Class in com.facebook.buck.cxx
-
Represents a header file mentioned in a `prefix_header` param in a cxx library/binary rule.
- CxxPrepareForLinkStep - Class in com.facebook.buck.cxx
-
Prepares argfile for the CxxLinkStep, so all arguments to the linker will be stored in a single
file.
- CxxPreprocessables - Class in com.facebook.buck.cxx
-
- CxxPreprocessables.IncludeType - Enum in com.facebook.buck.cxx
-
- CxxPreprocessAndCompile - Class in com.facebook.buck.cxx
-
A build rule which preprocesses and/or compiles a C/C++ source in a single step.
- CxxPreprocessorDep - Interface in com.facebook.buck.cxx
-
An interface that represents a
BuildRule
which can contribute components (e.g.
- CxxPreprocessorInput - Class in com.facebook.buck.cxx
-
The components that get contributed to a top-level run of the C++ preprocessor.
- CxxPreprocessorInput() - Constructor for class com.facebook.buck.cxx.CxxPreprocessorInput
-
- CxxPreprocessorInput.Builder - Class in com.facebook.buck.cxx
-
- CxxPythonExtension - Class in com.facebook.buck.features.python
-
- CxxPythonExtension(BuildTarget, ProjectFilesystem, BuildRuleParams) - Constructor for class com.facebook.buck.features.python.CxxPythonExtension
-
- CxxPythonExtensionDescription - Class in com.facebook.buck.features.python
-
- CxxPythonExtensionDescription(ToolchainProvider, CxxBuckConfig) - Constructor for class com.facebook.buck.features.python.CxxPythonExtensionDescription
-
- CxxPythonExtensionDescription.Type - Enum in com.facebook.buck.features.python
-
- CxxPythonExtensionDescriptionArg - Class in com.facebook.buck.features.python
-
Immutable implementation of CxxPythonExtensionDescription.AbstractCxxPythonExtensionDescriptionArg
.
- CxxPythonExtensionDescriptionArg.Builder - Class in com.facebook.buck.features.python
-
- CxxRawHeaders - Class in com.facebook.buck.cxx
-
- CxxRawHeaders() - Constructor for class com.facebook.buck.cxx.CxxRawHeaders
-
- CxxSource - Class in com.facebook.buck.cxx
-
Describes a source file written in the C programming language or a derivative (C++, Objective-C,
Objective-C++, etc.) and the various paths it uses from input to output.
- CxxSource() - Constructor for class com.facebook.buck.cxx.CxxSource
-
- CxxSource.Type - Enum in com.facebook.buck.cxx
-
- CxxSourceRuleFactory - Class in com.facebook.buck.cxx
-
- CxxSourceRuleFactory() - Constructor for class com.facebook.buck.cxx.CxxSourceRuleFactory
-
- CxxSourceTypes - Class in com.facebook.buck.cxx
-
Utilities for working with C-like source types.
- CxxStrip - Class in com.facebook.buck.cxx
-
Controls how strip tool is invoked.
- CxxStrip(BuildTarget, ProjectFilesystem, SourcePath, SourcePathRuleFinder, StripStyle, Tool, boolean, Path) - Constructor for class com.facebook.buck.cxx.CxxStrip
-
- CxxSymlinkTreeHeaders - Class in com.facebook.buck.cxx
-
- CxxSymlinkTreeHeaders() - Constructor for class com.facebook.buck.cxx.CxxSymlinkTreeHeaders
-
- CxxTest - Class in com.facebook.buck.cxx
-
A no-op
BuildRule
which houses the logic to run and form the results for C/C++ tests.
- CxxTest(BuildTarget, ProjectFilesystem, BuildRuleParams, BuildRule, Tool, ImmutableMap<String, Arg>, ImmutableList<Arg>, ImmutableSortedSet<? extends SourcePath>, ImmutableSet<SourcePath>, Function<SourcePathRuleFinder, ImmutableSortedSet<BuildRule>>, ImmutableSet<String>, ImmutableSet<String>, boolean, Optional<Long>, CxxTestType) - Constructor for class com.facebook.buck.cxx.CxxTest
-
- CxxTestDescription - Class in com.facebook.buck.cxx
-
- CxxTestDescription(ToolchainProvider, CxxBuckConfig, CxxBinaryMetadataFactory) - Constructor for class com.facebook.buck.cxx.CxxTestDescription
-
- CxxTestDescriptionArg - Class in com.facebook.buck.cxx
-
Immutable implementation of CxxTestDescription.AbstractCxxTestDescriptionArg
.
- CxxTestDescriptionArg.Builder - Class in com.facebook.buck.cxx
-
- CxxTestModuleRule - Class in com.facebook.buck.features.project.intellij.lang.cxx
-
Rule to create a module from a cxx_test
- CxxTestModuleRule(ProjectFilesystem, IjModuleFactoryResolver, IjProjectConfig) - Constructor for class com.facebook.buck.features.project.intellij.lang.cxx.CxxTestModuleRule
-
- CxxThinLTOIndex - Class in com.facebook.buck.cxx
-
A BuildRule for linking c++ objects.
- CxxThinLTOIndex(BuildTarget, ProjectFilesystem, SourcePathRuleFinder, Linker, Path, ImmutableList<Arg>, Optional<RuleScheduleInfo>, boolean) - Constructor for class com.facebook.buck.cxx.CxxThinLTOIndex
-
- CxxThinLTOIndex.Impl - Class in com.facebook.buck.cxx
-
Buildable implementation of CxxLink.
- CxxThinLTOIndexArg - Class in com.facebook.buck.cxx
-
Holds an argument specifying the location of a thinLTO index file for optimization
- CxxThinLTOIndexArg(SourcePath, SourcePath) - Constructor for class com.facebook.buck.cxx.CxxThinLTOIndexArg
-
- CxxThinLTOOpt - Class in com.facebook.buck.cxx
-
A build rule which runs the opt phase of an incremental ThinLTO build
- CxxThinLTOOpt.Impl - Class in com.facebook.buck.cxx
-
Buildable implementation for CxxThinLTOOpt.
- CxxToolchainDescription - Class in com.facebook.buck.cxx
-
Defines a cxx_toolchain rule that allows a
CxxPlatform
to be configured as a build
target.
- CxxToolchainDescription() - Constructor for class com.facebook.buck.cxx.CxxToolchainDescription
-
- CxxToolchainDescriptionArg - Class in com.facebook.buck.cxx
-
This is roughly analagous to the configuration provided by CxxBuckConfig
.
- CxxToolchainDescriptionArg.Builder - Class in com.facebook.buck.cxx
-
- CxxToolchainsSupplier - Class in com.facebook.buck.cxx.toolchain.impl
-
- CxxToolchainsSupplier() - Constructor for class com.facebook.buck.cxx.toolchain.impl.CxxToolchainsSupplier
-
- CxxToolFlags - Class in com.facebook.buck.cxx
-
Tracks flags passed to the preprocessor or compiler.
- CxxToolFlags() - Constructor for class com.facebook.buck.cxx.CxxToolFlags
-
- CxxToolProvider<T> - Class in com.facebook.buck.cxx.toolchain
-
- CxxToolProvider(ToolProvider, Supplier<CxxToolProvider.Type>, ToolType, boolean) - Constructor for class com.facebook.buck.cxx.toolchain.CxxToolProvider
-
- CxxToolProvider(ToolProvider, CxxToolProvider.Type, ToolType, boolean) - Constructor for class com.facebook.buck.cxx.toolchain.CxxToolProvider
-
- CxxToolProvider(ToolProvider, CxxToolProvider.Type, ToolType) - Constructor for class com.facebook.buck.cxx.toolchain.CxxToolProvider
-
- CxxToolProvider.Type - Enum in com.facebook.buck.cxx.toolchain
-
- CxxToolTypeInferer - Class in com.facebook.buck.cxx.toolchain
-
- CxxToolTypeInferer() - Constructor for class com.facebook.buck.cxx.toolchain.CxxToolTypeInferer
-
- CycleException - Exception in com.facebook.buck.core.util.graph
-
Exception thrown when graph traveral finds a cycle
- FACTORY - Static variable in class com.facebook.buck.features.project.intellij.lang.android.AndroidResourceFolder
-
- FACTORY - Static variable in class com.facebook.buck.features.project.intellij.model.folders.ExcludeFolder
-
- FACTORY - Static variable in class com.facebook.buck.features.project.intellij.model.folders.JavaResourceFolder
-
- FACTORY - Static variable in class com.facebook.buck.features.project.intellij.model.folders.JavaTestResourceFolder
-
- FACTORY - Static variable in class com.facebook.buck.features.project.intellij.model.folders.SourceFolder
-
- FACTORY - Static variable in class com.facebook.buck.features.project.intellij.model.folders.TestFolder
-
- failed(IOException, String, CacheResult) - Method in interface com.facebook.buck.artifact_cache.AbstractAsynchronousCache.CacheEventListener.FetchRequestEvents
-
- failed(int, IOException, String, CacheResult) - Method in interface com.facebook.buck.artifact_cache.AbstractAsynchronousCache.CacheEventListener.MultiFetchRequestEvents
-
- failed(IOException, String) - Method in interface com.facebook.buck.artifact_cache.AbstractAsynchronousCache.StoreEvents.StoreRequestEvents
-
- failure(BuildRule, Throwable) - Static method in class com.facebook.buck.core.build.engine.BuildResult
-
- failure(Optional<String>, Optional<String>, ImmutableList<String>, Optional<Exception>) - Static method in interface com.facebook.buck.core.rules.actions.ActionExecutionResult
-
- FAILURE_EXIT_CODE - Static variable in class com.facebook.buck.android.DxStep
-
- fakeOutParseEvents(BuckEventBus) - Method in class com.facebook.buck.cli.CacheCommand
-
- FakeRDotTxtEntry - Class in com.facebook.buck.android.aapt
-
- FakeRDotTxtEntry(RDotTxtEntry.IdType, RDotTxtEntry.RType, String) - Constructor for class com.facebook.buck.android.aapt.FakeRDotTxtEntry
-
- FALSE - Static variable in class com.facebook.buck.rules.keys.hasher.RuleKeyHasherTypes
-
- FasterPattern - Class in com.facebook.buck.cxx.toolchain
-
Pattern-like object which is compatible with Pattern but faster at handling simpler patterns like
.*foo.*
.
- FastPaths - Class in com.facebook.buck.io.file
-
FastPaths is primarily utilities for interacting with Path objects in a way that is efficient
when those Paths are BuckUnixPath.
- FastPaths() - Constructor for class com.facebook.buck.io.file.FastPaths
-
- fastVersionControlStats() - Method in class com.facebook.buck.util.versioncontrol.DelegatingVersionControlCmdLineInterface
-
- fastVersionControlStats() - Method in class com.facebook.buck.util.versioncontrol.HgCmdLineInterface
-
- fastVersionControlStats() - Method in class com.facebook.buck.util.versioncontrol.NoOpCmdLineInterface
-
- fastVersionControlStats() - Method in interface com.facebook.buck.util.versioncontrol.VersionControlCmdLineInterface
-
- FastVersionControlStatsEvent - Class in com.facebook.buck.util.versioncontrol
-
- FastVersionControlStatsEvent(CommonFastVersionControlStats) - Constructor for class com.facebook.buck.util.versioncontrol.FastVersionControlStatsEvent
-
- FAT_JAR_INFO_RESOURCE - Static variable in class com.facebook.buck.jvm.java.FatJar
-
- FAT_JAR_MAIN_SRC_RESOURCE - Static variable in class com.facebook.buck.jvm.java.JarFattener
-
- FAT_JAR_SRC_RESOURCES - Static variable in class com.facebook.buck.jvm.java.JarFattener
-
- fatalError(SAXParseException) - Method in class com.facebook.buck.util.xml.PositionalXmlHandler
-
- FatJar - Class in com.facebook.buck.jvm.java
-
Helper class for unpacking fat JAR resources.
- FatJar(String, Map<String, String>) - Constructor for class com.facebook.buck.jvm.java.FatJar
-
- FatJarMain - Class in com.facebook.buck.jvm.java
-
- fatLTO(Path) - Method in interface com.facebook.buck.cxx.toolchain.linker.HasLTO
-
- fatLTO(Path) - Method in class com.facebook.buck.cxx.toolchain.linker.impl.DarwinLinker
-
- fcntl(int, int, Object...) - Method in interface com.facebook.buck.util.Libc
-
- fetch(ArtifactCache, RuleKey, LazyPath) - Method in class com.facebook.buck.core.build.engine.cache.manager.BuildCacheArtifactFetcher
-
- fetch(BuckEventBus, URI, Optional<PasswordAuthentication>, Path) - Method in interface com.facebook.buck.file.downloader.AuthAwareDownloader
-
- fetch(BuckEventBus, URI, Path) - Method in interface com.facebook.buck.file.downloader.Downloader
-
Download the given URL and, upon a successful download, place it in output
.
- fetch(BuckEventBus, URI, Path) - Method in class com.facebook.buck.file.downloader.impl.ExplodingDownloader
-
- fetch(BuckEventBus, URI, Path) - Method in class com.facebook.buck.file.downloader.impl.HttpDownloader
-
- fetch(BuckEventBus, URI, Optional<PasswordAuthentication>, Path) - Method in class com.facebook.buck.file.downloader.impl.HttpDownloader
-
- fetch(BuckEventBus, URI, Path) - Method in class com.facebook.buck.file.downloader.impl.OnDiskMavenDownloader
-
- fetch(BuckEventBus, URI, Path) - Method in class com.facebook.buck.file.downloader.impl.RemoteMavenDownloader
-
- fetch(BuckEventBus, URI, Path) - Method in class com.facebook.buck.file.downloader.impl.RetryingDownloader
-
- fetch(BuckEventBus, URI, Path) - Method in class com.facebook.buck.file.downloader.impl.StackedDownloader
-
- fetch(Protocol.Digest) - Method in interface com.facebook.buck.remoteexecution.AsyncBlobFetcher
-
- fetch(Protocol.Digest) - Method in interface com.facebook.buck.remoteexecution.ContentAddressedStorageClient
-
- fetch(Protocol.Digest) - Method in class com.facebook.buck.remoteexecution.grpc.GrpcAsyncBlobFetcher
-
- fetch(Protocol.Digest) - Method in class com.facebook.buck.remoteexecution.grpc.GrpcContentAddressableStorageClient
-
- fetch(Protocol.Digest) - Method in class com.facebook.buck.remoteexecution.util.LocalContentAddressedStorage
-
- fetchAsync(BuildTarget, RuleKey, LazyPath) - Method in class com.facebook.buck.artifact_cache.AbstractAsynchronousCache
-
- fetchAsync(BuildTarget, RuleKey, LazyPath) - Method in interface com.facebook.buck.artifact_cache.ArtifactCache
-
Fetch a cached artifact, keyed by ruleKey, save the artifact to path specified by output, and
return true on success.
- fetchAsync(BuildTarget, RuleKey, LazyPath) - Method in class com.facebook.buck.artifact_cache.DirArtifactCache
-
- fetchAsync(BuildTarget, RuleKey, LazyPath) - Method in class com.facebook.buck.artifact_cache.LoggingArtifactCacheDecorator
-
- fetchAsync(BuildTarget, RuleKey, LazyPath) - Method in class com.facebook.buck.artifact_cache.MultiArtifactCache
-
Fetch the artifact matching ruleKey and store it to output.
- fetchAsync(BuildTarget, RuleKey, LazyPath) - Method in class com.facebook.buck.artifact_cache.NoopArtifactCache
-
- fetchAsync(BuildTarget, RuleKey, LazyPath) - Method in class com.facebook.buck.artifact_cache.RetryingCacheDecorator
-
- fetchAsync(BuildTarget, RuleKey, LazyPath) - Method in class com.facebook.buck.artifact_cache.SQLiteArtifactCache
-
- fetchAsync(BuildTarget, RuleKey, LazyPath) - Method in class com.facebook.buck.artifact_cache.TwoLevelArtifactCacheDecorator
-
- fetchClient - Variable in class com.facebook.buck.artifact_cache.AbstractNetworkCache
-
- FetchCommand - Class in com.facebook.buck.cli
-
- FetchCommand() - Constructor for class com.facebook.buck.cli.FetchCommand
-
- fetchImpl(BuildTarget, RuleKey, LazyPath) - Method in class com.facebook.buck.artifact_cache.AbstractAsynchronousCache
-
- fetchImpl(BuildTarget, RuleKey, LazyPath) - Method in class com.facebook.buck.artifact_cache.HttpArtifactCache
-
- fetchImpl(BuildTarget, RuleKey, LazyPath) - Method in class com.facebook.buck.artifact_cache.ThriftArtifactCache
-
- fetchManifest(RuleKey) - Method in class com.facebook.buck.core.build.engine.cache.manager.ManifestRuleKeyManager
-
- fetchManifest(RuleKey, LazyPath) - Method in interface com.facebook.buck.core.build.engine.cache.manager.ManifestRuleKeyService
-
Reads the manifest used the ManifestRuleKey from some persistent storage.
- FetchRequest(BuildTarget, RuleKey, LazyPath, SettableFuture<CacheResult>) - Constructor for class com.facebook.buck.artifact_cache.AbstractAsynchronousCache.FetchRequest
-
- FetchResponse(ImmutableSet<RuleKey>, ImmutableMap<String, String>, ByteSource) - Constructor for class com.facebook.buck.artifact_cache.HttpArtifactCacheBinaryProtocol.FetchResponse
-
- fetchScheduled(RuleKey) - Method in interface com.facebook.buck.artifact_cache.AbstractAsynchronousCache.CacheEventListener
-
- fetchStarted(BuildTarget, RuleKey) - Method in interface com.facebook.buck.artifact_cache.AbstractAsynchronousCache.CacheEventListener
-
- fetchToStream(Protocol.Digest, WritableByteChannel) - Method in interface com.facebook.buck.remoteexecution.AsyncBlobFetcher
-
- fetchToStream(Protocol.Digest, WritableByteChannel) - Method in class com.facebook.buck.remoteexecution.grpc.GrpcAsyncBlobFetcher
-
- Field() - Constructor for class com.facebook.buck.rules.coercer.BuildConfigFields.Field
-
- FieldInfo<T> - Class in com.facebook.buck.rules.modern
-
Holds a java.lang.reflect.Field and a ValueTypeInfo for a field referenced from a Buildable.
- FieldInfo(Field, ValueTypeInfo<T>, List<Class<? extends CustomFieldBehaviorTag>>) - Constructor for class com.facebook.buck.rules.modern.FieldInfo
-
- fieldReferences - Variable in class com.facebook.buck.android.dalvik.DalvikStatsTool.Stats
-
Fields referenced by the class.
- FieldValueExtractor - Class in com.facebook.buck.rules.keys
-
Extracts a value of a given field, that is assumed to be accessible.
- FILE_EXTENSION_TO_IDENTIFIER - Static variable in class com.facebook.buck.apple.xcode.xcodeproj.FileTypes
-
Map of file extension to Xcode identifiers.
- FileAttributesScrubber - Interface in com.facebook.buck.io.file
-
Created by beefon on 06/06/2016.
- FileBasedWorkerRequirementsProvider - Class in com.facebook.buck.remoteexecution
-
Provides rule's RE worker requirements based on JSON file
- FileBasedWorkerRequirementsProvider(ProjectFilesystem, String, boolean, int) - Constructor for class com.facebook.buck.remoteexecution.FileBasedWorkerRequirementsProvider
-
- FileBundler - Class in com.facebook.buck.features.filebundler
-
- FileBundler(ProjectFilesystem, BuildTarget) - Constructor for class com.facebook.buck.features.filebundler.FileBundler
-
- FileBundler(Path) - Constructor for class com.facebook.buck.features.filebundler.FileBundler
-
- FileBundlerModule - Class in com.facebook.buck.features.filebundler
-
- FileBundlerModule() - Constructor for class com.facebook.buck.features.filebundler.FileBundlerModule
-
- FileBundlerModuleAdapterPlugin - Class in com.facebook.buck.features.filebundler
-
- FileBundlerModuleAdapterPlugin(PluginWrapper) - Constructor for class com.facebook.buck.features.filebundler.FileBundlerModuleAdapterPlugin
-
- FileClassPathRunner - Class in com.facebook.buck.jvm.java.runner
-
This class handles extra large classpaths by allowing the client to pass the classpath via file
specified by buck.classpath_file
.
- fileContentsDiffer(InputStream, Path, ProjectFilesystem) - Static method in class com.facebook.buck.io.MoreProjectFilesystems
-
- FileContentsScrubber - Interface in com.facebook.buck.io.file
-
- fileCreation(String) - Static method in class com.facebook.buck.event.WatchmanStatusEvent
-
- FileCreation(String) - Constructor for class com.facebook.buck.event.WatchmanStatusEvent.FileCreation
-
- fileDeletion(String) - Static method in class com.facebook.buck.event.WatchmanStatusEvent
-
- FileDeletion(String) - Constructor for class com.facebook.buck.event.WatchmanStatusEvent.FileDeletion
-
- FileDescriptionsProvider - Class in com.facebook.buck.file
-
- FileDescriptionsProvider() - Constructor for class com.facebook.buck.file.FileDescriptionsProvider
-
- FileExtensionMatcher - Class in com.facebook.buck.io.filesystem
-
Matcher that matches file paths with specific extension.
- FileFinder - Class in com.facebook.buck.io.file
-
Methods for finding files.
- fileFlavorForSourcePath(Path) - Static method in class com.facebook.buck.features.js.JsFlavors
-
- Filegroup - Class in com.facebook.buck.features.filegroup
-
A build rule that copies inputs provided in srcs
to an output directory.
- Filegroup(BuildTarget, ProjectFilesystem, SourcePathRuleFinder, String, ImmutableSortedSet<SourcePath>) - Constructor for class com.facebook.buck.features.filegroup.Filegroup
-
- FilegroupDescription - Class in com.facebook.buck.features.filegroup
-
- FilegroupDescription() - Constructor for class com.facebook.buck.features.filegroup.FilegroupDescription
-
- FileGroupDescriptionArg - Class in com.facebook.buck.features.filegroup
-
Immutable implementation of FilegroupDescription.AbstractFileGroupDescriptionArg
.
- FileGroupDescriptionArg.Builder - Class in com.facebook.buck.features.filegroup
-
- FilegroupDescriptionsProvider - Class in com.facebook.buck.features.filegroup
-
- FilegroupDescriptionsProvider() - Constructor for class com.facebook.buck.features.filegroup.FilegroupDescriptionsProvider
-
- FilegroupModule - Class in com.facebook.buck.features.filegroup
-
- FilegroupModule() - Constructor for class com.facebook.buck.features.filegroup.FilegroupModule
-
- FilegroupModuleAdapterPlugin - Class in com.facebook.buck.features.filegroup
-
- FilegroupModuleAdapterPlugin(PluginWrapper) - Constructor for class com.facebook.buck.features.filegroup.FilegroupModuleAdapterPlugin
-
- FileHash - Class in com.facebook.buck.file
-
A small class that encapsulates a file hash that is either sha1, or sha256
- FileHashCache - Interface in com.facebook.buck.util.cache
-
A cache which maps Paths to cached hashes of their contents, based on a simplified subset of the
java.util.Map<Path, HashCode> interface.
- FileHashCache.FileHashCacheVerificationResult - Interface in com.facebook.buck.util.cache
-
- FileHashCacheEngine - Interface in com.facebook.buck.util.cache
-
This interface extracts the methods available to a file hash cache, so that the underlying
implementation is hidden and can be swapped.
- FileHashCacheEngine.ValueLoader<T> - Interface in com.facebook.buck.util.cache
-
- FileHashCacheEvent - Class in com.facebook.buck.event
-
- FileHashCacheEvent(String, long, long, long) - Constructor for class com.facebook.buck.event.FileHashCacheEvent
-
- FileHashCacheEvent(EventKey) - Constructor for class com.facebook.buck.event.FileHashCacheEvent
-
- FileHashCacheEvent.InvalidationFinished - Class in com.facebook.buck.event
-
- FileHashCacheEvent.InvalidationStarted - Class in com.facebook.buck.event
-
- FileHashCacheMode - Enum in com.facebook.buck.util.cache
-
Defines which file hash cache engine to use.
- FileHashLoader - Interface in com.facebook.buck.util.hashing
-
- FileKind - Enum in com.facebook.buck.skylark.parser
-
BUCK
, .bzl
or PACKAGE
file, which have slight different syntax
- FileLike - Interface in com.facebook.buck.jvm.java.classes
-
Provides a file-like interface for objects which may be present within more specialized
containers (like zip files).
- FileLikeCharSource - Class in com.facebook.buck.jvm.java.classes
-
- FileLikeCharSource(FileLike) - Constructor for class com.facebook.buck.jvm.java.classes.FileLikeCharSource
-
- FileLikes - Class in com.facebook.buck.jvm.java.classes
-
Utilities for common operations when working with
FileLike
s.
- fileList(Path) - Method in class com.facebook.buck.cxx.toolchain.linker.impl.DarwinLinker
-
- fileList(Path) - Method in class com.facebook.buck.cxx.toolchain.linker.impl.GnuLinker
-
- fileList(Path) - Method in class com.facebook.buck.cxx.toolchain.linker.impl.WindowsLinker
-
- fileList(Path) - Method in interface com.facebook.buck.cxx.toolchain.linker.Linker
-
Specifies that the linker should link the files listed in file.
- fileList(AbsPath) - Method in interface com.facebook.buck.cxx.toolchain.linker.Linker
-
- FileListableLinkerInputArg - Class in com.facebook.buck.rules.args
-
Arg that represents object file that should be linked into resulting binary using normal
mechanism, e.g.
- FileManagerSimulator - Class in com.facebook.buck.jvm.java.abi.source
-
Simulates the behavior of javac
's file manager for source-only ABI classpaths.
- FileManagerSimulator(Elements, Trees, SourceOnlyAbiRuleInfoFactory.SourceOnlyAbiRuleInfo) - Constructor for class com.facebook.buck.jvm.java.abi.source.FileManagerSimulator
-
- FileManifest - Interface in com.facebook.buck.parser.api
-
- fileName - Variable in class com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.InputsUploaded.LargeBlob
-
- filenameFor(BuildTarget, String, CxxPlatform) - Method in enum com.facebook.buck.features.rust.CrateType
-
Return an appropriate filename for this crate, given its type and the platform.
- fileOutputName(BuildTarget, Optional<String>) - Static method in class com.facebook.buck.features.halide.HalideCompile
-
- FileParsePipeline<T extends FileManifest> - Interface in com.facebook.buck.parser
-
Abstract node parsing pipeline.
- FileParser<T extends FileManifest> - Interface in com.facebook.buck.parser.api
-
Generic file parser, meant to be extended for more specific parsers.
- FileParserFactory<T extends FileManifest> - Interface in com.facebook.buck.parser
-
- FilePathHashLoader - Class in com.facebook.buck.util.hashing
-
A
FileHashLoader
that only hashes the files' paths without reading their contents.
- FilePathHashLoader(Path, ImmutableSet<Path>, boolean) - Constructor for class com.facebook.buck.util.hashing.FilePathHashLoader
-
- FileScrubber - Interface in com.facebook.buck.io.file
-
- FileScrubber.ScrubException - Exception in com.facebook.buck.io.file
-
- FileScrubberStep - Class in com.facebook.buck.step.fs
-
Scrub any non-deterministic meta-data from the given file (e.g.
- FileScrubberStep(ProjectFilesystem, Path, ImmutableList<FileScrubber>) - Constructor for class com.facebook.buck.step.fs.FileScrubberStep
-
- FileSerializationEventBusListener - Class in com.facebook.buck.event.listener
-
BuckEventListener
that subscribes to
IndividualTestEvent.Finished
events and
serialize them to outputFile in json-format.
- FileSerializationEventBusListener(Path) - Constructor for class com.facebook.buck.event.listener.FileSerializationEventBusListener
-
- FileSerializationOutputRuleDepsListener - Class in com.facebook.buck.event.listener
-
BuckEventListener
that subscribes to
BuildRuleExecutionEvent.Finished
events and
serialize rule build target, rule type, rule execution time, rule's dependencies to outputFile in
csv format.
- FileSerializationOutputRuleDepsListener(Path) - Constructor for class com.facebook.buck.event.listener.FileSerializationOutputRuleDepsListener
-
- FileSerializationOutputRuleDepsListener.RuleExecutionTimeData - Interface in com.facebook.buck.event.listener
-
Data object that is used to serialize rule execution information into a file
- filesystem - Variable in class com.facebook.buck.android.AndroidBinaryOptimizer
-
- fileSystem - Variable in class com.facebook.buck.android.toolchain.common.BaseAndroidToolchainResolver
-
- filesystem - Variable in class com.facebook.buck.features.ocaml.OcamlLinkStep
-
- filesystem - Variable in class com.facebook.buck.unarchive.UnarchiveStep
-
- FilesystemBackedBuildFileTree - Class in com.facebook.buck.core.model.impl
-
Class to allow looking up parents and children of build files.
- FilesystemBackedBuildFileTree(ProjectFilesystem, String) - Constructor for class com.facebook.buck.core.model.impl.FilesystemBackedBuildFileTree
-
- FilesystemBackedDelegate() - Constructor for class com.facebook.buck.remoteexecution.util.OutputsCollector.FilesystemBackedDelegate
-
- FilesystemFileMaterializer(Path) - Constructor for class com.facebook.buck.remoteexecution.util.OutputsMaterializer.FilesystemFileMaterializer
-
- FileSystemMap<T> - Class in com.facebook.buck.util.filesystem
-
This class implements a map for a filesystem structure relying on a prefix tree.
- FileSystemMap(FileSystemMap.ValueLoader<T>, ProjectFilesystem) - Constructor for class com.facebook.buck.util.filesystem.FileSystemMap
-
- FileSystemMap.ValueLoader<T> - Interface in com.facebook.buck.util.filesystem
-
Wrapper class that implements a method for loading a value in the leaves of the trie.
- FileSystemNotWatchedException - Exception in com.facebook.buck.io.watchman
-
- FileSystemNotWatchedException() - Constructor for exception com.facebook.buck.io.watchman.FileSystemNotWatchedException
-
- FileTree - Class in com.facebook.buck.core.files
-
Has information about files and folders at some directory
- FileTree() - Constructor for class com.facebook.buck.core.files.FileTree
-
- FileTreeCache - Class in com.facebook.buck.core.files
-
Stores a recursive file tree
- FileTreeCache.Invalidator - Class in com.facebook.buck.core.files
-
Subscribes to watchman event and invalidates internal state of a provided
FileTreeCache
- FileTreeComputation - Class in com.facebook.buck.core.files
-
Produce a file tree of a provided folder, i.e.
- FileTreeFileNameIterator - Class in com.facebook.buck.core.files
-
Iterator which recursively traverses
FileTree
searching for specific file name Returns
relative Path of that file including file name itself This type of iterator is useful for finding
all build files under some path
- FileTreeKey - Class in com.facebook.buck.core.files
-
Transformation key that has info about recursive directory tree computation
- FileTreeKey() - Constructor for class com.facebook.buck.core.files.FileTreeKey
-
- FileTypes - Class in com.facebook.buck.apple.xcode.xcodeproj
-
File types used in Apple targets.
- FileZipEntrySource - Interface in com.facebook.buck.util.zip.collect
-
A file source for an entry in a zip file.
- fillConfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, ImmutableCollection.Builder<T>, D) - Method in class com.facebook.buck.rules.coercer.CollectionTypeCoercer
-
Helper method to add coerced elements to the builder.
- fillUnconfigured(CellNameResolver, ProjectFilesystem, ForwardRelativePath, ImmutableCollection.Builder<U>, Object) - Method in class com.facebook.buck.rules.coercer.CollectionTypeCoercer
-
Helper method to add coerced elements to the builder.
- filter(Predicate<T>) - Method in class com.facebook.buck.cli.ThriftOutput.Builder
-
- filter(Iterable<TargetNodeMaybeIncompatible>) - Method in class com.facebook.buck.parser.spec.BuildTargetSpec
-
- filter(Iterable<TargetNodeMaybeIncompatible>) - Method in class com.facebook.buck.parser.spec.TargetNodePredicateSpec
-
- filter(Iterable<TargetNodeMaybeIncompatible>) - Method in interface com.facebook.buck.parser.spec.TargetNodeSpec
-
- filter(TargetNodeSpec, Iterable<TargetNodeMaybeIncompatible>) - Method in interface com.facebook.buck.parser.TargetSpecResolver.TargetNodeFilterForSpecResolver
-
- filter(Class<U>) - Method in interface com.facebook.buck.util.stream.RichStream
-
Filter stream elements, returning only those that is an instance of the given class.
- filter(Predicate<? super T>) - Method in interface com.facebook.buck.util.stream.RichStream
-
- filterArgs(List<String>, ImmutableSet<String>) - Static method in class com.facebook.buck.support.cli.args.BuckArgsMethods
-
Drops options from the args array.
- filterAttributeContents(QueryBuildTarget, String, Predicate<Object>) - Method in class com.facebook.buck.cli.BuckQueryEnvironment
-
- filterAttributeContents(NODE_TYPE, String, Predicate<Object>) - Method in interface com.facebook.buck.query.QueryEnvironment
-
Returns the objects in the `attribute` of the given `target` that satisfy `predicate`
- filterAttributeContents(NODE_TYPE, String, Predicate<Object>) - Method in class com.facebook.buck.query.TargetVariablesQueryEnvironment
-
- filterAttributeContents(QueryBuildTarget, String, Predicate<Object>) - Method in class com.facebook.buck.rules.query.GraphEnhancementQueryEnvironment
-
- filterAttributeContents(TypeCoercerFactory, TargetNode<T>, String, Predicate<Object>, CellNameResolver) - Static method in class com.facebook.buck.rules.query.QueryTargetAccessor
-
Filters the objects in the given attribute that satisfy the given predicate.
- filterBuildRuleInputs(Iterable<? extends SourcePath>) - Method in class com.facebook.buck.core.rules.impl.AbstractBuildRuleResolver
-
- filterBuildRuleInputs(SourcePath...) - Method in class com.facebook.buck.core.rules.impl.AbstractBuildRuleResolver
-
- filterBuildRuleInputs(Stream<SourcePath>) - Method in class com.facebook.buck.core.rules.impl.AbstractBuildRuleResolver
-
- filterBuildRuleInputs(Optional<SourcePath>) - Method in class com.facebook.buck.core.rules.impl.AbstractBuildRuleResolver
-
- filterBuildRuleInputs(Iterable<? extends SourcePath>) - Method in class com.facebook.buck.core.rules.impl.DefaultSourcePathRuleFinder
-
- filterBuildRuleInputs(SourcePath...) - Method in class com.facebook.buck.core.rules.impl.DefaultSourcePathRuleFinder
-
- filterBuildRuleInputs(Stream<SourcePath>) - Method in class com.facebook.buck.core.rules.impl.DefaultSourcePathRuleFinder
-
- filterBuildRuleInputs(Optional<SourcePath>) - Method in class com.facebook.buck.core.rules.impl.DefaultSourcePathRuleFinder
-
- filterBuildRuleInputs(Iterable<? extends SourcePath>) - Method in interface com.facebook.buck.core.rules.SourcePathRuleFinder
-
- filterBuildRuleInputs(SourcePath...) - Method in interface com.facebook.buck.core.rules.SourcePathRuleFinder
-
- filterBuildRuleInputs(Stream<SourcePath>) - Method in interface com.facebook.buck.core.rules.SourcePathRuleFinder
-
- filterBuildRuleInputs(Optional<SourcePath>) - Method in interface com.facebook.buck.core.rules.SourcePathRuleFinder
-
- filterConsumer(BuildRuleResolver, Consumer<? super NativeLinkableGroup>) - Static method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableGroups
-
- FilteredDirectoryCopier - Interface in com.facebook.buck.util
-
- FilteredResourcesProvider - Interface in com.facebook.buck.android
-
- FilteredSourceFiles - Class in com.facebook.buck.features.go
-
- FilteredSourceFiles(List<Path>, GoPlatform, List<GoListStep.ListType>) - Constructor for class com.facebook.buck.features.go.FilteredSourceFiles
-
- FilteredSourceFiles(List<Path>, List<Path>, GoPlatform, List<GoListStep.ListType>) - Constructor for class com.facebook.buck.features.go.FilteredSourceFiles
-
- filterForSubpaths(Iterable<Path>, Path) - Static method in class com.facebook.buck.io.file.MorePaths
-
Filters out
Path
objects from
paths
that aren't a subpath of
root
and
returns a set of paths relative to
root
.
- FilterFunction<NODE_TYPE> - Class in com.facebook.buck.query
-
A filter(pattern, argument) expression, evaluates its argument and filters the resulting targets
by applying the given regular expression pattern to the targets' names.
- FilterFunction() - Constructor for class com.facebook.buck.query.FilterFunction
-
- filterInputsToCompareToOutput(Iterable<? extends SourcePath>) - Method in class com.facebook.buck.core.sourcepath.resolver.impl.AbstractSourcePathResolver
-
- filterInputsToCompareToOutput(Iterable<? extends SourcePath>) - Method in interface com.facebook.buck.core.sourcepath.resolver.SourcePathResolver
-
- filterInputsToCompareToOutput(Iterable<? extends SourcePath>) - Method in class com.facebook.buck.core.sourcepath.resolver.SourcePathResolverAdapter
-
Returns a collection of
Path
instances by filtering the given
SourcePath
instances for
Path
instances.
- filterLibrariesForAbi(Path, ImmutableMultimap<String, Path>, String, ImmutableSet<String>) - Static method in class com.facebook.buck.android.exopackage.NativeExoHelper
-
- filterMatchingMapKeys(Map<String, V>) - Method in class com.facebook.buck.util.PatternsMatcher
-
- filterPEMInputStream(InputStream, String) - Static method in class com.facebook.buck.artifact_cache.ClientCertificateHandler
-
Filter an InputStream containing PEM sections into another InputStream just containing sections
of a specific PEM block type
- FilterResourcesSteps - Class in com.facebook.buck.android
-
This
Step
copies
res
directories to a different location,
while filtering out certain resources.
- FilterResourcesSteps.Builder - Class in com.facebook.buck.android
-
- FilterResourcesSteps.DefaultDrawableFinder - Class in com.facebook.buck.android
-
- FilterResourcesSteps.DrawableFinder - Interface in com.facebook.buck.android
-
- FilterResourcesSteps.ImageScaler - Interface in com.facebook.buck.android
-
- FilterResourcesSteps.ResourceFilter - Class in com.facebook.buck.android
-
Helper class for interpreting the resource_filter argument to android_binary().
- filterTests(ImmutableSet<BuildTarget>, CellPathResolver, ImmutableSet<String>, ImmutableSet<String>) - Static method in class com.facebook.buck.features.project.intellij.IjProjectCommandHelper
-
- filterValues(Map<K, V>, Predicate<? super V>) - Static method in class com.facebook.buck.util.MoreMaps
-
Version of Maps.filterValues(Map, Predicate)
that collects the results in an immutable
map.
- finalize() - Method in class com.facebook.buck.io.unixsocket.UnixDomainSocket
-
- finalize() - Method in class com.facebook.buck.log.GlobalStateManager
-
Since this is a Singleton class, make sure it cleans after itself once it's GC'ed.
- FinalizingBuildRuleEvent - Class in com.facebook.buck.core.build.event
-
Event to signal the end of finalize BuildRule stage during building of a rule.
- finallyCallback(Runnable) - Static method in class com.facebook.buck.util.concurrent.MoreFutures
-
- finallyCallback(Consumer<ListenableFuture<V>>) - Static method in class com.facebook.buck.util.concurrent.MoreFutures
-
- find(String) - Method in interface com.facebook.buck.rules.modern.Deserializer.ClassFinder
-
- findAll(ImmutableSet<String>, String) - Static method in class com.facebook.buck.core.macros.MacroFinder
-
- FindAndReplaceStep - Class in com.facebook.buck.step.fs
-
- FindAndReplaceStep(ProjectFilesystem, AbsPath, Path, Function<String, String>) - Constructor for class com.facebook.buck.step.fs.FindAndReplaceStep
-
- findAppleSdkName(Flavor) - Static method in class com.facebook.buck.apple.toolchain.ApplePlatform
-
- findArchitecture(Flavor) - Static method in class com.facebook.buck.apple.toolchain.ApplePlatform
-
- findChildren(T) - Method in interface com.facebook.buck.core.util.graph.GraphTraversable
-
- findChildren(T, DependencyStack) - Method in interface com.facebook.buck.core.util.graph.GraphTraversableWithDependencyStack
-
- findChildren(T) - Method in interface com.facebook.buck.core.util.graph.TopologicalSort.Traversable
-
- findChildren(AggregationTreeNode) - Method in class com.facebook.buck.features.project.intellij.aggregation.AggregationTree
-
- findCurrentSsid() - Static method in class com.facebook.buck.util.environment.MacWifiSsidFinder
-
Finds the SSID of the default Wi-Fi interface using Mac OS X APIs.
- findCycles() - Method in class com.facebook.buck.core.util.graph.MutableDirectedGraph
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, AndroidAarDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.android.AndroidAarDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, AndroidBinaryDescription.AbstractAndroidBinaryDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.android.AndroidBinaryDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, AndroidBuildConfigDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.android.AndroidBuildConfigDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, AndroidBundleDescription.AbstractAndroidBundleDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.android.AndroidBundleDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, AndroidInstrumentationApkDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.android.AndroidInstrumentationApkDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, AndroidInstrumentationTestDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.android.AndroidInstrumentationTestDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, AndroidLibraryDescription.AbstractAndroidLibraryDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.android.AndroidLibraryDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, AndroidPrebuiltAarDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.android.AndroidPrebuiltAarDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, AndroidResourceDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.android.AndroidResourceDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, NdkLibraryDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.android.NdkLibraryDescription
-
Deprecated.
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, RobolectricTestDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.android.RobolectricTestDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, AppleBinaryDescription.AbstractAppleBinaryDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.apple.AppleBinaryDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, AppleBundleDescription.AbstractAppleBundleDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.apple.AppleBundleDescription
-
Propagate the bundle's platform, debug symbol and strip flavors to its dependents which are
other bundles (e.g.
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, AppleLibraryDescription.AbstractAppleLibraryDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.apple.AppleLibraryDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, ApplePackageDescription.AbstractApplePackageDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.apple.ApplePackageDescription
-
Propagate the packages's flavors to its dependents.
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, AppleTestDescription.AbstractAppleTestDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.apple.AppleTestDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, T, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in interface com.facebook.buck.core.description.attr.ImplicitDepsInferringDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, LegacyToolchainDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.core.toolchain.rule.LegacyToolchainRuleDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, CxxBinaryDescription.AbstractCxxBinaryDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.cxx.CxxBinaryDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, CxxGenruleDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.cxx.CxxGenruleDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, CxxLibraryDescription.CommonArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.cxx.CxxLibraryDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, CxxTestDescription.AbstractCxxTestDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.cxx.CxxTestDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, PrebuiltCxxLibraryDescription.AbstractPrebuiltCxxLibraryDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescription
-
- findDepsForTargetFromConstructorArgs(CxxPlatformsProvider, BuildTarget, Optional<Flavor>) - Static method in class com.facebook.buck.cxx.toolchain.impl.CxxPlatforms
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, DBinaryDescription.AbstractDBinaryDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.features.d.DBinaryDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, DLibraryDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.features.d.DLibraryDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, DTestDescription.AbstractDTestDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.features.d.DTestDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, CgoLibraryDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.features.go.CgoLibraryDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, GoBinaryDescription.AbstractGoBinaryDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.features.go.GoBinaryDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, GoLibraryDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.features.go.GoLibraryDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, GoTestDescription.AbstractGoTestDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.features.go.GoTestDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, GwtBinaryDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.features.gwt.GwtBinaryDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, HaskellBinaryDescription.AbstractHaskellBinaryDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.features.haskell.HaskellBinaryDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, HaskellGhciDescription.AbstractHaskellGhciDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.features.haskell.HaskellGhciDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, HaskellHaddockDescription.AbstractHaskellHaddockDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.features.haskell.HaskellHaddockDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, HaskellLibraryDescription.AbstractHaskellLibraryDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.features.haskell.HaskellLibraryDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, JsBundleDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.features.js.JsBundleDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, JsLibraryDescription.AbstractJsLibraryDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.features.js.JsLibraryDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, CxxLuaExtensionDescription.AbstractCxxLuaExtensionDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, LuaBinaryDescription.AbstractLuaBinaryDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.features.lua.LuaBinaryDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, OcamlBinaryDescription.AbstractOcamlBinaryDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.features.ocaml.OcamlBinaryDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, OcamlLibraryDescription.AbstractOcamlLibraryDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.features.ocaml.OcamlLibraryDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, CxxPythonExtensionDescription.AbstractCxxPythonExtensionDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, PythonBinaryDescription.AbstractPythonBinaryDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.features.python.PythonBinaryDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, PythonTestDescription.AbstractPythonTestDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.features.python.PythonTestDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, RustBinaryDescription.AbstractRustBinaryDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.features.rust.RustBinaryDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, RustLibraryDescription.AbstractRustLibraryDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.features.rust.RustLibraryDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, RustTestDescription.AbstractRustTestDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.features.rust.RustTestDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, GroovyLibraryDescription.AbstractGroovyLibraryDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, GroovyTestDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, JarGenruleDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.jvm.java.JarGenruleDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, JavaBinaryDescription.AbstractJavaBinaryDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.jvm.java.JavaBinaryDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, JavaLibraryDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.jvm.java.JavaLibraryDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, JavaTestDescription.AbstractJavaTestDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.jvm.java.JavaTestDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, JavaTestRunnerDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, KotlinLibraryDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, KotlinTestDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, ScalaLibraryDescription.AbstractScalaLibraryDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, ScalaTestDescription.AbstractScalaTestDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.jvm.scala.ScalaTestDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, T, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.shell.AbstractGenruleDescription
-
- findDepsForTargetFromConstructorArgs(BuildTarget, CellNameResolver, SwiftLibraryDescription.AbstractSwiftLibraryDescriptionArg, ImmutableCollection.Builder<BuildTarget>, ImmutableCollection.Builder<BuildTarget>) - Method in class com.facebook.buck.swift.SwiftLibraryDescription
-
- findDrawables(Collection<Path>, ProjectFilesystem) - Method in class com.facebook.buck.android.FilterResourcesSteps.DefaultDrawableFinder
-
- findDrawables(Collection<Path>, ProjectFilesystem) - Method in interface com.facebook.buck.android.FilterResourcesSteps.DrawableFinder
-
- findFirstDirectory(ImmutableList<Pair<String, Optional<String>>>) - Method in class com.facebook.buck.android.toolchain.common.BaseAndroidToolchainResolver
-
- findIncludeForBuildFile(Path) - Method in class com.facebook.buck.parser.implicit.PackageImplicitIncludesFinder
-
Find the file (if any) that should be included implicitly for a given build file path
- findJavaPackage(Path) - Method in interface com.facebook.buck.jvm.core.JavaPackageFinder
-
- findJavaPackage(BuildTarget) - Method in interface com.facebook.buck.jvm.core.JavaPackageFinder
-
- findJavaPackage(Path) - Method in class com.facebook.buck.jvm.java.DefaultJavaPackageFinder
-
- findJavaPackage(BuildTarget) - Method in class com.facebook.buck.jvm.java.DefaultJavaPackageFinder
-
- findJavaPackage(Path) - Method in class com.facebook.buck.jvm.java.ResourcesRootPackageFinder
-
- findJavaPackage(BuildTarget) - Method in class com.facebook.buck.jvm.java.ResourcesRootPackageFinder
-
- findJavaPackageFolder(Path) - Method in interface com.facebook.buck.jvm.core.JavaPackageFinder
-
Given the relative path to a file under the project root, return the Java package with which
the file is associated.
- findJavaPackageFolder(Path) - Method in class com.facebook.buck.jvm.java.DefaultJavaPackageFinder
-
- findJavaPackageFolder(Path) - Method in class com.facebook.buck.jvm.java.ResourcesRootPackageFinder
-
- findJavaPackageWithPackageFolder(Path) - Static method in class com.facebook.buck.jvm.java.DefaultJavaPackageFinder
-
- findManifestFiles() - Method in class com.facebook.buck.android.AndroidTransitiveDependencyGraph
-
- findManifestModuleForTarget(BuildTarget) - Method in class com.facebook.buck.android.apkmodule.APKModuleGraph
-
Get the Module that should contain the manifest for the given target or else fallback to the same logic of findResourceModuleForTarget.
- findMatchingConditions(SelectableConfigurationContext, Selector<T>, DependencyStack) - Method in class com.facebook.buck.core.select.AbstractSelectorListResolver
-
Returns the value for which the current configuration matches the key inside the select
dictionary
- findMissing(Iterable<Protocol.Digest>) - Method in class com.facebook.buck.remoteexecution.util.LocalContentAddressedStorage
-
- findModuleForTarget(BuildTarget) - Method in class com.facebook.buck.android.apkmodule.APKModuleGraph
-
Get the Module that contains the given target
- findNdkVersion(Path) - Method in class com.facebook.buck.android.toolchain.ndk.impl.AndroidNdkResolver
-
- findNdkVersionFromDirectory(Path) - Static method in class com.facebook.buck.android.toolchain.ndk.impl.AndroidNdkResolver
-
The method returns the NDK version of a path.
- findNodeAndChildren(T) - Method in interface com.facebook.buck.core.util.graph.GraphTraversableWithPayload
-
- findNodeAndChildren(T, DependencyStack) - Method in interface com.facebook.buck.core.util.graph.GraphTraversableWithPayloadAndDependencyStack
-
- findReferenceAssembly(String) - Method in class com.facebook.buck.features.dotnet.DotnetFramework
-
- findResourceModuleForTarget(BuildTarget) - Method in class com.facebook.buck.android.apkmodule.APKModuleGraph
-
Get the Module that should contain the resources for the given target
- findSelector(TestDescription) - Method in class com.facebook.buck.test.selectors.TestSelectorList
-
- findSources(ProjectFilesystem, Path) - Method in class com.facebook.buck.android.NdkLibraryDescription
-
Deprecated.
- findStronglyConnectedComponents() - Method in class com.facebook.buck.core.util.graph.MutableDirectedGraph
-
For this graph, returns the set of strongly connected components using Tarjan's algorithm.
- findSwiftCompatibilityRuntimePath(Path, String) - Static method in class com.facebook.buck.swift.toolchain.impl.SwiftPlatformFactory
-
- findSwiftRuntimePath(Path, String) - Static method in class com.facebook.buck.swift.toolchain.impl.SwiftPlatformFactory
-
- fine(String) - Static method in class com.facebook.buck.event.ConsoleEvent
-
- fine(String, Object...) - Static method in class com.facebook.buck.event.ConsoleEvent
-
- finer(String) - Static method in class com.facebook.buck.event.ConsoleEvent
-
- finer(String, Object...) - Static method in class com.facebook.buck.event.ConsoleEvent
-
- finish(long) - Static method in class com.facebook.buck.event.listener.util.EventInterval
-
- finished(AbstractAsynchronousCache.FetchResult) - Method in interface com.facebook.buck.artifact_cache.AbstractAsynchronousCache.CacheEventListener.FetchRequestEvents
-
- finished(int, AbstractAsynchronousCache.FetchResult) - Method in interface com.facebook.buck.artifact_cache.AbstractAsynchronousCache.CacheEventListener.MultiFetchRequestEvents
-
- finished(AbstractAsynchronousCache.StoreResult) - Method in interface com.facebook.buck.artifact_cache.AbstractAsynchronousCache.StoreEvents.StoreRequestEvents
-
- finished(ArtifactCacheConnectEvent.Started) - Static method in class com.facebook.buck.artifact_cache.ArtifactCacheConnectEvent
-
- Finished(ArtifactCacheConnectEvent.Started) - Constructor for class com.facebook.buck.artifact_cache.ArtifactCacheConnectEvent.Finished
-
- Finished(EventKey, ArtifactCacheEvent.CacheMode, ArtifactCacheEvent.Operation, Optional<BuildTarget>, ImmutableSet<RuleKey>, ArtifactCacheEvent.InvocationType, Optional<CacheResult>) - Constructor for class com.facebook.buck.artifact_cache.ArtifactCacheEvent.Finished
-
- Finished(EventKey, ArtifactCacheEvent.CacheMode, ArtifactCacheEvent.Operation, Optional<BuildTarget>, ImmutableSet<RuleKey>, ArtifactCacheEvent.InvocationType, Optional<CacheResult>, ArtifactCacheEvent.StoreType) - Constructor for class com.facebook.buck.artifact_cache.ArtifactCacheEvent.Finished
-
- Finished(EventKey, ArtifactCacheEvent.CacheMode, ArtifactCacheEvent.Operation, Optional<BuildTarget>, ImmutableSet<RuleKey>, ArtifactCacheEvent.InvocationType, Optional<CacheResult>) - Constructor for class com.facebook.buck.artifact_cache.DirArtifactCacheEvent.Finished
-
- Finished(ArtifactCacheEvent.Started, Optional<BuildTarget>, HttpArtifactCacheEvent.HttpArtifactCacheEventFetchData) - Constructor for class com.facebook.buck.artifact_cache.HttpArtifactCacheEvent.Finished
-
- Finished(ArtifactCacheEvent.Started, HttpArtifactCacheEvent.HttpArtifactCacheEventStoreData) - Constructor for class com.facebook.buck.artifact_cache.HttpArtifactCacheEvent.Finished
-
- Finished(EventKey, ArtifactCacheEvent.CacheMode, ArtifactCacheEvent.Operation, Optional<BuildTarget>, ImmutableSet<RuleKey>, ArtifactCacheEvent.InvocationType, Optional<CacheResult>) - Constructor for class com.facebook.buck.artifact_cache.SQLiteArtifactCacheEvent.Finished
-
- finished(BuildResult, Optional<Long>, Optional<HashCode>, Optional<BuildRuleSuccessType>, UploadToCacheResultType, Optional<Pair<Long, Long>>, Optional<Pair<Long, Long>>, Optional<Pair<Long, Long>>, Optional<Pair<Long, Long>>) - Method in class com.facebook.buck.core.build.engine.cache.manager.BuildRuleScopeManager
-
- finished(BuildEvent.Started, ExitCode) - Static method in class com.facebook.buck.core.build.event.BuildEvent
-
- Finished(BuildEvent.Started, ExitCode) - Constructor for class com.facebook.buck.core.build.event.BuildEvent.Finished
-
- finished(BuildRuleEvent.BeginningBuildRuleEvent, BuildRuleKeys, BuildRuleStatus, CacheResult, Optional<BuildId>, Optional<BuildRuleSuccessType>, UploadToCacheResultType, Optional<HashCode>, Optional<Long>, Optional<BuildRuleDiagnosticData>, Optional<ManifestFetchResult>, Optional<ManifestStoreResult>, Optional<Pair<Long, Long>>, Optional<Pair<Long, Long>>, Optional<Pair<Long, Long>>, Optional<Pair<Long, Long>>, Optional<String>) - Static method in class com.facebook.buck.core.build.event.BuildRuleEvent
-
- Finished(EventKey, BuildRule, long) - Constructor for class com.facebook.buck.core.build.event.BuildRuleExecutionEvent.Finished
-
- finished(Iterable<String>, TestResults) - Static method in class com.facebook.buck.core.test.event.IndividualTestEvent
-
- finished(ImmutableSet<String>, List<TestResults>) - Static method in class com.facebook.buck.core.test.event.TestRunEvent
-
- Finished(int, List<TestResults>) - Constructor for class com.facebook.buck.core.test.event.TestRunEvent.Finished
-
- finished(TestStatusMessageEvent.Started, TestStatusMessage) - Static method in class com.facebook.buck.core.test.event.TestStatusMessageEvent
-
- Finished(TestStatusMessageEvent.Started, TestStatusMessage) - Constructor for class com.facebook.buck.core.test.event.TestStatusMessageEvent.Finished
-
- finished(UUID, TestResultSummary) - Static method in class com.facebook.buck.core.test.event.TestSummaryEvent
-
- Finished(UUID, TestResultSummary) - Constructor for class com.facebook.buck.core.test.event.TestSummaryEvent.Finished
-
- finished(ActionGraphEvent.Started) - Static method in class com.facebook.buck.event.ActionGraphEvent
-
- finished(ActionGraphEvent.Started, int) - Static method in class com.facebook.buck.event.ActionGraphEvent
-
- Finished(ActionGraphEvent.Started, OptionalInt) - Constructor for class com.facebook.buck.event.ActionGraphEvent.Finished
-
- finished(ArtifactCompressionEvent.Started, long, long, HasNameAndType) - Static method in class com.facebook.buck.event.ArtifactCompressionEvent
-
Create a new Finished event for corresponding Started event
- Finished(ArtifactCompressionEvent.Started, long, long, HasNameAndType) - Constructor for class com.facebook.buck.event.ArtifactCompressionEvent.Finished
-
- finished(CommandEvent.Started, ExitCode) - Static method in class com.facebook.buck.event.CommandEvent
-
- finished(CompilerPluginDurationEvent.Started, ImmutableMap<String, String>) - Static method in class com.facebook.buck.event.CompilerPluginDurationEvent
-
- Finished(CompilerPluginDurationEvent.Started, ImmutableMap<String, String>) - Constructor for class com.facebook.buck.event.CompilerPluginDurationEvent.Finished
-
- finished(InstallEvent.Started, boolean, Optional<Long>, Optional<String>, ImmutableMap<String, String>) - Static method in class com.facebook.buck.event.InstallEvent
-
- finished(InstallEvent.Started, boolean, Optional<Long>, Optional<String>) - Static method in class com.facebook.buck.event.InstallEvent
-
- Finished(InstallEvent.Started, boolean, Optional<Long>, Optional<String>, ImmutableMap<String, String>) - Constructor for class com.facebook.buck.event.InstallEvent.Finished
-
- finished() - Static method in class com.facebook.buck.event.ProjectGenerationEvent
-
- Finished() - Constructor for class com.facebook.buck.event.ProjectGenerationEvent.Finished
-
- Finished(SimplePerfEvent.StartedImpl, ImmutableMap<String, Object>) - Constructor for class com.facebook.buck.event.SimplePerfEvent.Finished
-
- finished(StartActivityEvent.Started, boolean) - Static method in class com.facebook.buck.event.StartActivityEvent
-
- Finished(StartActivityEvent.Started, boolean) - Constructor for class com.facebook.buck.event.StartActivityEvent.Finished
-
- finished(UninstallEvent.Started, boolean) - Static method in class com.facebook.buck.event.UninstallEvent
-
- Finished(UninstallEvent.Started, boolean) - Constructor for class com.facebook.buck.event.UninstallEvent.Finished
-
- finished() - Static method in class com.facebook.buck.event.WatchmanStatusEvent
-
- Finished() - Constructor for class com.facebook.buck.event.WatchmanStatusEvent.Finished
-
- finished(DownloadEvent.Started) - Static method in class com.facebook.buck.file.downloader.impl.DownloadEvent
-
- Finished(DownloadEvent.Started) - Constructor for class com.facebook.buck.file.downloader.impl.DownloadEvent.Finished
-
- Finished(ProjectBuildFileParseEvents.Started) - Constructor for class com.facebook.buck.json.ProjectBuildFileParseEvents.Finished
-
- finished(TaskEvent) - Method in class com.facebook.buck.jvm.java.abi.source.ValidatingTaskListener
-
- finished(AnnotationProcessingEvent.Started) - Static method in class com.facebook.buck.jvm.java.AnnotationProcessingEvent
-
- Finished(AnnotationProcessingEvent.Started) - Constructor for class com.facebook.buck.jvm.java.AnnotationProcessingEvent.Finished
-
- Finished(EventKey, BuildTarget, String, AnnotationProcessingEvent.Operation, int, boolean) - Constructor for class com.facebook.buck.jvm.java.AnnotationProcessingEvent.Finished
-
- finished(TaskEvent) - Method in class com.facebook.buck.jvm.java.plugin.adapter.BuckJavacTask
-
- finished(TaskEvent) - Method in class com.facebook.buck.jvm.java.plugin.adapter.BuckJavacTaskListenerProxy
-
- finished(TaskEvent) - Method in class com.facebook.buck.jvm.java.plugin.adapter.PostEnterTaskListener
-
- finished(TaskEventMirror) - Method in class com.facebook.buck.jvm.java.plugin.adapter.TaskListenerProxy
-
- finished(TaskEvent) - Method in class com.facebook.buck.jvm.java.plugin.adapter.TaskListenerWrapper
-
- finished(TaskEventMirror) - Method in interface com.facebook.buck.jvm.java.plugin.api.BuckJavacTaskListener
-
- finished(JavacPhaseEvent.Started, ImmutableMap<String, String>) - Static method in class com.facebook.buck.jvm.java.tracing.JavacPhaseEvent
-
- Finished(JavacPhaseEvent.Started, ImmutableMap<String, String>) - Constructor for class com.facebook.buck.jvm.java.tracing.JavacPhaseEvent.Finished
-
- finished(TaskEventMirror) - Method in class com.facebook.buck.jvm.java.tracing.TracingTaskListener
-
- finished(ParseBuckFileEvent.Started, int, long, Optional<String>) - Static method in class com.facebook.buck.parser.events.ParseBuckFileEvent
-
Create an event when parsing of build file finishes
- Finished(ParseBuckFileEvent.Started, int, long, Optional<String>) - Constructor for class com.facebook.buck.parser.events.ParseBuckFileEvent.Finished
-
- finished(ParseEvent.Started, long, Optional<TargetGraph>) - Static method in class com.facebook.buck.parser.ParseEvent
-
- Finished(ParseEvent.Started, long, Optional<TargetGraph>) - Constructor for class com.facebook.buck.parser.ParseEvent.Finished
-
- Finished(CasBlobDownloadEvent.Started) - Constructor for class com.facebook.buck.remoteexecution.event.CasBlobDownloadEvent.Finished
-
- finished(RemoteExecutionSessionEvent.Started) - Static method in class com.facebook.buck.remoteexecution.event.RemoteExecutionSessionEvent
-
- finished(StepEvent.Started, int) - Static method in class com.facebook.buck.step.StepEvent
-
- Finished(StepEvent.Started, int) - Constructor for class com.facebook.buck.step.StepEvent.Finished
-
- finished(Set<String>, ExitCode) - Static method in class com.facebook.buck.test.external.ExternalTestRunEvent
-
- Finished(int, ExitCode) - Constructor for class com.facebook.buck.test.external.ExternalTestRunEvent.Finished
-
- finished(BuildTarget) - Static method in class com.facebook.buck.test.external.ExternalTestSpecCalculationEvent
-
- Finished(BuildTarget) - Constructor for class com.facebook.buck.test.external.ExternalTestSpecCalculationEvent.Finished
-
- finished(BuildTarget) - Static method in class com.facebook.buck.test.TestRuleEvent
-
- Finished(BuildTarget) - Constructor for class com.facebook.buck.test.TestRuleEvent.Finished
-
- finished(VersionedTargetGraphEvent.Started) - Static method in class com.facebook.buck.versions.VersionedTargetGraphEvent
-
- finishExoFileInstallation(ImmutableSortedSet<Path>, ExopackageInfo) - Method in class com.facebook.buck.android.exopackage.ExopackageInstaller
-
- finishModuleCreation() - Method in class com.facebook.buck.features.project.intellij.aggregation.AggregationContext
-
- FirstOrderDepsFunction() - Constructor for class com.facebook.buck.query.DepsFunction.FirstOrderDepsFunction
-
- FirstOrderHelper - Class in com.facebook.buck.android.dalvik.firstorder
-
- FixBuckConfig - Class in com.facebook.buck.support.fix
-
Configuration that handles how `buck fix` and automatic invocations of fix scripts work
- FixBuckConfig() - Constructor for class com.facebook.buck.support.fix.FixBuckConfig
-
- FixCommand - Class in com.facebook.buck.cli
-
Attempts to fix errors encountered in previous builds
- FixCommand() - Constructor for class com.facebook.buck.cli.FixCommand
-
- FixCommandHandler - Class in com.facebook.buck.cli
-
Encapsulates the logic around running `buck fix`.
- fixedDelegate(NativeLinkableInput, ImmutableMap<String, SourcePath>) - Static method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableInfo
-
Creates a delegate that always returns a fixed instance.
- fixPath(Path) - Static method in class com.facebook.buck.io.file.MorePaths
-
Drop any "." parts (useless).
- fixupSourcePath(ActionGraphBuilder, CxxPlatform, SourcePath) - Static method in class com.facebook.buck.cxx.CxxGenruleDescription
-
- fixupSourcePaths(ActionGraphBuilder, CxxPlatform, ImmutableList<SourcePath>) - Static method in class com.facebook.buck.cxx.CxxGenruleDescription
-
- fixupSourcePaths(ActionGraphBuilder, CxxPlatform, ImmutableSortedSet<SourcePath>) - Static method in class com.facebook.buck.cxx.CxxGenruleDescription
-
- fixupSourcePaths(ActionGraphBuilder, CxxPlatform, ImmutableMap<T, SourcePath>) - Static method in class com.facebook.buck.cxx.CxxGenruleDescription
-
- flags - Variable in class com.facebook.buck.cxx.toolchain.objectfile.MachoExportTrieNode.ExportInfo
-
- flags - Variable in class com.facebook.buck.features.ocaml.OcamlLinkStep
-
- flags - Variable in class com.facebook.buck.features.ocaml.OcamlNativePluginStep
-
- flagsKey - Variable in enum com.facebook.buck.cxx.toolchain.ToolType
-
Buck config key used to specify tool flags.
- flatMap(Function<? super T, ? extends Stream<? extends R>>) - Method in interface com.facebook.buck.util.stream.RichStream
-
- flattenToSpaceSeparatedString(Optional<Arg>, SourcePathResolverAdapter) - Static method in interface com.facebook.buck.rules.args.Arg
-
- FLAVOR - Static variable in class com.facebook.buck.apple.AppleAssetCatalog
-
- FLAVOR - Static variable in class com.facebook.buck.apple.CoreDataModel
-
- FLAVOR - Static variable in class com.facebook.buck.apple.SceneKitAssets
-
- Flavor - Interface in com.facebook.buck.core.model
-
- FLAVOR - Static variable in class com.facebook.buck.cxx.CxxPrefixHeader
-
- FLAVOR - Static variable in class com.facebook.buck.cxx.toolchain.impl.DefaultCxxPlatforms
-
- FLAVOR_DELIMITER - Static variable in class com.facebook.buck.core.parser.buildtargetpattern.BuildTargetLanguageConstants
-
Symbol that delimits flavors specified after FLAVOR_SYMBOL
- FLAVOR_DOMAIN - Static variable in enum com.facebook.buck.apple.AppleDebugFormat
-
- FLAVOR_DOMAIN - Static variable in enum com.facebook.buck.cxx.toolchain.LinkerMapMode
-
- FLAVOR_DOMAIN - Static variable in enum com.facebook.buck.cxx.toolchain.StripStyle
-
- FLAVOR_DOMAIN_NAME - Static variable in class com.facebook.buck.features.lua.LuaPlatform
-
- FLAVOR_ORDERING - Static variable in class com.facebook.buck.core.model.FlavorSet
-
Flavors passed to this object should be sorted using this ordering
- FLAVOR_SYMBOL - Static variable in class com.facebook.buck.core.parser.buildtargetpattern.BuildTargetLanguageConstants
-
Symbol that represents flavor part of a build target
- FLAVOR_VALUES - Static variable in enum com.facebook.buck.features.haskell.HaskellLibraryDescription.Type
-
- FlavorConvertible - Interface in com.facebook.buck.core.model
-
Values that has a canonical mapping to flavors.
- FlavorDomain<T> - Class in com.facebook.buck.core.model
-
Provides a named flavor abstraction on top of boolean flavors.
- FlavorDomain(String, ImmutableMap<Flavor, T>) - Constructor for class com.facebook.buck.core.model.FlavorDomain
-
- FlavorDomainException - Exception in com.facebook.buck.core.model
-
- FlavorDomainException(String) - Constructor for exception com.facebook.buck.core.model.FlavorDomainException
-
- flavorDomains(TargetConfiguration) - Method in class com.facebook.buck.apple.AppleBinaryDescription
-
- flavorDomains(TargetConfiguration) - Method in class com.facebook.buck.apple.AppleBundleDescription
-
- flavorDomains(TargetConfiguration) - Method in class com.facebook.buck.apple.AppleLibraryDescription
-
- flavorDomains(TargetConfiguration) - Method in class com.facebook.buck.apple.ApplePackageDescription
-
- flavorDomains(TargetConfiguration) - Method in class com.facebook.buck.apple.AppleTestDescription
-
- flavorDomains(TargetConfiguration) - Method in class com.facebook.buck.apple.PrebuiltAppleFrameworkDescription
-
- flavorDomains(TargetConfiguration) - Method in interface com.facebook.buck.core.model.Flavored
-
- flavorDomains(TargetConfiguration) - Method in class com.facebook.buck.cxx.CxxBinaryDescription
-
- flavorDomains(TargetConfiguration) - Method in class com.facebook.buck.cxx.CxxBinaryFlavored
-
- flavorDomains(TargetConfiguration) - Method in class com.facebook.buck.cxx.CxxLibraryDescription
-
- flavorDomains(TargetConfiguration) - Method in class com.facebook.buck.cxx.CxxLibraryFlavored
-
- flavorDomains(TargetConfiguration) - Method in class com.facebook.buck.features.js.JsBundleDescription
-
- flavorDomains(TargetConfiguration) - Method in class com.facebook.buck.features.js.JsBundleGenruleDescription
-
- flavorDomains(TargetConfiguration) - Method in class com.facebook.buck.features.js.JsLibraryDescription
-
- flavorDomains(TargetConfiguration) - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescription
-
- flavorDomains(TargetConfiguration) - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescription
-
- flavorDomains(TargetConfiguration) - Method in class com.facebook.buck.features.python.PrebuiltPythonLibraryDescription
-
- flavorDomains(TargetConfiguration) - Method in class com.facebook.buck.features.python.PythonLibraryDescription
-
- flavorDomains(TargetConfiguration) - Method in class com.facebook.buck.features.rust.RustBinaryDescription
-
- flavorDomains(TargetConfiguration) - Method in class com.facebook.buck.features.rust.RustLibraryDescription
-
- flavorDomains(TargetConfiguration) - Method in class com.facebook.buck.features.rust.RustTestDescription
-
- flavorDomains(TargetConfiguration) - Method in class com.facebook.buck.swift.SwiftLibraryDescription
-
- Flavored - Interface in com.facebook.buck.core.model
-
- flavorForLinkableDepType(Linker.LinkableDepType) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- Flavors - Class in com.facebook.buck.apple
-
- flavorsDoNotAllowLinkerMapMode(BuildTarget) - Static method in class com.facebook.buck.apple.AppleDescriptions
-
- FlavorSet - Class in com.facebook.buck.core.model
-
- FlavorTypeCoercer - Class in com.facebook.buck.rules.coercer
-
- FlavorTypeCoercer() - Constructor for class com.facebook.buck.rules.coercer.FlavorTypeCoercer
-
- FLOAT - Static variable in class com.facebook.buck.rules.keys.hasher.RuleKeyHasherTypes
-
- flush() - Method in class com.facebook.buck.cli.bootstrapper.CompressingFileHandler
-
- flush() - Method in class com.facebook.buck.cli.bootstrapper.ConsoleHandler
-
- flush() - Method in class com.facebook.buck.cli.bootstrapper.LogFileHandler
-
- flush() - Method in class com.facebook.buck.cli.bootstrapper.MemoryHandler
-
- flush() - Method in class com.facebook.buck.counters.Counter
-
If the counter has no data, returns an absent value.
- flush() - Method in class com.facebook.buck.counters.IntegerCounter
-
- flush() - Method in class com.facebook.buck.counters.SamplingCounter
-
- flush() - Method in class com.facebook.buck.counters.TagSetCounter
-
- flush() - Method in class com.facebook.buck.log.AsyncLogHandler
-
- flush() - Method in class com.facebook.buck.log.ConsoleHandler
-
- flush() - Method in interface com.facebook.buck.log.ConsoleHandlerState.Writer
-
- flush() - Method in class com.facebook.buck.log.LogFileHandler
-
- flush() - Method in class com.facebook.buck.log.LogFileHandlerDispatcher
-
- flush() - Method in class com.facebook.buck.log.memory.MemoryHandler
-
- flush() - Method in class com.facebook.buck.log.ReferenceCountedWriter
-
- flush() - Method in class com.facebook.buck.util.TeeOutputStream
-
- FlushConsoleEvent - Class in com.facebook.buck.event
-
Event to tell the console that it needs to flush now.
- FlushConsoleEvent() - Constructor for class com.facebook.buck.event.FlushConsoleEvent
-
- flushLogs() - Static method in class com.facebook.buck.log.LogConfig
-
- flushToFile() - Method in class com.facebook.buck.maven.Pom
-
- flushToLogger() - Method in class com.facebook.buck.rules.keys.hasher.ThriftRuleKeyHasher
-
Writes the object out to the logger
- FocusedModuleTargetMatcher - Class in com.facebook.buck.features.apple.project
-
- focusedOn(ImmutableSet<UnflavoredBuildTarget>) - Static method in class com.facebook.buck.features.apple.project.FocusedModuleTargetMatcher
-
Returns a matcher that specifies a set of targets to focus on.
- FocusedTargetMatcher - Class in com.facebook.buck.features.apple.projectV2
-
Matcher class that matches build targets against specific focused target entries.
- FocusedTargetMatcher(String, CellNameResolver) - Constructor for class com.facebook.buck.features.apple.projectV2.FocusedTargetMatcher
-
Returns a matcher configured to match any Build Target Patterns or String Regular Expressions.
- FOLDER_IJ_NAME - Static variable in class com.facebook.buck.features.project.intellij.model.folders.ExcludeFolder
-
- FolderTypeWithPackageInfo - Enum in com.facebook.buck.features.project.intellij
-
- forAllData(MerkleTreeNodeCache.MerkleTreeNode, Consumer<MerkleTreeNodeCache.NodeData>) - Method in class com.facebook.buck.remoteexecution.util.MerkleTreeNodeCache
-
Iterate over all the encoded data for the tree rooted at the provided node.
- forAllData(Consumer<InputsMapBuilder.Data>) - Method in class com.facebook.buck.rules.modern.impl.InputsMapBuilder.Data
-
- forAllFiles(BiConsumer<Path, Protocol.FileNode>) - Method in class com.facebook.buck.remoteexecution.util.MerkleTreeNodeCache.MerkleTreeNode
-
Iterate over the files in the tree rooted at this node.
- forAllNodes(Consumer<MerkleTreeNodeCache.MerkleTreeNode>) - Method in class com.facebook.buck.remoteexecution.util.MerkleTreeNodeCache.MerkleTreeNode
-
Iterate over the nodes in the tree rooted at this node.
- FORCE_JS_BUNDLE - Static variable in class com.facebook.buck.features.js.JsFlavors
-
- forceFlush() - Method in class com.facebook.buck.util.network.AbstractBatchingLogger
-
- forceFlush() - Method in interface com.facebook.buck.util.network.BatchingLogger
-
Signals to upload whatever remaining information is buffered.
- forcefullyCreateDirs(Path) - Method in class com.facebook.buck.util.unarchive.DirectoryCreator
-
Force a directory to be created.
- forceLinkWholeForHaskellOmnibus() - Method in class com.facebook.buck.cxx.CxxLibraryGroup
-
- forceLinkWholeForHaskellOmnibus() - Method in interface com.facebook.buck.cxx.toolchain.nativelink.LegacyNativeLinkableGroup
-
Deprecated.
- forceLinkWholeForHaskellOmnibus() - Method in interface com.facebook.buck.cxx.toolchain.nativelink.NativeLinkable
-
- forceLinkWholeForHaskellOmnibus() - Method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableInfo
-
- forceLinkWholeForHaskellOmnibus() - Method in class com.facebook.buck.cxx.toolchain.nativelink.PlatformLockedNativeLinkableGroup
-
- forceRender(FlushConsoleEvent) - Method in class com.facebook.buck.event.listener.SuperConsoleEventBusListener
-
- forceTty() - Static method in class com.facebook.buck.util.Ansi
-
- forDirectory(ProjectFilesystem, Path, Path, CopyStep.DirectoryMode) - Static method in class com.facebook.buck.step.fs.CopyStep
-
Creates a CopyStep which recursively copies a directory from 'source' to 'destination'.
- forEach(Consumer<N>) - Method in class com.facebook.buck.core.util.graph.ConsumingTraverser
-
- forEach(CxxPlatform, Consumer<BuildTarget>) - Method in class com.facebook.buck.cxx.CxxDeps
-
- forEachForAllPlatforms(Consumer<BuildTarget>) - Method in class com.facebook.buck.cxx.CxxDeps
-
- forEachFwdDep(Iterable<NODE_TYPE>, Consumer<NODE_TYPE>) - Method in interface com.facebook.buck.query.QueryEnvironment
-
Applies action
to each forward dependencies of the specified targets.
- forEachFwdDep(Iterable<QueryBuildTarget>, Consumer<QueryBuildTarget>) - Method in class com.facebook.buck.rules.query.GraphEnhancementQueryEnvironment
-
- forEachInput(Consumer<SourcePath>) - Method in interface com.facebook.buck.features.python.PythonComponents
-
Run
consumer
on all
SourcePath
s contained in this object.
- forEachInput(Consumer<SourcePath>) - Method in class com.facebook.buck.features.python.PythonMappedComponents
-
- forEachInput(Consumer<SourcePath>) - Method in class com.facebook.buck.features.python.PythonPackageComponents
-
- forEachMatchingValue(String, Consumer<T>) - Method in class com.facebook.buck.rules.coercer.PatternMatchedCollection
-
Apply
consumer
to all values whose
Pattern
matches
string
.
- forEachModule(BuildTarget, ActionGraphBuilder, PythonPlatform, CxxPlatform, String, Path, SourceSortedSet, PatternMatchedCollection<SourceSortedSet>, Optional<VersionMatchedCollection<SourceSortedSet>>, Optional<ImmutableMap<BuildTarget, Version>>, BiConsumer<Path, SourcePath>) - Static method in class com.facebook.buck.features.python.PythonUtil
-
- forEachOrderedThrowing(ThrowingConsumer<? super T, E>) - Method in interface com.facebook.buck.util.stream.RichStream
-
A variant of Stream.forEachOrdered(java.util.function.Consumer<? super T>)
that can safely throw a checked exception.
- forEachPair(Iterable<L>, Iterable<R>, BiConsumer<? super L, ? super R>) - Static method in class com.facebook.buck.util.MoreIterables
-
Provides convenient consumption of a pair of Iterables of the same length.
- forEachPythonComponent(PythonComponents.Resolved.ComponentConsumer) - Method in interface com.facebook.buck.features.python.PythonComponents.Resolved
-
- forEachPythonComponent(PythonComponents.Resolved.ComponentConsumer) - Method in class com.facebook.buck.features.python.PythonMappedComponents.Resolved
-
- forEachSrc(BuildTarget, ActionGraphBuilder, PythonPlatform, CxxPlatform, Optional<ImmutableMap<BuildTarget, Version>>, PythonLibraryDescription.CoreArg, BiConsumer<Path, SourcePath>) - Static method in class com.facebook.buck.features.python.PythonUtil
-
- forEachSuccessor(N, Consumer<N>) - Method in interface com.facebook.buck.core.util.graph.ForEachSuccessorFunction
-
Runs consumer
on all nodes in this graph adjacent to node which can be reached by
traversing node's outgoing edges in the direction (if any) of the edge.
- ForEachSuccessorFunction<N> - Interface in com.facebook.buck.core.util.graph
-
A
Consumer
-based interface for graph operations/traversals (based on Guava's
`SuccessorsFunction`).
- forEachSymlink(SymlinkPaths.SymlinkConsumer) - Method in class com.facebook.buck.step.fs.SymlinkDirPaths
-
- forEachSymlink(SymlinkPaths.SymlinkConsumer) - Method in class com.facebook.buck.step.fs.SymlinkMapsPaths
-
- forEachSymlink(SymlinkPaths.SymlinkConsumer) - Method in class com.facebook.buck.step.fs.SymlinkPackPaths
-
- forEachSymlink(SymlinkPaths.SymlinkConsumer) - Method in interface com.facebook.buck.step.fs.SymlinkPaths
-
Run consumer
on all links.
- forEachSymlinkBuildDep(SourcePathRuleFinder, Consumer<BuildRule>) - Method in class com.facebook.buck.core.rules.impl.SymlinkDir
-
- forEachSymlinkBuildDep(SourcePathRuleFinder, Consumer<BuildRule>) - Method in class com.facebook.buck.core.rules.impl.SymlinkMap
-
- forEachSymlinkBuildDep(SourcePathRuleFinder, Consumer<BuildRule>) - Method in class com.facebook.buck.core.rules.impl.SymlinkPack
-
- forEachSymlinkBuildDep(SourcePathRuleFinder, Consumer<BuildRule>) - Method in interface com.facebook.buck.core.rules.impl.Symlinks
-
Run
consumer
on all
BuildRule
build dependencies for this group of symlinks.
- forEachSymlinkInput(Consumer<SourcePath>) - Method in class com.facebook.buck.core.rules.impl.SymlinkDir
-
- forEachSymlinkInput(Consumer<SourcePath>) - Method in class com.facebook.buck.core.rules.impl.SymlinkMap
-
- forEachSymlinkInput(Consumer<SourcePath>) - Method in class com.facebook.buck.core.rules.impl.SymlinkPack
-
- forEachSymlinkInput(Consumer<SourcePath>) - Method in interface com.facebook.buck.core.rules.impl.Symlinks
-
Run
consumer
on all
SourcePath
s in this groups of links.
- forEachThrowing(ThrowingConsumer<N, E>) - Method in class com.facebook.buck.core.util.graph.ConsumingTraverser
-
- forEachThrowing(ThrowingConsumer<? super T, E>) - Method in interface com.facebook.buck.util.stream.RichStream
-
A variant of Stream.forEach(java.util.function.Consumer<? super T>)
that can safely throw a checked exception.
- forEachValue(Consumer<T>) - Method in class com.facebook.buck.rules.coercer.PatternMatchedCollection
-
Apply consumer
to all values.
- forFile(ProjectFilesystem, Path, Path) - Static method in class com.facebook.buck.step.fs.CopyStep
-
Creates a CopyStep which copies a single file from 'source' to 'destination'.
- forInstance(T) - Static method in class com.facebook.buck.rules.modern.impl.DefaultClassInfoFactory
-
Returns the ClassInfo for the object based on its runtime type.
- forkJoinPoolWithThreadLimit(int, int) - Static method in class com.facebook.buck.util.concurrent.MostExecutors
-
Construct a ForkJoinPool with a stricter thread limit.
- ForkMode - Enum in com.facebook.buck.jvm.java
-
- forkMode() - Method in class com.facebook.buck.jvm.java.JavaTest
-
- format(LogRecord) - Method in class com.facebook.buck.cli.bootstrapper.LogFormatter
-
- format(Diagnostic<? extends JavaFileObject>) - Static method in class com.facebook.buck.jvm.java.DiagnosticPrettyPrinter
-
- format(LogRecord) - Method in class com.facebook.buck.log.LogFormatter
-
- format(Function<? super MacroContainer, ? extends CharSequence>) - Method in class com.facebook.buck.rules.macros.StringWithMacros
-
- format(String) - Method in enum com.facebook.buck.support.cli.config.JsonAttributeFormat
-
Returns a formatted rule attribute
- format(LogRecord) - Method in class com.facebook.buck.testrunner.JulLogFormatter
-
- format(String, Object...) - Method in class com.facebook.buck.util.DirtyPrintStreamDecorator
-
- format(Locale, String, Object...) - Method in class com.facebook.buck.util.DirtyPrintStreamDecorator
-
- format(Locale, double) - Method in class com.facebook.buck.util.i18n.NumberFormatter
-
- format(Locale, double, StringBuffer, FieldPosition) - Method in class com.facebook.buck.util.i18n.NumberFormatter
-
- format(Locale, long) - Method in class com.facebook.buck.util.i18n.NumberFormatter
-
- format(Locale, Object) - Method in class com.facebook.buck.util.i18n.NumberFormatter
-
- format(Locale, Object, StringBuffer, FieldPosition) - Method in class com.facebook.buck.util.i18n.NumberFormatter
-
- format(String, Object...) - Method in class com.facebook.buck.util.ThrowingPrintWriter
-
- FORMAT_SESSION_ID_VARIABLE_STRING - Static variable in class com.facebook.buck.remoteexecution.config.RemoteExecutionConfig
-
The variable identifier string to be replace in any configured format defined by
DEBUG_FORMAT_STRING_URL_KEY.
- FormatArg - Class in com.facebook.buck.rules.args
-
- FormatArg() - Constructor for class com.facebook.buck.rules.args.FormatArg
-
- formatConfigChange(Map.Entry<String, ConfigDifference.ConfigChange>, boolean) - Static method in class com.facebook.buck.command.config.ConfigDifference
-
Format a single config change
- formatConfigDiff(Map<String, ConfigDifference.ConfigChange>) - Static method in class com.facebook.buck.command.config.ConfigDifference
-
Format the full set of changes between configs to be logged
- formatConfigDiffShort(Map<String, ConfigDifference.ConfigChange>, int) - Static method in class com.facebook.buck.command.config.ConfigDifference
-
Format a set of changes between configs for the console
- formatConsoleEvent(ConsoleEvent) - Method in class com.facebook.buck.event.listener.AbstractConsoleEventBusListener
-
- formatConsoleEvent(ConsoleEvent, Ansi) - Static method in class com.facebook.buck.util.console.ConsoleUtils
-
- formatElapsedTime(long) - Method in class com.facebook.buck.event.listener.AbstractConsoleEventBusListener
-
- formatElapsedTime(long) - Method in class com.facebook.buck.event.listener.SuperConsoleEventBusListener
-
- formatForConsole(Locale, long, Ansi) - Static method in class com.facebook.buck.util.TimeFormat
-
- forModuleMapMode(ModuleMapMode) - Static method in enum com.facebook.buck.cxx.toolchain.HeaderMode
-
Returns the appropriate header mode for module map mode.
- forPath(Path) - Static method in class com.facebook.buck.android.DefaultAndroidManifestReader
-
- forString(String) - Static method in class com.facebook.buck.android.DefaultAndroidManifestReader
-
- forTypeToken(TypeToken<T>) - Static method in class com.facebook.buck.rules.modern.impl.ValueTypeInfoFactory
-
- forVisibilityArgument() - Static method in class com.facebook.buck.core.parser.buildtargetparser.BuildTargetMatcherParser
-
Used when parsing target names in the visibility
argument to a build rule.
- ForwardingBuildTargetSourcePath - Class in com.facebook.buck.core.sourcepath
-
- ForwardingBuildTargetSourcePath() - Constructor for class com.facebook.buck.core.sourcepath.ForwardingBuildTargetSourcePath
-
- ForwardingProcessListener - Class in com.facebook.buck.util
-
- ForwardingProcessListener(OutputStream, OutputStream) - Constructor for class com.facebook.buck.util.ForwardingProcessListener
-
- ForwardingProjectBuildFileParserDecorator - Class in com.facebook.buck.parser.api
-
- ForwardingProjectBuildFileParserDecorator(ProjectBuildFileParser) - Constructor for class com.facebook.buck.parser.api.ForwardingProjectBuildFileParserDecorator
-
- ForwardingRuleKeyHasher<HASH,HASH2> - Class in com.facebook.buck.rules.keys.hasher
-
A
RuleKeyHasher
that forwards all the methods to the two underlying hashers.
- ForwardingRuleKeyHasher(RuleKeyHasher<HASH>, RuleKeyHasher<HASH2>) - Constructor for class com.facebook.buck.rules.keys.hasher.ForwardingRuleKeyHasher
-
- ForwardingStandardJavaFileManager - Class in com.facebook.buck.jvm.java
-
- ForwardingStandardJavaFileManager(StandardJavaFileManager) - Constructor for class com.facebook.buck.jvm.java.ForwardingStandardJavaFileManager
-
- ForwardRelativePath - Class in com.facebook.buck.core.path
-
A normalized relative path object which:
Does not contain dot or dot-dot
Does not start and does not end with slash
Does not contain slash-slash
- fragmentToPath(PathFragment) - Static method in class com.facebook.buck.util.filesystem.PathFragments
-
Convert a skylark PathFragment to a Path using the default filesystem.
- fragmentToPath(FileSystem, PathFragment) - Static method in class com.facebook.buck.util.filesystem.PathFragments
-
Convert a skylark PathFragment to a Path.
- FRAMEWORK - Static variable in class com.facebook.buck.apple.xcode.xcodeproj.ProductTypes
-
- FRAMEWORK_CURRENT_PROJECT - Static variable in enum com.facebook.buck.features.apple.project.ProjectGenerator.FilterFlags
-
Filter framework deps *
- FRAMEWORK_FLAVOR - Static variable in class com.facebook.buck.apple.AppleDescriptions
-
- FRAMEWORK_FOCUSED - Static variable in enum com.facebook.buck.features.apple.project.ProjectGenerator.FilterFlags
-
- FRAMEWORK_OTHER - Static variable in enum com.facebook.buck.features.apple.project.ProjectGenerator.FilterFlags
-
- FrameworkDependencies - Class in com.facebook.buck.cxx
-
Metadata query for collecting framework dependencies to include in a bundle.
- FrameworkDependencies() - Constructor for class com.facebook.buck.cxx.FrameworkDependencies
-
- FrameworkPath - Class in com.facebook.buck.rules.coercer
-
Frameworks can be specified as either a path to a file, or a path prefixed by a build setting.
- FrameworkPath() - Constructor for class com.facebook.buck.rules.coercer.FrameworkPath
-
- FrameworkPath.Type - Enum in com.facebook.buck.rules.coercer
-
The type of framework entry this object represents.
- frameworkPathToSearchPath(CxxPlatform, SourcePathResolverAdapter) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- FrameworkPathTypeCoercer - Class in com.facebook.buck.rules.coercer
-
- FrameworkPathTypeCoercer(TypeCoercer<UnconfiguredSourcePath, SourcePath>) - Constructor for class com.facebook.buck.rules.coercer.FrameworkPathTypeCoercer
-
- FrameworkVersion - Enum in com.facebook.buck.features.dotnet
-
- from(String) - Static method in enum com.facebook.buck.android.aapt.RDotTxtEntry.IdType
-
- from(AndroidLibraryDescription.CoreArg) - Method in class com.facebook.buck.android.AndroidAarDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.android.AndroidLibraryDescription.CoreArg
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.android.AndroidAarDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasDepsQuery) - Method in class com.facebook.buck.android.AndroidAarDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDepsQuery
instance.
- from(AndroidKotlinCoreArg) - Method in class com.facebook.buck.android.AndroidAarDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.android.AndroidKotlinCoreArg
instance.
- from(HasSrcs) - Method in class com.facebook.buck.android.AndroidAarDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasSrcs
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.android.AndroidAarDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(MaybeRequiredForSourceOnlyAbiArg) - Method in class com.facebook.buck.android.AndroidAarDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.MaybeRequiredForSourceOnlyAbiArg
instance.
- from(HasProvidedDeps) - Method in class com.facebook.buck.android.AndroidAarDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasProvidedDeps
instance.
- from(JavaLibraryDescription.CoreArg) - Method in class com.facebook.buck.android.AndroidAarDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JavaLibraryDescription.CoreArg
instance.
- from(HasProvidedDepsQuery) - Method in class com.facebook.buck.android.AndroidAarDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasProvidedDepsQuery
instance.
- from(HasTests) - Method in class com.facebook.buck.android.AndroidAarDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(AndroidAarDescriptionArg) - Method in class com.facebook.buck.android.AndroidAarDescriptionArg.Builder
-
Fill a builder with attribute values from the provided AndroidAarDescriptionArg
instance.
- from(AndroidAarDescription.AbstractAndroidAarDescriptionArg) - Method in class com.facebook.buck.android.AndroidAarDescriptionArg.Builder
-
Copy abstract value type AbstractAndroidAarDescriptionArg
instance into builder.
- from(JvmLibraryArg) - Method in class com.facebook.buck.android.AndroidAarDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JvmLibraryArg
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.android.AndroidAarDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(KotlinLibraryDescription.CoreArg) - Method in class com.facebook.buck.android.AndroidAarDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.kotlin.KotlinLibraryDescription.CoreArg
instance.
- from(HasApplicationModuleBlacklist) - Method in class com.facebook.buck.android.AndroidAppModularityDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasApplicationModuleBlacklist
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.android.AndroidAppModularityDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.android.AndroidAppModularityDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.android.AndroidAppModularityDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(AndroidAppModularityDescriptionArg) - Method in class com.facebook.buck.android.AndroidAppModularityDescriptionArg.Builder
-
Fill a builder with attribute values from the provided AndroidAppModularityDescriptionArg
instance.
- from(AndroidAppModularityDescription.AbstractAndroidAppModularityDescriptionArg) - Method in class com.facebook.buck.android.AndroidAppModularityDescriptionArg.Builder
-
Copy abstract value type AbstractAndroidAppModularityDescriptionArg
instance into builder.
- from(HasApplicationModuleBlacklist) - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasApplicationModuleBlacklist
instance.
- from(AndroidGraphEnhancerArgs) - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.android.AndroidGraphEnhancerArgs
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasTests) - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(AndroidBinaryDescriptionArg) - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided AndroidBinaryDescriptionArg
instance.
- from(AndroidBinaryDescription.AbstractAndroidBinaryDescriptionArg) - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg.Builder
-
Copy abstract value type AbstractAndroidBinaryDescriptionArg
instance into builder.
- from(HasExopackageArgs) - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.android.HasExopackageArgs
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasDuplicateAndroidResourceTypes) - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.android.HasDuplicateAndroidResourceTypes
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(AndroidBuildConfigDescriptionArg) - Method in class com.facebook.buck.android.AndroidBuildConfigDescriptionArg.Builder
-
Fill a builder with attribute values from the provided AndroidBuildConfigDescriptionArg
instance.
- from(AndroidBuildConfigDescription.AbstractAndroidBuildConfigDescriptionArg) - Method in class com.facebook.buck.android.AndroidBuildConfigDescriptionArg.Builder
-
Copy abstract value type AbstractAndroidBuildConfigDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.android.AndroidBuildConfigDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.android.AndroidBuildConfigDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(HasApplicationModuleBlacklist) - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasApplicationModuleBlacklist
instance.
- from(AndroidGraphEnhancerArgs) - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.android.AndroidGraphEnhancerArgs
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasTests) - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(AndroidBundleDescriptionArg) - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided AndroidBundleDescriptionArg
instance.
- from(AndroidBundleDescription.AbstractAndroidBundleDescriptionArg) - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg.Builder
-
Copy abstract value type AbstractAndroidBundleDescriptionArg
instance into builder.
- from(HasExopackageArgs) - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.android.HasExopackageArgs
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasDuplicateAndroidResourceTypes) - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.android.HasDuplicateAndroidResourceTypes
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.android.AndroidInstrumentationApkDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.android.AndroidInstrumentationApkDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(AndroidInstrumentationApkDescriptionArg) - Method in class com.facebook.buck.android.AndroidInstrumentationApkDescriptionArg.Builder
-
Fill a builder with attribute values from the provided AndroidInstrumentationApkDescriptionArg
instance.
- from(AndroidInstrumentationApkDescription.AbstractAndroidInstrumentationApkDescriptionArg) - Method in class com.facebook.buck.android.AndroidInstrumentationApkDescriptionArg.Builder
-
Copy abstract value type AbstractAndroidInstrumentationApkDescriptionArg
instance into builder.
- from(ConstructorArg) - Method in class com.facebook.buck.android.AndroidInstrumentationApkDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(HasTestTimeout) - Method in class com.facebook.buck.android.AndroidInstrumentationTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTestTimeout
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.android.AndroidInstrumentationTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasContacts) - Method in class com.facebook.buck.android.AndroidInstrumentationTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasContacts
instance.
- from(AndroidInstrumentationTestDescriptionArg) - Method in class com.facebook.buck.android.AndroidInstrumentationTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided AndroidInstrumentationTestDescriptionArg
instance.
- from(AndroidInstrumentationTestDescription.AbstractAndroidInstrumentationTestDescriptionArg) - Method in class com.facebook.buck.android.AndroidInstrumentationTestDescriptionArg.Builder
-
Copy abstract value type AbstractAndroidInstrumentationTestDescriptionArg
instance into builder.
- from(ConstructorArg) - Method in class com.facebook.buck.android.AndroidInstrumentationTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(AndroidLibraryDescription.CoreArg) - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.android.AndroidLibraryDescription.CoreArg
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasDepsQuery) - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDepsQuery
instance.
- from(AndroidKotlinCoreArg) - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.android.AndroidKotlinCoreArg
instance.
- from(HasSrcs) - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasSrcs
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(MaybeRequiredForSourceOnlyAbiArg) - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.MaybeRequiredForSourceOnlyAbiArg
instance.
- from(HasProvidedDeps) - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasProvidedDeps
instance.
- from(JavaLibraryDescription.CoreArg) - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JavaLibraryDescription.CoreArg
instance.
- from(HasProvidedDepsQuery) - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasProvidedDepsQuery
instance.
- from(HasTests) - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(JvmLibraryArg) - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JvmLibraryArg
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(KotlinLibraryDescription.CoreArg) - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.kotlin.KotlinLibraryDescription.CoreArg
instance.
- from(AndroidLibraryDescriptionArg) - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided AndroidLibraryDescriptionArg
instance.
- from(AndroidLibraryDescription.AbstractAndroidLibraryDescriptionArg) - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg.Builder
-
Copy abstract value type AbstractAndroidLibraryDescriptionArg
instance into builder.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.android.AndroidManifestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(AndroidManifestDescriptionArg) - Method in class com.facebook.buck.android.AndroidManifestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided AndroidManifestDescriptionArg
instance.
- from(AndroidManifestDescription.AbstractAndroidManifestDescriptionArg) - Method in class com.facebook.buck.android.AndroidManifestDescriptionArg.Builder
-
Copy abstract value type AbstractAndroidManifestDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.android.AndroidManifestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.android.AndroidManifestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(AndroidPrebuiltAarDescriptionArg) - Method in class com.facebook.buck.android.AndroidPrebuiltAarDescriptionArg.Builder
-
Fill a builder with attribute values from the provided AndroidPrebuiltAarDescriptionArg
instance.
- from(AndroidPrebuiltAarDescription.AbstractAndroidPrebuiltAarDescriptionArg) - Method in class com.facebook.buck.android.AndroidPrebuiltAarDescriptionArg.Builder
-
Copy abstract value type AbstractAndroidPrebuiltAarDescriptionArg
instance into builder.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.android.AndroidPrebuiltAarDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.android.AndroidPrebuiltAarDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.android.AndroidPrebuiltAarDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(MaybeRequiredForSourceOnlyAbiArg) - Method in class com.facebook.buck.android.AndroidPrebuiltAarDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.MaybeRequiredForSourceOnlyAbiArg
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.android.AndroidResourceDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(AndroidResourceDescriptionArg) - Method in class com.facebook.buck.android.AndroidResourceDescriptionArg.Builder
-
Fill a builder with attribute values from the provided AndroidResourceDescriptionArg
instance.
- from(AndroidResourceDescription.AbstractAndroidResourceDescriptionArg) - Method in class com.facebook.buck.android.AndroidResourceDescriptionArg.Builder
-
Copy abstract value type AbstractAndroidResourceDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.android.AndroidResourceDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.android.AndroidResourceDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(ApkGenruleDescriptionArg) - Method in class com.facebook.buck.android.ApkGenruleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided ApkGenruleDescriptionArg
instance.
- from(ApkGenruleDescription.AbstractApkGenruleDescriptionArg) - Method in class com.facebook.buck.android.ApkGenruleDescriptionArg.Builder
-
Copy abstract value type AbstractApkGenruleDescriptionArg
instance into builder.
- from(HasTests) - Method in class com.facebook.buck.android.ApkGenruleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(AbstractGenruleDescription.CommonArg) - Method in class com.facebook.buck.android.ApkGenruleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.shell.AbstractGenruleDescription.CommonArg
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.android.ApkGenruleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.android.ApkGenruleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(GenAidlDescriptionArg) - Method in class com.facebook.buck.android.GenAidlDescriptionArg.Builder
-
Fill a builder with attribute values from the provided GenAidlDescriptionArg
instance.
- from(GenAidlDescription.AbstractGenAidlDescriptionArg) - Method in class com.facebook.buck.android.GenAidlDescriptionArg.Builder
-
Copy abstract value type AbstractGenAidlDescriptionArg
instance into builder.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.android.GenAidlDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.android.GenAidlDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.android.GenAidlDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.android.NdkLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(NdkLibraryDescriptionArg) - Method in class com.facebook.buck.android.NdkLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided NdkLibraryDescriptionArg
instance.
- from(NdkLibraryDescription.AbstractNdkLibraryDescriptionArg) - Method in class com.facebook.buck.android.NdkLibraryDescriptionArg.Builder
-
Copy abstract value type AbstractNdkLibraryDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.android.NdkLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasSrcs) - Method in class com.facebook.buck.android.NdkLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasSrcs
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.android.NdkLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(NdkToolchainDescriptionArg) - Method in class com.facebook.buck.android.NdkToolchainDescriptionArg.Builder
-
Fill a builder with attribute values from the provided NdkToolchainDescriptionArg
instance.
- from(NdkToolchainDescription.AbstractNdkToolchainDescriptionArg) - Method in class com.facebook.buck.android.NdkToolchainDescriptionArg.Builder
-
Copy abstract value type AbstractNdkToolchainDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.android.NdkToolchainDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.android.NdkToolchainDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.android.PrebuiltNativeLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.android.PrebuiltNativeLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.android.PrebuiltNativeLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(PrebuiltNativeLibraryDescriptionArg) - Method in class com.facebook.buck.android.PrebuiltNativeLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided PrebuiltNativeLibraryDescriptionArg
instance.
- from(PrebuiltNativeLibraryDescription.AbstractPrebuiltNativeLibraryDescriptionArg) - Method in class com.facebook.buck.android.PrebuiltNativeLibraryDescriptionArg.Builder
-
Copy abstract value type AbstractPrebuiltNativeLibraryDescriptionArg
instance into builder.
- from(String) - Static method in enum com.facebook.buck.android.ResourceFilters.Density
-
- from(Path) - Static method in class com.facebook.buck.android.ResourceFilters.Qualifiers
-
Creates a Qualfiers given the Path to a resource folder, pulls out the density filters and
leaves the rest.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasTestTimeout) - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTestTimeout
instance.
- from(AndroidKotlinCoreArg) - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.android.AndroidKotlinCoreArg
instance.
- from(HasSrcs) - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasSrcs
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(JavaTestDescription.CoreArg) - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JavaTestDescription.CoreArg
instance.
- from(MaybeRequiredForSourceOnlyAbiArg) - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.MaybeRequiredForSourceOnlyAbiArg
instance.
- from(RobolectricTestDescriptionArg) - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided RobolectricTestDescriptionArg
instance.
- from(RobolectricTestDescription.AbstractRobolectricTestDescriptionArg) - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg.Builder
-
Copy abstract value type AbstractRobolectricTestDescriptionArg
instance into builder.
- from(HasProvidedDeps) - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasProvidedDeps
instance.
- from(JavaLibraryDescription.CoreArg) - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JavaLibraryDescription.CoreArg
instance.
- from(HasTests) - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(JvmLibraryArg) - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JvmLibraryArg
instance.
- from(HasTestRunner) - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.test.rule.HasTestRunner
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasContacts) - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasContacts
instance.
- from(KotlinLibraryDescription.CoreArg) - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.kotlin.KotlinLibraryDescription.CoreArg
instance.
- from(AndroidPlatformArg) - Method in class com.facebook.buck.android.toolchain.platform.AndroidPlatformArg.Builder
-
Fill a builder with attribute values from the provided AndroidPlatformArg
instance.
- from(AndroidPlatformDescription.AbstractAndroidPlatformArg) - Method in class com.facebook.buck.android.toolchain.platform.AndroidPlatformArg.Builder
-
Copy abstract value type AbstractAndroidPlatformArg
instance into builder.
- from(ConstructorArg) - Method in class com.facebook.buck.android.toolchain.platform.AndroidPlatformArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(AppleAssetCatalogDescriptionArg) - Method in class com.facebook.buck.apple.AppleAssetCatalogDescriptionArg.Builder
-
Fill a builder with attribute values from the provided AppleAssetCatalogDescriptionArg
instance.
- from(AppleAssetCatalogDescription.AbstractAppleAssetCatalogDescriptionArg) - Method in class com.facebook.buck.apple.AppleAssetCatalogDescriptionArg.Builder
-
Copy abstract value type AbstractAppleAssetCatalogDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.apple.AppleAssetCatalogDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.apple.AppleAssetCatalogDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(AppleAssetCatalogsCompilationOptions) - Method in class com.facebook.buck.apple.AppleAssetCatalogsCompilationOptions.Builder
-
Fill a builder with attribute values from the provided AppleAssetCatalogsCompilationOptions
instance.
- from(AppleBinaryDescriptionArg) - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided AppleBinaryDescriptionArg
instance.
- from(AppleBinaryDescription.AbstractAppleBinaryDescriptionArg) - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg.Builder
-
Copy abstract value type AbstractAppleBinaryDescriptionArg
instance into builder.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(CxxConstructorArg) - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.CxxConstructorArg
instance.
- from(HasEntitlementsFile) - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.apple.HasEntitlementsFile
instance.
- from(HasDefaultPlatform) - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDefaultPlatform
instance.
- from(HasSystemFrameworkAndLibraries) - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.toolchain.HasSystemFrameworkAndLibraries
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(LinkableCxxConstructorArg) - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.LinkableCxxConstructorArg
instance.
- from(CxxLibraryDescription.CommonArg) - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
instance.
- from(HasTests) - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(SwiftCommonArg) - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.swift.SwiftCommonArg
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasContacts) - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasContacts
instance.
- from(AppleNativeTargetDescriptionArg) - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.apple.AppleNativeTargetDescriptionArg
instance.
- from(HasAppleBundleFields) - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.apple.HasAppleBundleFields
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasTests) - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(AppleBundleDescriptionArg) - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided AppleBundleDescriptionArg
instance.
- from(AppleBundleDescription.AbstractAppleBundleDescriptionArg) - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg.Builder
-
Copy abstract value type AbstractAppleBundleDescriptionArg
instance into builder.
- from(HasDefaultPlatform) - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDefaultPlatform
instance.
- from(HasAppleCodesignFields) - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.apple.HasAppleCodesignFields
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasContacts) - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasContacts
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(CxxConstructorArg) - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.CxxConstructorArg
instance.
- from(HasDefaultPlatform) - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDefaultPlatform
instance.
- from(HasSystemFrameworkAndLibraries) - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.toolchain.HasSystemFrameworkAndLibraries
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(LinkableCxxConstructorArg) - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.LinkableCxxConstructorArg
instance.
- from(CxxLibraryDescription.CommonArg) - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
instance.
- from(HasTests) - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(SwiftCommonArg) - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.swift.SwiftCommonArg
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasContacts) - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasContacts
instance.
- from(AppleLibraryDescriptionArg) - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided AppleLibraryDescriptionArg
instance.
- from(AppleLibraryDescription.AbstractAppleLibraryDescriptionArg) - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg.Builder
-
Copy abstract value type AbstractAppleLibraryDescriptionArg
instance into builder.
- from(AppleNativeTargetDescriptionArg) - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.apple.AppleNativeTargetDescriptionArg
instance.
- from(ImmutableSortedSet<SourceWithFlags>, SourcePathResolverAdapter) - Static method in class com.facebook.buck.apple.AppleLibrarySwiftMetadata
-
- from(ApplePackageDescriptionArg) - Method in class com.facebook.buck.apple.ApplePackageDescriptionArg.Builder
-
Fill a builder with attribute values from the provided ApplePackageDescriptionArg
instance.
- from(ApplePackageDescription.AbstractApplePackageDescriptionArg) - Method in class com.facebook.buck.apple.ApplePackageDescriptionArg.Builder
-
Copy abstract value type AbstractApplePackageDescriptionArg
instance into builder.
- from(HasDefaultPlatform) - Method in class com.facebook.buck.apple.ApplePackageDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDefaultPlatform
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.apple.ApplePackageDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.apple.ApplePackageDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(AppleResourceDescriptionArg) - Method in class com.facebook.buck.apple.AppleResourceDescriptionArg.Builder
-
Fill a builder with attribute values from the provided AppleResourceDescriptionArg
instance.
- from(AppleResourceDescription.AbstractAppleResourceDescriptionArg) - Method in class com.facebook.buck.apple.AppleResourceDescriptionArg.Builder
-
Copy abstract value type AbstractAppleResourceDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.apple.AppleResourceDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.apple.AppleResourceDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(HasAppleBundleFields) - Method in class com.facebook.buck.apple.AppleTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.apple.HasAppleBundleFields
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.apple.AppleTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasTestTimeout) - Method in class com.facebook.buck.apple.AppleTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTestTimeout
instance.
- from(CxxConstructorArg) - Method in class com.facebook.buck.apple.AppleTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.CxxConstructorArg
instance.
- from(HasEntitlementsFile) - Method in class com.facebook.buck.apple.AppleTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.apple.HasEntitlementsFile
instance.
- from(HasDefaultPlatform) - Method in class com.facebook.buck.apple.AppleTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDefaultPlatform
instance.
- from(HasAppleCodesignFields) - Method in class com.facebook.buck.apple.AppleTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.apple.HasAppleCodesignFields
instance.
- from(HasSystemFrameworkAndLibraries) - Method in class com.facebook.buck.apple.AppleTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.toolchain.HasSystemFrameworkAndLibraries
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.apple.AppleTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(AppleTestDescriptionArg) - Method in class com.facebook.buck.apple.AppleTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided AppleTestDescriptionArg
instance.
- from(AppleTestDescription.AbstractAppleTestDescriptionArg) - Method in class com.facebook.buck.apple.AppleTestDescriptionArg.Builder
-
Copy abstract value type AbstractAppleTestDescriptionArg
instance into builder.
- from(LinkableCxxConstructorArg) - Method in class com.facebook.buck.apple.AppleTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.LinkableCxxConstructorArg
instance.
- from(CxxLibraryDescription.CommonArg) - Method in class com.facebook.buck.apple.AppleTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
instance.
- from(HasTests) - Method in class com.facebook.buck.apple.AppleTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(SwiftCommonArg) - Method in class com.facebook.buck.apple.AppleTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.swift.SwiftCommonArg
instance.
- from(HasTestRunner) - Method in class com.facebook.buck.apple.AppleTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.test.rule.HasTestRunner
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.apple.AppleTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasContacts) - Method in class com.facebook.buck.apple.AppleTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasContacts
instance.
- from(AppleNativeTargetDescriptionArg) - Method in class com.facebook.buck.apple.AppleTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.apple.AppleNativeTargetDescriptionArg
instance.
- from(AppleToolchainDescriptionArg) - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg.Builder
-
Fill a builder with attribute values from the provided AppleToolchainDescriptionArg
instance.
- from(AppleToolchainDescription.AbstractAppleToolchainDescriptionArg) - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg.Builder
-
Copy abstract value type AbstractAppleToolchainDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(AppleToolchainSetDescriptionArg) - Method in class com.facebook.buck.apple.AppleToolchainSetDescriptionArg.Builder
-
Fill a builder with attribute values from the provided AppleToolchainSetDescriptionArg
instance.
- from(AppleToolchainSetDescription.AbstractAppleToolchainSetDescriptionArg) - Method in class com.facebook.buck.apple.AppleToolchainSetDescriptionArg.Builder
-
Copy abstract value type AbstractAppleToolchainSetDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.apple.AppleToolchainSetDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.apple.AppleToolchainSetDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(AppleWrapperResourceArg) - Method in class com.facebook.buck.apple.AppleWrapperResourceArg.Builder
-
Fill a builder with attribute values from the provided AppleWrapperResourceArg
instance.
- from(AbstractAppleWrapperResourceArg) - Method in class com.facebook.buck.apple.AppleWrapperResourceArg.Builder
-
Copy abstract value type AbstractAppleWrapperResourceArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.apple.AppleWrapperResourceArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.apple.AppleWrapperResourceArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.apple.PrebuiltAppleFrameworkDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasSystemFrameworkAndLibraries) - Method in class com.facebook.buck.apple.PrebuiltAppleFrameworkDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.toolchain.HasSystemFrameworkAndLibraries
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.apple.PrebuiltAppleFrameworkDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.apple.PrebuiltAppleFrameworkDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(PrebuiltAppleFrameworkDescriptionArg) - Method in class com.facebook.buck.apple.PrebuiltAppleFrameworkDescriptionArg.Builder
-
Fill a builder with attribute values from the provided PrebuiltAppleFrameworkDescriptionArg
instance.
- from(PrebuiltAppleFrameworkDescription.AbstractPrebuiltAppleFrameworkDescriptionArg) - Method in class com.facebook.buck.apple.PrebuiltAppleFrameworkDescriptionArg.Builder
-
Copy abstract value type AbstractPrebuiltAppleFrameworkDescriptionArg
instance into builder.
- from(XcodeScriptDescriptionArg) - Method in class com.facebook.buck.apple.XcodeScriptDescriptionArg.Builder
-
Fill a builder with attribute values from the provided XcodeScriptDescriptionArg
instance.
- from(AbstractXcodeScriptDescriptionArg) - Method in class com.facebook.buck.apple.XcodeScriptDescriptionArg.Builder
-
Copy abstract value type AbstractXcodeScriptDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.apple.XcodeScriptDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasSrcs) - Method in class com.facebook.buck.apple.XcodeScriptDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasSrcs
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.apple.XcodeScriptDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(Cell, OwnersReport.Builder, Parser, PerBuildState, TargetPatternEvaluator, BuckEventBus, TypeCoercerFactory) - Static method in class com.facebook.buck.cli.BuckQueryEnvironment
-
- from(CommandRunnerParams, PerBuildState, ParsingContext) - Static method in class com.facebook.buck.cli.BuckQueryEnvironment
-
- from(String, Iterable<T>) - Static method in class com.facebook.buck.core.model.FlavorDomain
-
Create a FlavorDomain from FlavorConvertible objects.
- from(String, Class<E>) - Static method in class com.facebook.buck.core.model.FlavorDomain
-
Create a FlavorDomain from FlavorConverbile Enum.
- from(ImmutableList<Object>) - Static method in class com.facebook.buck.core.rules.actions.lib.args.CommandLineArgsFactory
-
- from(ImmutableList<Object>, String) - Static method in class com.facebook.buck.core.rules.actions.lib.args.CommandLineArgsFactory
-
- from(ConfigSettingArg) - Method in class com.facebook.buck.core.rules.configsetting.ConfigSettingArg.Builder
-
Fill a builder with attribute values from the provided ConfigSettingArg
instance.
- from(ConfigSettingDescription.AbstractConfigSettingArg) - Method in class com.facebook.buck.core.rules.configsetting.ConfigSettingArg.Builder
-
Copy abstract value type AbstractConfigSettingArg
instance into builder.
- from(ConstructorArg) - Method in class com.facebook.buck.core.rules.configsetting.ConfigSettingArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(ProjectFilesystem, BuildRuleParams, SourcePathRuleFinder, BuildTarget, Path, SourcePath, ImmutableMap<String, String>, boolean) - Static method in class com.facebook.buck.core.rules.impl.WriteStringTemplateRule
-
- from(ConstructorArg) - Method in class com.facebook.buck.core.rules.platform.ConstraintSettingArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(ConstraintSettingArg) - Method in class com.facebook.buck.core.rules.platform.ConstraintSettingArg.Builder
-
Fill a builder with attribute values from the provided ConstraintSettingArg
instance.
- from(ConstraintSettingDescription.AbstractConstraintSettingArg) - Method in class com.facebook.buck.core.rules.platform.ConstraintSettingArg.Builder
-
Copy abstract value type AbstractConstraintSettingArg
instance into builder.
- from(ConstraintValueArg) - Method in class com.facebook.buck.core.rules.platform.ConstraintValueArg.Builder
-
Fill a builder with attribute values from the provided ConstraintValueArg
instance.
- from(ConstraintValueDescription.AbstractConstraintValueArg) - Method in class com.facebook.buck.core.rules.platform.ConstraintValueArg.Builder
-
Copy abstract value type AbstractConstraintValueArg
instance into builder.
- from(ConstructorArg) - Method in class com.facebook.buck.core.rules.platform.ConstraintValueArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(PlatformArg) - Method in class com.facebook.buck.core.rules.platform.PlatformArg.Builder
-
Fill a builder with attribute values from the provided PlatformArg
instance.
- from(PlatformDescription.AbstractPlatformArg) - Method in class com.facebook.buck.core.rules.platform.PlatformArg.Builder
-
Copy abstract value type AbstractPlatformArg
instance into builder.
- from(ConstructorArg) - Method in class com.facebook.buck.core.rules.platform.PlatformArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(SourcePath) - Static method in class com.facebook.buck.core.sourcepath.PathSourcePath
-
- from(SourcePathRuleFinder) - Static method in class com.facebook.buck.core.sourcepath.resolver.impl.DefaultSourcePathResolver
-
- from(ExternalTestRunnerDescriptionArg) - Method in class com.facebook.buck.core.test.rule.impl.ExternalTestRunnerDescriptionArg.Builder
-
Fill a builder with attribute values from the provided ExternalTestRunnerDescriptionArg
instance.
- from(ExternalTestRunnerDescription.AbstractExternalTestRunnerDescriptionArg) - Method in class com.facebook.buck.core.test.rule.impl.ExternalTestRunnerDescriptionArg.Builder
-
Copy abstract value type AbstractExternalTestRunnerDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.core.test.rule.impl.ExternalTestRunnerDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.core.test.rule.impl.ExternalTestRunnerDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(LegacyToolchainDescriptionArg) - Method in class com.facebook.buck.core.toolchain.rule.LegacyToolchainDescriptionArg.Builder
-
Fill a builder with attribute values from the provided LegacyToolchainDescriptionArg
instance.
- from(LegacyToolchainRuleDescription.AbstractLegacyToolchainDescriptionArg) - Method in class com.facebook.buck.core.toolchain.rule.LegacyToolchainDescriptionArg.Builder
-
Copy abstract value type AbstractLegacyToolchainDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.core.toolchain.rule.LegacyToolchainDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.core.toolchain.rule.LegacyToolchainDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(String, Object...) - Static method in class com.facebook.buck.core.toolchain.toolprovider.impl.ErrorToolProvider
-
- from(BuildTarget, ProjectFilesystem, BuildRuleResolver, CxxPlatform, String, ImmutableList<SourcePath>, ArchiveContents, boolean) - Static method in class com.facebook.buck.cxx.Archive
-
- from(BuildTarget, ProjectFilesystem, BuildRuleResolver, CxxPlatform, String, ImmutableList<SourcePath>) - Static method in class com.facebook.buck.cxx.Archive
-
- from(HasVersionUniverse) - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.versions.HasVersionUniverse
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(CxxConstructorArg) - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.CxxConstructorArg
instance.
- from(HasTests) - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(CxxBinaryDescription.CommonArg) - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.CxxBinaryDescription.CommonArg
instance.
- from(HasDepsQuery) - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDepsQuery
instance.
- from(HasDefaultPlatform) - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDefaultPlatform
instance.
- from(HasSystemFrameworkAndLibraries) - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.toolchain.HasSystemFrameworkAndLibraries
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(LinkableCxxConstructorArg) - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.LinkableCxxConstructorArg
instance.
- from(CxxBinaryDescriptionArg) - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided CxxBinaryDescriptionArg
instance.
- from(CxxBinaryDescription.AbstractCxxBinaryDescriptionArg) - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg.Builder
-
Copy abstract value type AbstractCxxBinaryDescriptionArg
instance into builder.
- from(HasTests) - Method in class com.facebook.buck.cxx.CxxGenruleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(AbstractGenruleDescription.CommonArg) - Method in class com.facebook.buck.cxx.CxxGenruleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.shell.AbstractGenruleDescription.CommonArg
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.cxx.CxxGenruleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(CxxGenruleDescriptionArg) - Method in class com.facebook.buck.cxx.CxxGenruleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided CxxGenruleDescriptionArg
instance.
- from(CxxGenruleDescription.AbstractCxxGenruleDescriptionArg) - Method in class com.facebook.buck.cxx.CxxGenruleDescriptionArg.Builder
-
Copy abstract value type AbstractCxxGenruleDescriptionArg
instance into builder.
- from(ConstructorArg) - Method in class com.facebook.buck.cxx.CxxGenruleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(CxxLibraryDescription.CommonArg) - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(CxxConstructorArg) - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.CxxConstructorArg
instance.
- from(HasTests) - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(HasDefaultPlatform) - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDefaultPlatform
instance.
- from(HasSystemFrameworkAndLibraries) - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.toolchain.HasSystemFrameworkAndLibraries
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(LinkableCxxConstructorArg) - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.LinkableCxxConstructorArg
instance.
- from(CxxLibraryDescriptionArg) - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided CxxLibraryDescriptionArg
instance.
- from(CxxLibraryDescription.AbstractCxxLibraryDescriptionArg) - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg.Builder
-
Copy abstract value type AbstractCxxLibraryDescriptionArg
instance into builder.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.cxx.CxxPrecompiledHeaderDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(CxxPrecompiledHeaderDescriptionArg) - Method in class com.facebook.buck.cxx.CxxPrecompiledHeaderDescriptionArg.Builder
-
Fill a builder with attribute values from the provided CxxPrecompiledHeaderDescriptionArg
instance.
- from(CxxPrecompiledHeaderDescription.AbstractCxxPrecompiledHeaderDescriptionArg) - Method in class com.facebook.buck.cxx.CxxPrecompiledHeaderDescriptionArg.Builder
-
Copy abstract value type AbstractCxxPrecompiledHeaderDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.cxx.CxxPrecompiledHeaderDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.cxx.CxxPrecompiledHeaderDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(HeaderSymlinkTree, CxxPreprocessables.IncludeType) - Static method in class com.facebook.buck.cxx.CxxSymlinkTreeHeaders
-
- from(CxxTestDescriptionArg) - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided CxxTestDescriptionArg
instance.
- from(CxxTestDescription.AbstractCxxTestDescriptionArg) - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg.Builder
-
Copy abstract value type AbstractCxxTestDescriptionArg
instance into builder.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasTestTimeout) - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTestTimeout
instance.
- from(CxxConstructorArg) - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.CxxConstructorArg
instance.
- from(CxxBinaryDescription.CommonArg) - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.CxxBinaryDescription.CommonArg
instance.
- from(HasDepsQuery) - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDepsQuery
instance.
- from(HasDefaultPlatform) - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDefaultPlatform
instance.
- from(HasSystemFrameworkAndLibraries) - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.toolchain.HasSystemFrameworkAndLibraries
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(LinkableCxxConstructorArg) - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.LinkableCxxConstructorArg
instance.
- from(HasVersionUniverse) - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.versions.HasVersionUniverse
instance.
- from(HasTests) - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasContacts) - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasContacts
instance.
- from(CxxToolchainDescriptionArg) - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg.Builder
-
Fill a builder with attribute values from the provided CxxToolchainDescriptionArg
instance.
- from(CxxToolchainDescription.AbstractCxxToolchainDescriptionArg) - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg.Builder
-
Copy abstract value type AbstractCxxToolchainDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(CxxBuckConfig, LinkableCxxConstructorArg, TargetGraph) - Static method in class com.facebook.buck.cxx.LinkableListFilterFactory
-
- from(CxxBuckConfig, Optional<String>, ImmutableList<CxxLinkGroupMapping>, TargetGraph) - Static method in class com.facebook.buck.cxx.LinkableListFilterFactory
-
- from(BuildTarget, ProjectFilesystem, SourcePathRuleFinder, Tool, SourcePath) - Static method in class com.facebook.buck.cxx.MachoDylibStubRule
-
Creates the rule for the input dylib.
- from(MachoDylibStubParams) - Static method in class com.facebook.buck.cxx.MachoDylibStubRuleFactory
-
- from(PrebuiltCxxLibraryDescriptionArg) - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided PrebuiltCxxLibraryDescriptionArg
instance.
- from(PrebuiltCxxLibraryDescription.AbstractPrebuiltCxxLibraryDescriptionArg) - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg.Builder
-
Copy abstract value type AbstractPrebuiltCxxLibraryDescriptionArg
instance into builder.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(PrebuiltCxxLibraryGroupDescriptionArg) - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescriptionArg.Builder
-
Fill a builder with attribute values from the provided PrebuiltCxxLibraryGroupDescriptionArg
instance.
- from(PrebuiltCxxLibraryGroupDescription.AbstractPrebuiltCxxLibraryGroupDescriptionArg) - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescriptionArg.Builder
-
Copy abstract value type AbstractPrebuiltCxxLibraryGroupDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(Archiver) - Static method in interface com.facebook.buck.cxx.toolchain.ArchiverProvider
-
- from(ToolProvider, Platform, Optional<ArchiverProvider.LegacyArchiverType>) - Static method in interface com.facebook.buck.cxx.toolchain.ArchiverProvider
-
- from(ToolProvider, ArchiverProvider.Type) - Static method in interface com.facebook.buck.cxx.toolchain.ArchiverProvider
-
Creates an appropriate ArchiverProvider instance for the given parameters.
- from(XcodeWorkspaceConfigDescriptionArg) - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg.Builder
-
Fill a builder with attribute values from the provided XcodeWorkspaceConfigDescriptionArg
instance.
- from(XcodeWorkspaceConfigDescription.AbstractXcodeWorkspaceConfigDescriptionArg) - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg.Builder
-
Copy abstract value type AbstractXcodeWorkspaceConfigDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.d.DBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(DBinaryDescriptionArg) - Method in class com.facebook.buck.features.d.DBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided DBinaryDescriptionArg
instance.
- from(DBinaryDescription.AbstractDBinaryDescriptionArg) - Method in class com.facebook.buck.features.d.DBinaryDescriptionArg.Builder
-
Copy abstract value type AbstractDBinaryDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.d.DBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.d.DBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.d.DLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.d.DLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.d.DLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(DLibraryDescriptionArg) - Method in class com.facebook.buck.features.d.DLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided DLibraryDescriptionArg
instance.
- from(DLibraryDescription.AbstractDLibraryDescriptionArg) - Method in class com.facebook.buck.features.d.DLibraryDescriptionArg.Builder
-
Copy abstract value type AbstractDLibraryDescriptionArg
instance into builder.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.d.DTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasTestTimeout) - Method in class com.facebook.buck.features.d.DTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTestTimeout
instance.
- from(DTestDescriptionArg) - Method in class com.facebook.buck.features.d.DTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided DTestDescriptionArg
instance.
- from(DTestDescription.AbstractDTestDescriptionArg) - Method in class com.facebook.buck.features.d.DTestDescriptionArg.Builder
-
Copy abstract value type AbstractDTestDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.d.DTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasContacts) - Method in class com.facebook.buck.features.d.DTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasContacts
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.d.DTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(CsharpLibraryDescriptionArg) - Method in class com.facebook.buck.features.dotnet.CsharpLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided CsharpLibraryDescriptionArg
instance.
- from(CsharpLibraryDescription.AbstractCsharpLibraryDescriptionArg) - Method in class com.facebook.buck.features.dotnet.CsharpLibraryDescriptionArg.Builder
-
Copy abstract value type AbstractCsharpLibraryDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.dotnet.CsharpLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasSrcs) - Method in class com.facebook.buck.features.dotnet.CsharpLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasSrcs
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.dotnet.CsharpLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(PrebuiltDotnetLibraryDescriptionArg) - Method in class com.facebook.buck.features.dotnet.PrebuiltDotnetLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided PrebuiltDotnetLibraryDescriptionArg
instance.
- from(PrebuiltDotnetLibraryDescription.AbstractPrebuiltDotnetLibraryDescriptionArg) - Method in class com.facebook.buck.features.dotnet.PrebuiltDotnetLibraryDescriptionArg.Builder
-
Copy abstract value type AbstractPrebuiltDotnetLibraryDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.dotnet.PrebuiltDotnetLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.dotnet.PrebuiltDotnetLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.filegroup.FileGroupDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasSrcs) - Method in class com.facebook.buck.features.filegroup.FileGroupDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasSrcs
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.filegroup.FileGroupDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(FileGroupDescriptionArg) - Method in class com.facebook.buck.features.filegroup.FileGroupDescriptionArg.Builder
-
Fill a builder with attribute values from the provided FileGroupDescriptionArg
instance.
- from(FilegroupDescription.AbstractFileGroupDescriptionArg) - Method in class com.facebook.buck.features.filegroup.FileGroupDescriptionArg.Builder
-
Copy abstract value type AbstractFileGroupDescriptionArg
instance into builder.
- from(HasVersionUniverse) - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.versions.HasVersionUniverse
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(CxxConstructorArg) - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.CxxConstructorArg
instance.
- from(HasTests) - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(CgoLibraryDescriptionArg) - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided CgoLibraryDescriptionArg
instance.
- from(CgoLibraryDescription.AbstractCgoLibraryDescriptionArg) - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg.Builder
-
Copy abstract value type AbstractCgoLibraryDescriptionArg
instance into builder.
- from(CxxBinaryDescription.CommonArg) - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.CxxBinaryDescription.CommonArg
instance.
- from(HasDepsQuery) - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDepsQuery
instance.
- from(HasDefaultPlatform) - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDefaultPlatform
instance.
- from(HasSystemFrameworkAndLibraries) - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.toolchain.HasSystemFrameworkAndLibraries
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(LinkableCxxConstructorArg) - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.LinkableCxxConstructorArg
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.go.GoBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.go.GoBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasGoLinkable) - Method in class com.facebook.buck.features.go.GoBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.features.go.HasGoLinkable
instance.
- from(HasSrcs) - Method in class com.facebook.buck.features.go.GoBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasSrcs
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.go.GoBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(GoBinaryDescriptionArg) - Method in class com.facebook.buck.features.go.GoBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided GoBinaryDescriptionArg
instance.
- from(GoBinaryDescription.AbstractGoBinaryDescriptionArg) - Method in class com.facebook.buck.features.go.GoBinaryDescriptionArg.Builder
-
Copy abstract value type AbstractGoBinaryDescriptionArg
instance into builder.
- from(GoLibraryDescriptionArg) - Method in class com.facebook.buck.features.go.GoLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided GoLibraryDescriptionArg
instance.
- from(GoLibraryDescription.AbstractGoLibraryDescriptionArg) - Method in class com.facebook.buck.features.go.GoLibraryDescriptionArg.Builder
-
Copy abstract value type AbstractGoLibraryDescriptionArg
instance into builder.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.go.GoLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasTests) - Method in class com.facebook.buck.features.go.GoLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.go.GoLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasSrcs) - Method in class com.facebook.buck.features.go.GoLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasSrcs
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.go.GoLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.go.GoTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasTestTimeout) - Method in class com.facebook.buck.features.go.GoTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTestTimeout
instance.
- from(GoTestDescriptionArg) - Method in class com.facebook.buck.features.go.GoTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided GoTestDescriptionArg
instance.
- from(GoTestDescription.AbstractGoTestDescriptionArg) - Method in class com.facebook.buck.features.go.GoTestDescriptionArg.Builder
-
Copy abstract value type AbstractGoTestDescriptionArg
instance into builder.
- from(HasTestRunner) - Method in class com.facebook.buck.features.go.GoTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.test.rule.HasTestRunner
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.go.GoTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasGoLinkable) - Method in class com.facebook.buck.features.go.GoTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.features.go.HasGoLinkable
instance.
- from(HasContacts) - Method in class com.facebook.buck.features.go.GoTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasContacts
instance.
- from(HasSrcs) - Method in class com.facebook.buck.features.go.GoTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasSrcs
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.go.GoTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(GoTestRunnerDescriptionArg) - Method in class com.facebook.buck.features.go.GoTestRunnerDescriptionArg.Builder
-
Fill a builder with attribute values from the provided GoTestRunnerDescriptionArg
instance.
- from(GoTestRunnerDescription.AbstractGoTestRunnerDescriptionArg) - Method in class com.facebook.buck.features.go.GoTestRunnerDescriptionArg.Builder
-
Copy abstract value type AbstractGoTestRunnerDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.go.GoTestRunnerDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.go.GoTestRunnerDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.go.PrebuiltGoLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(PrebuiltGoLibraryDescriptionArg) - Method in class com.facebook.buck.features.go.PrebuiltGoLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided PrebuiltGoLibraryDescriptionArg
instance.
- from(PrebuiltGoLibraryDescription.AbstractPrebuiltGoLibraryDescriptionArg) - Method in class com.facebook.buck.features.go.PrebuiltGoLibraryDescriptionArg.Builder
-
Copy abstract value type AbstractPrebuiltGoLibraryDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.go.PrebuiltGoLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.go.PrebuiltGoLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.gwt.GwtBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(GwtBinaryDescriptionArg) - Method in class com.facebook.buck.features.gwt.GwtBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided GwtBinaryDescriptionArg
instance.
- from(GwtBinaryDescription.AbstractGwtBinaryDescriptionArg) - Method in class com.facebook.buck.features.gwt.GwtBinaryDescriptionArg.Builder
-
Copy abstract value type AbstractGwtBinaryDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.gwt.GwtBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.gwt.GwtBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(HasVersionUniverse) - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.versions.HasVersionUniverse
instance.
- from(HalideLibraryDescriptionArg) - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided HalideLibraryDescriptionArg
instance.
- from(HalideLibraryDescription.AbstractHalideLibraryDescriptionArg) - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg.Builder
-
Copy abstract value type AbstractHalideLibraryDescriptionArg
instance into builder.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(CxxConstructorArg) - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.CxxConstructorArg
instance.
- from(HasTests) - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(CxxBinaryDescription.CommonArg) - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.CxxBinaryDescription.CommonArg
instance.
- from(HasDepsQuery) - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDepsQuery
instance.
- from(HasDefaultPlatform) - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDefaultPlatform
instance.
- from(HasSystemFrameworkAndLibraries) - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.toolchain.HasSystemFrameworkAndLibraries
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(LinkableCxxConstructorArg) - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.LinkableCxxConstructorArg
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.haskell.HaskellBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HaskellBinaryDescriptionArg) - Method in class com.facebook.buck.features.haskell.HaskellBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided HaskellBinaryDescriptionArg
instance.
- from(HaskellBinaryDescription.AbstractHaskellBinaryDescriptionArg) - Method in class com.facebook.buck.features.haskell.HaskellBinaryDescriptionArg.Builder
-
Copy abstract value type AbstractHaskellBinaryDescriptionArg
instance into builder.
- from(HasDepsQuery) - Method in class com.facebook.buck.features.haskell.HaskellBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDepsQuery
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.haskell.HaskellBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.haskell.HaskellBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(BuildTarget, ProjectFilesystem, BuildRuleParams, SourcePathRuleFinder, Tool, HaskellCompilerFlags, HaskellPlatform, Linker.LinkableDepType, boolean, Optional<String>, Optional<HaskellPackageInfo>, HaskellSources, Preprocessor) - Static method in class com.facebook.buck.features.haskell.HaskellCompileRule
-
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.haskell.HaskellGhciDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasDepsQuery) - Method in class com.facebook.buck.features.haskell.HaskellGhciDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDepsQuery
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.haskell.HaskellGhciDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.haskell.HaskellGhciDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(HaskellGhciDescriptionArg) - Method in class com.facebook.buck.features.haskell.HaskellGhciDescriptionArg.Builder
-
Fill a builder with attribute values from the provided HaskellGhciDescriptionArg
instance.
- from(HaskellGhciDescription.AbstractHaskellGhciDescriptionArg) - Method in class com.facebook.buck.features.haskell.HaskellGhciDescriptionArg.Builder
-
Copy abstract value type AbstractHaskellGhciDescriptionArg
instance into builder.
- from(BuildTarget, ProjectFilesystem, BuildRuleParams, SourcePathRuleFinder, HaskellSources, ImmutableList<String>, Optional<SourcePath>, Optional<SourcePath>, BuildRule, ImmutableSortedMap<String, SourcePath>, ImmutableSortedMap<String, SourcePath>, ImmutableSet<HaskellPackage>, ImmutableSet<HaskellPackage>, ImmutableSet<HaskellPackage>, boolean, HaskellPlatform, ImmutableList<SourcePath>) - Static method in class com.facebook.buck.features.haskell.HaskellGhciRule
-
- from(HaskellHaddockDescriptionArg) - Method in class com.facebook.buck.features.haskell.HaskellHaddockDescriptionArg.Builder
-
Fill a builder with attribute values from the provided HaskellHaddockDescriptionArg
instance.
- from(HaskellHaddockDescription.AbstractHaskellHaddockDescriptionArg) - Method in class com.facebook.buck.features.haskell.HaskellHaddockDescriptionArg.Builder
-
Copy abstract value type AbstractHaskellHaddockDescriptionArg
instance into builder.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.haskell.HaskellHaddockDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasDepsQuery) - Method in class com.facebook.buck.features.haskell.HaskellHaddockDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDepsQuery
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.haskell.HaskellHaddockDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.haskell.HaskellHaddockDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(BuildTarget, ProjectFilesystem, BuildRuleParams, SourcePathRuleFinder, HaskellSources, Tool, ImmutableList<String>, HaskellCompilerFlags, ImmutableList<String>, HaskellPackageInfo, HaskellPlatform, Preprocessor) - Static method in class com.facebook.buck.features.haskell.HaskellHaddockLibRule
-
- from(BuildTarget, ProjectFilesystem, BuildRuleParams, SourcePathRuleFinder, Tool, ImmutableList<String>, ImmutableSet<HaskellHaddockInput>) - Static method in class com.facebook.buck.features.haskell.HaskellHaddockRule
-
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.haskell.HaskellLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HaskellLibraryDescriptionArg) - Method in class com.facebook.buck.features.haskell.HaskellLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided HaskellLibraryDescriptionArg
instance.
- from(HaskellLibraryDescription.AbstractHaskellLibraryDescriptionArg) - Method in class com.facebook.buck.features.haskell.HaskellLibraryDescriptionArg.Builder
-
Copy abstract value type AbstractHaskellLibraryDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.haskell.HaskellLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.haskell.HaskellLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(BuildTarget, ProjectFilesystem, BuildRuleParams, SourcePathRuleFinder, Tool, HaskellVersion, Linker.LinkableDepType, HaskellPackageInfo, ImmutableSortedMap<String, HaskellPackage>, ImmutableSortedSet<String>, ImmutableSortedSet<SourcePath>, ImmutableSortedSet<SourcePath>, ImmutableSortedSet<SourcePath>) - Static method in class com.facebook.buck.features.haskell.HaskellPackageRule
-
- from(HaskellPrebuiltLibraryDescriptionArg) - Method in class com.facebook.buck.features.haskell.HaskellPrebuiltLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided HaskellPrebuiltLibraryDescriptionArg
instance.
- from(HaskellPrebuiltLibraryDescription.AbstractHaskellPrebuiltLibraryDescriptionArg) - Method in class com.facebook.buck.features.haskell.HaskellPrebuiltLibraryDescriptionArg.Builder
-
Copy abstract value type AbstractHaskellPrebuiltLibraryDescriptionArg
instance into builder.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.haskell.HaskellPrebuiltLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.haskell.HaskellPrebuiltLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.haskell.HaskellPrebuiltLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.js.JsBundleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(JsBundleDescriptionArg) - Method in class com.facebook.buck.features.js.JsBundleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided JsBundleDescriptionArg
instance.
- from(JsBundleDescription.AbstractJsBundleDescriptionArg) - Method in class com.facebook.buck.features.js.JsBundleDescriptionArg.Builder
-
Copy abstract value type AbstractJsBundleDescriptionArg
instance into builder.
- from(HasExtraJson) - Method in class com.facebook.buck.features.js.JsBundleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.features.js.HasExtraJson
instance.
- from(HasBundleName) - Method in class com.facebook.buck.features.js.JsBundleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.features.js.HasBundleName
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.js.JsBundleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.js.JsBundleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(JsBundleGenruleDescriptionArg) - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided JsBundleGenruleDescriptionArg
instance.
- from(JsBundleGenruleDescription.AbstractJsBundleGenruleDescriptionArg) - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg.Builder
-
Copy abstract value type AbstractJsBundleGenruleDescriptionArg
instance into builder.
- from(HasTests) - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(AbstractGenruleDescription.CommonArg) - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.shell.AbstractGenruleDescription.CommonArg
instance.
- from(HasBundleName) - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.features.js.HasBundleName
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.js.JsLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasTests) - Method in class com.facebook.buck.features.js.JsLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(HasDepsQuery) - Method in class com.facebook.buck.features.js.JsLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDepsQuery
instance.
- from(HasExtraJson) - Method in class com.facebook.buck.features.js.JsLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.features.js.HasExtraJson
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.js.JsLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.js.JsLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(JsLibraryDescriptionArg) - Method in class com.facebook.buck.features.js.JsLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided JsLibraryDescriptionArg
instance.
- from(JsLibraryDescription.AbstractJsLibraryDescriptionArg) - Method in class com.facebook.buck.features.js.JsLibraryDescriptionArg.Builder
-
Copy abstract value type AbstractJsLibraryDescriptionArg
instance into builder.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(CxxConstructorArg) - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.CxxConstructorArg
instance.
- from(HasTests) - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(CxxLuaExtensionDescriptionArg) - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg.Builder
-
Fill a builder with attribute values from the provided CxxLuaExtensionDescriptionArg
instance.
- from(CxxLuaExtensionDescription.AbstractCxxLuaExtensionDescriptionArg) - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg.Builder
-
Copy abstract value type AbstractCxxLuaExtensionDescriptionArg
instance into builder.
- from(HasDefaultPlatform) - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDefaultPlatform
instance.
- from(HasSystemFrameworkAndLibraries) - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.toolchain.HasSystemFrameworkAndLibraries
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.lua.LuaBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.lua.LuaBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.lua.LuaBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(LuaBinaryDescriptionArg) - Method in class com.facebook.buck.features.lua.LuaBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided LuaBinaryDescriptionArg
instance.
- from(LuaBinaryDescription.AbstractLuaBinaryDescriptionArg) - Method in class com.facebook.buck.features.lua.LuaBinaryDescriptionArg.Builder
-
Copy abstract value type AbstractLuaBinaryDescriptionArg
instance into builder.
- from(LuaLibraryDescriptionArg) - Method in class com.facebook.buck.features.lua.LuaLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided LuaLibraryDescriptionArg
instance.
- from(LuaLibraryDescription.AbstractLuaLibraryDescriptionArg) - Method in class com.facebook.buck.features.lua.LuaLibraryDescriptionArg.Builder
-
Copy abstract value type AbstractLuaLibraryDescriptionArg
instance into builder.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.lua.LuaLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.lua.LuaLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.lua.LuaLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(OcamlBinaryDescriptionArg) - Method in class com.facebook.buck.features.ocaml.OcamlBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided OcamlBinaryDescriptionArg
instance.
- from(OcamlBinaryDescription.AbstractOcamlBinaryDescriptionArg) - Method in class com.facebook.buck.features.ocaml.OcamlBinaryDescriptionArg.Builder
-
Copy abstract value type AbstractOcamlBinaryDescriptionArg
instance into builder.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.ocaml.OcamlBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.ocaml.OcamlBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.ocaml.OcamlBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(OcamlLibraryDescriptionArg) - Method in class com.facebook.buck.features.ocaml.OcamlLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided OcamlLibraryDescriptionArg
instance.
- from(OcamlLibraryDescription.AbstractOcamlLibraryDescriptionArg) - Method in class com.facebook.buck.features.ocaml.OcamlLibraryDescriptionArg.Builder
-
Copy abstract value type AbstractOcamlLibraryDescriptionArg
instance into builder.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.ocaml.OcamlLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.ocaml.OcamlLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.ocaml.OcamlLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(PrebuiltOcamlLibraryDescriptionArg) - Method in class com.facebook.buck.features.ocaml.PrebuiltOcamlLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided PrebuiltOcamlLibraryDescriptionArg
instance.
- from(PrebuiltOcamlLibraryDescription.AbstractPrebuiltOcamlLibraryDescriptionArg) - Method in class com.facebook.buck.features.ocaml.PrebuiltOcamlLibraryDescriptionArg.Builder
-
Copy abstract value type AbstractPrebuiltOcamlLibraryDescriptionArg
instance into builder.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.ocaml.PrebuiltOcamlLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.ocaml.PrebuiltOcamlLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.ocaml.PrebuiltOcamlLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(ProjectFilesystem, IjProjectConfig, TargetGraph, IjLibraryFactory, IjModuleFactory, AggregationModuleFactory) - Static method in class com.facebook.buck.features.project.intellij.IjModuleGraphFactory
-
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(CxxConstructorArg) - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.CxxConstructorArg
instance.
- from(HasTests) - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(CxxPythonExtensionDescriptionArg) - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg.Builder
-
Fill a builder with attribute values from the provided CxxPythonExtensionDescriptionArg
instance.
- from(CxxPythonExtensionDescription.AbstractCxxPythonExtensionDescriptionArg) - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg.Builder
-
Copy abstract value type AbstractCxxPythonExtensionDescriptionArg
instance into builder.
- from(HasDefaultPlatform) - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDefaultPlatform
instance.
- from(HasSystemFrameworkAndLibraries) - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.cxx.toolchain.HasSystemFrameworkAndLibraries
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(PrebuiltPythonLibraryDescriptionArg) - Method in class com.facebook.buck.features.python.PrebuiltPythonLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided PrebuiltPythonLibraryDescriptionArg
instance.
- from(PrebuiltPythonLibraryDescription.AbstractPrebuiltPythonLibraryDescriptionArg) - Method in class com.facebook.buck.features.python.PrebuiltPythonLibraryDescriptionArg.Builder
-
Copy abstract value type AbstractPrebuiltPythonLibraryDescriptionArg
instance into builder.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.python.PrebuiltPythonLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.python.PrebuiltPythonLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.python.PrebuiltPythonLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(HasVersionUniverse) - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.versions.HasVersionUniverse
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasTests) - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(PythonBinaryDescriptionArg) - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided PythonBinaryDescriptionArg
instance.
- from(PythonBinaryDescription.AbstractPythonBinaryDescriptionArg) - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg.Builder
-
Copy abstract value type AbstractPythonBinaryDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(BuildTarget, ProjectFilesystem, SourcePathRuleFinder, PythonEnvironment, PythonComponents, boolean) - Static method in class com.facebook.buck.features.python.PythonCompileRule
-
- from(PythonLibraryDescription.CoreArg) - Method in class com.facebook.buck.features.python.PythonLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.features.python.PythonLibraryDescription.CoreArg
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.python.PythonLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasTests) - Method in class com.facebook.buck.features.python.PythonLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.python.PythonLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.python.PythonLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(PythonLibraryDescriptionArg) - Method in class com.facebook.buck.features.python.PythonLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided PythonLibraryDescriptionArg
instance.
- from(PythonLibraryDescription.AbstractPythonLibraryDescriptionArg) - Method in class com.facebook.buck.features.python.PythonLibraryDescriptionArg.Builder
-
Copy abstract value type AbstractPythonLibraryDescriptionArg
instance into builder.
- from(BuildTarget, ProjectFilesystem, BuildRuleParams, BuildRuleResolver, Function<BuildRuleResolver, ImmutableMap<String, Arg>>, PythonBinary, ImmutableSet<String>, ImmutableList<Pair<Float, ImmutableSet<Path>>>, ImmutableSet<SourcePath>, Optional<Long>, ImmutableSet<String>) - Static method in class com.facebook.buck.features.python.PythonTest
-
- from(PythonLibraryDescription.CoreArg) - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.features.python.PythonLibraryDescription.CoreArg
instance.
- from(HasVersionUniverse) - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.versions.HasVersionUniverse
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasTestTimeout) - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTestTimeout
instance.
- from(HasTests) - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(PythonTestDescriptionArg) - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided PythonTestDescriptionArg
instance.
- from(PythonTestDescription.AbstractPythonTestDescriptionArg) - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg.Builder
-
Copy abstract value type AbstractPythonTestDescriptionArg
instance into builder.
- from(HasTestRunner) - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.test.rule.HasTestRunner
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasContacts) - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasContacts
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(PythonTestRunnerDescriptionArg) - Method in class com.facebook.buck.features.python.PythonTestRunnerDescriptionArg.Builder
-
Fill a builder with attribute values from the provided PythonTestRunnerDescriptionArg
instance.
- from(PythonTestRunnerDescription.AbstractPythonTestRunnerDescriptionArg) - Method in class com.facebook.buck.features.python.PythonTestRunnerDescriptionArg.Builder
-
Copy abstract value type AbstractPythonTestRunnerDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.python.PythonTestRunnerDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.python.PythonTestRunnerDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(BuildTarget, ProjectFilesystem, BuildRuleParams, PythonBinary, ImmutableSet<String>, ImmutableSet<String>, CoercedTestRunnerSpec) - Static method in class com.facebook.buck.features.python.PythonTestX
-
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.rust.PrebuiltRustLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.rust.PrebuiltRustLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.rust.PrebuiltRustLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(PrebuiltRustLibraryDescriptionArg) - Method in class com.facebook.buck.features.rust.PrebuiltRustLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided PrebuiltRustLibraryDescriptionArg
instance.
- from(PrebuiltRustLibraryDescription.AbstractPrebuiltRustLibraryDescriptionArg) - Method in class com.facebook.buck.features.rust.PrebuiltRustLibraryDescriptionArg.Builder
-
Copy abstract value type AbstractPrebuiltRustLibraryDescriptionArg
instance into builder.
- from(HasVersionUniverse) - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.versions.HasVersionUniverse
instance.
- from(HasNamedDeclaredDeps) - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.features.rust.HasNamedDeclaredDeps
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasTests) - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(HasDefaultPlatform) - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDefaultPlatform
instance.
- from(RustCommonArgs) - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.features.rust.RustCommonArgs
instance.
- from(RustBinaryDescriptionArg) - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided RustBinaryDescriptionArg
instance.
- from(RustBinaryDescription.AbstractRustBinaryDescriptionArg) - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg.Builder
-
Copy abstract value type AbstractRustBinaryDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasSrcs) - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasSrcs
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(SourcePathRuleFinder, BuildTarget, ProjectFilesystem, String, Tool, Linker, ImmutableList<Arg>, ImmutableList<Arg>, ImmutableList<Arg>, ImmutableSortedMap<String, Arg>, ImmutableSortedMap<SourcePath, Optional<String>>, String, RustBuckConfig.RemapSrcPaths, Optional<String>) - Static method in class com.facebook.buck.features.rust.RustCompileRule
-
- from(HasNamedDeclaredDeps) - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.features.rust.HasNamedDeclaredDeps
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasTests) - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(HasDefaultPlatform) - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDefaultPlatform
instance.
- from(RustCommonArgs) - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.features.rust.RustCommonArgs
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasSrcs) - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasSrcs
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(RustLibraryDescriptionArg) - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided RustLibraryDescriptionArg
instance.
- from(RustLibraryDescription.AbstractRustLibraryDescriptionArg) - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg.Builder
-
Copy abstract value type AbstractRustLibraryDescriptionArg
instance into builder.
- from(HasVersionUniverse) - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.versions.HasVersionUniverse
instance.
- from(HasNamedDeclaredDeps) - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.features.rust.HasNamedDeclaredDeps
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(RustTestDescriptionArg) - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided RustTestDescriptionArg
instance.
- from(RustTestDescription.AbstractRustTestDescriptionArg) - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg.Builder
-
Copy abstract value type AbstractRustTestDescriptionArg
instance into builder.
- from(HasDefaultPlatform) - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDefaultPlatform
instance.
- from(RustCommonArgs) - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.features.rust.RustCommonArgs
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasSrcs) - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasSrcs
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(ZipFileDescriptionArg) - Method in class com.facebook.buck.features.zip.rules.ZipFileDescriptionArg.Builder
-
Fill a builder with attribute values from the provided ZipFileDescriptionArg
instance.
- from(ZipFileDescription.AbstractZipFileDescriptionArg) - Method in class com.facebook.buck.features.zip.rules.ZipFileDescriptionArg.Builder
-
Copy abstract value type AbstractZipFileDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.features.zip.rules.ZipFileDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.features.zip.rules.ZipFileDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(HttpCommonDescriptionArg) - Method in class com.facebook.buck.file.HttpArchiveDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.file.HttpCommonDescriptionArg
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.file.HttpArchiveDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.file.HttpArchiveDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(HttpArchiveDescriptionArg) - Method in class com.facebook.buck.file.HttpArchiveDescriptionArg.Builder
-
Fill a builder with attribute values from the provided HttpArchiveDescriptionArg
instance.
- from(HttpArchiveDescription.AbstractHttpArchiveDescriptionArg) - Method in class com.facebook.buck.file.HttpArchiveDescriptionArg.Builder
-
Copy abstract value type AbstractHttpArchiveDescriptionArg
instance into builder.
- from(HttpCommonDescriptionArg) - Method in class com.facebook.buck.file.HttpFileDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.file.HttpCommonDescriptionArg
instance.
- from(HttpFileDescriptionArg) - Method in class com.facebook.buck.file.HttpFileDescriptionArg.Builder
-
Fill a builder with attribute values from the provided HttpFileDescriptionArg
instance.
- from(HttpFileDescription.AbstractHttpFileDescriptionArg) - Method in class com.facebook.buck.file.HttpFileDescriptionArg.Builder
-
Copy abstract value type AbstractHttpFileDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.file.HttpFileDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.file.HttpFileDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.file.RemoteFileDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(RemoteFileDescriptionArg) - Method in class com.facebook.buck.file.RemoteFileDescriptionArg.Builder
-
Fill a builder with attribute values from the provided RemoteFileDescriptionArg
instance.
- from(RemoteFileDescription.AbstractRemoteFileDescriptionArg) - Method in class com.facebook.buck.file.RemoteFileDescriptionArg.Builder
-
Copy abstract value type AbstractRemoteFileDescriptionArg
instance into builder.
- from(ConstructorArg) - Method in class com.facebook.buck.file.RemoteFileDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasProvidedDeps) - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasProvidedDeps
instance.
- from(JavaLibraryDescription.CoreArg) - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JavaLibraryDescription.CoreArg
instance.
- from(HasTests) - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(JvmLibraryArg) - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JvmLibraryArg
instance.
- from(GroovyLibraryDescription.CoreArg) - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.groovy.GroovyLibraryDescription.CoreArg
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasSrcs) - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasSrcs
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(MaybeRequiredForSourceOnlyAbiArg) - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.MaybeRequiredForSourceOnlyAbiArg
instance.
- from(GroovyLibraryDescriptionArg) - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided GroovyLibraryDescriptionArg
instance.
- from(GroovyLibraryDescription.AbstractGroovyLibraryDescriptionArg) - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg.Builder
-
Copy abstract value type AbstractGroovyLibraryDescriptionArg
instance into builder.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasTestTimeout) - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTestTimeout
instance.
- from(GroovyLibraryDescription.CoreArg) - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.groovy.GroovyLibraryDescription.CoreArg
instance.
- from(HasSrcs) - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasSrcs
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(JavaTestDescription.CoreArg) - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JavaTestDescription.CoreArg
instance.
- from(MaybeRequiredForSourceOnlyAbiArg) - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.MaybeRequiredForSourceOnlyAbiArg
instance.
- from(HasProvidedDeps) - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasProvidedDeps
instance.
- from(JavaLibraryDescription.CoreArg) - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JavaLibraryDescription.CoreArg
instance.
- from(HasTests) - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(JvmLibraryArg) - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JvmLibraryArg
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasContacts) - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasContacts
instance.
- from(GroovyTestDescriptionArg) - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided GroovyTestDescriptionArg
instance.
- from(GroovyTestDescription.AbstractGroovyTestDescriptionArg) - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg.Builder
-
Copy abstract value type AbstractGroovyTestDescriptionArg
instance into builder.
- from(HasTests) - Method in class com.facebook.buck.jvm.java.JarGenruleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(AbstractGenruleDescription.CommonArg) - Method in class com.facebook.buck.jvm.java.JarGenruleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.shell.AbstractGenruleDescription.CommonArg
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.jvm.java.JarGenruleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.jvm.java.JarGenruleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(JarGenruleDescriptionArg) - Method in class com.facebook.buck.jvm.java.JarGenruleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided JarGenruleDescriptionArg
instance.
- from(JarGenruleDescription.AbstractJarGenruleDescriptionArg) - Method in class com.facebook.buck.jvm.java.JarGenruleDescriptionArg.Builder
-
Copy abstract value type AbstractJarGenruleDescriptionArg
instance into builder.
- from(JavacPluginArgs) - Method in class com.facebook.buck.jvm.java.JavaAnnotationProcessorDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JavacPluginArgs
instance.
- from(JavaAnnotationProcessorDescriptionArg) - Method in class com.facebook.buck.jvm.java.JavaAnnotationProcessorDescriptionArg.Builder
-
Fill a builder with attribute values from the provided JavaAnnotationProcessorDescriptionArg
instance.
- from(JavaAnnotationProcessorDescription.AbstractJavaAnnotationProcessorDescriptionArg) - Method in class com.facebook.buck.jvm.java.JavaAnnotationProcessorDescriptionArg.Builder
-
Copy abstract value type AbstractJavaAnnotationProcessorDescriptionArg
instance into builder.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.jvm.java.JavaAnnotationProcessorDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.jvm.java.JavaAnnotationProcessorDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.jvm.java.JavaAnnotationProcessorDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(JavaBinaryDescriptionArg) - Method in class com.facebook.buck.jvm.java.JavaBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided JavaBinaryDescriptionArg
instance.
- from(JavaBinaryDescription.AbstractJavaBinaryDescriptionArg) - Method in class com.facebook.buck.jvm.java.JavaBinaryDescriptionArg.Builder
-
Copy abstract value type AbstractJavaBinaryDescriptionArg
instance into builder.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.jvm.java.JavaBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasTests) - Method in class com.facebook.buck.jvm.java.JavaBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.jvm.java.JavaBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.jvm.java.JavaBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasProvidedDeps) - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasProvidedDeps
instance.
- from(JavaLibraryDescription.CoreArg) - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JavaLibraryDescription.CoreArg
instance.
- from(HasTests) - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(JvmLibraryArg) - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JvmLibraryArg
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasSrcs) - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasSrcs
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(MaybeRequiredForSourceOnlyAbiArg) - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.MaybeRequiredForSourceOnlyAbiArg
instance.
- from(JavaLibraryDescriptionArg) - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided JavaLibraryDescriptionArg
instance.
- from(JavaLibraryDescription.AbstractJavaLibraryDescriptionArg) - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg.Builder
-
Copy abstract value type AbstractJavaLibraryDescriptionArg
instance into builder.
- from(JavacPluginArgs) - Method in class com.facebook.buck.jvm.java.JavaPluginDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JavacPluginArgs
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.jvm.java.JavaPluginDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.jvm.java.JavaPluginDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.jvm.java.JavaPluginDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(JavaPluginDescriptionArg) - Method in class com.facebook.buck.jvm.java.JavaPluginDescriptionArg.Builder
-
Fill a builder with attribute values from the provided JavaPluginDescriptionArg
instance.
- from(JavaPluginDescription.AbstractJavaPluginDescriptionArg) - Method in class com.facebook.buck.jvm.java.JavaPluginDescriptionArg.Builder
-
Copy abstract value type AbstractJavaPluginDescriptionArg
instance into builder.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasTestTimeout) - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTestTimeout
instance.
- from(HasSrcs) - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasSrcs
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(JavaTestDescription.CoreArg) - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JavaTestDescription.CoreArg
instance.
- from(MaybeRequiredForSourceOnlyAbiArg) - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.MaybeRequiredForSourceOnlyAbiArg
instance.
- from(HasProvidedDeps) - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasProvidedDeps
instance.
- from(JavaLibraryDescription.CoreArg) - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JavaLibraryDescription.CoreArg
instance.
- from(HasTests) - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(JvmLibraryArg) - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JvmLibraryArg
instance.
- from(HasTestRunner) - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.test.rule.HasTestRunner
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasContacts) - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasContacts
instance.
- from(JavaTestDescriptionArg) - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided JavaTestDescriptionArg
instance.
- from(JavaTestDescription.AbstractJavaTestDescriptionArg) - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg.Builder
-
Copy abstract value type AbstractJavaTestDescriptionArg
instance into builder.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasProvidedDeps) - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasProvidedDeps
instance.
- from(JavaLibraryDescription.CoreArg) - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JavaLibraryDescription.CoreArg
instance.
- from(HasTests) - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(JavaTestRunnerDescriptionArg) - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg.Builder
-
Fill a builder with attribute values from the provided JavaTestRunnerDescriptionArg
instance.
- from(JavaTestRunnerDescription.AbstractJavaTestRunnerDescriptionArg) - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg.Builder
-
Copy abstract value type AbstractJavaTestRunnerDescriptionArg
instance into builder.
- from(JvmLibraryArg) - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JvmLibraryArg
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasSrcs) - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasSrcs
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(MaybeRequiredForSourceOnlyAbiArg) - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.MaybeRequiredForSourceOnlyAbiArg
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.jvm.java.KeystoreDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.jvm.java.KeystoreDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(KeystoreDescriptionArg) - Method in class com.facebook.buck.jvm.java.KeystoreDescriptionArg.Builder
-
Fill a builder with attribute values from the provided KeystoreDescriptionArg
instance.
- from(KeystoreDescription.AbstractKeystoreDescriptionArg) - Method in class com.facebook.buck.jvm.java.KeystoreDescriptionArg.Builder
-
Copy abstract value type AbstractKeystoreDescriptionArg
instance into builder.
- from(ConstructorArg) - Method in class com.facebook.buck.jvm.java.KeystoreDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from - Variable in class com.facebook.buck.jvm.java.lang.model.BridgeMethod
-
For a normal override bridge, this is the overriding method.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.jvm.java.PrebuiltJarDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.jvm.java.PrebuiltJarDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.jvm.java.PrebuiltJarDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(PrebuiltJarDescriptionArg) - Method in class com.facebook.buck.jvm.java.PrebuiltJarDescriptionArg.Builder
-
Fill a builder with attribute values from the provided PrebuiltJarDescriptionArg
instance.
- from(PrebuiltJarDescription.AbstractPrebuiltJarDescriptionArg) - Method in class com.facebook.buck.jvm.java.PrebuiltJarDescriptionArg.Builder
-
Copy abstract value type AbstractPrebuiltJarDescriptionArg
instance into builder.
- from(MaybeRequiredForSourceOnlyAbiArg) - Method in class com.facebook.buck.jvm.java.PrebuiltJarDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.MaybeRequiredForSourceOnlyAbiArg
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasProvidedDeps) - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasProvidedDeps
instance.
- from(JavaLibraryDescription.CoreArg) - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JavaLibraryDescription.CoreArg
instance.
- from(HasTests) - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(JvmLibraryArg) - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JvmLibraryArg
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasSrcs) - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasSrcs
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(KotlinLibraryDescription.CoreArg) - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.kotlin.KotlinLibraryDescription.CoreArg
instance.
- from(MaybeRequiredForSourceOnlyAbiArg) - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.MaybeRequiredForSourceOnlyAbiArg
instance.
- from(KotlinLibraryDescriptionArg) - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided KotlinLibraryDescriptionArg
instance.
- from(KotlinLibraryDescription.AbstractKotlinLibraryDescriptionArg) - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg.Builder
-
Copy abstract value type AbstractKotlinLibraryDescriptionArg
instance into builder.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasTestTimeout) - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTestTimeout
instance.
- from(HasSrcs) - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasSrcs
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(JavaTestDescription.CoreArg) - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JavaTestDescription.CoreArg
instance.
- from(MaybeRequiredForSourceOnlyAbiArg) - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.MaybeRequiredForSourceOnlyAbiArg
instance.
- from(HasProvidedDeps) - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasProvidedDeps
instance.
- from(JavaLibraryDescription.CoreArg) - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JavaLibraryDescription.CoreArg
instance.
- from(HasTests) - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(JvmLibraryArg) - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JvmLibraryArg
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasContacts) - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasContacts
instance.
- from(KotlinLibraryDescription.CoreArg) - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.kotlin.KotlinLibraryDescription.CoreArg
instance.
- from(KotlinTestDescriptionArg) - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided KotlinTestDescriptionArg
instance.
- from(KotlinTestDescription.AbstractKotlinTestDescriptionArg) - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg.Builder
-
Copy abstract value type AbstractKotlinTestDescriptionArg
instance into builder.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasProvidedDeps) - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasProvidedDeps
instance.
- from(JavaLibraryDescription.CoreArg) - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JavaLibraryDescription.CoreArg
instance.
- from(HasTests) - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(JvmLibraryArg) - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JvmLibraryArg
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasSrcs) - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasSrcs
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(ScalaLibraryDescription.CoreArg) - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.scala.ScalaLibraryDescription.CoreArg
instance.
- from(MaybeRequiredForSourceOnlyAbiArg) - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.MaybeRequiredForSourceOnlyAbiArg
instance.
- from(ScalaLibraryDescriptionArg) - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided ScalaLibraryDescriptionArg
instance.
- from(ScalaLibraryDescription.AbstractScalaLibraryDescriptionArg) - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg.Builder
-
Copy abstract value type AbstractScalaLibraryDescriptionArg
instance into builder.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasTestTimeout) - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTestTimeout
instance.
- from(HasSrcs) - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasSrcs
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(JavaTestDescription.CoreArg) - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JavaTestDescription.CoreArg
instance.
- from(ScalaLibraryDescription.CoreArg) - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.scala.ScalaLibraryDescription.CoreArg
instance.
- from(MaybeRequiredForSourceOnlyAbiArg) - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.MaybeRequiredForSourceOnlyAbiArg
instance.
- from(HasProvidedDeps) - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasProvidedDeps
instance.
- from(JavaLibraryDescription.CoreArg) - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JavaLibraryDescription.CoreArg
instance.
- from(HasTests) - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(JvmLibraryArg) - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.jvm.java.JvmLibraryArg
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasContacts) - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasContacts
instance.
- from(ScalaTestDescriptionArg) - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided ScalaTestDescriptionArg
instance.
- from(ScalaTestDescription.AbstractScalaTestDescriptionArg) - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg.Builder
-
Copy abstract value type AbstractScalaTestDescriptionArg
instance into builder.
- from(String) - Static method in enum com.facebook.buck.parser.api.Syntax
-
Converts a syntax name to a corresponding enum value.
- from(Exception) - Static method in class com.facebook.buck.parser.exceptions.ParsingError
-
Transform regular Exception to parsing error object
- from(UnconfiguredBuildTargetWithOutputs) - Static method in class com.facebook.buck.parser.spec.BuildTargetSpec
-
- from(UnconfiguredBuildTarget) - Static method in class com.facebook.buck.parser.spec.BuildTargetSpec
-
- from(Object, String) - Static method in class com.facebook.buck.rules.args.ArgFactory
-
- from(Object) - Static method in class com.facebook.buck.rules.args.ArgFactory
-
Convert a command line argument to an
Arg
- from(ImmutableList<SourcePathArg>) - Static method in class com.facebook.buck.rules.args.FileListableLinkerInputArg
-
- from(Function<? super String, String>, Iterable<String>) - Static method in class com.facebook.buck.rules.args.SanitizedArg
-
Create a list of SanitizedArgs by applying the given sanitizer function to a list of arg
strings and filtering empty args
- from(Iterable<SourcePath>) - Static method in class com.facebook.buck.rules.args.SourcePathArg
-
- from(SourcePath...) - Static method in class com.facebook.buck.rules.args.SourcePathArg
-
- from(Iterable<String>) - Static method in class com.facebook.buck.rules.args.StringArg
-
- from(String...) - Static method in class com.facebook.buck.rules.args.StringArg
-
- from(Path) - Method in interface com.facebook.buck.rules.modern.BuildCellRelativePathFactory
-
Converts a Path relative to the Buildable's ProjectFilesystem to a BuildCellRelativePath.
- from(OutputPath) - Method in interface com.facebook.buck.rules.modern.BuildCellRelativePathFactory
-
Converts an OutputPath to a BuildCellRelativePath.
- from(Path) - Method in class com.facebook.buck.rules.modern.DefaultBuildCellRelativePathFactory
-
- from(OutputPath) - Method in class com.facebook.buck.rules.modern.DefaultBuildCellRelativePathFactory
-
- from(CommandAliasDescriptionArg) - Method in class com.facebook.buck.shell.CommandAliasDescriptionArg.Builder
-
Fill a builder with attribute values from the provided CommandAliasDescriptionArg
instance.
- from(CommandAliasDescription.AbstractCommandAliasDescriptionArg) - Method in class com.facebook.buck.shell.CommandAliasDescriptionArg.Builder
-
Copy abstract value type AbstractCommandAliasDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.shell.CommandAliasDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.shell.CommandAliasDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(ExportFileDescriptionArg) - Method in class com.facebook.buck.shell.ExportFileDescriptionArg.Builder
-
Fill a builder with attribute values from the provided ExportFileDescriptionArg
instance.
- from(ExportFileDescription.AbstractExportFileDescriptionArg) - Method in class com.facebook.buck.shell.ExportFileDescriptionArg.Builder
-
Copy abstract value type AbstractExportFileDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.shell.ExportFileDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.shell.ExportFileDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(GenruleDescriptionArg) - Method in class com.facebook.buck.shell.GenruleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided GenruleDescriptionArg
instance.
- from(GenruleDescription.AbstractGenruleDescriptionArg) - Method in class com.facebook.buck.shell.GenruleDescriptionArg.Builder
-
Copy abstract value type AbstractGenruleDescriptionArg
instance into builder.
- from(HasTests) - Method in class com.facebook.buck.shell.GenruleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(AbstractGenruleDescription.CommonArg) - Method in class com.facebook.buck.shell.GenruleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.shell.AbstractGenruleDescription.CommonArg
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.shell.GenruleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.shell.GenruleDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(ShBinaryDescriptionArg) - Method in class com.facebook.buck.shell.ShBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided ShBinaryDescriptionArg
instance.
- from(ShBinaryDescription.AbstractShBinaryDescriptionArg) - Method in class com.facebook.buck.shell.ShBinaryDescriptionArg.Builder
-
Copy abstract value type AbstractShBinaryDescriptionArg
instance into builder.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.shell.ShBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasTests) - Method in class com.facebook.buck.shell.ShBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTests
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.shell.ShBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.shell.ShBinaryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(HasDeclaredDeps) - Method in class com.facebook.buck.shell.ShTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(HasTestTimeout) - Method in class com.facebook.buck.shell.ShTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasTestTimeout
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.shell.ShTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(HasContacts) - Method in class com.facebook.buck.shell.ShTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasContacts
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.shell.ShTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(ShTestDescriptionArg) - Method in class com.facebook.buck.shell.ShTestDescriptionArg.Builder
-
Fill a builder with attribute values from the provided ShTestDescriptionArg
instance.
- from(ShTestDescription.AbstractShTestDescriptionArg) - Method in class com.facebook.buck.shell.ShTestDescriptionArg.Builder
-
Copy abstract value type AbstractShTestDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.shell.TestSuiteDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.shell.TestSuiteDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(TestSuiteDescriptionArg) - Method in class com.facebook.buck.shell.TestSuiteDescriptionArg.Builder
-
Fill a builder with attribute values from the provided TestSuiteDescriptionArg
instance.
- from(TestSuiteDescription.AbstractTestSuiteDescriptionArg) - Method in class com.facebook.buck.shell.TestSuiteDescriptionArg.Builder
-
Copy abstract value type AbstractTestSuiteDescriptionArg
instance into builder.
- from(WorkerToolDescriptionArg) - Method in class com.facebook.buck.shell.WorkerToolDescriptionArg.Builder
-
Fill a builder with attribute values from the provided WorkerToolDescriptionArg
instance.
- from(WorkerToolDescription.AbstractWorkerToolDescriptionArg) - Method in class com.facebook.buck.shell.WorkerToolDescriptionArg.Builder
-
Copy abstract value type AbstractWorkerToolDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.shell.WorkerToolDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.shell.WorkerToolDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(BuckConfig) - Static method in class com.facebook.buck.support.cli.config.AliasConfig
-
- from(HasDeclaredDeps) - Method in class com.facebook.buck.swift.SwiftLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasDeclaredDeps
instance.
- from(BuildRuleArg) - Method in class com.facebook.buck.swift.SwiftLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(SwiftLibraryDescriptionArg) - Method in class com.facebook.buck.swift.SwiftLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided SwiftLibraryDescriptionArg
instance.
- from(SwiftLibraryDescription.AbstractSwiftLibraryDescriptionArg) - Method in class com.facebook.buck.swift.SwiftLibraryDescriptionArg.Builder
-
Copy abstract value type AbstractSwiftLibraryDescriptionArg
instance into builder.
- from(HasSrcs) - Method in class com.facebook.buck.swift.SwiftLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.HasSrcs
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.swift.SwiftLibraryDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(SwiftToolchainDescriptionArg) - Method in class com.facebook.buck.swift.SwiftToolchainDescriptionArg.Builder
-
Fill a builder with attribute values from the provided SwiftToolchainDescriptionArg
instance.
- from(SwiftToolchainDescription.AbstractSwiftToolchainDescriptionArg) - Method in class com.facebook.buck.swift.SwiftToolchainDescriptionArg.Builder
-
Copy abstract value type AbstractSwiftToolchainDescriptionArg
instance into builder.
- from(BuildRuleArg) - Method in class com.facebook.buck.swift.SwiftToolchainDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.swift.SwiftToolchainDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(T[]) - Static method in interface com.facebook.buck.util.stream.RichStream
-
- from(Iterable<T>) - Static method in interface com.facebook.buck.util.stream.RichStream
-
- from(Iterator<T>) - Static method in interface com.facebook.buck.util.stream.RichStream
-
- from(Optional<T>) - Static method in interface com.facebook.buck.util.stream.RichStream
-
- from(Stream<T>) - Static method in interface com.facebook.buck.util.stream.RichStream
-
- from(BuildRuleArg) - Method in class com.facebook.buck.versions.VersionedAliasDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.BuildRuleArg
instance.
- from(ConstructorArg) - Method in class com.facebook.buck.versions.VersionedAliasDescriptionArg.Builder
-
Fill a builder with attribute values from the provided com.facebook.buck.core.description.arg.ConstructorArg
instance.
- from(VersionedAliasDescriptionArg) - Method in class com.facebook.buck.versions.VersionedAliasDescriptionArg.Builder
-
Fill a builder with attribute values from the provided VersionedAliasDescriptionArg
instance.
- from(VersionedAliasDescription.AbstractVersionedAliasDescriptionArg) - Method in class com.facebook.buck.versions.VersionedAliasDescriptionArg.Builder
-
Copy abstract value type AbstractVersionedAliasDescriptionArg
instance into builder.
- fromArchitecture(Architecture) - Static method in enum com.facebook.buck.features.go.GoArch
-
returns the corresponding GoOs for a given Architecture
- fromArgs(Function<? super String, String>, Iterable<Arg>) - Static method in class com.facebook.buck.rules.args.SanitizedArg
-
Create a list of SanitizedArg from list of Arg by applying the given sanitizer StringArg and
filtering empty StringArg.
- fromArgs(String...) - Static method in class com.facebook.buck.testrunner.InstrumentationTestRunner
-
- fromArtifactCache(BuildCacheArtifactFetcher, ArtifactCache) - Static method in class com.facebook.buck.core.build.engine.cache.manager.ManifestRuleKeyServiceFactory
-
Return an implementation of ManifestRuleKeyService that uses the ArtifactCache/buckcache.
- fromArtifactInfo(ArtifactInfo) - Static method in enum com.facebook.buck.artifact_cache.ArtifactCacheEvent.StoreType
-
- fromBuckConfig(ParserConfig, UnconfiguredBuildTargetViewFactory, CellPathResolver, CellNameResolver) - Static method in class com.facebook.buck.parser.detector.TargetConfigurationDetectorFactory
-
Configure detector using provided .buckconfig
- fromBuckconfigValue(String) - Static method in enum com.facebook.buck.android.toolchain.ndk.NdkTargetArchAbi
-
Get a value from a string used in buckconfig, throw if ABI is unknown.
- fromBuildSetting(String) - Static method in enum com.facebook.buck.apple.xcode.xcodeproj.PBXReference.SourceTree
-
Return a sourceTree given a build setting that is typically used as a source tree prefix.
- fromBytes(byte[]) - Static method in class com.facebook.buck.util.sha1.Sha1HashCode
-
Clones the specified bytes and uses the clone to create a new
Sha1HashCode
.
- fromCellRelativePath(Path, ProjectFilesystem, Path) - Static method in class com.facebook.buck.io.BuildCellRelativePath
-
- fromCellRelativePath(AbsPath, ProjectFilesystem, Path) - Static method in class com.facebook.buck.io.BuildCellRelativePath
-
- fromCommandLineArgs(String[]) - Static method in class com.facebook.buck.maven.ArtifactConfig
-
- fromConfiguration(Iterable<String>) - Static method in class com.facebook.buck.android.ClassNameFilter
-
Convenience factory to produce a filter from a very simple pattern language.
- fromConfiguration(ArtifactCacheBuckConfig) - Static method in class com.facebook.buck.artifact_cache.ClientCertificateHandler
-
Create a new ClientCertificateHandler based on client tls settings in configuration
- fromConfiguration(ArtifactCacheBuckConfig, Optional<HostnameVerifier>) - Static method in class com.facebook.buck.artifact_cache.ClientCertificateHandler
-
Create a new ClientCertificateHandler based on client tls settings in configuration, with
optional HostnameVerifier to allow for ignoring hostname mismatches in tests
- fromConfiguration(ImmutableMap<String, ImplicitInclude>) - Static method in class com.facebook.buck.parser.implicit.PackageImplicitIncludesFinder
-
- fromConfigurationString(String) - Static method in class com.facebook.buck.parser.implicit.ImplicitInclude
-
Constructs a AbstractImplicitInclude
from a configuration string in the form of
- fromDeps() - Static method in interface com.facebook.buck.cxx.CxxLibraryDescription.TransitiveCxxPreprocessorInputFunction
-
- fromExtension(String) - Static method in enum com.facebook.buck.cxx.CxxSource.Type
-
- fromFieldDeclarations(Iterable<String>) - Static method in class com.facebook.buck.rules.coercer.BuildConfigFields
-
- fromFields(Iterable<BuildConfigFields.Field>) - Static method in class com.facebook.buck.rules.coercer.BuildConfigFields
-
- fromFlavor(Flavor) - Static method in class com.facebook.buck.apple.toolchain.ApplePlatform
-
- fromFolder(IjFolder) - Static method in enum com.facebook.buck.features.project.intellij.FolderTypeWithPackageInfo
-
- fromHashCode(HashCode) - Static method in class com.facebook.buck.util.sha1.Sha1HashCode
-
- fromIdentifier(String) - Static method in class com.facebook.buck.core.starlark.rule.names.UserDefinedRuleNames
-
Parses the extension label and the rule name from an identifier
- fromInterpreter(ProcessExecutor, Path) - Static method in class com.facebook.buck.features.python.toolchain.impl.PythonVersionFactory
-
- fromJson(String) - Static method in class com.facebook.buck.core.model.BuildId
-
- fromJson(String, String, String, long, String, String, String, String) - Static method in class com.facebook.buck.test.TestResultSummary
-
- fromJsonFunction(Class<T>) - Static method in class com.facebook.buck.util.json.ObjectMappers
-
- fromLanguage(String) - Static method in enum com.facebook.buck.cxx.CxxSource.Type
-
Returns existing type based on the language string
- fromLibraryRule() - Static method in interface com.facebook.buck.cxx.CxxLibraryDescription.TransitiveCxxPreprocessorInputFunction
-
Retrieve the transitive CxxPreprocessorInput from the CxxLibrary rule.
- fromMode(long) - Static method in class com.facebook.buck.io.file.MorePosixFilePermissions
-
Convert a unix bit representation (e.g.
- fromName(String) - Static method in enum com.facebook.buck.util.environment.Architecture
-
- fromPath(CellRelativePath) - Static method in class com.facebook.buck.parser.spec.BuildFileSpec
-
Create a
BuildFileSpec
for a package build target pattern like foo/bar: or foo/bar:baz
- fromPaths(ImmutableMap<Path, Path>, char, Charset) - Static method in class com.facebook.buck.util.ByteBufferReplacer
-
Build a replacer using the given map of paths to replacement paths, using charset
to
convert to underlying byte arrays.
- fromPlatform(Platform) - Static method in enum com.facebook.buck.features.go.GoOs
-
returns the corresponding GoOs for a given Platform
- fromProvisioningProfilePath(ProcessExecutor, ImmutableList<String>, Path) - Static method in class com.facebook.buck.apple.toolchain.impl.ProvisioningProfileMetadataFactory
-
- fromRecursivePath(CellRelativePath) - Static method in class com.facebook.buck.parser.spec.BuildFileSpec
-
Create a
BuildFileSpec
for a recursive build target pattern like foo/bar/...
- fromResourceArgs(AppleWrapperResourceArg, ProjectFilesystem) - Static method in class com.facebook.buck.features.apple.projectV2.CoreDataResource
-
Creates a CoreDataResource object from an AppleWrapperResourceArg
- fromSearchPath(ProcessExecutor, ImmutableList<String>, Path) - Static method in class com.facebook.buck.apple.toolchain.impl.ProvisioningProfileStoreFactory
-
- fromSourcePath(SourcePath, SourcePathResolverAdapter) - Static method in class com.facebook.buck.rules.keys.DependencyFileEntry
-
- fromString(String) - Static method in enum com.facebook.buck.apple.simulator.AppleSimulatorState
-
- fromString(String) - Static method in class com.facebook.buck.artifact_cache.SecondLevelContentKey
-
Parses a given string into a SecondLevelContentKey
- fromString(String) - Static method in enum com.facebook.buck.features.go.GoArch
-
Finds the GoArch from it's name.
- fromString(String) - Static method in enum com.facebook.buck.features.go.GoOs
-
Finds the GoOs from it's name.
- fromString(String) - Static method in class com.facebook.buck.features.project.intellij.aggregation.AggregationMode
-
- fromString(String) - Static method in class com.facebook.buck.features.python.toolchain.impl.PythonVersionFactory
-
- fromString(String) - Static method in enum com.facebook.buck.jvm.java.tracing.JavacPhaseEvent.Phase
-
- fromStringWithMacros(Arg, BuildTarget, BuildRuleResolver, StringWithMacros) - Static method in class com.facebook.buck.rules.macros.WorkerMacroArg
-
- fromSupplier(Supplier<T>) - Static method in interface com.facebook.buck.util.function.ThrowingSupplier
-
- fromSupplierOfIterable(Supplier<? extends Iterable<T>>) - Static method in interface com.facebook.buck.util.stream.RichStream
-
- fromSystem(ProcessExecutor, ImmutableList<String>) - Static method in class com.facebook.buck.apple.toolchain.impl.CodeSignIdentityStoreFactory
-
Construct a store by asking the system keychain for all stored code sign identities.
- fromUnconfiguredBuildTarget(UnconfiguredBuildTarget) - Static method in class com.facebook.buck.parser.spec.BuildFileSpec
-
- FrontendOnlyJavacTask - Class in com.facebook.buck.jvm.java.abi.source
-
An implementation of JavacTask
that implements only the frontend portions of the task,
using only the parse phase of the underlying compiler and without requiring a complete classpath.
- FrontendOnlyJavacTask(JavacTask) - Constructor for class com.facebook.buck.jvm.java.abi.source.FrontendOnlyJavacTask
-
- FrontendOnlyJavacTaskProxy - Interface in com.facebook.buck.jvm.java.abi.source.api
-
- FrontendOnlyJavacTaskProxyImpl - Class in com.facebook.buck.jvm.java.abi.source
-
- FrontendOnlyJavacTaskProxyImpl(JavaCompiler.CompilationTask) - Constructor for class com.facebook.buck.jvm.java.abi.source.FrontendOnlyJavacTaskProxyImpl
-
- FrontendOnlyJavacTaskProxyImpl(FrontendOnlyJavacTask) - Constructor for class com.facebook.buck.jvm.java.abi.source.FrontendOnlyJavacTaskProxyImpl
-
- FrontendService - Class in com.facebook.buck.frontend
-
Extension of ThriftOverHttpServiceImpl to get rid of the template arguments and make it
easymock-able
- FrontendService(ThriftOverHttpServiceConfig) - Constructor for class com.facebook.buck.frontend.FrontendService
-
- FullBuildReport - Interface in com.facebook.buck.support.build.report
-
FullBuildReport is an object serialized and uploaded to the server by
BuildReportUpload
to capture diagnostics about a specific buck invocation.
- fullSize - Variable in class com.facebook.buck.event.ArtifactCompressionEvent.Finished
-
- FullVersionControlStats - Interface in com.facebook.buck.util.versioncontrol
-
- FullVersionControlStats.Builder - Class in com.facebook.buck.util.versioncontrol
-
- FullyReadOnCloseInputStream - Class in com.facebook.buck.artifact_cache
-
An
InputStream
wrapper that fully reads the underlying stream on close.
- FullyReadOnCloseInputStream(InputStream) - Constructor for class com.facebook.buck.artifact_cache.FullyReadOnCloseInputStream
-
- FunctionMacroReplacer<T> - Class in com.facebook.buck.rules.macros
-
A @{link MacroReplacer} wrapping a @{link Function}.
- FunctionMacroReplacer(Function<ImmutableList<String>, T>) - Constructor for class com.facebook.buck.rules.macros.FunctionMacroReplacer
-
- future - Variable in class com.facebook.buck.remoteexecution.util.OutputsMaterializer.PendingMaterialization
-
- garbageCollection(GCCollectionEvent) - Method in class com.facebook.buck.event.listener.MachineReadableLoggerListener
-
- gatherDeps(BuildRule) - Method in enum com.facebook.buck.jvm.java.JarShape
-
- GccCompiler - Class in com.facebook.buck.cxx.toolchain
-
- GccCompiler(Tool, ToolType, boolean) - Constructor for class com.facebook.buck.cxx.toolchain.GccCompiler
-
- GccCompiler(Tool, ToolType, boolean, boolean) - Constructor for class com.facebook.buck.cxx.toolchain.GccCompiler
-
- GCCollectionEvent - Class in com.facebook.buck.support.jvm
-
- GccPreprocessor - Class in com.facebook.buck.cxx.toolchain
-
Preprocessor implementation for a gcc toolchain.
- GccPreprocessor(Tool) - Constructor for class com.facebook.buck.cxx.toolchain.GccPreprocessor
-
- GCMajorCollectionEvent - Class in com.facebook.buck.support.jvm
-
GC Buck event representing a major GC collection.
- GCMajorCollectionEvent(GcInfo) - Constructor for class com.facebook.buck.support.jvm.GCMajorCollectionEvent
-
- GCMinorCollectionEvent - Class in com.facebook.buck.support.jvm
-
GC Buck event representing a major GC collection.
- GCMinorCollectionEvent(GcInfo) - Constructor for class com.facebook.buck.support.jvm.GCMinorCollectionEvent
-
- GCNotificationEventEmitter - Class in com.facebook.buck.support.jvm
-
- GEN_JAVA_FLAVOR - Static variable in class com.facebook.buck.android.AndroidBuildConfigDescription
-
- GenAidl - Class in com.facebook.buck.android
-
Buildable for generating a .java file from an .aidl file.
- GenAidlDescription - Class in com.facebook.buck.android
-
- GenAidlDescription() - Constructor for class com.facebook.buck.android.GenAidlDescription
-
- GenAidlDescriptionArg - Class in com.facebook.buck.android
-
Immutable implementation of GenAidlDescription.AbstractGenAidlDescriptionArg
.
- GenAidlDescriptionArg.Builder - Class in com.facebook.buck.android
-
- generate(String) - Method in class com.facebook.buck.features.ocaml.OcamlDependencyGraphGenerator
-
- generate() - Method in class com.facebook.buck.jvm.java.abi.source.FrontendOnlyJavacTask
-
- generate(Set<Element>) - Method in class com.facebook.buck.jvm.java.abi.StubGenerator
-
- generate() - Method in class com.facebook.buck.jvm.java.plugin.adapter.BuckJavacTaskProxyImpl
-
- generate() - Method in interface com.facebook.buck.jvm.java.plugin.api.BuckJavacTaskProxy
-
- GENERATE - Static variable in class com.facebook.buck.jvm.java.tracing.JavacPhaseEvent.Constants
-
- generateActiveNetworkAsync(ExecutorService, BuckEventBus) - Static method in class com.facebook.buck.util.environment.NetworkInfo
-
- generateBuildConfigDotJava(UnflavoredBuildTarget, String) - Static method in class com.facebook.buck.android.BuildConfigs
-
- generateBuildConfigDotJava(UnflavoredBuildTarget, String, boolean, BuildConfigFields) - Static method in class com.facebook.buck.android.BuildConfigs
-
Generates the source code for an Android BuildConfig.java
file with fields specified by
userFields
.
- generateBuildConfigDotJava(UnflavoredBuildTarget, String, boolean) - Method in class com.facebook.buck.rules.coercer.BuildConfigFields
-
Creates the Java code for a BuildConfig.java
file in the specified javaPackage
.
- GenerateBuildConfigStep - Class in com.facebook.buck.android
-
- GenerateBuildConfigStep(ProjectFilesystem, UnflavoredBuildTarget, String, boolean, Supplier<BuildConfigFields>, Path) - Constructor for class com.facebook.buck.android.GenerateBuildConfigStep
-
- GenerateCodeCoverageReportStep - Class in com.facebook.buck.jvm.java
-
- GenerateCodeCoverageReportStep(ImmutableList<String>, ProjectFilesystem, Set<String>, Set<Path>, Path, Set<CoverageReportFormat>, String, Optional<String>, Optional<String>) - Constructor for class com.facebook.buck.jvm.java.GenerateCodeCoverageReportStep
-
- generateDependencyMap(String) - Method in class com.facebook.buck.features.ocaml.OcamlDependencyGraphGenerator
-
- generatedProject - Variable in class com.facebook.buck.features.apple.projectV2.ProjectGenerator.Result
-
- generateEndpointRequest(BuildLogEntry, DefectReporter.DefectSubmitResult) - Method in class com.facebook.buck.doctor.DoctorReportHelper
-
- generateFileId() - Method in class com.facebook.buck.logd.server.LogFileIdGenerator
-
- generateForConsole(Console) - Method in class com.facebook.buck.command.BuildReport
-
- generateGid(String, int) - Method in class com.facebook.buck.apple.xcode.GidGenerator
-
Generate a stable GID based on the class name and hash of some object info.
- generateGid(GidGenerator) - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXObject
-
Generate a stable GID.
- generateJsonBuildReport() - Method in class com.facebook.buck.command.BuildReport
-
- generateJsonOutput - Variable in class com.facebook.buck.cli.AbstractQueryCommand
-
Deprecated.
- GenerateManifestStep - Class in com.facebook.buck.android
-
- GenerateManifestStep(ProjectFilesystem, Path, APKModule, ImmutableSet<Path>, Path, Path) - Constructor for class com.facebook.buck.android.GenerateManifestStep
-
- generatePomFile(SourcePathResolverAdapter, MavenPublishable) - Static method in class com.facebook.buck.maven.Pom
-
- GenerateRDotJava - Class in com.facebook.buck.android
-
- generateReplacementMap(Map<Path, Path>) - Static method in class com.facebook.buck.cxx.toolchain.objectfile.Machos
-
Prepares a replacement map for prefixes.
- generateStats(VersionControlStatsGenerator.Mode) - Method in class com.facebook.buck.util.versioncontrol.VersionControlStatsGenerator
-
- generateStatsAsync(boolean, boolean, BuckEventBus, ListeningExecutorService) - Method in class com.facebook.buck.util.versioncontrol.VersionControlStatsGenerator
-
- GenerateStringResources - Class in com.facebook.buck.android
-
Copy filtered string resources (values/strings.xml) files to output directory.
- GenerateStringResources(BuildTarget, ProjectFilesystem, SourcePathRuleFinder, ImmutableList<FilteredResourcesProvider>) - Constructor for class com.facebook.buck.android.GenerateStringResources
-
- generateTarget(TargetNode<?>) - Method in class com.facebook.buck.features.apple.projectV2.XcodeNativeTargetGenerator
-
Generates the target node.
- generateThinFlavors(SortedSet<Flavor>) - Static method in class com.facebook.buck.apple.MultiarchFileInfos
-
Expand flavors representing a fat binary into its thin binary equivalents.
- generateWorkspaceAndDependentProjects(Map<Path, ProjectGenerator>, ListeningExecutorService) - Method in class com.facebook.buck.features.apple.project.WorkspaceAndProjectGenerator
-
- generateWorkspaceAndDependentProjects(ListeningExecutorService) - Method in class com.facebook.buck.features.apple.projectV2.WorkspaceAndProjectGenerator
-
Generates a workspace and all projects
- GenericFileParsePipeline<T extends FileManifest> - Class in com.facebook.buck.parser
-
A pipeline that provides cached parsed results for a given file.
- GenericFileParsePipeline(PipelineNodeCache<AbsPath, T>, FileParserPool<T>, ListeningExecutorService, BuckEventBus, Watchman) - Constructor for class com.facebook.buck.parser.GenericFileParsePipeline
-
- Genrule - Class in com.facebook.buck.shell
-
Build rule for generating a file via a shell command.
- Genrule(BuildTarget, ProjectFilesystem, BuildRuleResolver, SandboxExecutionStrategy, SourceSet, Optional<Arg>, Optional<Arg>, Optional<Arg>, Optional<String>, Optional<String>, Optional<ImmutableMap<String, ImmutableSet<String>>>, boolean, boolean, Optional<String>, Optional<AndroidTools>, boolean) - Constructor for class com.facebook.buck.shell.Genrule
-
- GenruleAndroidTools - Class in com.facebook.buck.shell
-
Immutable class for holding Android paths and tools, for use in
GenruleBuildable
.
- GenruleAndroidTools() - Constructor for class com.facebook.buck.shell.GenruleAndroidTools
-
- GenruleBinary - Class in com.facebook.buck.shell
-
Same as a Genrule, but marked as a binary.
- GenruleBinary(BuildTarget, ProjectFilesystem, SandboxExecutionStrategy, BuildRuleResolver, SourceSet, Optional<Arg>, Optional<Arg>, Optional<Arg>, Optional<String>, Optional<String>, Optional<ImmutableMap<String, ImmutableSet<String>>>, boolean, Optional<String>, Optional<AndroidTools>, boolean) - Constructor for class com.facebook.buck.shell.GenruleBinary
-
- GenruleBuildable - Class in com.facebook.buck.shell
-
Buildable for
Genrule
suitable for building Genrules directly and also for subclasses
extending the functionality of a bare Genrule.
- GenruleBuildable(BuildTarget, ProjectFilesystem, SandboxExecutionStrategy, SourceSet, Optional<Arg>, Optional<Arg>, Optional<Arg>, Optional<String>, Optional<String>, Optional<ImmutableMap<OutputLabel, ImmutableSet<String>>>, boolean, boolean, String, Optional<SandboxProperties>, Optional<GenruleAndroidTools>, boolean) - Constructor for class com.facebook.buck.shell.GenruleBuildable
-
- GenruleDescription - Class in com.facebook.buck.shell
-
- GenruleDescription(ToolchainProvider, BuckConfig, SandboxExecutionStrategy) - Constructor for class com.facebook.buck.shell.GenruleDescription
-
- GenruleDescriptionArg - Class in com.facebook.buck.shell
-
Immutable implementation of GenruleDescription.AbstractGenruleDescriptionArg
.
- GenruleDescriptionArg.Builder - Class in com.facebook.buck.shell
-
- GenruleOutPath - Class in com.facebook.buck.core.path
-
Class to store paths which are in out/outs argument of genrule.
- get() - Method in class com.facebook.buck.android.dalvik.EstimateDexWeightStep
-
- get(ToolchainProvider, Supplier<ExecutionContext>, BuckConfig, AdbOptions, TargetDeviceOptions) - Static method in class com.facebook.buck.android.exopackage.AndroidDevicesHelperFactory
-
- get() - Method in class com.facebook.buck.android.PackagedResource
-
- get(ByteBuffer) - Static method in class com.facebook.buck.android.resources.ResourcesXml
-
- get(ByteBuffer) - Static method in class com.facebook.buck.android.resources.ResourceTable
-
- get(ByteBuffer) - Static method in class com.facebook.buck.android.resources.ResTableType
-
- get(ByteBuffer) - Static method in class com.facebook.buck.android.resources.ResTableTypeSpec
-
- get(ByteBuffer) - Static method in class com.facebook.buck.android.resources.StringPool
-
- get(ProjectFilesystem) - Method in class com.facebook.buck.core.build.engine.cache.manager.BuildInfoStoreManager
-
- get(BuildRule) - Method in class com.facebook.buck.core.build.engine.impl.DefaultRuleDepsCache
-
- get(BuildEngineAction) - Method in class com.facebook.buck.core.build.engine.impl.DefaultRuleDepsCache
-
- get(BuildRule) - Method in interface com.facebook.buck.core.build.engine.RuleDepsCache
-
- get(BuildEngineAction) - Method in interface com.facebook.buck.core.build.engine.RuleDepsCache
-
- get(DirectoryListKey) - Method in class com.facebook.buck.core.files.DirectoryListCache
-
- get(FileTreeKey) - Method in class com.facebook.buck.core.files.FileTreeCache
-
- get(String) - Static method in interface com.facebook.buck.core.filesystems.AbsPath
-
- get(String, String...) - Static method in interface com.facebook.buck.core.filesystems.RelPath
-
Construct a path.
- get() - Method in class com.facebook.buck.core.graph.transformation.executor.DepsAwareTask.DepsSupplier
-
- get(Key) - Method in interface com.facebook.buck.core.graph.transformation.GraphEngineCache
-
Optionally returns the cached result given the key
- get(Key) - Method in class com.facebook.buck.core.graph.transformation.impl.NoOpGraphEngineCache
-
- get(BuildTarget) - Method in class com.facebook.buck.core.model.targetgraph.TargetGraph
-
Get a target from graph.
- get(BuildTarget, DependencyStack) - Method in class com.facebook.buck.core.model.targetgraph.TargetGraph
-
Get a target from graph
- get(RuleAnalysisKey) - Method in interface com.facebook.buck.core.rules.analysis.computation.RuleAnalysisGraph
-
- get(RuleAnalysisKey) - Method in class com.facebook.buck.core.rules.analysis.impl.RuleAnalysisCacheImpl
-
- get(RuleAnalysisKey) - Method in class com.facebook.buck.core.rules.analysis.impl.RuleAnalysisGraphImpl
-
- get() - Method in class com.facebook.buck.core.rules.common.BuildableSupport.DepsSupplier
-
- get(Cell) - Method in class com.facebook.buck.core.rules.knowntypes.provider.KnownRuleTypesProvider
-
- get(Provider<T>) - Method in class com.facebook.buck.core.rules.providers.collect.impl.LegacyProviderInfoCollectionImpl
-
- get(Provider<T>) - Method in class com.facebook.buck.core.rules.providers.collect.impl.ProviderInfoCollectionImpl
-
- get(Provider<T>) - Method in interface com.facebook.buck.core.rules.providers.collect.ProviderInfoCollection
-
- get(RuleAnalysisKey) - Method in class com.facebook.buck.core.rules.resolver.impl.RuleAnalysisCompatibleDelegatingActionGraphBuilder
-
- get(Object) - Method in class com.facebook.buck.core.starlark.coercer.SkylarkParamInfo
-
- get(Class<?>) - Static method in class com.facebook.buck.core.util.log.Logger
-
Gets a logger named after a class' fully qualified name.
- get(String) - Static method in class com.facebook.buck.core.util.log.Logger
-
Gets a named logger
- get() - Method in class com.facebook.buck.counters.IntegerCounter
-
- get(BuildRuleResolver, CxxPlatform) - Method in class com.facebook.buck.cxx.CxxDeps
-
- get(TargetConfiguration) - Method in class com.facebook.buck.cxx.toolchain.BuildRuleResolverCacheByTargetConfiguration
-
- get(CxxPlatform) - Method in class com.facebook.buck.cxx.toolchain.nativelink.PlatformLockedNativeLinkableGroup.Cache
-
- get(CxxPlatform, Supplier<T>) - Method in class com.facebook.buck.cxx.toolchain.nativelink.PlatformMappedCache
-
Returns either a cached or computed linkable.
- get(int) - Method in interface com.facebook.buck.cxx.toolchain.objectfile.IntIntMap
-
- get(int) - Method in class com.facebook.buck.cxx.toolchain.objectfile.IntIntMap4a
-
- get() - Method in class com.facebook.buck.io.file.LazyPath
-
On first access it will invoke the given supplier to obtain the value of the Path.
- get() - Method in class com.facebook.buck.io.watchman.WatchmanCursor
-
- get(BuildPackagePathToBuildFileManifestKey) - Method in class com.facebook.buck.parser.manifest.BuildFileManifestCache
-
- get(Protocol.Digest) - Static method in class com.facebook.buck.remoteexecution.grpc.GrpcProtocol
-
- get(Protocol.OutputFile) - Static method in class com.facebook.buck.remoteexecution.grpc.GrpcProtocol
-
- get(Protocol.OutputDirectory) - Static method in class com.facebook.buck.remoteexecution.grpc.GrpcProtocol
-
- get(Protocol.Directory) - Static method in class com.facebook.buck.remoteexecution.grpc.GrpcProtocol
-
- get() - Method in interface com.facebook.buck.remoteexecution.interfaces.MetadataProvider
-
- get() - Method in interface com.facebook.buck.remoteexecution.UploadDataSupplier
-
- get(Object) - Method in interface com.facebook.buck.rules.coercer.ParamInfo
-
- get(Object) - Method in class com.facebook.buck.rules.coercer.ReflectionParamInfo
-
- get(BuildEngineAction, CacheStatsTracker) - Method in class com.facebook.buck.rules.keys.DefaultRuleKeyCache
-
- get(BuildEngineAction, Function<? super BuildEngineAction, RuleKeyResult<V>>, CacheStatsTracker) - Method in class com.facebook.buck.rules.keys.DefaultRuleKeyCache
-
- get(AddsToRuleKey, Function<? super AddsToRuleKey, RuleKeyResult<V>>, CacheStatsTracker) - Method in class com.facebook.buck.rules.keys.DefaultRuleKeyCache
-
- get(BuildEngineAction) - Method in interface com.facebook.buck.rules.keys.RuleKeyCache
-
- get(BuildEngineAction, Function<? super BuildEngineAction, RuleKeyResult<V>>) - Method in interface com.facebook.buck.rules.keys.RuleKeyCache
-
- get(AddsToRuleKey, Function<? super AddsToRuleKey, RuleKeyResult<V>>) - Method in interface com.facebook.buck.rules.keys.RuleKeyCache
-
- get(BuildEngineAction, Function<BuildEngineAction, V>) - Method in class com.facebook.buck.rules.keys.SingleBuildActionRuleKeyCache
-
- get(AddsToRuleKey, Function<AddsToRuleKey, V>) - Method in class com.facebook.buck.rules.keys.SingleBuildActionRuleKeyCache
-
- get(Action, Function<Action, V>) - Method in class com.facebook.buck.rules.keys.SingleBuildActionRuleKeyCache
-
- get(BuildEngineAction, CacheStatsTracker) - Method in interface com.facebook.buck.rules.keys.TrackableRuleKeyCache
-
- get(BuildEngineAction, Function<? super BuildEngineAction, RuleKeyResult<V>>, CacheStatsTracker) - Method in interface com.facebook.buck.rules.keys.TrackableRuleKeyCache
-
- get(AddsToRuleKey, Function<? super AddsToRuleKey, RuleKeyResult<V>>, CacheStatsTracker) - Method in interface com.facebook.buck.rules.keys.TrackableRuleKeyCache
-
- get(BuildEngineAction) - Method in class com.facebook.buck.rules.keys.TrackedRuleKeyCache
-
- get(BuildEngineAction, Function<? super BuildEngineAction, RuleKeyResult<V>>) - Method in class com.facebook.buck.rules.keys.TrackedRuleKeyCache
-
- get(AddsToRuleKey, Function<? super AddsToRuleKey, RuleKeyResult<V>>) - Method in class com.facebook.buck.rules.keys.TrackedRuleKeyCache
-
- get(Class<U>, List<Class<? extends CustomFieldBehaviorTag>>) - Static method in class com.facebook.buck.rules.modern.CustomBehaviorUtils
-
Returns the field behavior behavior of the requested type (if there is one).
- get() - Method in class com.facebook.buck.util.AbstractCloseableMemoizedSupplier
-
- get() - Method in class com.facebook.buck.util.AbstractCloseableWrapper
-
- get(Path) - Method in class com.facebook.buck.util.cache.DelegatingFileHashCacheEngine
-
- get(Path) - Method in interface com.facebook.buck.util.cache.FileHashCacheEngine
-
- get(Path) - Method in class com.facebook.buck.util.cache.impl.DefaultFileHashCache
-
- get(Path) - Method in class com.facebook.buck.util.cache.impl.StackedFileHashCache
-
- get(ProjectFilesystem, Path) - Method in class com.facebook.buck.util.cache.impl.StackedFileHashCache
-
- get(Path) - Method in class com.facebook.buck.util.cache.impl.StatsTrackingFileHashCacheEngine
-
- get() - Method in class com.facebook.buck.util.CloseableHolder
-
- get(String, String) - Method in class com.facebook.buck.util.config.Config
-
- get(String) - Method in class com.facebook.buck.util.config.Config
-
- get() - Method in class com.facebook.buck.util.Discardable
-
- get(Path) - Method in class com.facebook.buck.util.filesystem.FileSystemMap
-
Gets the value associated with the given path.
- get() - Method in interface com.facebook.buck.util.function.ThrowingSupplier
-
- get(Path) - Method in interface com.facebook.buck.util.hashing.FileHashLoader
-
- get(ProjectFilesystem, Path) - Method in interface com.facebook.buck.util.hashing.FileHashLoader
-
- get(Path) - Method in class com.facebook.buck.util.hashing.FilePathHashLoader
-
- get(Path) - Method in interface com.facebook.buck.util.hashing.ProjectFileHashLoader
-
- get(Object) - Method in class com.facebook.buck.util.ImmutableMapWithNullValues
-
- get(Supplier<T>) - Method in class com.facebook.buck.util.Memoizer
-
- get() - Method in class com.facebook.buck.util.NamedTemporaryFile
-
- get() - Method in interface com.facebook.buck.util.versioncontrol.VersionControlSupplier
-
- get(Supplier<T>) - Method in class com.facebook.buck.util.WeakMemoizer
-
Get the value and memoize the result.
- GET_PATH_MODIFIED_TIME - Static variable in class com.facebook.buck.io.file.PathListing
-
Uses Files.getLastModifiedTime()
to get the last modified time for a Path.
- getAapt2Override() - Method in class com.facebook.buck.android.AndroidBuckConfig
-
Returns the tool provider to the platform specific aapt2 executable that is overridden by the
current project.
- getAapt2Path() - Method in interface com.facebook.buck.android.toolchain.AndroidBuildToolsLocation
-
- getAapt2Tool() - Method in class com.facebook.buck.shell.GenruleAndroidTools
-
- getAapt2ToolProvider() - Method in class com.facebook.buck.android.toolchain.AndroidPlatformTarget
-
- getAaptExecutable() - Method in class com.facebook.buck.android.toolchain.AndroidPlatformTarget
-
- getAaptMode() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getAaptMode() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getAaptMode() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getAaptMode() - Method in class com.facebook.buck.android.AndroidInstrumentationApkDescriptionArg
-
- getAaptNoResourceRemoval() - Method in class com.facebook.buck.android.AndroidBuckConfig
-
Whether to disable resource removal in aapt2.
- getAaptOutputInfo() - Method in class com.facebook.buck.android.Aapt2Link
-
- getAaptOutputInfo() - Method in class com.facebook.buck.android.AaptPackageResources
-
- getAaptOverride() - Method in class com.facebook.buck.android.AndroidBuckConfig
-
Returns the path to the platform specific aapt executable that is overridden by the current
project.
- getAaptPath() - Method in interface com.facebook.buck.android.toolchain.AndroidBuildToolsLocation
-
- getAaptTool() - Method in class com.facebook.buck.shell.GenruleAndroidTools
-
- getAar() - Method in class com.facebook.buck.android.AndroidPrebuiltAarDescriptionArg
-
- getAarUnzipPathFormat() - Static method in class com.facebook.buck.android.UnzipAar
-
- getAbbreviateName() - Method in enum com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.State
-
Abbreviated name for the current state.
- getAbbreviation() - Method in enum com.facebook.buck.util.unit.SizeUnit
-
- getAbiCompatibilityMode() - Method in class com.facebook.buck.jvm.java.CompilerParameters
-
- getAbiGenerationMode() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getAbiGenerationMode() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getAbiGenerationMode() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getAbiGenerationMode() - Method in interface com.facebook.buck.jvm.groovy.GroovyLibraryDescription.CoreArg
-
- getAbiGenerationMode() - Method in class com.facebook.buck.jvm.java.CompilerParameters
-
- getAbiGenerationMode() - Method in class com.facebook.buck.jvm.java.ConfiguredCompilerFactory
-
- getAbiGenerationMode() - Method in class com.facebook.buck.jvm.java.JavaBuckConfig
-
- getAbiGenerationMode() - Method in class com.facebook.buck.jvm.java.JavaConfiguredCompilerFactory
-
- getAbiGenerationMode() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getAbiGenerationMode() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getAbiGenerationMode() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getAbiGenerationMode() - Method in interface com.facebook.buck.jvm.java.JvmLibraryArg
-
- getAbiGenerationMode() - Method in class com.facebook.buck.jvm.kotlin.KotlinBuckConfig
-
- getAbiGenerationMode() - Method in class com.facebook.buck.jvm.kotlin.KotlinConfiguredCompilerFactory
-
- getAbiGenerationMode() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getAbiGenerationMode() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getAbiGenerationMode() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getAbiGenerationMode() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getAbiInfo() - Method in class com.facebook.buck.android.DummyRDotJava
-
- getAbiInfo() - Method in interface com.facebook.buck.jvm.core.HasJavaAbi
-
- getAbiInfo() - Method in class com.facebook.buck.jvm.java.CalculateClassAbi
-
- getAbiInfo() - Method in class com.facebook.buck.jvm.java.CalculateSourceAbi
-
- getAbiInfo() - Method in class com.facebook.buck.jvm.java.CalculateSourceAbiFromLibraryTarget
-
- getAbiInfo() - Method in class com.facebook.buck.jvm.java.CompareAbis
-
- getAbiInfo() - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getAbiInfo() - Method in class com.facebook.buck.jvm.java.PrebuiltJar
-
- getAbiJar() - Method in class com.facebook.buck.android.DummyRDotJava
-
- getAbiJar() - Method in interface com.facebook.buck.jvm.core.CalculateAbi
-
- getAbiJar() - Method in interface com.facebook.buck.jvm.core.HasJavaAbi
-
- getAbiJar() - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getAbiJar() - Method in class com.facebook.buck.jvm.java.PrebuiltJar
-
- getAbiJarParameters(BuildTarget, BuildContext, ProjectFilesystem, CompilerParameters) - Method in class com.facebook.buck.jvm.java.JarBuildStepsFactory
-
- getAbiJarPath() - Method in class com.facebook.buck.jvm.java.CompilerOutputPaths
-
- getAbiJarPath(BuildTarget, ProjectFilesystem) - Static method in class com.facebook.buck.jvm.java.CompilerOutputPaths
-
- getAbiRules(ActionGraphBuilder, Iterable<BuildRule>) - Static method in class com.facebook.buck.jvm.java.JavaLibraryRules
-
- getAbsoluteHeaderPath() - Method in class com.facebook.buck.cxx.PreInclude
-
- getAbsolutePath(SourcePath) - Method in class com.facebook.buck.core.sourcepath.resolver.impl.AbstractSourcePathResolver
-
- getAbsolutePath(SourcePath) - Method in interface com.facebook.buck.core.sourcepath.resolver.SourcePathResolver
-
- getAbsolutePath(SourcePath) - Method in class com.facebook.buck.core.sourcepath.resolver.SourcePathResolverAdapter
-
- getAbsolutePathToBuildFile(Cell, UnconfiguredBuildTarget) - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getAbsolutePathToBuildFileUnsafe(Cell, UnconfiguredBuildTarget) - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getAccessedConfigurationOptions() - Method in class com.facebook.buck.skylark.parser.context.ParseContext
-
- getAccessFlags(TypeElement) - Method in class com.facebook.buck.jvm.java.abi.AccessFlags
-
Gets the class access flags (see JVMS8 4.1) for the given type element, augmented by the
special ASM pseudo-access flag for @Deprecated types.
- getAccessFlags(ExecutableElement) - Method in class com.facebook.buck.jvm.java.abi.AccessFlags
-
Gets the method access flags (see JVMS8 4.6) for the given executable element, augmented by the
special ASM pseudo-access flag for @Deprecated methods.
- getAccessFlags(VariableElement) - Method in class com.facebook.buck.jvm.java.abi.AccessFlags
-
Gets the field access flags (see JVMS8 4.5) for the given variable element, augmented by the
special ASM pseudo-access flag for @Deprecated fields.
- getAccessFlagsForClassNode(TypeElement) - Method in class com.facebook.buck.jvm.java.abi.AccessFlags
-
Gets the class access flags (see JVMS8 4.1) for the given type element as they should appear in
the ClassNode of a class file.
- getAccessLevel() - Method in class com.facebook.buck.jvm.java.JarFileObject
-
- getAction() - Method in interface com.facebook.buck.core.rules.actions.ActionWrapperData
-
- getActionConfigNames() - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg
-
- getActionConfigNamesFromArg(Optional<XcodeWorkspaceConfigDescriptionArg>) - Static method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescription
-
- getActionDataKey() - Method in interface com.facebook.buck.core.artifact.BuildArtifact
-
- getActionDigest() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.Started
-
- getActionDigest() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.Terminal
-
- getActionDigest() - Method in class com.facebook.buck.rules.modern.builders.RemoteExecutionActionInfo
-
- getActionGraph() - Method in class com.facebook.buck.core.model.actiongraph.ActionGraphAndBuilder
-
- getActionGraph(TargetGraphCreationResult) - Method in class com.facebook.buck.core.model.actiongraph.computation.ActionGraphProvider
-
Create an ActionGraph, using options extracted from a BuckConfig.
- getActionGraph(TargetNodeToBuildRuleTransformer, TargetGraphCreationResult, Optional<ThriftRuleKeyLogger>) - Method in class com.facebook.buck.core.model.actiongraph.computation.ActionGraphProvider
-
- getActionGraphAndBuilder() - Method in class com.facebook.buck.core.model.graph.ActionAndTargetGraphs
-
- getActionGraphBuilder() - Method in class com.facebook.buck.core.model.actiongraph.ActionGraphAndBuilder
-
- getActionGraphBuilder() - Method in interface com.facebook.buck.core.rules.BuildRuleCreationContext
-
- getActionGraphBuilder() - Method in interface com.facebook.buck.core.rules.BuildRuleCreationContextWithTargetGraph
-
- getActionGraphBuilder() - Method in class com.facebook.buck.cxx.CxxSourceRuleFactory
-
- getActionGraphBuilder() - Method in class com.facebook.buck.rules.macros.StringWithMacrosConverter
-
- getActionGraphCache() - Method in class com.facebook.buck.support.state.BuckGlobalState
-
- getActionGraphProvider() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getActionGraphProvider() - Method in interface com.facebook.buck.cli.MainRunner.ParserAndCaches
-
- getActionGraphTimeMs() - Method in class com.facebook.buck.log.PerfTimesStats
-
- getActionMetadata() - Method in interface com.facebook.buck.remoteexecution.RemoteExecutionServiceClient.ExecutionResult
-
- getActionOptional(ActionAnalysisData.ID) - Method in interface com.facebook.buck.core.rules.analysis.action.ActionAnalysisDataLookUp
-
- getActionOptional(ActionAnalysisData.ID) - Method in class com.facebook.buck.core.rules.analysis.impl.LegacyProviderRuleAnalysisResult
-
- getActionResultDigest() - Method in interface com.facebook.buck.remoteexecution.RemoteExecutionServiceClient.ExecutionResult
-
- getActions() - Method in class com.facebook.buck.core.starlark.rule.SkylarkRuleContext
-
- getActionsPerState() - Method in class com.facebook.buck.remoteexecution.event.listener.RemoteExecutionEventListener
-
- getActionsPerState() - Method in interface com.facebook.buck.remoteexecution.event.RemoteExecutionStatsProvider
-
Current state of all remote execution Actions.
- getActivityLogs() - Method in interface com.facebook.buck.apple.AbstractIdbTestResult
-
Array of strings that show the activity logs
- getActivityName() - Method in class com.facebook.buck.event.StartActivityEvent
-
- getActivityToStart() - Method in class com.facebook.buck.cli.InstallCommand
-
- getActool() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
actool binary.
- getActool() - Method in class com.facebook.buck.apple.toolchain.AppleCxxPlatform
-
- getActualHashCode() - Method in class com.facebook.buck.artifact_cache.HttpArtifactCacheBinaryProtocol.MetadataAndPayloadReadResult
-
- getAdbExecutable() - Method in class com.facebook.buck.android.toolchain.AndroidPlatformTarget
-
- getAdbOptions(BuckConfig) - Method in class com.facebook.buck.cli.AdbCommandLineOptions
-
- getAdbOptions(BuckConfig) - Method in class com.facebook.buck.cli.TestCommand
-
- getAdbOverride() - Method in class com.facebook.buck.android.AndroidBuckConfig
-
Returns the path to the adb executable overridden by the current project.
- getAdbPath() - Method in interface com.facebook.buck.android.toolchain.AdbToolchain
-
- getAdbRapidInstallTypes() - Method in class com.facebook.buck.android.exopackage.AdbConfig
-
- getAdbSearchOrder() - Method in class com.facebook.buck.android.AndroidBuckConfig
-
Defines the order to search for the adb executable: a list consisting of the elements '
',
representing the first adb on the system PATH, or '', representing the adb in the
platform-tools directory of the currently configured Android SDK location.
- getAdbThreadCount() - Method in class com.facebook.buck.step.AdbOptions
-
- getAdbTimeout() - Method in class com.facebook.buck.android.AndroidBuckConfig
-
- getAdbTimeout() - Method in class com.facebook.buck.step.AdbOptions
-
- getAdditionalAaptParams() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getAdditionalAaptParams() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getAdditionalAaptParams() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getAdditionalClasspathEntries(SourcePathResolverAdapter) - Method in interface com.facebook.buck.jvm.java.JavaTest.AdditionalClasspathEntriesProvider
-
- getAdditionalClasspathEntries(SourcePathResolverAdapter) - Method in class com.facebook.buck.jvm.kotlin.ExternalKotlinc
-
- getAdditionalClasspathEntries(SourcePathResolverAdapter) - Method in class com.facebook.buck.jvm.kotlin.JarBackedReflectedKotlinc
-
- getAdditionalClasspathEntries(SourcePathResolverAdapter) - Method in interface com.facebook.buck.jvm.kotlin.Kotlinc
-
- getAdditionalCoverageTargets() - Method in class com.facebook.buck.core.test.rule.ExternalTestRunnerTestSpec
-
- getAdditionalCoverageTargets() - Method in class com.facebook.buck.cxx.CxxTest
-
- getAdditionalCoverageTargets() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getAdditionalCoverageTargets() - Method in class com.facebook.buck.features.python.PythonTest
-
- getAdditionalCoverageTargets() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getAdditionalExportedLinkerFlags() - Method in interface com.facebook.buck.cxx.CxxLibraryDescriptionDelegate.ConfiguredDelegate
-
Provides the ability to inject additional exported linker flags.
- getAdditionalSchemeActions() - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg
-
- getAdditionalTargetsToBuild(BuildCommand.GraphsAndBuildTargets) - Method in class com.facebook.buck.cli.BuildCommand
-
- getAdditionalTargetsToBuild(BuildCommand.GraphsAndBuildTargets) - Method in class com.facebook.buck.cli.InstallCommand
-
- getAggregatedCacheRateStats(ImmutableCollection<CacheRateStatsKeeper.CacheRateStatsUpdateEvent>) - Static method in class com.facebook.buck.event.listener.stats.cache.CacheRateStatsKeeper
-
- getAggregationLimit(IjProjectConfig) - Method in enum com.facebook.buck.features.project.intellij.model.IjModuleType
-
- getAggregationLimitForAndroidResourceModule() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getAggregationMode() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getAggregationTag() - Method in class com.facebook.buck.features.project.intellij.aggregation.AggregationContext
-
- getAggregationTag() - Method in class com.facebook.buck.features.project.intellij.aggregation.AggregationModule
-
Uniquely identifies the type of this module for aggregation purpose.
- getAidl() - Method in class com.facebook.buck.android.GenAidlDescriptionArg
-
- getAidlExecutable() - Method in class com.facebook.buck.android.toolchain.AndroidPlatformTarget
-
- getAidlSrcs() - Method in class com.facebook.buck.android.GenAidlDescriptionArg
-
- getAlias() - Method in class com.facebook.buck.android.KeystoreProperties
-
- getAliases() - Method in class com.facebook.buck.support.cli.config.AliasConfig
-
- getAll() - Method in class com.facebook.buck.apple.AppleBundleResources
-
Returns all the SourcePaths from the different types of resources.
- getAll(Iterable<BuildTarget>) - Method in class com.facebook.buck.core.model.targetgraph.TargetGraph
-
- getAll(Set<RuleAnalysisKey>) - Method in interface com.facebook.buck.core.rules.analysis.computation.RuleAnalysisGraph
-
- getAll(Set<RuleAnalysisKey>) - Method in class com.facebook.buck.core.rules.analysis.impl.RuleAnalysisGraphImpl
-
- getAll(Set<RuleAnalysisKey>) - Method in class com.facebook.buck.core.rules.resolver.impl.RuleAnalysisCompatibleDelegatingActionGraphBuilder
-
- getAll(ListeningExecutorService, Iterable<Callable<V>>) - Static method in class com.facebook.buck.util.concurrent.MoreFutures
-
Invoke multiple callables on the provided executor and wait for all to return successfully.
- getAllAbsolutePaths(Collection<? extends SourcePath>) - Method in class com.facebook.buck.core.sourcepath.resolver.impl.AbstractSourcePathResolver
-
- getAllAbsolutePaths(Collection<? extends SourcePath>) - Method in interface com.facebook.buck.core.sourcepath.resolver.SourcePathResolver
-
- getAllAbsolutePaths(Collection<? extends SourcePath>) - Method in class com.facebook.buck.core.sourcepath.resolver.SourcePathResolverAdapter
-
Returns the
Path
instances associated with the given
SourcePath
instances.
- getAllAvailableWriters() - Method in interface com.facebook.buck.log.ConsoleHandlerState
-
- getAllBridgeMethods(TypeElement) - Method in interface com.facebook.buck.jvm.java.lang.model.ElementsExtended
-
- getAllBridgeMethods(TypeElement) - Method in class com.facebook.buck.jvm.java.plugin.adapter.ElementsExtendedImpl
-
- getAllCells() - Method in interface com.facebook.buck.core.cell.Cell
-
Returns a list of all cells, including this cell.
- getAllCells() - Method in class com.facebook.buck.core.cell.Cells
-
- getAllDestinations() - Method in class com.facebook.buck.apple.AppleBundleResources
-
All kinds of destinations that are used by paths in this object.
- getAllFlags() - Method in class com.facebook.buck.cxx.CxxToolFlags
-
Returns all flags in the appropriate order.
- getAllKnownTargets() - Method in class com.facebook.buck.core.rulekey.calculator.ParallelRuleKeyCalculator
-
- getAllMavenRepos() - Method in class com.facebook.buck.file.downloader.impl.DownloadConfig
-
- getAllMetadata(BuildTarget) - Method in interface com.facebook.buck.core.build.engine.buildinfo.BuildInfoStore
-
- getAllMetadata(BuildTarget) - Method in class com.facebook.buck.core.build.engine.buildinfo.SQLiteBuildInfoStore
-
- getAllMethods(TypeElement, CharSequence) - Method in interface com.facebook.buck.jvm.java.lang.model.ElementsExtended
-
- getAllMethods(TypeElement, CharSequence) - Method in class com.facebook.buck.jvm.java.plugin.adapter.ElementsExtendedImpl
-
- getAllModules(InputStream) - Method in class com.facebook.buck.features.project.intellij.IntellijModulesListParser
-
- getAllNodesJob(Cell, AbsPath) - Method in class com.facebook.buck.parser.UnconfiguredTargetNodePipeline
-
Get or load all raw target nodes from a build file
- getAllOutputs() - Method in class com.facebook.buck.features.ocaml.OcamlMLCompileStep.Args
-
- getAllowedDuplicateResourceTypes() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getAllowedDuplicateResourceTypes() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getAllowedDuplicateResourceTypes() - Method in interface com.facebook.buck.android.HasDuplicateAndroidResourceTypes
-
- getAllowedToReadMetadataPaths() - Method in class com.facebook.buck.sandbox.SandboxProperties
-
Paths which metadata is allowed to be read during process execution.
- getAllowedToReadPaths() - Method in class com.facebook.buck.sandbox.SandboxProperties
-
Paths that are allowed to be read during process execution.
- getAllowedToWritePaths() - Method in class com.facebook.buck.sandbox.SandboxProperties
-
Paths that are allowed to be writen during process execution.
- getAllowEmpty() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.DepListAttribute
-
Whether or not the list can be empty
- getAllowEmpty() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.IntListAttribute
-
Whether or not the list can be empty
- getAllowEmpty() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.OutputListAttribute
-
Whether or not the list can be empty
- getAllowEmpty() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.SourceListAttribute
-
Whether or not the list can be empty
- getAllowEmpty() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.SourceSortedSetAttribute
-
Whether or not the list can be empty
- getAllowEmpty() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.StringListAttribute
-
Whether or not the list can be empty
- getAllowEmpty() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.StringSortedSetAttribute
-
Whether or not the set can be empty
- getAllowEmpty() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.UnconfiguredDepListAttribute
-
Whether or not the list can be empty
- getAllowEmpty() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.UnconfiguredOptionalDepAttribute
-
Whether or not the list can be empty
- getAllowEmptyGlobs() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getAllowEmptyGlobs() - Method in class com.facebook.buck.parser.options.ProjectBuildFileParserOptions
-
- getAllowSymlinks() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getAllParamInfo() - Method in class com.facebook.buck.core.starlark.rule.SkylarkDescriptionArg
-
- getAllParamInfo() - Method in class com.facebook.buck.core.starlark.rule.SkylarkUserDefinedRule
-
Get ParamInfo objects for all of the
Attribute
s provided to this instance
- getAllPaths(Optional<Path>) - Method in class com.facebook.buck.cxx.NoopDebugPathSanitizer
-
- getAllPaths(Optional<Path>) - Method in class com.facebook.buck.cxx.toolchain.DebugPathSanitizer
-
- getAllPaths(Optional<Path>) - Method in class com.facebook.buck.cxx.toolchain.PrefixMapDebugPathSanitizer
-
- getAllPossibleHostFlavors() - Static method in class com.facebook.buck.cxx.toolchain.impl.CxxPlatforms
-
- getAllReachableJavaLibraries(Iterable<? extends BuildRule>) - Static method in class com.facebook.buck.jvm.java.JavaLibraryClasspathProvider
-
Return the classpath, including traversing any provided_deps edges and non-java edges
- getAllRules(Iterable<BuildTarget>) - Method in interface com.facebook.buck.core.rules.BuildRuleResolver
-
- getAllRules(Iterable<BuildTarget>) - Method in class com.facebook.buck.core.rules.impl.AbstractBuildRuleResolver
-
- getAllRulesInternal(Path) - Method in class com.facebook.buck.parser.PythonDslProjectBuildFileParser
-
- getAllTargetNodes(PerBuildState, Cell, AbsPath, Optional<TargetConfiguration>) - Method in interface com.facebook.buck.parser.Parser
-
- getAllTargetNodesWithTargetCompatibilityFiltering(PerBuildState, Cell, AbsPath, Optional<TargetConfiguration>) - Method in interface com.facebook.buck.parser.Parser
-
- getAllVersionPaths() - Method in class com.facebook.buck.features.apple.projectV2.CoreDataResource.VersionInformation
-
- getAllWarningsAsErrors() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
Report an error if there are any warnings.
- getAllWarningsAsErrors() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
Report an error if there are any warnings.
- getAllWarningsAsErrors() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
Report an error if there are any warnings.
- getAllWarningsAsErrors() - Method in interface com.facebook.buck.jvm.kotlin.KotlinLibraryDescription.CoreArg
-
Report an error if there are any warnings.
- getAllWarningsAsErrors() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
Report an error if there are any warnings.
- getAllWarningsAsErrors() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
Report an error if there are any warnings.
- getAllZipEntries(Path) - Static method in class com.facebook.buck.util.zip.Zip
-
- getAmortizedNanoTime() - Method in class com.facebook.buck.event.FileHashCacheEvent
-
- getAmortizedNanoTime() - Method in class com.facebook.buck.event.listener.TimeCostEntry
-
- getAmountsPerRuleType() - Method in class com.facebook.buck.core.build.engine.config.ResourceAwareSchedulingInfo
-
- getAnalyzeAction() - Method in class com.facebook.buck.apple.xcode.XCScheme
-
- getAndPostAnnouncements() - Method in class com.facebook.buck.event.listener.PublicAnnouncementManager
-
- getAndroidApkDir(ProjectFilesystem) - Static method in class com.facebook.buck.features.project.intellij.IjAndroidHelper
-
- getAndroidAppModularityResult() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getAndroidAppModularityResult() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getAndroidCompileSdkVersion() - Method in class com.facebook.buck.android.AndroidBuckConfig
-
- getAndroidDevicesHelper() - Method in class com.facebook.buck.core.build.execution.context.ExecutionContext
-
- getAndroidFacet() - Method in class com.facebook.buck.features.project.intellij.model.IjModule
-
- getAndroidFacet() - Method in class com.facebook.buck.features.project.intellij.ModuleBuildContext
-
- getAndroidFacetRelativePath(Path) - Static method in class com.facebook.buck.features.project.intellij.IjProjectPaths
-
Paths in Android facet config marked RELATIVE_PATH expect / prefix
- getAndroidFrameworkIdlFile() - Method in class com.facebook.buck.android.toolchain.AndroidPlatformTarget
-
- getAndroidGenDir(ProjectFilesystem, IjProjectConfig) - Static method in class com.facebook.buck.features.project.intellij.IjAndroidHelper
-
This directory is analogous to the gen/ directory that IntelliJ would produce when building an
Android module.
- getAndroidGenDir() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getAndroidJar() - Method in class com.facebook.buck.android.toolchain.AndroidPlatformTarget
-
- getAndroidManifest() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getAndroidManifestPath() - Method in class com.facebook.buck.features.project.intellij.model.IjModuleAndroidFacet
-
- getAndroidManifestPath(TargetNode<AndroidBinaryDescriptionArg>) - Method in interface com.facebook.buck.features.project.intellij.model.IjModuleFactoryResolver
-
- getAndroidManifestPieces() - Method in interface com.facebook.buck.android.packageable.AndroidPackageableCollection
-
Android manifests to merge with the manifest skeleton.
- getAndroidModuleSdkName() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getAndroidModuleSdkType() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getAndroidNdk() - Method in interface com.facebook.buck.android.toolchain.AndroidTools
-
- getAndroidNdkLocation() - Method in class com.facebook.buck.shell.GenruleAndroidTools
-
- getAndroidPackage() - Method in class com.facebook.buck.features.js.JsBundleDescriptionArg
-
For R.java
- getAndroidPackageableCollection() - Method in class com.facebook.buck.android.AndroidBinary
-
- getAndroidPathToDx() - Method in class com.facebook.buck.shell.GenruleAndroidTools
-
- getAndroidPathToZipalign() - Method in class com.facebook.buck.shell.GenruleAndroidTools
-
- getAndroidPlatformTarget() - Method in interface com.facebook.buck.android.toolchain.AndroidTools
-
- getAndroidProjectType() - Method in class com.facebook.buck.features.project.intellij.model.IjModuleAndroidFacet
-
- getAndroidProperties(IjModule) - Method in class com.facebook.buck.features.project.intellij.IjProjectTemplateDataPreparer
-
- getAndroidResourceDeps() - Method in class com.facebook.buck.android.DummyRDotJava
-
- getAndroidResourcePath(TargetNode<AndroidResourceDescriptionArg>) - Method in interface com.facebook.buck.features.project.intellij.model.IjModuleFactoryResolver
-
- getAndroidSdkLocation() - Method in interface com.facebook.buck.android.toolchain.AndroidTools
-
- getAndroidSdkLocation() - Method in class com.facebook.buck.shell.GenruleAndroidTools
-
- getAndroidSdkProguardConfig() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getAndroidSdkProguardConfig() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getAndroidSdkProguardConfig() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getAndroidTools(ToolchainProvider, TargetConfiguration) - Static method in interface com.facebook.buck.android.toolchain.AndroidTools
-
Returns AndroidTools
derived from a given toolProvider
- getAndroidToolsOptional(T, TargetConfiguration) - Method in class com.facebook.buck.shell.AbstractGenruleDescription
-
Returns android tools if args
has need_android_tools option set or empty optional
otherwise.
- getAnnotation(Class<A>) - Method in class com.facebook.buck.jvm.java.abi.source.TreeBackedAnnotatedConstruct
-
- getAnnotationDir(ProjectFilesystem, BuildTarget) - Static method in class com.facebook.buck.core.model.impl.BuildPaths
-
Return a path to a file in the buck-out/annotation/ directory, formatted with the target short
name.
- getAnnotationDir() - Method in class com.facebook.buck.io.filesystem.BuckPaths
-
- getAnnotationMirrors() - Method in class com.facebook.buck.jvm.java.abi.source.TreeBackedAnnotatedConstruct
-
- getAnnotationOutputPath(TargetNode<? extends JvmLibraryArg>) - Method in interface com.facebook.buck.features.project.intellij.model.IjModuleFactoryResolver
-
- getAnnotationPath(ProjectFilesystem, BuildTarget, String) - Static method in class com.facebook.buck.core.model.impl.BuildTargetPaths
-
Deprecated.
Return a path to a file in the buck-out/annotation/ directory.
- getAnnotationPath() - Method in class com.facebook.buck.jvm.java.CompilerOutputPaths
-
- getAnnotationPath(ProjectFilesystem, BuildTarget) - Static method in class com.facebook.buck.jvm.java.CompilerOutputPaths
-
- getAnnotationProcessingTool() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getAnnotationProcessingTool() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getAnnotationProcessingTool() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getAnnotationProcessingTool() - Method in interface com.facebook.buck.jvm.kotlin.KotlinLibraryDescription.CoreArg
-
- getAnnotationProcessingTool() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getAnnotationProcessingTool() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getAnnotationProcessorDeps() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getAnnotationProcessorDeps() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getAnnotationProcessorDeps() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getAnnotationProcessorDeps() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getAnnotationProcessorDeps() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getAnnotationProcessorDeps() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getAnnotationProcessorDeps() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getAnnotationProcessorDeps() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getAnnotationProcessorDeps() - Method in interface com.facebook.buck.jvm.java.JvmLibraryArg
-
- getAnnotationProcessorDeps() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getAnnotationProcessorDeps() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getAnnotationProcessorDeps() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getAnnotationProcessorDeps() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getAnnotationProcessorName() - Method in class com.facebook.buck.jvm.java.AnnotationProcessingEvent
-
- getAnnotationProcessorOnly() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getAnnotationProcessorOnly() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getAnnotationProcessorOnly() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getAnnotationProcessorOnly() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getAnnotationProcessorOnly() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getAnnotationProcessorOnly() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getAnnotationProcessorOnly() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getAnnotationProcessorOnly() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getAnnotationProcessorOnly() - Method in interface com.facebook.buck.jvm.java.JvmLibraryArg
-
- getAnnotationProcessorOnly() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getAnnotationProcessorOnly() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getAnnotationProcessorOnly() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getAnnotationProcessorOnly() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getAnnotationProcessorParams() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getAnnotationProcessorParams() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getAnnotationProcessorParams() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getAnnotationProcessorParams() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getAnnotationProcessorParams() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getAnnotationProcessorParams() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getAnnotationProcessorParams() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getAnnotationProcessorParams() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getAnnotationProcessorParams() - Method in interface com.facebook.buck.jvm.java.JvmLibraryArg
-
- getAnnotationProcessorParams() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getAnnotationProcessorParams() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getAnnotationProcessorParams() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getAnnotationProcessorParams() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getAnnotationProcessorPath(SourcePathResolverAdapter) - Method in class com.facebook.buck.jvm.kotlin.ExternalKotlinc
-
- getAnnotationProcessorPath(SourcePathResolverAdapter) - Method in class com.facebook.buck.jvm.kotlin.JarBackedReflectedKotlinc
-
- getAnnotationProcessorPath(SourcePathResolverAdapter) - Method in interface com.facebook.buck.jvm.kotlin.Kotlinc
-
- getAnnotationProcessors() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getAnnotationProcessors() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getAnnotationProcessors() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getAnnotationProcessors() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getAnnotationProcessors() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getAnnotationProcessors() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getAnnotationProcessors() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getAnnotationProcessors() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getAnnotationProcessors() - Method in interface com.facebook.buck.jvm.java.JvmLibraryArg
-
- getAnnotationProcessors() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getAnnotationProcessors() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getAnnotationProcessors() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getAnnotationProcessors() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getAnnotationsByType(Class<A>) - Method in class com.facebook.buck.jvm.java.abi.source.TreeBackedAnnotatedConstruct
-
- getAnsi() - Method in class com.facebook.buck.core.build.execution.context.ExecutionContext
-
- getAnsi() - Method in class com.facebook.buck.event.listener.RenderingConsole
-
- getAnsi() - Method in class com.facebook.buck.util.Console
-
- getAnyNode() - Method in class com.facebook.buck.core.model.targetgraph.MergedTargetNode
-
- getApiVersion() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
Allow to use declarations only from the specified version of bundled libraries.
- getApiVersion() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
Allow to use declarations only from the specified version of bundled libraries.
- getApiVersion() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
Allow to use declarations only from the specified version of bundled libraries.
- getApiVersion() - Method in interface com.facebook.buck.jvm.kotlin.KotlinLibraryDescription.CoreArg
-
Allow to use declarations only from the specified version of bundled libraries.
- getApiVersion() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
Allow to use declarations only from the specified version of bundled libraries.
- getApiVersion() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
Allow to use declarations only from the specified version of bundled libraries.
- getApk() - Method in class com.facebook.buck.android.AndroidInstrumentationApkDescriptionArg
-
- getApk() - Method in class com.facebook.buck.android.AndroidInstrumentationTest
-
- getApk() - Method in class com.facebook.buck.android.AndroidInstrumentationTestDescriptionArg
-
- getApk() - Method in class com.facebook.buck.android.ApkGenruleDescriptionArg
-
- getApkInfo() - Method in class com.facebook.buck.android.AndroidBinary
-
The APK at this path is the final one that points to an APK that a user should install.
- getApkInfo() - Method in class com.facebook.buck.android.AndroidBundle
-
The APK at this path is the final one that points to an APK that a user should install.
- getApkInfo() - Method in class com.facebook.buck.android.ApkGenrule
-
- getApkInfo() - Method in interface com.facebook.buck.android.HasInstallableApk
-
- getApkModule() - Method in interface com.facebook.buck.android.AndroidLinkableMetadata
-
- getApkModule() - Method in class com.facebook.buck.android.CopyNativeLibraries.StrippedObjectDescription
-
- getAPKModules() - Method in class com.facebook.buck.android.apkmodule.APKModuleGraph
-
- getAPKModuleToClassesMap(ImmutableMultimap<APKModule, Path>, Function<String, String>, ProjectFilesystem) - Static method in class com.facebook.buck.android.apkmodule.APKModuleGraph
-
Group the classes in the input jars into a multimap based on the APKModule they belong to
- getApkPath() - Method in class com.facebook.buck.android.HasInstallableApk.ApkInfo
-
- getApkUnderTest() - Method in class com.facebook.buck.android.AndroidInstrumentationApk
-
- getAppIcon() - Method in class com.facebook.buck.apple.AppleAssetCatalogDescriptionArg
-
- getAppID() - Method in class com.facebook.buck.apple.toolchain.ProvisioningProfileMetadata
-
Returns a (prefix, identifier) pair for which the profile is valid.
- getAppIncludesFrameworks() - Method in class com.facebook.buck.apple.toolchain.ApplePlatform
-
- getAppleCxxPlatform() - Method in class com.facebook.buck.apple.AppleToolchainBuildRule
-
- getAppleCxxPlatform(Flavor) - Method in class com.facebook.buck.apple.AppleToolchainSetBuildRule
-
- getAppleCxxPlatformForBuildTarget(BuildRuleResolver, CxxPlatformsProvider, FlavorDomain<UnresolvedAppleCxxPlatform>, BuildTarget, Optional<Flavor>, Optional<MultiarchFileInfo>) - Static method in class com.facebook.buck.apple.ApplePlatforms
-
- getAppleDebugSymbolDeps() - Method in class com.facebook.buck.apple.MultiarchFile
-
- getAppleDebugSymbolDeps() - Method in class com.facebook.buck.cxx.CxxBinary
-
- getAppleDebugSymbolDeps() - Method in class com.facebook.buck.cxx.CxxLink
-
- getAppleDebugSymbolDeps() - Method in class com.facebook.buck.cxx.CxxThinLTOIndex
-
- getAppleDebugSymbolDeps() - Method in interface com.facebook.buck.cxx.HasAppleDebugSymbolDeps
-
- getAppleDeveloperDirectory() - Method in interface com.facebook.buck.apple.toolchain.AppleDeveloperDirectoryProvider
-
- getAppleDeveloperDirectoryForTests() - Method in interface com.facebook.buck.apple.toolchain.AppleDeveloperDirectoryForTestsProvider
-
- getAppleDeveloperDirectorySupplier(ProcessExecutor) - Method in class com.facebook.buck.apple.AppleConfig
-
If specified, the value of
[apple] xcode_developer_dir
wrapped in a
Supplier
.
- getAppleDeveloperDirIfSet() - Method in class com.facebook.buck.features.rust.RustBuckConfig
-
- getAppleDeviceHelperAbsolutePath() - Method in class com.facebook.buck.apple.AppleConfig
-
- getAppleDeviceHelperTarget(Optional<TargetConfiguration>) - Method in class com.facebook.buck.apple.AppleConfig
-
Query buckconfig for device helper target.
- getAppleDsym() - Method in class com.facebook.buck.apple.AppleBundle
-
- getAppleDsym() - Method in class com.facebook.buck.apple.AppleDebuggableBinary
-
- getApplePlatform() - Method in class com.facebook.buck.apple.toolchain.AppleSdk
-
The platform of the SDK.
- getAppleSdk() - Method in class com.facebook.buck.apple.toolchain.AppleCxxPlatform
-
- getAppleSdkPaths() - Method in class com.facebook.buck.apple.toolchain.AppleCxxPlatform
-
- getAppleSdkPaths() - Method in interface com.facebook.buck.apple.toolchain.AppleSdkLocation
-
- getAppleToolchains() - Method in class com.facebook.buck.apple.AppleToolchainSetDescriptionArg
-
List of available toolchains in apple_toolchain targets.
- getAppleToolchains() - Method in interface com.facebook.buck.apple.toolchain.AppleToolchainProvider
-
- getAppleToolchainSetTarget(TargetConfiguration) - Method in class com.facebook.buck.apple.AppleConfig
-
- getAppleXcrunPath() - Method in class com.facebook.buck.features.rust.RustBuckConfig
-
- getApplicationLanguage() - Method in class com.facebook.buck.apple.xcode.XCScheme.LaunchAction
-
- getApplicationLanguage() - Method in class com.facebook.buck.apple.xcode.XCScheme.TestAction
-
- getApplicationLanguage() - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg
-
- getApplicationModuleBlacklist() - Method in class com.facebook.buck.android.AndroidAppModularityDescriptionArg
-
- getApplicationModuleBlacklist() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getApplicationModuleBlacklist() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getApplicationModuleBlacklist() - Method in interface com.facebook.buck.core.description.arg.HasApplicationModuleBlacklist
-
- getApplicationModuleConfigs() - Method in class com.facebook.buck.android.AndroidAppModularityDescriptionArg
-
- getApplicationModuleConfigs() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getApplicationModuleConfigs() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getApplicationModuleConfigs() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getApplicationModuleDependencies() - Method in class com.facebook.buck.android.AndroidAppModularityDescriptionArg
-
- getApplicationModuleDependencies() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getApplicationModuleDependencies() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getApplicationModuleDependencies() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getApplicationModulesWithManifest() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getApplicationModulesWithManifest() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getApplicationModulesWithManifest() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getApplicationModulesWithResources() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getApplicationModulesWithResources() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getApplicationModulesWithResources() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getApplicationModuleTargets() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getApplicationModuleTargets() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getApplicationModuleTargets() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getApplicationRegion() - Method in class com.facebook.buck.apple.xcode.XCScheme.LaunchAction
-
- getApplicationRegion() - Method in class com.facebook.buck.apple.xcode.XCScheme.TestAction
-
- getApplicationRegion() - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg
-
- getApplyDefaultFlavorsMode() - Method in class com.facebook.buck.parser.ParsingContext
-
Controls how flavors are appended to the build targets.
- getApproximateBuildProgress() - Method in class com.facebook.buck.event.listener.AbstractConsoleEventBusListener
-
- getApproximateBuildProgress() - Method in class com.facebook.buck.event.listener.util.ProgressEstimator
-
- getAr() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getArchitecture() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
Target architecture.
- getArchitecture() - Method in interface com.facebook.buck.apple.simulator.AppleDevice
-
String that represents the architecture of the device (i.e., "x86_64", etc)
- getArchitecture() - Method in class com.facebook.buck.core.config.BuckConfig
-
- getArchitecture() - Method in class com.facebook.buck.swift.toolchain.SwiftTargetTriple
-
- getArchitectures() - Method in class com.facebook.buck.apple.toolchain.ApplePlatform
-
- getArchitectures() - Method in class com.facebook.buck.apple.toolchain.AppleSdk
-
The architectures supported by the SDK.
- getArchiveAction() - Method in class com.facebook.buck.apple.xcode.XCScheme
-
- getArchiveContents() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getArchiveContents() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getArchiveContents(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getArchiveMembers(SourcePathRuleFinder) - Method in class com.facebook.buck.jvm.java.ZipArchiveDependencySupplier
-
- getArchiveMembers(SourcePathRuleFinder) - Method in interface com.facebook.buck.rules.keys.ArchiveDependencySupplier
-
- getArchiveOptions(boolean) - Method in interface com.facebook.buck.cxx.toolchain.Archiver
-
- getArchiveOptions(boolean) - Method in class com.facebook.buck.cxx.toolchain.BsdArchiver
-
- getArchiveOptions(boolean) - Method in class com.facebook.buck.cxx.toolchain.ClangWindowsArchiver
-
- getArchiveOptions(boolean) - Method in class com.facebook.buck.cxx.toolchain.GnuArchiver
-
- getArchiveOptions(boolean) - Method in class com.facebook.buck.cxx.toolchain.WindowsArchiver
-
- getArchivePath() - Method in class com.facebook.buck.core.io.ArchiveMemberPath
-
- getArchiver() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
Archiver binary.
- getArchiverFlags() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
Archiver flags.
- getArchiverProvider(Platform) - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getArchiverType() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
ArchiverProvider.Type
of the archiver.
- getArchiveSourcePath() - Method in class com.facebook.buck.core.sourcepath.ArchiveMemberSourcePath
-
- getArea() - Method in interface com.facebook.buck.doctor.config.DoctorSuggestion
-
- getArflags() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getArflags() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getArg() - Method in class com.facebook.buck.rules.args.FormatArg
-
- getArg() - Method in class com.facebook.buck.rules.args.StringArg
-
- getArg() - Method in class com.facebook.buck.support.cli.args.BuckCellArg
-
- getArgs(Iterable<CxxHeaders>, SourcePathResolverAdapter, Optional<PathShortener>, Preprocessor) - Static method in class com.facebook.buck.cxx.CxxHeaders
-
- getArgs() - Method in class com.facebook.buck.cxx.CxxLink
-
- getArgs() - Method in class com.facebook.buck.cxx.CxxTest
-
- getArgs() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getArgs() - Method in class com.facebook.buck.cxx.CxxThinLTOIndex
-
- getArgs() - Method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableInput
-
- getArgs() - Method in class com.facebook.buck.event.chrome_trace.ChromeTraceEvent
-
- getArgs() - Method in class com.facebook.buck.event.CommandEvent
-
- getArgs() - Method in class com.facebook.buck.event.CompilerPluginDurationEvent
-
- getArgs() - Method in class com.facebook.buck.jvm.java.tracing.JavacPhaseEvent
-
- getArgs() - Method in class com.facebook.buck.shell.CommandAliasDescriptionArg
-
- getArgs() - Method in class com.facebook.buck.shell.ShTest
-
- getArgs() - Method in class com.facebook.buck.shell.ShTestDescriptionArg
-
- getArgs() - Method in class com.facebook.buck.shell.WorkerToolDescriptionArg
-
- getArgsAndFormatStrings() - Method in interface com.facebook.buck.core.rules.actions.lib.args.CommandLineArgs
-
- getArgsAndFormatStrings() - Method in class com.facebook.buck.core.rules.providers.lib.RunInfo
-
- getArgsParser() - Method in class com.facebook.buck.cli.ProjectGeneratorParameters
-
- getArguments() - Method in class com.facebook.buck.cli.AuditCellCommand
-
- getArguments() - Method in class com.facebook.buck.cli.AuditClasspathCommand
-
- getArguments() - Method in class com.facebook.buck.cli.AuditConfigCommand
-
- getArguments() - Method in class com.facebook.buck.cli.AuditDependenciesCommand
-
- getArguments() - Method in class com.facebook.buck.cli.AuditFlavorsCommand
-
- getArguments() - Method in class com.facebook.buck.cli.AuditIncludesCommand
-
- getArguments() - Method in class com.facebook.buck.cli.AuditInputCommand
-
- getArguments() - Method in class com.facebook.buck.cli.AuditMbrIsolationCommand
-
- getArguments() - Method in class com.facebook.buck.cli.AuditOwnerCommand
-
- getArguments() - Method in class com.facebook.buck.cli.AuditRulesCommand
-
- getArguments() - Method in class com.facebook.buck.cli.AuditTestsCommand
-
- getArguments() - Method in class com.facebook.buck.cli.BuildCommand
-
- getArguments() - Method in class com.facebook.buck.cli.CacheCommand
-
- getArguments() - Method in class com.facebook.buck.cli.PerfManifestCommand
-
- getArguments() - Method in class com.facebook.buck.cli.UninstallCommand
-
- getArguments() - Method in class com.facebook.buck.cxx.CxxCompilationDatabaseEntry
-
- getArgumentsFormattedAsBuildTargets(Cell, Path, BuckConfig) - Method in class com.facebook.buck.cli.AuditDependenciesCommand
-
- getArgumentsFormattedAsBuildTargets(Cell, Path, BuckConfig) - Method in class com.facebook.buck.cli.AuditTestsCommand
-
- getArgumentTypes() - Method in class com.facebook.buck.query.AllPathsFunction
-
- getArgumentTypes() - Method in class com.facebook.buck.query.AttrFilterFunction
-
- getArgumentTypes() - Method in class com.facebook.buck.query.AttrRegexFilterFunction
-
- getArgumentTypes() - Method in class com.facebook.buck.query.BuildFileFunction
-
- getArgumentTypes() - Method in class com.facebook.buck.query.DepsFunction.FirstOrderDepsFunction
-
- getArgumentTypes() - Method in class com.facebook.buck.query.DepsFunction
-
- getArgumentTypes() - Method in class com.facebook.buck.query.DepsFunction.LookupFunction
-
- getArgumentTypes() - Method in class com.facebook.buck.query.FilterFunction
-
- getArgumentTypes() - Method in class com.facebook.buck.query.InputsFunction
-
- getArgumentTypes() - Method in class com.facebook.buck.query.KindFunction
-
- getArgumentTypes() - Method in class com.facebook.buck.query.LabelsFunction
-
- getArgumentTypes() - Method in class com.facebook.buck.query.OwnerFunction
-
- getArgumentTypes() - Method in interface com.facebook.buck.query.QueryEnvironment.QueryFunction
-
The types of the arguments of the function.
- getArgumentTypes() - Method in class com.facebook.buck.query.RdepsFunction
-
- getArgumentTypes() - Method in class com.facebook.buck.query.TestsOfFunction
-
- getArgumentTypes() - Method in class com.facebook.buck.rules.query.ClasspathFunction
-
- getArgv() - Method in class com.facebook.buck.support.fix.BuckRunSpec
-
The arguments to invoke the command.
- getArtifact() - Method in class com.facebook.buck.core.artifact.OutputArtifact
-
- getArtifactCache() - Method in class com.facebook.buck.core.build.engine.BuildEngineBuildContext
-
- getArtifactCacheFactory() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getArtifactCacheFactory() - Method in class com.facebook.buck.command.BuildExecutorArgs
-
- getArtifactCacheModes() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getArtifactCacheModesRaw() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getArtifactContentHash() - Method in interface com.facebook.buck.artifact_cache.HttpArtifactCacheEvent.HttpArtifactCacheEventFetchData
-
- getArtifactContentHash() - Method in interface com.facebook.buck.artifact_cache.HttpArtifactCacheEvent.HttpArtifactCacheEventStoreData
-
- getArtifactFilesystem() - Method in class com.facebook.buck.core.rules.actions.ActionExecutionContext
-
- getArtifactOnlyHashCode() - Method in class com.facebook.buck.artifact_cache.HttpArtifactCacheBinaryProtocol.MetadataAndPayloadReadResult
-
- getArtifacts(DefaultInfo, BuildTargetWithOutputs) - Static method in class com.facebook.buck.core.artifact.converter.DefaultInfoArtifactsRetriever
-
- getArtifacts() - Method in interface com.facebook.buck.event.listener.stats.cache.NetworkStatsKeeper.RemoteDownloadStats
-
- getArtifactsFromSrc(SourcePath, ImmutableMap<BuildTarget, ProviderInfoCollection>) - Static method in class com.facebook.buck.core.artifact.converter.SourceArtifactConverter
-
- getArtifactsFromSrcs(Iterable<SourcePath>, ImmutableMap<BuildTarget, ProviderInfoCollection>) - Static method in class com.facebook.buck.core.artifact.converter.SourceArtifactConverter
-
- getArtifactSizeBytes() - Method in class com.facebook.buck.artifact_cache.CacheResult
-
- getArtifactSizeBytes() - Method in interface com.facebook.buck.artifact_cache.HttpArtifactCacheEvent.HttpArtifactCacheEventFetchData
-
- getArtifactSizeBytes() - Method in interface com.facebook.buck.artifact_cache.HttpArtifactCacheEvent.HttpArtifactCacheEventStoreData
-
- getAs() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getAs() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getAsflags() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getAsflags() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getAsm() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getAsm() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getAsmflags() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getAsmflags() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getAsmpp() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getAsmpp() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getAsmppflags() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getAsmppflags() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getAspp() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getAspp() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getAsppflags() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getAsppflags() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getAssembler() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
Assembler binary.
- getAssemblerFlags(NdkCompilerType) - Method in class com.facebook.buck.android.toolchain.ndk.NdkCxxPlatformTargetConfiguration
-
- getAssemblerFlags(NdkCompilerType) - Method in enum com.facebook.buck.android.toolchain.ndk.TargetCpuType
-
- getAssemblerFlags() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
Flags for the assembler.
- getAssemblerFlags() - Method in class com.facebook.buck.features.go.GoBinaryDescriptionArg
-
- getAssemblerFlags() - Method in class com.facebook.buck.features.go.GoLibraryDescriptionArg
-
- getAssemblerFlags() - Method in class com.facebook.buck.features.go.GoTestDescriptionArg
-
- getAssemblerFlags() - Method in interface com.facebook.buck.features.go.HasGoLinkable
-
- getAssembly() - Method in class com.facebook.buck.features.dotnet.PrebuiltDotnetLibraryDescriptionArg
-
- getAssetCatalogsCompilationOptions() - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg
-
- getAssetCatalogsCompilationOptions() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getAssetCatalogsCompilationOptions() - Method in interface com.facebook.buck.apple.HasAppleBundleFields
-
- getAssetCompressionAlgorithm() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getAssetCompressionAlgorithm() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getAssetDirectories() - Method in class com.facebook.buck.android.ModuleInfo
-
- getAssetPaths() - Method in class com.facebook.buck.features.project.intellij.model.IjModuleAndroidFacet
-
- getAssets() - Method in class com.facebook.buck.android.AndroidPrebuiltAar
-
- getAssets() - Method in class com.facebook.buck.android.AndroidResource
-
- getAssets() - Method in class com.facebook.buck.android.AndroidResourceDescriptionArg
-
- getAssets() - Method in interface com.facebook.buck.android.HasAndroidResourceDeps
-
- getAssetsDirectories() - Method in interface com.facebook.buck.android.packageable.AndroidPackageableCollection
-
Directories containing assets to be included directly in the apk, under the "assets" directory.
- getAssetsPath(TargetNode<AndroidResourceDescriptionArg>) - Method in interface com.facebook.buck.features.project.intellij.model.IjModuleFactoryResolver
-
- getAssociatedRuleKeys() - Method in interface com.facebook.buck.artifact_cache.HttpArtifactCacheEvent.HttpArtifactCacheEventFetchData
-
- getAstLinkArgs() - Method in class com.facebook.buck.swift.SwiftCompile
-
- getAttr() - Method in class com.facebook.buck.core.starlark.coercer.SkylarkParamInfo
-
- getAttr() - Method in class com.facebook.buck.core.starlark.rule.SkylarkRuleContext
-
- getAttribute() - Method in class com.facebook.buck.core.starlark.rule.attr.Attribute
-
- getAttribute() - Method in interface com.facebook.buck.core.starlark.rule.attr.AttributeHolder
-
Get the actual attribute object
- getAttributes() - Method in class com.facebook.buck.core.model.targetgraph.impl.ImmutableUnconfiguredTargetNode
-
- getAttributes() - Method in interface com.facebook.buck.core.model.targetgraph.raw.UnconfiguredTargetNode
-
Attributes of this node coerced to the types declared in constructor arguments.
- getAttrs() - Method in class com.facebook.buck.core.starlark.rule.SkylarkUserDefinedRule
-
The attributes that this function accepts
- getAugmentedError(String) - Method in class com.facebook.buck.core.exceptions.HumanReadableExceptionAugmentor
-
Adds messages to the end of an existing error message based on regular expressions provided in
.buckconfig.
- getAugmentedErrorWithContext(String, HumanReadableExceptionAugmentor) - Method in class com.facebook.buck.util.ErrorLogger.DeconstructedException
-
Creates the user-friendly exception with context, masked stack trace (if not suppressed), and
with augmentations.
- getAutoconfName() - Method in enum com.facebook.buck.util.environment.Platform
-
- getAutofixCommands() - Method in class com.facebook.buck.support.fix.FixBuckConfig
-
List of commands that autofix is enabled for
- getAutofixEnabled() - Method in class com.facebook.buck.support.fix.FixBuckConfig
-
When running `buck fix` automatically on command failure is enabled
- getAuxiliaryBuildTag() - Method in class com.facebook.buck.remoteexecution.config.RemoteExecutionConfig
-
Provides an auxiliary tag used for capturing any custom configurations.
- getAvailableCores() - Method in class com.facebook.buck.util.environment.BuildEnvironmentDescription
-
- getAvailableCores() - Method in class com.facebook.buck.util.environment.DefaultExecutionEnvironment
-
- getAvailableCores() - Method in interface com.facebook.buck.util.environment.ExecutionEnvironment
-
- getAvailableResources() - Method in class com.facebook.buck.util.concurrent.ListeningMultiSemaphore
-
- getAverage() - Method in class com.facebook.buck.counters.SamplingCounter
-
- getAverageLoadTime() - Method in interface com.facebook.buck.util.cache.CacheStatsTracker
-
- getAverageLoadTime() - Method in class com.facebook.buck.util.cache.InstrumentingCacheStatsTracker
-
- getAverageLoadTime() - Method in class com.facebook.buck.util.cache.NoOpCacheStatsTracker
-
- getAverageMissTime() - Method in interface com.facebook.buck.util.cache.CacheStatsTracker
-
- getAverageMissTime() - Method in class com.facebook.buck.util.cache.InstrumentingCacheStatsTracker
-
- getAverageMissTime() - Method in class com.facebook.buck.util.cache.NoOpCacheStatsTracker
-
- getAverageRetrievalTime() - Method in interface com.facebook.buck.util.cache.CacheStatsTracker
-
- getAverageRetrievalTime() - Method in class com.facebook.buck.util.cache.InstrumentingCacheStatsTracker
-
- getAverageRetrievalTime() - Method in class com.facebook.buck.util.cache.NoOpCacheStatsTracker
-
- getBackoffStrategy() - Method in class com.facebook.buck.remoteexecution.grpc.retry.RetryPolicy
-
- getBannedDuplicateResourceTypes() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getBannedDuplicateResourceTypes() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getBannedDuplicateResourceTypes() - Method in interface com.facebook.buck.android.HasDuplicateAndroidResourceTypes
-
- getBannedDuplicateResourceTypes() - Method in class com.facebook.buck.android.MergeAndroidResourcesStep
-
- getBaseBookmarks() - Method in interface com.facebook.buck.util.versioncontrol.CommonFastVersionControlStats
-
- getBaseBuildTarget() - Method in class com.facebook.buck.cxx.CxxSourceRuleFactory
-
- getBaseConfigurationReference() - Method in class com.facebook.buck.apple.xcode.xcodeproj.XCBuildConfiguration
-
- getBaseDir(ProjectFilesystem, BuildTarget) - Static method in class com.facebook.buck.core.model.impl.BuildPaths
-
Return a relative path to a file taking into account the target
's package path and
formatting with the short name.
- getBasedOffWhichTracked() - Method in interface com.facebook.buck.doctor.config.SourceControlInfo
-
- getBasedOnConfigAndPath(BuckConfig, ExecutableFinder) - Static method in class com.facebook.buck.infer.toolchain.InferPlatformFactory
-
Tries to construct
InferPlatform
based on buck config or otherwise env vars.
- getBaseModule() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getBaseModule() - Method in class com.facebook.buck.features.lua.LuaLibraryDescriptionArg
-
- getBaseModule(BuildTarget, Optional<String>) - Static method in class com.facebook.buck.features.lua.LuaUtil
-
- getBaseModule() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getBaseModule() - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg
-
- getBaseModule() - Method in class com.facebook.buck.features.python.PythonLibraryDescriptionArg
-
- getBaseModule() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getBasename() - Method in class com.facebook.buck.core.artifact.SourceArtifactImpl
-
- getBaseName() - Method in class com.facebook.buck.core.model.BuildTarget
-
- getBaseName() - Method in class com.facebook.buck.core.model.UnconfiguredBuildTarget
-
- getBaseName() - Method in class com.facebook.buck.core.model.UnflavoredBuildTarget
-
- getBasename() - Method in interface com.facebook.buck.core.starlark.rule.artifact.SkylarkArtifactApi
-
- getBaseName() - Method in class com.facebook.buck.rules.query.Query
-
- getBasePath(ProjectFilesystem, BuildTarget, String) - Static method in class com.facebook.buck.core.model.impl.BuildTargetPaths
-
Deprecated.
Return a relative path to a file.
- getBasePath() - Method in class com.facebook.buck.features.js.JsLibraryDescriptionArg
-
- getBasePath(BuildTarget, Optional<String>) - Static method in class com.facebook.buck.features.python.PythonUtil
-
- getBasePath() - Method in class com.facebook.buck.support.cli.args.BuckCellArg
-
- getBasePathForBaseName(ProjectFilesystem, BuildTarget) - Static method in class com.facebook.buck.core.model.impl.BuildTargetPaths
-
Deprecated.
Return a relative path for all targets in a package of a
BuildTarget
.
- getBasePathOfAncestorTarget(RelPath) - Method in interface com.facebook.buck.core.model.BuildFileTree
-
Returns the base path for a given path.
- getBasePathOfAncestorTarget(RelPath) - Method in class com.facebook.buck.core.model.impl.FilesystemBackedBuildFileTree
-
Returns the base path for a given path.
- getBasePathOfAncestorTarget(RelPath) - Method in class com.facebook.buck.core.model.impl.InMemoryBuildFileTree
-
- getBasePlatform() - Method in class com.facebook.buck.android.toolchain.platform.AndroidMultiPlatform
-
- getBasePlatform() - Method in class com.facebook.buck.android.toolchain.platform.AndroidPlatformArg
-
- getBasePlatform() - Method in interface com.facebook.buck.core.model.platform.MultiPlatform
-
Access base platform of this platform, for example, CPU-neutral Android platform
- getBaseType(Field) - Static method in class com.facebook.buck.util.Types
-
Determine the "base type" of a field.
- getBash() - Method in class com.facebook.buck.android.ApkGenruleDescriptionArg
-
- getBash() - Method in class com.facebook.buck.cxx.CxxGenruleDescriptionArg
-
- getBash() - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg
-
- getBash() - Method in class com.facebook.buck.jvm.java.JarGenruleDescriptionArg
-
- getBash() - Method in interface com.facebook.buck.shell.AbstractGenruleDescription.CommonArg
-
- getBash() - Method in class com.facebook.buck.shell.GenruleDescriptionArg
-
- getBeforeRetry() - Method in class com.facebook.buck.remoteexecution.grpc.retry.RetryPolicy
-
- getBeginningEvent() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.EndingBuildRuleEvent
-
- getBehavior(Class<?>, Class<C>) - Static method in class com.facebook.buck.rules.modern.CustomBehaviorUtils
-
Returns the class behavior of the requested type (if there is one).
- getBestProvisioningProfile(String, ApplePlatform, Optional<ImmutableMap<String, NSObject>>, Optional<? extends Iterable<CodeSignIdentity>>, StringBuffer) - Method in class com.facebook.buck.apple.toolchain.ProvisioningProfileStore
-
- getBestServer() - Method in class com.facebook.buck.slb.ClientSideSlb
-
- getBestServer() - Method in interface com.facebook.buck.slb.HttpLoadBalancer
-
- getBestServer() - Method in class com.facebook.buck.slb.ServerHealthManager
-
- getBinary() - Method in class com.facebook.buck.apple.AppleBundle
-
- getBinary() - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg
-
- getBinary() - Method in class com.facebook.buck.core.test.rule.impl.ExternalTestRunner
-
- getBinary() - Method in class com.facebook.buck.core.test.rule.impl.ExternalTestRunnerDescriptionArg
-
- getBinary() - Method in class com.facebook.buck.features.python.PythonTest
-
- getBinary() - Method in class com.facebook.buck.infer.InferConfig
-
- getBinaryBuildRule() - Method in class com.facebook.buck.apple.AppleBundle
-
- getBinaryBuildRule() - Method in class com.facebook.buck.apple.AppleDebuggableBinary
-
- getBinaryBuildRule() - Method in interface com.facebook.buck.apple.BuildRuleWithBinary
-
- getBinaryDeps() - Method in class com.facebook.buck.features.haskell.HaskellBinary
-
- getBinaryExtension() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getBinaryExtension() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
Extension for binary files.
- getBinaryExtension() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getBinaryFileContent() - Method in class com.facebook.buck.android.StringResources
-
Returns a byte array that represents the entire set of strings, plurals and string arrays in
the following binary file format:
- getBinaryImplementationOwner(ExecutableElement, TypeElement) - Method in interface com.facebook.buck.jvm.java.lang.model.ElementsExtended
-
- getBinaryImplementationOwner(ExecutableElement, TypeElement) - Method in class com.facebook.buck.jvm.java.plugin.adapter.ElementsExtendedImpl
-
- getBinaryJar() - Method in class com.facebook.buck.android.AndroidPrebuiltAar
-
- getBinaryJar() - Method in class com.facebook.buck.jvm.java.PrebuiltJarDescriptionArg
-
- getBinaryJars() - Method in class com.facebook.buck.features.project.intellij.model.IjLibrary
-
- getBinaryName(BuildTarget, Optional<String>) - Static method in class com.facebook.buck.apple.AppleBundle
-
- getBinaryRule() - Method in class com.facebook.buck.cxx.CxxLinkAndCompileRules
-
- getBinarySrc() - Method in class com.facebook.buck.features.python.PrebuiltPythonLibraryDescriptionArg
-
- getBindInfoOffset() - Method in class com.facebook.buck.cxx.toolchain.objectfile.MachoDyldInfoCommand
-
- getBindInfoSize() - Method in class com.facebook.buck.cxx.toolchain.objectfile.MachoDyldInfoCommand
-
- getBlacklist() - Method in class com.facebook.buck.jvm.java.JavaBinaryDescriptionArg
-
- getBlacklistedPaths() - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- getBlacklistedPaths() - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
- getBlacklistedWifiSsids() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getBlacklistedWifiSsids() - Method in class com.facebook.buck.artifact_cache.config.HttpCacheEntry
-
- getBlacklistRegex() - Method in class com.facebook.buck.cxx.toolchain.InferBuckConfig
-
- getBlobCount() - Method in class com.facebook.buck.remoteexecution.event.CasBlobDownloadEvent.Started
-
- getBlobCount() - Method in class com.facebook.buck.remoteexecution.event.CasBlobUploadEvent.Started
-
- getBlueprintIdentifier() - Method in class com.facebook.buck.apple.xcode.XCScheme.BuildableReference
-
- getBlueprintName() - Method in class com.facebook.buck.apple.xcode.XCScheme.BuildableReference
-
- getBody() - Method in interface com.facebook.buck.slb.HttpResponse
-
- getBody() - Method in class com.facebook.buck.slb.LoadBalancedHttpResponse
-
- getBody() - Method in class com.facebook.buck.slb.OkHttpResponseWrapper
-
- getBoolean(String, String) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getBoolean(String, String) - Method in class com.facebook.buck.util.config.Config
-
- getBooleanValue(String, String, boolean) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getBooleanValue(String, String, boolean) - Method in class com.facebook.buck.util.config.Config
-
- getBoostTestDep(TargetConfiguration) - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getBootClasspath(BuildContext) - Method in class com.facebook.buck.jvm.java.CompileToJarStepFactory
-
This can be used make the bootclasspath if available, to the postprocess classes commands.
- getBootclasspath() - Method in class com.facebook.buck.jvm.java.JavacOptions
-
- getBootClasspath(BuildContext) - Method in class com.facebook.buck.jvm.java.JavacToJarStepFactory
-
- getBootClasspath(BuildContext) - Method in class com.facebook.buck.jvm.kotlin.KotlincToJarStepFactory
-
- getBootClasspathEntries() - Method in class com.facebook.buck.android.RobolectricTest
-
- getBootclasspathEntries() - Method in class com.facebook.buck.android.toolchain.AndroidPlatformTarget
-
- getBootClasspathEntries() - Method in class com.facebook.buck.jvm.java.JavaTest
-
- getBootedSimulatorsUdids() - Method in class com.facebook.buck.apple.simulator.AppleDeviceController
-
- getBootstrapClasspath() - Static method in class com.facebook.buck.util.env.BuckClasspath
-
Returns Buck's "bootstrap" classpath.
- getBranchedFromMasterRevisionId() - Method in interface com.facebook.buck.util.versioncontrol.CommonFastVersionControlStats
-
- getBranchedFromMasterTS() - Method in interface com.facebook.buck.util.versioncontrol.CommonFastVersionControlStats
-
- getBridgeMethods(TypeElement, CharSequence) - Method in interface com.facebook.buck.jvm.java.lang.model.ElementsExtended
-
- getBridgeMethods(TypeElement) - Method in class com.facebook.buck.jvm.java.plugin.adapter.BridgeMethods
-
- getBridgeMethods(TypeElement, Name) - Method in class com.facebook.buck.jvm.java.plugin.adapter.BridgeMethods
-
- getBridgeMethods(TypeElement, CharSequence) - Method in class com.facebook.buck.jvm.java.plugin.adapter.ElementsExtendedImpl
-
- getBridgeMethodsNoCreate(TypeElement, Name) - Method in class com.facebook.buck.jvm.java.plugin.adapter.BridgeMethods
-
- getBridgingHeader() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
These fields are passed through to SwiftLibrary for mixed C/Swift targets; they are not used
otherwise.
- getBridgingHeader() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
These fields are passed through to SwiftLibrary for mixed C/Swift targets; they are not used
otherwise.
- getBridgingHeader() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
These fields are passed through to SwiftLibrary for mixed C/Swift targets; they are not used
otherwise.
- getBridgingHeader() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
These fields are passed through to SwiftLibrary for mixed C/Swift targets; they are not used
otherwise.
- getBridgingHeader() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
These fields are passed through to SwiftLibrary for mixed C/Swift targets; they are not used
otherwise.
- getBridgingHeader() - Method in class com.facebook.buck.swift.SwiftLibraryDescriptionArg
-
- getBuckBinaryHash() - Static method in class com.facebook.buck.rules.keys.config.impl.BuckBinaryHashProvider
-
Returns Buck binary hash
- getBuckBootstrapClasspathFromEnvVarOrNull() - Static method in class com.facebook.buck.util.env.BuckClasspath
-
- getBuckClasspathForIntellij() - Static method in class com.facebook.buck.util.env.BuckClasspath
-
Return Buck's classpath when running under Intellij.
- getBuckClasspathFromEnvVarOrNull() - Static method in class com.facebook.buck.util.env.BuckClasspath
-
- getBuckClasspathFromEnvVarOrThrow() - Static method in class com.facebook.buck.util.env.BuckClasspath
-
- getBuckCommit() - Method in class com.facebook.buck.util.environment.BuildEnvironmentDescription
-
- getBuckConfig() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getBuckConfig() - Method in class com.facebook.buck.command.BuildExecutorArgs
-
- getBuckConfig() - Method in interface com.facebook.buck.core.cell.Cell
-
- getBuckConfig() - Method in interface com.facebook.buck.core.description.DescriptionCreationContext
-
- getBuckConfig() - Method in interface com.facebook.buck.core.rules.configsetting.ConfigSettingSelectableConfigurationContext
-
- getBuckConfig() - Method in interface com.facebook.buck.core.toolchain.ToolchainCreationContext
-
- getBuckConfig() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getBuckConfig() - Method in class com.facebook.buck.parser.DefaultSelectableConfigurationContext
-
- getBuckConfig() - Method in class com.facebook.buck.support.state.BuckGlobalStateLifecycleManager
-
- getBuckconfigValue() - Method in enum com.facebook.buck.android.toolchain.ndk.NdkTargetArchAbi
-
- getBuckConfigView(Class<T>) - Method in interface com.facebook.buck.core.cell.Cell
-
- getBuckDirty() - Method in class com.facebook.buck.util.environment.BuildEnvironmentDescription
-
- getBuckEventBus() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getBuckEventBus() - Method in class com.facebook.buck.command.BuildExecutorArgs
-
- getBuckEventBus() - Method in class com.facebook.buck.core.build.execution.context.ExecutionContext
-
- getBuckEventBus() - Method in class com.facebook.buck.core.rules.actions.ActionExecutionContext
-
- getBuckFilePath() - Method in class com.facebook.buck.parser.events.ParseBuckFileEvent
-
- getBuckFixSpecFile() - Method in interface com.facebook.buck.doctor.config.BuildLogEntry
-
- getBuckGlobalState(Cells, KnownRuleTypesProvider, Watchman, Console, Clock, UnconfiguredBuildTargetViewFactory, TargetConfigurationSerializer) - Method in class com.facebook.buck.support.state.BuckGlobalStateLifecycleManager
-
Get or create Daemon.
- getBuckLogDir() - Method in class com.facebook.buck.log.InvocationInfo
-
- getBuckModuleHashStrategy() - Method in class com.facebook.buck.rules.keys.config.RuleKeyConfiguration
-
- getBuckModuleManager() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getBuckOut() - Method in class com.facebook.buck.io.filesystem.BuckPaths
-
The relative path to the directory where Buck will generate its files.
- getBuckOutCompatLink() - Method in class com.facebook.buck.command.config.BuildBuckConfig
-
- getBuckOutDelegate() - Method in class com.facebook.buck.io.filesystem.ProjectFilesystemDelegatePair
-
- getBuckOutIncludeTargetConfigHashFromRootCellConfig(Config) - Static method in class com.facebook.buck.io.filesystem.BuckPaths
-
Is hashed buck-out enabled? Must be queried using root cell buckconfig.
- getBuckOutputPath() - Static method in class com.facebook.buck.util.BuckConstant
-
The relative path to the directory where Buck will generate its files.
- getBuckPackageBoundaryExceptions() - Method in class com.facebook.buck.parser.config.ParserConfig
-
A list of absolute paths under which buck package boundary checks should not be performed.
- getBuckPaths() - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- getBuckPaths() - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
- getBuckProvidedScripts() - Method in class com.facebook.buck.support.fix.BuckFixSpec
-
Get a mapping of names to paths of fix-scripts that are built into buck (such as the original
JASABI fix script).
- getBuckProvidedScripts() - Method in class com.facebook.buck.support.fix.FixBuckConfig
-
Get a mapping of short names to Paths for buck provided fix scripts
- getBuild() - Method in class com.facebook.buck.command.BuildExecutor
-
- getBuildable() - Method in class com.facebook.buck.rules.modern.ModernBuildRule
-
- getBuildableContext() - Method in interface com.facebook.buck.core.build.engine.BuildStrategyContext
-
- getBuildableContext() - Method in class com.facebook.buck.core.build.engine.DelegatingBuildStrategyContext
-
- getBuildableForAndroidResources(ActionGraphBuilder, boolean) - Method in class com.facebook.buck.android.AndroidLibraryGraphEnhancer
-
- getBuildableName() - Method in class com.facebook.buck.apple.xcode.XCScheme.BuildableReference
-
- getBuildableReference() - Method in class com.facebook.buck.apple.xcode.XCScheme.BuildActionEntry
-
- getBuildableReference() - Method in class com.facebook.buck.apple.xcode.XCScheme.LaunchAction
-
- getBuildableReference() - Method in class com.facebook.buck.apple.xcode.XCScheme.ProfileAction
-
- getBuildableReference() - Method in class com.facebook.buck.apple.xcode.XCScheme.SchemePrePostAction
-
- getBuildableReference() - Method in class com.facebook.buck.apple.xcode.XCScheme.TestableReference
-
- getBuildAction() - Method in class com.facebook.buck.apple.xcode.XCScheme
-
- getBuildActionEntries() - Method in class com.facebook.buck.apple.xcode.XCScheme.BuildAction
-
- getBuildArgs() - Method in class com.facebook.buck.core.build.event.BuildEvent.Finished
-
- getBuildArgs() - Method in class com.facebook.buck.core.build.event.BuildEvent.Started
-
- getBuildArgs() - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg
-
- getBuildArgs() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getBuildArtifactCacheSizeLimit() - Method in class com.facebook.buck.core.build.engine.config.CachingBuildEngineBuckConfig
-
- getBuildCellPathFactory(BuildContext, ProjectFilesystem, OutputPathResolver) - Static method in class com.facebook.buck.rules.modern.ModernBuildRule
-
- getBuildCellRootPath() - Method in class com.facebook.buck.core.build.context.BuildContext
-
- getBuildCellRootPath() - Method in class com.facebook.buck.core.build.execution.context.ExecutionContext
-
- getBuildConfigFields() - Method in class com.facebook.buck.android.AndroidBuildConfig
-
- getBuildConfigs() - Method in interface com.facebook.buck.android.packageable.AndroidPackageableCollection
-
- getBuildConfiguration() - Method in class com.facebook.buck.apple.xcode.XCScheme.AnalyzeAction
-
- getBuildConfiguration() - Method in class com.facebook.buck.apple.xcode.XCScheme.ArchiveAction
-
- getBuildConfiguration() - Method in class com.facebook.buck.apple.xcode.XCScheme.LaunchAction
-
- getBuildConfiguration() - Method in class com.facebook.buck.apple.xcode.XCScheme.ProfileAction
-
- getBuildConfiguration() - Method in class com.facebook.buck.apple.xcode.XCScheme.TestAction
-
- getBuildConfigurationList() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXProject
-
- getBuildConfigurationList() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXTarget
-
- getBuildConfigurationsByName() - Method in class com.facebook.buck.apple.xcode.xcodeproj.XCConfigurationList
-
- getBuildConfigValues() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getBuildConfigValues() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getBuildConfigValues() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getBuildConfigValues() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getBuildConfigValuesFile() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getBuildConfigValuesFile() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getBuildConfigValuesFile() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getBuildContext() - Method in class com.facebook.buck.core.build.engine.BuildEngineBuildContext
-
BuildContext
used by various rules to generate
Step
s.
- getBuildDepFiles() - Method in class com.facebook.buck.core.build.engine.config.CachingBuildEngineBuckConfig
-
- getBuildDeps() - Method in class com.facebook.buck.android.aapt.MergeAndroidResourceSources
-
- getBuildDeps() - Method in class com.facebook.buck.android.Aapt2Link
-
- getBuildDeps() - Method in class com.facebook.buck.android.AaptPackageResources
-
- getBuildDeps() - Method in class com.facebook.buck.android.AndroidAppModularity
-
- getBuildDeps() - Method in class com.facebook.buck.android.AndroidAppModularityVerification
-
- getBuildDeps() - Method in class com.facebook.buck.android.AndroidBinary
-
- getBuildDeps() - Method in class com.facebook.buck.android.AndroidBinaryExopackageSymlinkTree
-
- getBuildDeps() - Method in class com.facebook.buck.android.AndroidBinaryNonExoInstaller
-
- getBuildDeps() - Method in class com.facebook.buck.android.AndroidBundle
-
- getBuildDeps() - Method in class com.facebook.buck.android.AndroidManifest
-
- getBuildDeps() - Method in class com.facebook.buck.android.AssembleDirectories
-
- getBuildDeps() - Method in class com.facebook.buck.android.CopyNativeLibraries
-
- getBuildDeps() - Method in class com.facebook.buck.android.DummyRDotJava
-
- getBuildDeps() - Method in class com.facebook.buck.android.ExopackageDeviceDirectoryLister
-
- getBuildDeps() - Method in class com.facebook.buck.android.ExopackageFilesInstaller
-
- getBuildDeps() - Method in class com.facebook.buck.android.ExopackageInstallFinisher
-
- getBuildDeps() - Method in class com.facebook.buck.android.ExopackageResourcesInstaller
-
- getBuildDeps() - Method in class com.facebook.buck.android.GenerateRDotJava
-
- getBuildDeps() - Method in class com.facebook.buck.android.GenerateStringResources
-
- getBuildDeps() - Method in class com.facebook.buck.android.MergeAssets
-
- getBuildDeps() - Method in class com.facebook.buck.android.PackageStringAssets
-
- getBuildDeps() - Method in class com.facebook.buck.android.ResourcesFilter
-
- getBuildDeps() - Method in class com.facebook.buck.android.SplitResources
-
- getBuildDeps() - Method in class com.facebook.buck.apple.AppleAssetCatalog
-
- getBuildDeps() - Method in class com.facebook.buck.apple.AppleBundle
-
- getBuildDeps() - Method in class com.facebook.buck.apple.AppleDebuggableBinary
-
- getBuildDeps() - Method in class com.facebook.buck.apple.AppleDsym
-
- getBuildDeps() - Method in interface com.facebook.buck.cli.ActionGraphSerializer.ActionGraphData
-
- getBuildDeps() - Method in class com.facebook.buck.core.model.targetgraph.impl.TargetNodeImpl
-
- getBuildDeps() - Method in interface com.facebook.buck.core.model.targetgraph.TargetNode
-
- getBuildDeps() - Method in interface com.facebook.buck.core.rules.BuildRule
-
- getBuildDeps() - Method in class com.facebook.buck.core.rules.BuildRuleParams
-
- getBuildDeps() - Method in class com.facebook.buck.core.rules.impl.AbstractBuildRuleWithDeclaredAndExtraDeps
-
- getBuildDeps() - Method in class com.facebook.buck.core.rules.impl.DependencyAggregation
-
- getBuildDeps() - Method in class com.facebook.buck.core.rules.impl.NoopBuildRule
-
- getBuildDeps() - Method in class com.facebook.buck.core.rules.impl.RuleAnalysisLegacyBuildRuleView
-
- getBuildDeps() - Method in class com.facebook.buck.core.rules.impl.SymlinkTree
-
- getBuildDeps() - Method in class com.facebook.buck.cxx.CxxCompilationDatabase
-
- getBuildDeps() - Method in class com.facebook.buck.cxx.CxxStrip
-
- getBuildDeps() - Method in class com.facebook.buck.features.go.CGoGenImport
-
- getBuildDeps() - Method in class com.facebook.buck.features.go.CGoGenSource
-
- getBuildDeps() - Method in class com.facebook.buck.features.go.GoTestCoverSource
-
- getBuildDeps() - Method in class com.facebook.buck.features.python.PythonInPlaceBinary
-
- getBuildDeps() - Method in class com.facebook.buck.features.python.PythonPackagedBinary
-
- getBuildDeps() - Method in class com.facebook.buck.file.WriteFile
-
- getBuildDeps(SourcePathRuleFinder) - Method in class com.facebook.buck.jvm.java.ConstantJavacProvider
-
- getBuildDeps(SourcePathRuleFinder) - Method in class com.facebook.buck.jvm.java.ExternalJavacProvider
-
- getBuildDeps(SourcePathRuleFinder) - Method in class com.facebook.buck.jvm.java.JarBackedJavacProvider
-
- getBuildDeps(SourcePathRuleFinder, TargetConfiguration) - Method in class com.facebook.buck.jvm.java.JavacFactory
-
- getBuildDeps(SourcePathRuleFinder) - Method in interface com.facebook.buck.jvm.java.JavacProvider
-
- getBuildDeps() - Method in class com.facebook.buck.rules.modern.ModernBuildRule
-
- getBuildDeps() - Method in class com.facebook.buck.shell.DefaultWorkerToolRule
-
- getBuildDeps() - Method in class com.facebook.buck.shell.ExportFile
-
- getBuildDeps() - Method in class com.facebook.buck.swift.SwiftCompile
-
- getBuildDetailsCommands() - Method in class com.facebook.buck.support.log.LogBuckConfig
-
- getBuildDetailsLine(BuildId, String) - Static method in class com.facebook.buck.event.listener.AbstractConsoleEventBusListener
-
- getBuildDetailsTemplate() - Method in class com.facebook.buck.support.log.LogBuckConfig
-
- getBuildEngineActionToBuildRuleResolver() - Method in class com.facebook.buck.core.model.actiongraph.ActionGraphAndBuilder
-
- getBuildEngineMode() - Method in class com.facebook.buck.cli.BuildCommand
-
- getBuildEngineMode() - Method in class com.facebook.buck.core.build.engine.config.CachingBuildEngineBuckConfig
-
- getBuildEnvironmentDescription() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getBuildEnvironmentDescription() - Method in interface com.facebook.buck.doctor.DefectReporter.DefectReport
-
- getBuilderFactory() - Method in class com.facebook.buck.rules.coercer.DataTransferObjectDescriptor
-
Get the builder for a constructor arg.
- getBuilderForAction(String, String) - Method in interface com.facebook.buck.remoteexecution.interfaces.MetadataProvider
-
- getBuildEventsByThread() - Method in class com.facebook.buck.event.listener.BuildRuleThreadTracker
-
- getBuildFileImportWhitelist() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getBuildFileImportWhitelist() - Method in class com.facebook.buck.parser.options.ProjectBuildFileParserOptions
-
- getBuildFileManifest(Cell, AbsPath) - Method in class com.facebook.buck.parser.PerBuildState
-
- getBuildFileManifestCaches() - Method in class com.facebook.buck.support.state.BuckGlobalState
-
Return a map of all build file manifest caches for each cell which is a key
- getBuildFileName() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getBuildFileName() - Method in class com.facebook.buck.parser.options.ProjectBuildFileParserOptions
-
- getBuildFiles(Set<QueryBuildTarget>) - Method in class com.facebook.buck.cli.BuckQueryEnvironment
-
- getBuildFiles(Set<NODE_TYPE>) - Method in interface com.facebook.buck.query.QueryEnvironment
-
Returns the build files that define the given targets.
- getBuildFiles(Set<NODE_TYPE>) - Method in class com.facebook.buck.query.TargetVariablesQueryEnvironment
-
- getBuildFiles(Set<QueryBuildTarget>) - Method in class com.facebook.buck.rules.query.GraphEnhancementQueryEnvironment
-
- getBuildFileSearchMethod() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getBuildFileSpec() - Method in class com.facebook.buck.parser.spec.BuildTargetSpec
-
- getBuildFileSpec() - Method in class com.facebook.buck.parser.spec.TargetNodePredicateSpec
-
- getBuildFileSpec() - Method in interface com.facebook.buck.parser.spec.TargetNodeSpec
-
- getBuildFor() - Method in class com.facebook.buck.apple.xcode.XCScheme.BuildActionEntry
-
- getBuildFunction() - Method in class com.facebook.buck.rules.coercer.DataTransferObjectDescriptor
-
- getBuildId() - Method in class com.facebook.buck.core.build.engine.BuildEngineBuildContext
-
- getBuildId() - Method in class com.facebook.buck.core.build.execution.context.ExecutionContext
-
- getBuildId() - Method in interface com.facebook.buck.doctor.config.BuildLogEntry
-
- getBuildId() - Method in interface com.facebook.buck.doctor.config.DoctorEndpointRequest
-
- getBuildId() - Method in class com.facebook.buck.event.AbstractBuckEvent
-
- getBuildId() - Method in interface com.facebook.buck.event.BuckEvent
-
- getBuildId() - Method in interface com.facebook.buck.event.BuckEventBus
-
- getBuildId() - Method in class com.facebook.buck.event.DefaultBuckEventBus
-
An id that every event posted to this event bus will share.
- getBuildId() - Method in class com.facebook.buck.log.InvocationInfo
-
- getBuildId() - Method in class com.facebook.buck.support.build.report.RequestUploader
-
- getBuildId() - Method in class com.facebook.buck.support.fix.BuckFixSpec
-
The build ID.
- getBuildInfoStoreManager() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getBuildInfoStoreManager() - Method in class com.facebook.buck.command.BuildExecutorArgs
-
- getBuildInputRuleKeyFileSizeLimit() - Method in class com.facebook.buck.command.config.BuildBuckConfig
-
- getBuildInputRuleKeyFileSizeLimit() - Method in class com.facebook.buck.rules.keys.config.RuleKeyConfiguration
-
- getBuildLogEntryFromId(BuildId) - Method in class com.facebook.buck.doctor.BuildLogHelper
-
Given a build id, return the corresponding
BuildLogEntry
of that build
- getBuildLogLine(BuildId) - Static method in class com.facebook.buck.event.listener.AbstractConsoleEventBusListener
-
- getBuildLogs() - Method in class com.facebook.buck.doctor.BuildLogHelper
-
- getBuildMaxDepFileCacheEntries() - Method in class com.facebook.buck.core.build.engine.config.CachingBuildEngineBuckConfig
-
- getBuildMetadataFor(String) - Method in class com.facebook.buck.core.build.engine.buildinfo.BuildInfoRecorder
-
- getBuildOutput() - Method in class com.facebook.buck.core.rules.attr.BuildOutputInitializer
-
The initialized buildOutput.
- getBuildOutputInitializer() - Method in class com.facebook.buck.android.AndroidResource
-
- getBuildOutputInitializer() - Method in class com.facebook.buck.android.DexProducedFromJavaLibrary
-
- getBuildOutputInitializer() - Method in class com.facebook.buck.android.DummyRDotJava
-
- getBuildOutputInitializer() - Method in class com.facebook.buck.android.PreDexSplitDexGroup
-
- getBuildOutputInitializer() - Method in class com.facebook.buck.android.ResourcesFilter
-
- getBuildOutputInitializer() - Method in class com.facebook.buck.android.UnzipAar
-
- getBuildOutputInitializer() - Method in interface com.facebook.buck.core.rules.attr.InitializableFromDisk
-
- getBuildOutputInitializer() - Method in class com.facebook.buck.jvm.java.CalculateClassAbi
-
- getBuildOutputInitializer() - Method in class com.facebook.buck.jvm.java.CalculateSourceAbi
-
- getBuildOutputInitializer() - Method in class com.facebook.buck.jvm.java.CalculateSourceAbiFromLibraryTarget
-
- getBuildOutputInitializer() - Method in class com.facebook.buck.jvm.java.CompareAbis
-
- getBuildOutputInitializer() - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getBuildOutputInitializer() - Method in class com.facebook.buck.jvm.java.PrebuiltJar
-
- getBuildOutputInitializer() - Method in class com.facebook.buck.shell.DefaultWorkerToolRule
-
- getBuildozerPath() - Method in class com.facebook.buck.jvm.java.UnusedDependenciesFinder
-
- getBuildPhases() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXTarget
-
- getBuildPrehookScriptInterpreterAndArgs() - Method in class com.facebook.buck.command.config.BuildBuckConfig
-
- getBuildReport() - Method in class com.facebook.buck.core.build.event.BuildEvent.BuildReport
-
- getBuildResult() - Method in interface com.facebook.buck.core.rules.build.strategy.BuildRuleStrategy.StrategyBuildResult
-
A ListenableFuture for the build result.
- getBuildRule() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent
-
- getBuildRule() - Method in class com.facebook.buck.core.build.event.BuildRuleExecutionEvent.Event
-
- getBuildRule() - Method in class com.facebook.buck.core.build.event.FinalizingBuildRuleEvent
-
- getBuildRule() - Method in class com.facebook.buck.remoteexecution.event.RemoteBuildRuleExecutionEvent
-
- getBuildRule() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.Finished
-
- getBuildRule() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.InputsUploaded
-
- getBuildRule() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.Scheduled
-
- getBuildRule() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.Started
-
- getBuildRule() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.Terminal
-
- getBuildRuleBuildContext() - Method in interface com.facebook.buck.core.build.engine.BuildStrategyContext
-
- getBuildRuleBuildContext() - Method in class com.facebook.buck.core.build.engine.DelegatingBuildStrategyContext
-
- getBuildRuleDirectedGraphFilteredBy(Iterable<? extends BuildRule>, Predicate<Object>, Predicate<Object>) - Static method in class com.facebook.buck.core.rules.common.BuildRuleDependencyVisitors
-
Given dependencies in inputs builds graph of transitive dependencies filtering them by
instanceOf T.
- getBuildRuleMinimumDurationMillis() - Method in class com.facebook.buck.event.listener.SuperConsoleConfig
-
- getBuildRuleResult(BuildTarget) - Method in interface com.facebook.buck.core.build.engine.BuildEngine
-
Returns the build result of the build rule associated with the given build target.
- getBuildRuleResult(BuildTarget) - Method in class com.facebook.buck.core.build.engine.impl.CachingBuildEngine
-
- getBuildRules() - Method in class com.facebook.buck.core.build.event.BuildEvent.RuleCountCalculated
-
- getBuildRules() - Method in interface com.facebook.buck.core.rules.ActionGraphBuilder
-
- getBuildRules() - Method in class com.facebook.buck.core.rules.resolver.impl.MultiThreadedActionGraphBuilder
-
- getBuildRules() - Method in class com.facebook.buck.core.rules.resolver.impl.RuleAnalysisCompatibleDelegatingActionGraphBuilder
-
- getBuildSettings() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXBuildStyle
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.aapt.MergeAndroidResourceSources
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.Aapt2Link
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.AaptPackageResources
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.AndroidAar
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.AndroidAppModularity
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.AndroidAppModularityVerification
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.AndroidBinary
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.AndroidBinaryExopackageSymlinkTree
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.AndroidBinaryNonExoInstaller
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.AndroidBinaryOptimizer
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.AndroidBuildConfig
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.AndroidBundle
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.AndroidInstrumentationTest
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.AndroidManifest
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.AndroidResource
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.AndroidResourceIndex
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.AssembleDirectories
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.CopyNativeLibraries
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.DummyRDotJava
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.ExopackageDeviceDirectoryLister
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.ExopackageFilesInstaller
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.ExopackageInstallFinisher
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.ExopackageResourcesInstaller
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.GenAidl
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.GenerateRDotJava
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.GenerateStringResources
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.MergeAssets
-
- getBuildSteps(BuildContext, ProjectFilesystem, OutputPathResolver, BuildCellRelativePathFactory) - Method in class com.facebook.buck.android.MergeThirdPartyJarResources
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.NativeLibraryProguardGenerator
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.NdkLibrary
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.PackageStringAssets
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.PrebuiltNativeLibrary
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.PreDexSingleDexMerge
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.PreDexSplitDexGroup
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.PreDexSplitDexMerge
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.ResourcesFilter
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.RobolectricTestX
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.SplitResources
-
- getBuildSteps(BuildContext, ProjectFilesystem, OutputPathResolver, BuildCellRelativePathFactory) - Method in class com.facebook.buck.android.SplitUberRDotJavaJar
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.UnstrippedNativeLibraries
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.android.UnzipAar
-
- getBuildSteps(BuildContext, ProjectFilesystem, OutputPathResolver, BuildCellRelativePathFactory) - Method in class com.facebook.buck.android.WriteFileHashCode
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.apple.AppleAssetCatalog
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.apple.AppleBundle
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.apple.AppleDebuggableBinary
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.apple.AppleDsym
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.apple.AppleTest
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.apple.AppleTestAggregatedDependencies
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.apple.AppleTestX
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.apple.BuiltinApplePackage
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.apple.CoreDataModel
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.apple.MultiarchFile
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.apple.PrebuiltAppleFramework
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.apple.SceneKitAssets
-
- getBuildSteps(BuildContext, BuildableContext) - Method in interface com.facebook.buck.core.rules.BuildRule
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.core.rules.impl.DependencyAggregation
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.core.rules.impl.NoopBuildRule
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.core.rules.impl.NoopBuildRuleWithDeclaredAndExtraDeps
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.core.rules.impl.RuleAnalysisLegacyBuildRuleView
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.core.rules.impl.SymlinkTree
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.core.rules.impl.WriteStringTemplateRule
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.core.rules.tool.BinaryWrapperRule
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.cxx.CxxBinary
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.cxx.CxxCompilationDatabase
-
- getBuildSteps(BuildContext, ProjectFilesystem, OutputPathResolver, BuildCellRelativePathFactory) - Method in class com.facebook.buck.cxx.CxxLink.Impl
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.cxx.CxxStrip
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.cxx.CxxTest
-
- getBuildSteps(BuildContext, ProjectFilesystem, OutputPathResolver, BuildCellRelativePathFactory) - Method in class com.facebook.buck.cxx.CxxThinLTOIndex.Impl
-
- getBuildSteps(BuildContext, ProjectFilesystem, OutputPathResolver, BuildCellRelativePathFactory) - Method in class com.facebook.buck.cxx.CxxThinLTOOpt.Impl
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.cxx.HeaderSymlinkTreeWithHeaderMap
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.cxx.toolchain.HeaderSymlinkTreeWithModuleMap
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.d.DBinary
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.d.DCompileBuildRule
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.d.DTest
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.dotnet.CsharpLibrary
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.dotnet.PrebuiltDotnetLibrary
-
- getBuildSteps(BuildContext, ProjectFilesystem, OutputPathResolver, BuildCellRelativePathFactory) - Method in class com.facebook.buck.features.filegroup.Filegroup
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.go.CGoGenImport
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.go.CGoGenSource
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.go.GoBinary
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.go.GoCompile
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.go.GoTest
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.go.GoTestCoverSource
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.go.GoTestMain
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.go.GoTestX
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.gwt.GwtBinary
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.gwt.GwtModule
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.halide.HalideCompile
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.haskell.HaskellCompileRule
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.haskell.HaskellGhciRule
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.haskell.HaskellHaddockLibRule
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.haskell.HaskellHaddockRule
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.haskell.HaskellLinkRule
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.haskell.HaskellPackageRule
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.js.JsBundle
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.js.JsBundleAndroid
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.js.JsDependenciesFile
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.lua.LuaBinary
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.lua.LuaStandaloneBinary
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.ocaml.OcamlBinary
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.ocaml.OcamlBuild
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.ocaml.OcamlCCompile
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.ocaml.OcamlClean
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.ocaml.OcamlDebugLauncher
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.ocaml.OcamlLink
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.ocaml.OcamlMLCompile
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.python.PrebuiltPythonLibrary
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.python.PythonInPlaceBinary
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.python.PythonPackagedBinary
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.python.PythonTest
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.python.PythonTestX
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.features.rust.RustTest
-
- getBuildSteps(BuildContext, ProjectFilesystem, OutputPathResolver, BuildCellRelativePathFactory) - Method in class com.facebook.buck.features.zip.rules.Zip
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.file.HttpArchive
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.file.HttpFile
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.file.RemoteFile
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.file.WriteFile
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.json.JsonConcatenate
-
- getBuildSteps(BuildContext, ProjectFilesystem, OutputPathResolver, BuildCellRelativePathFactory) - Method in class com.facebook.buck.jvm.java.CalculateSourceAbi.SourceAbiBuildable
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.jvm.java.CompareAbis
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.jvm.java.JarFattener
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.jvm.java.JavaBinary
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.jvm.java.Javadoc
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.jvm.java.JavaSourceJar
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.jvm.java.JavaTest
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.jvm.java.JavaTestX
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.jvm.java.Keystore
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.jvm.java.MavenUberJar
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.jvm.java.PrebuiltJar
-
- getBuildSteps(BuildContext, ProjectFilesystem, OutputPathResolver, BuildCellRelativePathFactory) - Method in interface com.facebook.buck.rules.modern.Buildable
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.rules.modern.ModernBuildRule
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.shell.ExportFile
-
- getBuildSteps(BuildContext, ProjectFilesystem, OutputPathResolver, BuildCellRelativePathFactory) - Method in class com.facebook.buck.shell.GenruleBuildable
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.shell.ShBinary
-
- getBuildSteps(BuildContext, BuildableContext) - Method in class com.facebook.buck.swift.SwiftCompile
-
- getBuildStepsForAbiJar(BuildContext, ProjectFilesystem, RecordArtifactVerifier, BuildTarget) - Method in class com.facebook.buck.jvm.java.JarBuildStepsFactory
-
- getBuildStepsForLibraryJar(BuildContext, ProjectFilesystem, RecordArtifactVerifier, BuildTarget, Path) - Method in class com.facebook.buck.jvm.java.JarBuildStepsFactory
-
- getBuildStrategy(ModernBuildRuleStrategyConfig, RemoteExecutionConfig, BuildRuleResolver, Cell, CellPathResolver, FileHashLoader, BuckEventBus, MetadataProvider, boolean, boolean) - Static method in class com.facebook.buck.rules.modern.builders.ModernBuildRuleBuilderFactory
-
Creates a BuildRuleStrategy for ModernBuildRules based on the buck configuration.
- getBuildStrategy(boolean, boolean) - Method in class com.facebook.buck.rules.modern.config.ModernBuildRuleConfig
-
- getBuildStrategy(boolean, boolean) - Method in interface com.facebook.buck.rules.modern.config.ModernBuildRuleStrategyConfig
-
- getBuildStrategy(boolean, boolean) - Method in class com.facebook.buck.rules.modern.config.ModernBuildRuleStrategyConfigFromSection
-
- getBuildTarget() - Method in interface com.facebook.buck.android.HasAndroidResourceDeps
-
- getBuildTarget() - Method in interface com.facebook.buck.android.HasInstallableApk
-
- getBuildTarget() - Method in class com.facebook.buck.android.toolchain.platform.AndroidMultiPlatform
-
- getBuildTarget() - Method in class com.facebook.buck.artifact_cache.AbstractAsynchronousCache.FetchRequest
-
- getBuildTarget() - Method in class com.facebook.buck.artifact_cache.ArtifactInfo
-
- getBuildTarget() - Method in interface com.facebook.buck.core.build.action.BuildEngineAction
-
- getBuildTarget(String, String, TargetConfiguration) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getBuildTarget() - Method in class com.facebook.buck.core.linkgroup.CxxLinkGroupMappingTarget
-
- getBuildTarget() - Method in class com.facebook.buck.core.model.BuildTargetWithOutputs
-
- getBuildTarget() - Method in interface com.facebook.buck.core.model.HasBuildTarget
-
- getBuildTarget() - Method in class com.facebook.buck.core.model.platform.ConstraintSetting
-
- getBuildTarget() - Method in class com.facebook.buck.core.model.platform.ConstraintValue
-
- getBuildTarget() - Method in class com.facebook.buck.core.model.platform.impl.ConstraintBasedPlatform
-
- getBuildTarget() - Method in interface com.facebook.buck.core.model.platform.NamedPlatform
-
Build target used to define this platform
- getBuildTarget() - Method in class com.facebook.buck.core.model.targetgraph.impl.ImmutableUnconfiguredTargetNode
-
- getBuildTarget() - Method in class com.facebook.buck.core.model.targetgraph.impl.TargetNodeImpl
-
- getBuildTarget() - Method in class com.facebook.buck.core.model.targetgraph.MergedTargetNode
-
- getBuildTarget() - Method in interface com.facebook.buck.core.model.targetgraph.raw.UnconfiguredTargetNode
-
Build target of this node.
- getBuildTarget() - Method in interface com.facebook.buck.core.model.targetgraph.TargetNode
-
- getBuildTarget() - Method in class com.facebook.buck.core.model.targetgraph.TargetNodeMaybeIncompatible
-
- getBuildTarget() - Method in class com.facebook.buck.core.model.UnconfiguredBuildTargetWithOutputs
-
- getBuildTarget() - Method in class com.facebook.buck.core.rules.actions.AbstractAction
-
- getBuildTarget() - Method in interface com.facebook.buck.core.rules.analysis.action.ActionAnalysisDataKey
-
- getBuildTarget() - Method in class com.facebook.buck.core.rules.analysis.impl.LegacyProviderRuleAnalysisResult
-
- getBuildTarget() - Method in class com.facebook.buck.core.rules.analysis.RuleAnalysisKey
-
TODO(bobyf) this really should be a ConfiguredBuildTarget
- getBuildTarget() - Method in interface com.facebook.buck.core.rules.analysis.RuleAnalysisResult
-
- getBuildTarget() - Method in interface com.facebook.buck.core.rules.BuildRule
-
- getBuildTarget() - Method in class com.facebook.buck.core.rules.config.AbstractConfigurationRule
-
- getBuildTarget() - Method in interface com.facebook.buck.core.rules.config.ConfigurationRule
-
- getBuildTarget() - Method in class com.facebook.buck.core.rules.configsetting.ConfigSettingSelectable
-
- getBuildTarget() - Method in class com.facebook.buck.core.rules.impl.AbstractBuildRule
-
- getBuildTarget() - Method in interface com.facebook.buck.core.select.Selectable
-
- getBuildTarget() - Method in class com.facebook.buck.core.select.SelectorKey
-
- getBuildTarget() - Method in interface com.facebook.buck.cxx.CxxPreprocessorDep
-
- getBuildTarget() - Method in interface com.facebook.buck.cxx.toolchain.nativelink.NativeLinkable
-
- getBuildTarget() - Method in interface com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableGroup
-
- getBuildTarget() - Method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableInfo
-
- getBuildTarget() - Method in interface com.facebook.buck.cxx.toolchain.nativelink.NativeLinkTarget
-
- getBuildTarget() - Method in interface com.facebook.buck.cxx.toolchain.nativelink.NativeLinkTargetGroup
-
- getBuildTarget() - Method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkTargetInfo
-
- getBuildTarget() - Method in class com.facebook.buck.cxx.toolchain.nativelink.PlatformLockedNativeLinkableGroup
-
- getBuildTarget() - Method in class com.facebook.buck.cxx.toolchain.nativelink.PlatformLockedNativeLinkTargetGroup
-
- getBuildTarget() - Method in class com.facebook.buck.event.CompilerPluginDurationEvent
-
- getBuildTarget() - Method in class com.facebook.buck.event.InstallEvent
-
- getBuildTarget() - Method in interface com.facebook.buck.event.listener.CriticalPathReportableNode
-
- getBuildTarget() - Method in class com.facebook.buck.event.StartActivityEvent
-
- getBuildTarget() - Method in class com.facebook.buck.features.lua.SystemLuaCxxLibrary
-
- getBuildTarget(SourcePath) - Method in class com.facebook.buck.features.project.intellij.IjProjectSourcePathResolver
-
- getBuildTarget() - Method in class com.facebook.buck.jvm.core.DefaultJavaAbiInfo
-
- getBuildTarget() - Method in class com.facebook.buck.jvm.core.EmptyJavaAbiInfo
-
- getBuildTarget() - Method in interface com.facebook.buck.jvm.core.JavaAbiInfo
-
- getBuildTarget() - Method in class com.facebook.buck.jvm.java.AnnotationProcessingEvent
-
- getBuildTarget() - Method in class com.facebook.buck.jvm.java.tracing.JavacPhaseEvent
-
- getBuildTarget() - Method in class com.facebook.buck.jvm.java.UnusedDependenciesFinder
-
- getBuildTarget() - Method in class com.facebook.buck.parser.targetnode.BuildTargetToUnconfiguredTargetNodeKey
-
- getBuildTarget() - Method in class com.facebook.buck.query.QueryBuildTarget
-
- getBuildTarget() - Method in class com.facebook.buck.remoteexecution.event.LocalFallbackEvent.Started
-
- getBuildTarget() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.Scheduled
-
- getBuildTarget() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.Started
-
- getBuildTarget() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.Terminal
-
- getBuildTarget() - Method in class com.facebook.buck.rules.coercer.NeededCoverageSpec
-
- getBuildTarget() - Method in class com.facebook.buck.rules.macros.StringWithMacrosConverter
-
- getBuildTarget() - Method in class com.facebook.buck.rules.modern.builders.HybridLocalEvent.Stolen
-
- getBuildTarget() - Method in interface com.facebook.buck.rules.visibility.ObeysVisibility
-
- getBuildTarget() - Method in class com.facebook.buck.swift.SwiftRuntimeNativeLinkableGroup
-
- getBuildTarget() - Method in class com.facebook.buck.test.external.ExternalTestSpecCalculationEvent
-
- getBuildTarget() - Method in class com.facebook.buck.test.TestResults
-
- getBuildTarget() - Method in class com.facebook.buck.test.TestRuleEvent
-
- getBuildTargetForAliasAsString(String) - Method in class com.facebook.buck.support.cli.config.AliasConfig
-
- getBuildTargetForFullyQualifiedTarget(String, TargetConfiguration) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getBuildTargetName() - Method in class com.facebook.buck.event.ActionGraphPerfStatEvent
-
- getBuildTargetNameWithOutputLabel(String) - Static method in class com.facebook.buck.core.parser.buildtargetparser.BuildTargetOutputLabelParser
-
Returns the fully-qualified or relative build target name and its associated output label, if
any.
- getBuildTargetPattern(Cell) - Method in class com.facebook.buck.parser.spec.BuildTargetSpec
-
- getBuildTargetPattern(Cell) - Method in class com.facebook.buck.parser.spec.TargetNodePredicateSpec
-
- getBuildTargetPattern(Cell) - Method in interface com.facebook.buck.parser.spec.TargetNodeSpec
-
- getBuildTargets(APKModule) - Method in class com.facebook.buck.android.apkmodule.APKModuleGraph
-
- getBuildTargets() - Method in class com.facebook.buck.core.model.targetgraph.TargetGraphCreationResult
-
Top level targets of the target graph.
- getBuildTargets() - Method in class com.facebook.buck.features.apple.project.XCodeProjectCommandHelper.Result
-
- getBuildTargets() - Method in class com.facebook.buck.features.apple.projectV2.XCodeProjectCommandHelper.Result
-
- getBuildTargets() - Method in class com.facebook.buck.parser.ParseEvent
-
- getBuildTargetsForAlias(String) - Method in class com.facebook.buck.support.cli.config.AliasConfig
-
- getBuildTargetSourcePathFilesystem(BuildTargetSourcePath) - Method in class com.facebook.buck.core.sourcepath.resolver.impl.AbstractSourcePathResolver
-
- getBuildTargetSourcePathFilesystem(BuildTargetSourcePath) - Method in class com.facebook.buck.core.sourcepath.resolver.impl.DefaultSourcePathResolver
-
- getBuildTargetSourcePathFilesystem(BuildTargetSourcePath) - Method in class com.facebook.buck.features.project.intellij.IjProjectSourcePathResolver
-
- getBuildTargetsToExcludeFromDex() - Method in class com.facebook.buck.android.AndroidBinary
-
- getBuildTargetToGeneratedTargetMap() - Method in class com.facebook.buck.features.apple.project.ProjectGenerator
-
- getBuildTimeMs() - Method in class com.facebook.buck.artifact_cache.ArtifactInfo
-
- getBuildTimeMs() - Method in interface com.facebook.buck.doctor.config.BuildLogEntry
-
- getBuildTimeMs() - Method in class com.facebook.buck.log.PerfTimesStats
-
- getBuildTimestamps() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.Finished
-
- getBuildToolsBinPath() - Method in interface com.facebook.buck.android.toolchain.AndroidBuildToolsLocation
-
- getBuildToolsPath() - Method in interface com.facebook.buck.android.toolchain.AndroidBuildToolsLocation
-
- getBuildToolsPath() - Method in class com.facebook.buck.android.toolchain.impl.AndroidBuildToolsResolver
-
- getBuildToolsVersion() - Method in class com.facebook.buck.android.AndroidBuckConfig
-
- getBuildToolsVersion() - Method in class com.facebook.buck.android.toolchain.impl.AndroidBuildToolsResolver
-
Returns Android SDK build tools version that was either discovered or provided during creation.
- getBuildType() - Method in class com.facebook.buck.util.environment.BuildEnvironmentDescription
-
- getBuildUuid() - Method in class com.facebook.buck.log.ErrorLogRecord
-
- getBuildValue(String) - Method in class com.facebook.buck.core.build.engine.buildinfo.DefaultOnDiskBuildInfo
-
- getBuildValue(String) - Method in interface com.facebook.buck.core.build.engine.buildinfo.OnDiskBuildInfo
-
- getBuildVersion() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
Build version.
- getBuildVersion() - Method in class com.facebook.buck.apple.toolchain.AppleCxxPlatform
-
- getBuildVersions() - Method in class com.facebook.buck.command.config.BuildBuckConfig
-
- getBuiltInProviders() - Method in interface com.facebook.buck.core.model.targetgraph.BuiltInProviderProvider
-
Providers to expose to users
- getBuiltInProviders() - Method in class com.facebook.buck.features.dotnet.DotNetRuleProvider
-
- getBundle() - Method in class com.facebook.buck.apple.ApplePackageDescriptionArg
-
- getBundleConfigFile() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getBundleIdFromPlistStream(Path, InputStream) - Static method in class com.facebook.buck.apple.AppleInfoPlistParsing
-
Extracts the bundle ID (CFBundleIdentifier) from an Info.plist, returning it if present.
- getBundleName() - Method in interface com.facebook.buck.apple.AbstractIdbTestResult
-
String that represents the name of the test bundle
- getBundleName() - Method in interface com.facebook.buck.features.js.HasBundleName
-
The name of the bundle.
- getBundleName() - Method in class com.facebook.buck.features.js.JsBundle
-
- getBundleName() - Method in class com.facebook.buck.features.js.JsBundleAndroid
-
- getBundleName() - Method in class com.facebook.buck.features.js.JsBundleDescriptionArg
-
The name of the bundle.
- getBundleName() - Method in class com.facebook.buck.features.js.JsBundleGenrule
-
- getBundleName() - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg
-
The name of the bundle.
- getBundleName() - Method in interface com.facebook.buck.features.js.JsBundleOutputs
-
- getBundleNameForFlavor() - Method in interface com.facebook.buck.features.js.HasBundleName
-
A mapping from flavors to bundle names.
- getBundleNameForFlavor() - Method in class com.facebook.buck.features.js.JsBundleDescriptionArg
-
A mapping from flavors to bundle names.
- getBundleNameForFlavor() - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg
-
A mapping from flavors to bundle names.
- getBundleRoot(ProjectFilesystem, BuildTarget, String, String) - Static method in class com.facebook.buck.apple.AppleBundle
-
- getBundleTypeFromPlistStream(Path, InputStream) - Static method in class com.facebook.buck.apple.AppleInfoPlistParsing
-
Extracts the bundle type (CFBundlePackageType) from an Info.plist, returning it if present.
- getByName(String, TargetConfiguration, Class<T>) - Method in class com.facebook.buck.core.toolchain.BaseToolchainProvider
-
- getByName(String, TargetConfiguration) - Method in class com.facebook.buck.core.toolchain.impl.DefaultToolchainProvider
-
- getByName(String, TargetConfiguration) - Method in interface com.facebook.buck.core.toolchain.ToolchainProvider
-
- getByName(String, TargetConfiguration, Class<T>) - Method in interface com.facebook.buck.core.toolchain.ToolchainProvider
-
- getByNameIfPresent(String, TargetConfiguration, Class<T>) - Method in class com.facebook.buck.core.toolchain.BaseToolchainProvider
-
- getByNameIfPresent(String, TargetConfiguration, Class<T>) - Method in interface com.facebook.buck.core.toolchain.ToolchainProvider
-
- getBytecodeCLibs() - Method in class com.facebook.buck.features.ocaml.PrebuiltOcamlLibraryDescriptionArg
-
- getBytecodeCompileDeps(OcamlPlatform) - Method in class com.facebook.buck.features.ocaml.OcamlLibrary
-
Dependencies for the bytecode (ocamlc) build
- getBytecodeIncludeDirs(OcamlPlatform) - Method in class com.facebook.buck.features.ocaml.OcamlLibrary
-
- getBytecodeLib() - Method in class com.facebook.buck.features.ocaml.PrebuiltOcamlLibraryDescriptionArg
-
- getBytecodeLinkableInput(OcamlPlatform) - Method in class com.facebook.buck.features.ocaml.OcamlLibrary
-
- getBytecodeLinkDeps(OcamlPlatform) - Method in class com.facebook.buck.features.ocaml.OcamlLibrary
-
- getBytecodeOnly() - Method in class com.facebook.buck.features.ocaml.OcamlBinaryDescriptionArg
-
- getBytecodeOnly() - Method in class com.facebook.buck.features.ocaml.OcamlLibraryDescriptionArg
-
- getBytecodeOnly() - Method in class com.facebook.buck.features.ocaml.PrebuiltOcamlLibraryDescriptionArg
-
- getBytes() - Method in class com.facebook.buck.apple.clang.HeaderMap
-
- getBytes(ByteOrder) - Method in class com.facebook.buck.apple.clang.HeaderMap
-
- getBytes(ByteBuffer, int) - Static method in class com.facebook.buck.cxx.toolchain.objectfile.ObjectFileScrubbers
-
- getBytes() - Method in interface com.facebook.buck.event.listener.stats.cache.NetworkStatsKeeper.RemoteDownloadStats
-
- getBytesRead() - Method in class com.facebook.buck.artifact_cache.ThriftArtifactCacheProtocol.Response.ReadPayloadInfo
-
- getBytesReceived() - Method in class com.facebook.buck.event.NetworkEvent.BytesReceivedEvent
-
- getBytesUploaded() - Method in class com.facebook.buck.event.listener.stats.cache.RemoteCacheUploadStats
-
- getCache() - Method in class com.facebook.buck.rules.keys.EventPostingRuleKeyCacheScope
-
- getCache() - Method in interface com.facebook.buck.rules.keys.RuleKeyCacheScope
-
- getCacheable() - Method in class com.facebook.buck.android.ApkGenruleDescriptionArg
-
This functionality only exists to get around the lack of extensibility in our current build
rule / build file apis.
- getCacheable() - Method in class com.facebook.buck.cxx.CxxGenruleDescriptionArg
-
This functionality only exists to get around the lack of extensibility in our current build
rule / build file apis.
- getCacheable() - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg
-
- getCacheable() - Method in class com.facebook.buck.jvm.java.JarGenruleDescriptionArg
-
This functionality only exists to get around the lack of extensibility in our current build
rule / build file apis.
- getCacheable() - Method in interface com.facebook.buck.shell.AbstractGenruleDescription.CommonArg
-
This functionality only exists to get around the lack of extensibility in our current build
rule / build file apis.
- getCacheable() - Method in class com.facebook.buck.shell.GenruleDescriptionArg
-
This functionality only exists to get around the lack of extensibility in our current build
rule / build file apis.
- getCacheBytesPerMode() - Method in class com.facebook.buck.artifact_cache.CacheCountersSummary
-
- getCachedBuildRules() - Method in class com.facebook.buck.rules.keys.DefaultRuleKeyCache
-
- getCachedBuildRules() - Method in class com.facebook.buck.rules.keys.RuleKeyCacheRecycler
-
- getCachedBuildRules() - Method in interface com.facebook.buck.rules.keys.TrackableRuleKeyCache
-
- getCacheDir() - Method in class com.facebook.buck.artifact_cache.config.DirCacheEntry
-
- getCacheDir() - Method in class com.facebook.buck.artifact_cache.config.SQLiteCacheEntry
-
- getCacheDir() - Method in class com.facebook.buck.io.filesystem.BuckPaths
-
- getCacheDir(Path, Optional<String>, BuckPaths) - Static method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- getCacheEntries() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getCacheError() - Method in class com.facebook.buck.artifact_cache.CacheResult
-
- getCacheErrorCount() - Method in interface com.facebook.buck.event.external.events.CacheRateStatsUpdateExternalEventInterface
-
- getCacheErrorCount() - Method in class com.facebook.buck.event.listener.stats.cache.CacheRateStatsKeeper.CacheRateStatsUpdateEvent
-
- getCacheErrorRate() - Method in interface com.facebook.buck.event.external.events.CacheRateStatsUpdateExternalEventInterface
-
- getCacheErrorRate() - Method in class com.facebook.buck.event.listener.stats.cache.CacheRateStatsKeeper.CacheRateStatsUpdateEvent
-
- getCacheErrorsPerMode() - Method in class com.facebook.buck.artifact_cache.CacheCountersSummary
-
- getCacheHitCount() - Method in interface com.facebook.buck.event.external.events.CacheRateStatsUpdateExternalEventInterface
-
- getCacheHitCount() - Method in class com.facebook.buck.event.listener.stats.cache.CacheRateStatsKeeper.CacheRateStatsUpdateEvent
-
- getCacheHitsPerMode() - Method in class com.facebook.buck.artifact_cache.CacheCountersSummary
-
- getCacheMissCount() - Method in interface com.facebook.buck.event.external.events.CacheRateStatsUpdateExternalEventInterface
-
- getCacheMissCount() - Method in class com.facebook.buck.event.listener.stats.cache.CacheRateStatsKeeper.CacheRateStatsUpdateEvent
-
- getCacheMissRate() - Method in interface com.facebook.buck.event.external.events.CacheRateStatsUpdateExternalEventInterface
-
- getCacheMissRate() - Method in class com.facebook.buck.event.listener.stats.cache.CacheRateStatsKeeper.CacheRateStatsUpdateEvent
-
- getCacheModes() - Method in class com.facebook.buck.util.environment.BuildEnvironmentDescription
-
- getCacheNames() - Method in class com.facebook.buck.artifact_cache.CacheDeleteResult
-
- getCacheRateStats() - Method in class com.facebook.buck.event.listener.stats.cache.NetworkStatsTracker
-
Get the current cache rate stats.
- getCacheReadMode() - Method in class com.facebook.buck.artifact_cache.AbstractAsynchronousCache
-
- getCacheReadMode() - Method in interface com.facebook.buck.artifact_cache.ArtifactCache
-
This method must return the same value over the lifetime of this object.
- getCacheReadMode() - Method in class com.facebook.buck.artifact_cache.config.DirCacheEntry
-
- getCacheReadMode() - Method in class com.facebook.buck.artifact_cache.config.HttpCacheEntry
-
- getCacheReadMode() - Method in class com.facebook.buck.artifact_cache.config.SQLiteCacheEntry
-
- getCacheReadMode() - Method in class com.facebook.buck.artifact_cache.DirArtifactCache
-
- getCacheReadMode() - Method in class com.facebook.buck.artifact_cache.LoggingArtifactCacheDecorator
-
- getCacheReadMode() - Method in class com.facebook.buck.artifact_cache.MultiArtifactCache
-
- getCacheReadMode() - Method in class com.facebook.buck.artifact_cache.NoopArtifactCache
-
- getCacheReadMode() - Method in class com.facebook.buck.artifact_cache.RetryingCacheDecorator
-
- getCacheReadMode() - Method in class com.facebook.buck.artifact_cache.SQLiteArtifactCache
-
- getCacheReadMode() - Method in class com.facebook.buck.artifact_cache.TwoLevelArtifactCacheDecorator
-
- getCacheResult() - Method in class com.facebook.buck.artifact_cache.ArtifactCacheEvent.Finished
-
- getCacheResult() - Method in class com.facebook.buck.core.build.engine.BuildResult
-
- getCacheResult() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.Finished
-
- getCaches() - Method in class com.facebook.buck.util.cache.impl.StackedFileHashCache
-
- getCachesExamined() - Method in interface com.facebook.buck.util.cache.FileHashCache.FileHashCacheVerificationResult
-
- getCacheSource() - Method in class com.facebook.buck.artifact_cache.CacheResult
-
- getCacheStats() - Method in class com.facebook.buck.versions.InstrumentedVersionedTargetGraphCache
-
- getCacheType() - Method in enum com.facebook.buck.artifact_cache.config.ArtifactCacheMode
-
- getCacheTypeName() - Method in enum com.facebook.buck.artifact_cache.config.ArtifactCacheMode
-
- getCachingBuildEngine() - Method in class com.facebook.buck.command.BuildExecutor
-
- getCallable() - Method in class com.facebook.buck.core.graph.transformation.executor.DepsAwareTask
-
- getCanaryClassName() - Method in class com.facebook.buck.android.apkmodule.APKModule
-
- getCanBeAsset() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getCanBeAsset() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getCanBeAsset() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getCanBeAsset() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
- getCanBeAsset() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getCanBeAsset() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getCancellableTasks() - Method in class com.facebook.buck.support.bgtasks.AsyncBackgroundTaskManager
-
Return map of tasks that might be cancelled (i.e.
- getCancelReason() - Method in class com.facebook.buck.rules.modern.builders.RemoteRuleContext
-
Get Throwable which caused action to cancel.
- getCandidatesToDelete(Path) - Method in interface com.facebook.buck.util.DirectoryCleaner.PathSelector
-
- getCanonicalCellName(Path) - Method in interface com.facebook.buck.core.cell.CellPathResolver
-
Returns a cell name that can be used to refer to the cell at the given path.
- getCanonicalCellName(AbsPath) - Method in interface com.facebook.buck.core.cell.CellPathResolver
-
- getCanonicalCellName(Path) - Method in class com.facebook.buck.core.cell.CellPathResolverView
-
- getCanonicalCellName(Path) - Method in class com.facebook.buck.core.cell.DefaultNewCellPathResolver
-
- getCanonicalCellName(Path) - Method in class com.facebook.buck.core.cell.impl.DefaultCellPathResolver
-
- getCanonicalCellName(Path) - Method in interface com.facebook.buck.core.cell.NewCellPathResolver
-
- getCanonicalName() - Method in interface com.facebook.buck.core.cell.Cell
-
- getCanonicalName() - Method in enum com.facebook.buck.util.environment.Platform
-
- getCanReuseClassLoader() - Method in class com.facebook.buck.jvm.java.JavacPluginJsr199Fields
-
- getCanReuseClassLoader() - Method in class com.facebook.buck.jvm.java.ResolvedJavacPluginProperties
-
- getCapabilities() - Method in class com.facebook.buck.io.watchman.Watchman
-
- getCapacity() - Method in interface com.facebook.buck.worker.WorkerProcessPool
-
- getCapacity() - Method in class com.facebook.buck.worker.WorkerProcessPoolAsync
-
- getCapacity() - Method in class com.facebook.buck.worker.WorkerProcessPoolSync
-
- getCasDeadline() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getCasDeadline() - Method in class com.facebook.buck.remoteexecution.config.RemoteExecutionConfig
-
- getCasDownloads() - Method in class com.facebook.buck.remoteexecution.event.listener.RemoteExecutionEventListener
-
- getCasDownloads() - Method in interface com.facebook.buck.remoteexecution.event.RemoteExecutionStatsProvider
-
Total number of downloads.
- getCasDownloadSizeBytes() - Method in class com.facebook.buck.remoteexecution.event.listener.RemoteExecutionEventListener
-
- getCasDownloadSizeBytes() - Method in interface com.facebook.buck.remoteexecution.event.RemoteExecutionStatsProvider
-
Total number of downloaded bytes from CAS.
- getCasHost() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getCasHost() - Method in class com.facebook.buck.remoteexecution.config.RemoteExecutionConfig
-
- getCasInsecure() - Method in class com.facebook.buck.remoteexecution.config.RemoteExecutionConfig
-
- getCasPort() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getCasPort() - Method in class com.facebook.buck.remoteexecution.config.RemoteExecutionConfig
-
- getCasUploads() - Method in class com.facebook.buck.remoteexecution.event.listener.RemoteExecutionEventListener
-
- getCasUploads() - Method in interface com.facebook.buck.remoteexecution.event.RemoteExecutionStatsProvider
-
Total number of downloads.
- getCasUploadSizeBytes() - Method in class com.facebook.buck.remoteexecution.event.listener.RemoteExecutionEventListener
-
- getCasUploadSizeBytes() - Method in interface com.facebook.buck.remoteexecution.event.RemoteExecutionStatsProvider
-
Total of uploaded bytes to CAS.
- getCategory() - Method in class com.facebook.buck.artifact_cache.ArtifactCacheConnectEvent
-
- getCategory() - Method in class com.facebook.buck.artifact_cache.ArtifactCacheEvent
-
- getCategory() - Method in class com.facebook.buck.core.test.event.TestStatusMessageEvent
-
- getCategory() - Method in class com.facebook.buck.core.test.event.TestSummaryEvent
-
- getCategory() - Method in class com.facebook.buck.counters.Counter
-
- getCategory() - Method in class com.facebook.buck.counters.CounterSnapshot
-
- getCategory() - Method in class com.facebook.buck.event.ActionGraphEvent
-
- getCategory() - Method in class com.facebook.buck.event.ArtifactCompressionEvent
-
- getCategory() - Method in class com.facebook.buck.event.chrome_trace.ChromeTraceEvent
-
- getCategory() - Method in class com.facebook.buck.event.FileHashCacheEvent
-
- getCategory() - Method in class com.facebook.buck.event.InstallEvent
-
- getCategory() - Method in interface com.facebook.buck.event.LeafEvent
-
- getCategory() - Method in class com.facebook.buck.event.LeafEvents.SimpleLeafEvent
-
- getCategory() - Method in class com.facebook.buck.event.listener.ScribeEventListenerConfig
-
- getCategory() - Method in interface com.facebook.buck.event.RuleKeyCalculationEvent
-
- getCategory() - Method in enum com.facebook.buck.event.RuleKeyCalculationEvent.Type
-
- getCategory() - Method in class com.facebook.buck.event.StartActivityEvent
-
- getCategory() - Method in class com.facebook.buck.event.UninstallEvent
-
- getCategory() - Method in class com.facebook.buck.json.ProjectBuildFileParseEvents.Finished
-
- getCategory() - Method in class com.facebook.buck.json.ProjectBuildFileParseEvents.Started
-
- getCategory() - Method in class com.facebook.buck.jvm.java.AnnotationProcessingEvent
-
- getCategory() - Method in class com.facebook.buck.log.ErrorLogRecord
-
Computes a category key based on relevant LogRecord information.
- getCategory() - Method in class com.facebook.buck.parser.ParseEvent
-
- getCategory() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionSessionEvent
-
- getCategory() - Method in class com.facebook.buck.step.StepEvent
-
- getCategory() - Method in class com.facebook.buck.test.external.ExternalTestRunEvent
-
- getCategory() - Method in class com.facebook.buck.test.external.ExternalTestSpecCalculationEvent
-
- getCategory() - Method in class com.facebook.buck.versions.VersionedTargetGraphEvent
-
- getCause() - Method in interface com.facebook.buck.step.StepExecutionResult
-
- getCc() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getCc() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getCCompiler() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
C compiler binary.
- getCCompilerFlags() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
C compiler flags.
- getCell(Path) - Method in interface com.facebook.buck.core.cell.Cell
-
- getCell(CanonicalCellName) - Method in interface com.facebook.buck.core.cell.Cell
-
- getCell(CanonicalCellName) - Method in class com.facebook.buck.core.cell.Cells
-
- getCell() - Method in class com.facebook.buck.core.model.BuildTarget
-
- getCell() - Method in class com.facebook.buck.core.model.UnconfiguredBuildTarget
-
Name of the cell that current build target belongs to
- getCell() - Method in class com.facebook.buck.core.model.UnflavoredBuildTarget
-
- getCell() - Method in class com.facebook.buck.parser.ParsingContext
-
Cell for which the parsing request is performed
- getCellBuckOut() - Method in class com.facebook.buck.io.filesystem.EmbeddedCellBuckOutInfo
-
Returns an absolute path to the cell's buck-out embedded inside the root's buck-out
- getCellByCanonicalCellName(CanonicalCellName) - Method in class com.facebook.buck.core.cell.CellProvider
-
Get cell object by canonicall cell name
- getCellByPath(Path) - Method in class com.facebook.buck.core.cell.CellProvider
-
- getCellByPath(AbsPath) - Method in class com.facebook.buck.core.cell.CellProvider
-
- getCellFreeRepresentation() - Method in interface com.facebook.buck.core.parser.buildtargetparser.BuildTargetMatcher
-
Value used in a build file to specify this pattern, devoid of any
Cell
prefix.
- getCellIgnoringVisibilityCheck(Path) - Method in interface com.facebook.buck.core.cell.Cell
-
- getCellName() - Method in class com.facebook.buck.core.model.CellRelativePath
-
- getCellName() - Method in class com.facebook.buck.io.filesystem.BuckPaths
-
- getCellName() - Method in class com.facebook.buck.io.filesystem.EmbeddedCellBuckOutInfo
-
- getCellName() - Method in class com.facebook.buck.parser.options.ProjectBuildFileParserOptions
-
- getCellName() - Method in class com.facebook.buck.support.cli.args.BuckCellArg
-
- getCellNameResolver() - Method in interface com.facebook.buck.core.cell.Cell
-
- getCellNameResolver() - Method in interface com.facebook.buck.core.cell.CellPathResolver
-
- getCellNameResolver() - Method in class com.facebook.buck.core.cell.CellPathResolverView
-
- getCellNameResolver() - Method in class com.facebook.buck.core.cell.impl.DefaultCellPathResolver
-
- getCellNameResolver() - Method in class com.facebook.buck.rules.macros.StringWithMacrosConverter
-
- getCellPath(Optional<String>) - Method in interface com.facebook.buck.core.cell.CellPathResolver
-
- getCellPath(Optional<String>) - Method in class com.facebook.buck.core.cell.CellPathResolverView
-
- getCellPath(CanonicalCellName) - Method in class com.facebook.buck.core.cell.DefaultNewCellPathResolver
-
- getCellPath(Optional<String>) - Method in class com.facebook.buck.core.cell.impl.DefaultCellPathResolver
-
- getCellPath(CanonicalCellName) - Method in interface com.facebook.buck.core.cell.NewCellPathResolver
-
- getCellPath() - Method in class com.facebook.buck.event.WatchmanStatusEvent.Overflow
-
- getCellPath() - Method in interface com.facebook.buck.io.watchman.WatchmanEvent
-
Absolute cell path root being watched.
- getCellPath() - Method in class com.facebook.buck.io.watchman.WatchmanMultiplePathEvent
-
- getCellPath() - Method in class com.facebook.buck.io.watchman.WatchmanOverflowEvent
-
- getCellPath() - Method in class com.facebook.buck.io.watchman.WatchmanPathEvent
-
- getCellPathOrThrow(Optional<String>) - Method in class com.facebook.buck.core.cell.AbstractCellPathResolver
-
- getCellPathOrThrow(CanonicalCellName) - Method in class com.facebook.buck.core.cell.AbstractCellPathResolver
-
- getCellPathOrThrow(Optional<String>) - Method in interface com.facebook.buck.core.cell.CellPathResolver
-
- getCellPathOrThrow(CanonicalCellName) - Method in interface com.facebook.buck.core.cell.CellPathResolver
-
- getCellPathPrefix() - Method in class com.facebook.buck.rules.modern.builders.ModernBuildRuleRemoteExecutionHelper
-
- getCellPathPrefix() - Method in interface com.facebook.buck.rules.modern.builders.RemoteExecutionHelper
-
The cell path prefix is the path that all remote execution related paths will be relative to.
- getCellPathResolver() - Method in class com.facebook.buck.core.build.execution.context.ExecutionContext
-
- getCellPathResolver() - Method in interface com.facebook.buck.core.cell.Cell
-
- getCellPathResolver() - Method in interface com.facebook.buck.core.rules.BuildRuleCreationContext
-
- getCellPathResolver() - Method in interface com.facebook.buck.core.rules.BuildRuleCreationContextWithTargetGraph
-
- getCellPathResolver() - Method in interface com.facebook.buck.jvm.java.JavacExecutionContext
-
- getCellPathsByRootCellExternalName() - Method in interface com.facebook.buck.core.cell.CellPathResolver
-
- getCellPathsByRootCellExternalName() - Method in class com.facebook.buck.core.cell.CellPathResolverView
-
- getCellPathsByRootCellExternalName() - Method in class com.facebook.buck.core.cell.impl.DefaultCellPathResolver
-
- getCellProvider() - Method in interface com.facebook.buck.core.cell.Cell
-
- getCellProvider() - Method in class com.facebook.buck.core.cell.Cells
-
- getCellRelativeBaseName() - Method in class com.facebook.buck.parser.spec.BuildFileSpec
-
- getCellRelativeBasePath() - Method in class com.facebook.buck.core.model.BuildTarget
-
- getCellRelativeBasePath() - Method in class com.facebook.buck.core.model.UnconfiguredBuildTarget
-
- getCellRelativeBasePath() - Method in class com.facebook.buck.core.model.UnflavoredBuildTarget
-
- getCellRelativeBasePath() - Method in class com.facebook.buck.core.parser.buildtargetpattern.BuildTargetPattern
-
Path to the package folder that is a root for all build targets matched by a pattern
- getCellRelativeName() - Method in class com.facebook.buck.core.model.BuildTarget
-
If this build target is cell//third_party/java/guava:guava-latest, then this would return
"//third_party/java/guava:guava-latest".
- getCellRelativeName() - Method in class com.facebook.buck.core.model.UnconfiguredBuildTarget
-
- getCellRoots() - Method in class com.facebook.buck.parser.options.ProjectBuildFileParserOptions
-
- getCells() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getCells() - Method in class com.facebook.buck.command.BuildExecutorArgs
-
- getCells() - Method in class com.facebook.buck.core.build.execution.context.ExecutionContext
-
- getCertFile() - Method in class com.facebook.buck.remoteexecution.config.RemoteExecutionConfig
-
client TLS certificate file in PEM format
- getCertificateAuthoritiesFile() - Method in class com.facebook.buck.remoteexecution.config.RemoteExecutionConfig
-
file containing all TLS authorities to verify server certificate with (PEM format)
- getCFiles() - Method in class com.facebook.buck.features.go.CGoGenSource
-
- getCflags() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getCflags() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getCgoCompilerFlags() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getCgoFiles() - Method in class com.facebook.buck.features.go.CGoGenSource
-
- getChain() - Method in class com.facebook.buck.artifact_cache.ClientCertificateHandler.CertificateInfo
-
- getChanges() - Method in class com.facebook.buck.io.watchman.WatchmanMultiplePathEvent
-
All changes to monitored file system that occurred since last invalidation
- getCharByteBuffer(byte[], int) - Static method in class com.facebook.buck.cxx.toolchain.objectfile.ObjectFileScrubbers
-
Returned buffer does _not_ include NULL-terminating char.
- getCharContent(boolean) - Method in class com.facebook.buck.jvm.java.JavaInMemoryFileObject
-
- getCharContent(boolean) - Method in class com.facebook.buck.jvm.java.JavaNoOpFileObject
-
- getChild(HashCode) - Method in interface com.facebook.buck.rules.modern.Deserializer.DataProvider
-
- getChildren() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXGroup
-
- getChildren() - Method in class com.facebook.buck.apple.xcode.xcodeproj.XCVersionGroup
-
- getChildren() - Method in class com.facebook.buck.core.files.FileTree
-
File trees of all subfolders recursively
- getChildren() - Method in class com.facebook.buck.rules.modern.impl.InputsMapBuilder.Data
-
- getChildrenList() - Method in interface com.facebook.buck.remoteexecution.interfaces.Protocol.Tree
-
- getChunks() - Method in class com.facebook.buck.util.ChunkAccumulator
-
- getChunkSize() - Method in class com.facebook.buck.android.resources.ResChunk
-
- getClassAbiJar(BuildTarget) - Static method in class com.facebook.buck.jvm.core.JavaAbis
-
- getClassAbiPath() - Method in class com.facebook.buck.jvm.java.DiffAbisStep
-
- getClassesDir() - Method in class com.facebook.buck.jvm.java.CompilerOutputPaths
-
- getClassesDir(BuildTarget, ProjectFilesystem) - Static method in class com.facebook.buck.jvm.java.CompilerOutputPaths
-
- getClassesHash() - Method in interface com.facebook.buck.android.DexWithClasses
-
- getClassExpanders() - Method in class com.facebook.buck.rules.macros.StringWithMacrosConverter
-
- getClassHashesProvider() - Method in interface com.facebook.buck.jvm.core.HasJavaClassHashes
-
- getClassHashesProvider() - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getClassHashesProvider() - Method in class com.facebook.buck.jvm.java.PrebuiltJar
-
- getClassLoader(JavaFileManager.Location) - Method in class com.facebook.buck.jvm.java.PluginLoaderJavaFileManager
-
- getClassLoaderCache() - Method in class com.facebook.buck.core.build.execution.context.ExecutionContext
-
- getClassLoaderCache() - Method in interface com.facebook.buck.jvm.java.JavacExecutionContext
-
- getClassLoaderForClassPath(ClassLoader, ImmutableList<URL>) - Method in class com.facebook.buck.util.ClassLoaderCache
-
- getClassName() - Method in interface com.facebook.buck.apple.AbstractIdbTestResult
-
String that represents the name of the class of the test
- getClassName() - Method in class com.facebook.buck.test.selectors.TestDescription
-
- getClassNames() - Method in interface com.facebook.buck.android.DexWithClasses
-
- getClassNamesToHashes() - Method in interface com.facebook.buck.jvm.core.HasJavaClassHashes
-
- getClassNamesToHashes(ProjectFilesystem, SourcePathResolverAdapter) - Method in interface com.facebook.buck.jvm.core.JavaClassHashesProvider
-
- getClassNamesToHashes() - Method in class com.facebook.buck.jvm.core.JavaLibrary.Data
-
- getClassNamesToHashes(ProjectFilesystem, SourcePathResolverAdapter) - Method in class com.facebook.buck.jvm.java.DefaultJavaClassHashesProvider
-
- getClassNamesToHashes() - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getClassNamesToHashes() - Method in class com.facebook.buck.jvm.java.PrebuiltJar
-
- getClassNamesToHashesSupplier() - Method in interface com.facebook.buck.android.packageable.AndroidPackageableCollection
-
- getClasspath() - Method in class com.facebook.buck.jvm.java.JarShape.Summary
-
- getClasspath() - Method in class com.facebook.buck.jvm.java.JavacPluginJsr199Fields
-
- getClasspath(SourcePathResolverAdapter, ProjectFilesystem) - Method in class com.facebook.buck.jvm.java.ResolvedJavacPluginProperties
-
Get the classpath for the plugin.
- getClasspath() - Static method in class com.facebook.buck.util.env.BuckClasspath
-
Returns Buck's classpath.
- getClasspathArgfile() - Method in class com.facebook.buck.jvm.java.JUnitStep
-
Returns the classpath argfile for Java 9+ invocations.
- getClasspathDeps(Iterable<BuildRule>) - Static method in class com.facebook.buck.jvm.java.JavaLibraryClasspathProvider
-
Include the classpath entries from all JavaLibraryRules that have a direct line of lineage to
this rule through other JavaLibraryRules.
- getClasspathEntries() - Method in class com.facebook.buck.jvm.java.CompilerParameters
-
- getClasspathEntriesToDex() - Method in interface com.facebook.buck.android.packageable.AndroidPackageableCollection
-
Java classes (jars) to include in the package.
- getClassPaths() - Method in class com.facebook.buck.features.project.intellij.model.IjLibrary
-
- getClasspathsFromLibraries(Iterable<JavaLibrary>) - Static method in class com.facebook.buck.jvm.java.JavaLibraryClasspathProvider
-
Given libraries that may contribute classpaths, visit them and collect the classpaths.
- getClassToModuleMap(ProjectFilesystem, Path) - Static method in class com.facebook.buck.android.AppModularityMetadataUtil
-
- getClazz() - Method in class com.facebook.buck.parser.api.BuildFileManifestPojoizer.PojoTransformer
-
Return a type that transformer is able to transform from; the real object should be
assignable to this class, so base classes and interfaces can be used too
- getCleanAdditionalPaths() - Method in class com.facebook.buck.cli.CleanCommandBuckConfig
-
- getCleanExcludedCaches() - Method in class com.facebook.buck.cli.CleanCommandBuckConfig
-
- getCLibs() - Method in class com.facebook.buck.features.ocaml.PrebuiltOcamlLibraryDescriptionArg
-
- getClient() - Method in class com.facebook.buck.edenfs.EdenClientPool
-
- getClientSubdirectory() - Method in class com.facebook.buck.event.CommandEvent.Started
-
- getClientTlsCertificate() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
Gets the path to a PEM encoded X509 certificate to use as the TLS client certificate for HTTP
cache requests from the content of the env var specified in http_client_tls_cert_env_var if set
or the field value
- getClientTlsCertRequired() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
If true, fail if client TLS certificate or key paths are unspecified, don't exist, are not the
right format or have expired
- getClientTlsForSlb() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
If true, use TLS client authentication certificate, private key and extra trusted certificates
also for CLIENT_SLB mode alive pings.
- getClientTlsKey() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
Gets the path to a PEM encoded PCKS#8 key to use as the TLS client key for HTTP cache requests
from the content of the env var specified in http_client_tls_key_env_var if set or the field
value.
- getClientTlsTrustedCertificates() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
Gets the path to a file containing PEM encoded X509 certificates to use as an additional list
of trusted certificates from the content of the env var specified in http_client_tls_ca_env_var
if set or the field value.
- getClientWorkingDir() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getClock() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getClock() - Method in class com.facebook.buck.command.BuildExecutorArgs
-
- getClock() - Method in class com.facebook.buck.core.build.engine.BuildEngineBuildContext
-
- getClockIds() - Method in class com.facebook.buck.io.watchman.Watchman
-
- getCmd() - Method in class com.facebook.buck.android.ApkGenruleDescriptionArg
-
- getCmd() - Method in class com.facebook.buck.apple.XcodeScriptDescriptionArg
-
- getCmd() - Method in class com.facebook.buck.cxx.CxxGenruleDescriptionArg
-
- getCmd() - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg
-
- getCmd() - Method in class com.facebook.buck.jvm.java.JarGenruleDescriptionArg
-
- getCmd() - Method in interface com.facebook.buck.shell.AbstractGenruleDescription.CommonArg
-
- getCmd() - Method in class com.facebook.buck.shell.GenruleBuildable
-
- getCmd() - Method in class com.facebook.buck.shell.GenruleDescriptionArg
-
- getCmdExe() - Method in class com.facebook.buck.android.ApkGenruleDescriptionArg
-
- getCmdExe() - Method in class com.facebook.buck.cxx.CxxGenruleDescriptionArg
-
- getCmdExe() - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg
-
- getCmdExe() - Method in class com.facebook.buck.jvm.java.JarGenruleDescriptionArg
-
- getCmdExe() - Method in interface com.facebook.buck.shell.AbstractGenruleDescription.CommonArg
-
- getCmdExe() - Method in class com.facebook.buck.shell.GenruleDescriptionArg
-
- getCode() - Method in enum com.facebook.buck.util.ExitCode
-
- getCodesign() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
codesign binary.
- getCodesignAllocate() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
codesign_allocate binary.
- getCodesignAllocate() - Method in class com.facebook.buck.apple.toolchain.AppleCxxPlatform
-
- getCodesignFlags() - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg
-
- getCodesignFlags() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getCodesignFlags() - Method in interface com.facebook.buck.apple.HasAppleCodesignFields
-
- getCodeSignIdentitiesCommand() - Method in class com.facebook.buck.apple.AppleConfig
-
- getCodesignIdentity() - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg
-
- getCodesignIdentity() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getCodesignIdentity() - Method in interface com.facebook.buck.apple.HasAppleCodesignFields
-
- getCodesignOnCopy() - Method in class com.facebook.buck.apple.AppleResourceDescriptionArg
-
- getCodeSignOnCopy() - Method in class com.facebook.buck.apple.PrebuiltAppleFrameworkDescriptionArg
-
- getCodesignOnCopy() - Method in class com.facebook.buck.apple.SourcePathWithAppleBundleDestination
-
- getCodesignProvider() - Method in class com.facebook.buck.apple.AppleConfig
-
- getCodesignProvider() - Method in class com.facebook.buck.apple.toolchain.AppleCxxPlatform
-
- getCodesignTimeout() - Method in class com.facebook.buck.apple.AppleConfig
-
Specify the maximum code-signing time before timing out.
- getColumnNumber() - Method in interface com.facebook.buck.util.xml.DocumentLocation
-
- getCommand() - Method in class com.facebook.buck.apple.IdbRunTestsStep
-
- getCommand() - Method in class com.facebook.buck.apple.xcode.XCScheme.SchemePrePostAction
-
- getCommand() - Method in interface com.facebook.buck.core.rules.actions.ActionExecutionResult.ActionExecutionFailure
-
- getCommand() - Method in interface com.facebook.buck.core.rules.actions.ActionExecutionResult.ActionExecutionSuccess
-
- getCommand() - Method in interface com.facebook.buck.core.rules.actions.ActionExecutionResult
-
- getCommand() - Method in class com.facebook.buck.core.test.rule.ExternalTestRunnerTestSpec
-
- getCommand(BuildContext) - Method in class com.facebook.buck.cxx.CxxPreprocessAndCompile
-
Returns the compilation command (used for compdb).
- getCommand(BuildContext) - Method in class com.facebook.buck.cxx.CxxThinLTOOpt
-
Returns the compilation command (used for compdb).
- getCommand() - Method in class com.facebook.buck.cxx.toolchain.objectfile.MachoDyldInfoCommand
-
- getCommand() - Method in class com.facebook.buck.cxx.toolchain.objectfile.MachoSymTabCommand
-
- getCommand() - Method in interface com.facebook.buck.remoteexecution.interfaces.Protocol.Command
-
- getCommand() - Method in class com.facebook.buck.step.AbstractTestStep
-
- getCommand() - Method in class com.facebook.buck.support.fix.BuckFixSpec
-
The name of the command that was run.
- getCommand() - Method in interface com.facebook.buck.util.ProcessExecutor.LaunchedProcess
-
- getCommand() - Method in class com.facebook.buck.util.ProcessExecutor.LaunchedProcessImpl
-
- getCommand() - Method in class com.facebook.buck.util.ProcessExecutor.Result
-
- getCommand() - Method in class com.facebook.buck.util.ProcessExecutorParams
-
The command and arguments to launch.
- getCommand() - Method in class com.facebook.buck.util.trace.BuildTraces.TraceAttributes
-
- getCommand(Platform, WorkerProcessParams) - Method in class com.facebook.buck.worker.WorkerProcessPoolFactory
-
- getCommandArgs() - Method in interface com.facebook.buck.doctor.config.BuildLogEntry
-
- getCommandArgs() - Method in class com.facebook.buck.log.InvocationInfo
-
- getCommandArgsFile() - Method in class com.facebook.buck.cli.AbstractCommand
-
- getCommandData() - Method in class com.facebook.buck.support.fix.BuckFixSpec
-
Arbitrary additional data from the specific command.
- getCommandDigest() - Method in interface com.facebook.buck.remoteexecution.interfaces.Protocol.Action
-
- getCommandId() - Method in class com.facebook.buck.log.InvocationInfo
-
- getCommandId() - Method in class com.facebook.buck.worker.WorkerProcessProtocol.CommandResponse
-
- getCommandIdToIsDaemonMapper() - Method in class com.facebook.buck.log.GlobalStateManager
-
- getCommandIdToIsRemoteExecutionMapper() - Method in class com.facebook.buck.log.GlobalStateManager
-
- getCommandIdToIsSuperConsoleEnabledMapper() - Method in class com.facebook.buck.log.GlobalStateManager
-
- getCommandLineArgs() - Method in interface com.facebook.buck.core.rules.actions.lib.args.CommandLine
-
- getCommandLineArguments() - Method in class com.facebook.buck.apple.xcode.XCScheme.LaunchAction
-
- getCommandLineArguments() - Method in class com.facebook.buck.apple.xcode.XCScheme.ProfileAction
-
- getCommandLineArguments() - Method in class com.facebook.buck.apple.xcode.XCScheme.TestAction
-
- getCommandLineArguments() - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg
-
- getCommandLineBuildTargetNormalizer(Cell, Path, BuckConfig) - Method in class com.facebook.buck.cli.AbstractCommand
-
- getCommandName() - Method in class com.facebook.buck.event.CommandEvent
-
- getCommandPrefix(SourcePathResolverAdapter) - Method in class com.facebook.buck.core.rules.tool.RunInfoLegacyTool
-
- getCommandPrefix(SourcePathResolverAdapter) - Method in class com.facebook.buck.core.toolchain.tool.DelegatingTool
-
- getCommandPrefix(SourcePathResolverAdapter) - Method in class com.facebook.buck.core.toolchain.tool.impl.CommandTool
-
- getCommandPrefix(SourcePathResolverAdapter) - Method in class com.facebook.buck.core.toolchain.tool.impl.HashedFileTool
-
- getCommandPrefix(SourcePathResolverAdapter) - Method in class com.facebook.buck.core.toolchain.tool.impl.VersionedTool
-
- getCommandPrefix(SourcePathResolverAdapter) - Method in interface com.facebook.buck.core.toolchain.tool.Tool
-
- getCommandPrefix() - Method in class com.facebook.buck.features.python.PexStep
-
- getCommandPrefix(SourcePathResolverAdapter) - Method in class com.facebook.buck.features.python.toolchain.PythonEnvironment
-
- getCommandPrefix(SourcePathResolverAdapter) - Method in class com.facebook.buck.infer.InferDistTool
-
- getCommandPrefix(SourcePathResolverAdapter) - Method in class com.facebook.buck.jvm.groovy.Groovyc
-
- getCommandPrefix(SourcePathResolverAdapter) - Method in class com.facebook.buck.jvm.java.ExternalJavac
-
- getCommandPrefix(SourcePathResolverAdapter) - Method in class com.facebook.buck.jvm.java.Jsr199Javac
-
- getCommandPrefix(SourcePathResolverAdapter) - Method in class com.facebook.buck.jvm.kotlin.ExternalKotlinc
-
- getCommandPrefix(SourcePathResolverAdapter) - Method in class com.facebook.buck.jvm.kotlin.JarBackedReflectedKotlinc
-
- getCommandRunnerParams() - Method in class com.facebook.buck.cli.ProjectGeneratorParameters
-
- getCommandsForArguments(Iterable<String>) - Method in class com.facebook.buck.util.CommandSplitter
-
- getCommandSize() - Method in class com.facebook.buck.cxx.toolchain.objectfile.MachoDyldInfoCommand
-
- getCommandSize() - Method in class com.facebook.buck.cxx.toolchain.objectfile.MachoSymTabCommand
-
- getCommandsRunning() - Method in class com.facebook.buck.support.bgtasks.AsyncBackgroundTaskManager
-
- getCommonProjectPrefix(List<String>, BuckConfig) - Static method in class com.facebook.buck.remoteexecution.util.RemoteExecutionUtil
-
Given a list of targets, determines if they all share a common prefix, and if they do then
returns it.
- getCompatibilityVersion() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXProject
-
- getCompatibleWith() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.android.AndroidAppModularityDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.android.AndroidBuildConfigDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.android.AndroidInstrumentationApkDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.android.AndroidInstrumentationTestDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.android.AndroidManifestDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.android.AndroidPrebuiltAarDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.android.AndroidResourceDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.android.ApkGenruleDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.android.GenAidlDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.android.NdkLibraryDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.android.NdkToolchainDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.android.PrebuiltNativeLibraryDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.apple.AppleAssetCatalogDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.apple.ApplePackageDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.apple.AppleResourceDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.apple.AppleToolchainSetDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.apple.AppleWrapperResourceArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.apple.PrebuiltAppleFrameworkDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.apple.XcodeScriptDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in interface com.facebook.buck.core.description.arg.BuildRuleArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.core.model.targetgraph.impl.ImmutableUnconfiguredTargetNode
-
- getCompatibleWith() - Method in interface com.facebook.buck.core.model.targetgraph.raw.UnconfiguredTargetNode
-
List of targets from compatible_with
attribute.
- getCompatibleWith() - Method in class com.facebook.buck.core.model.targetgraph.TargetNodeMaybeIncompatible
-
- getCompatibleWith() - Method in class com.facebook.buck.core.starlark.rule.SkylarkDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.core.test.rule.impl.ExternalTestRunnerDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.core.toolchain.rule.LegacyToolchainDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.cxx.CxxGenruleDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.cxx.CxxPrecompiledHeaderDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.d.DBinaryDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.d.DLibraryDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.d.DTestDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.dotnet.CsharpLibraryDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.dotnet.PrebuiltDotnetLibraryDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.filegroup.FileGroupDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.go.GoBinaryDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.go.GoLibraryDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.go.GoTestDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.go.GoTestRunnerDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.go.PrebuiltGoLibraryDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.gwt.GwtBinaryDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.haskell.HaskellBinaryDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.haskell.HaskellGhciDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.haskell.HaskellHaddockDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.haskell.HaskellLibraryDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.haskell.HaskellPrebuiltLibraryDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.js.JsBundleDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.js.JsLibraryDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.lua.LuaBinaryDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.lua.LuaLibraryDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.ocaml.OcamlBinaryDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.ocaml.OcamlLibraryDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.ocaml.PrebuiltOcamlLibraryDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.python.PrebuiltPythonLibraryDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.python.PythonLibraryDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.python.PythonTestRunnerDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.rust.PrebuiltRustLibraryDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.features.zip.rules.ZipFileDescriptionArg
-
- getCompatibleWith() - Method in class com.facebook.buck.file.HttpArchiveDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.file.HttpFileDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.file.RemoteFileDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.jvm.java.JarGenruleDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.jvm.java.JavaAnnotationProcessorDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.jvm.java.JavaBinaryDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.jvm.java.JavaPluginDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.jvm.java.KeystoreDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.jvm.java.PrebuiltJarDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.shell.CommandAliasDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.shell.ExportFileDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.shell.GenruleDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.shell.ShBinaryDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.shell.ShTestDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.shell.TestSuiteDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.shell.WorkerToolDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.swift.SwiftLibraryDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.swift.SwiftToolchainDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompatibleWith() - Method in class com.facebook.buck.versions.VersionedAliasDescriptionArg
-
A list of config_setting
a target is compatible with.
- getCompilationDirectory() - Method in class com.facebook.buck.cxx.NoopDebugPathSanitizer
-
- getCompilationDirectory() - Method in class com.facebook.buck.cxx.toolchain.DebugPathSanitizer
-
- getCompilationDirectory() - Method in class com.facebook.buck.cxx.toolchain.PrefixMapDebugPathSanitizer
-
- getCompilationEnvironment(Path, boolean) - Method in class com.facebook.buck.cxx.NoopDebugPathSanitizer
-
- getCompilationEnvironment(Path, boolean) - Method in class com.facebook.buck.cxx.toolchain.DebugPathSanitizer
-
- getCompilationEnvironment(Path, boolean) - Method in class com.facebook.buck.cxx.toolchain.PrefixMapDebugPathSanitizer
-
- getCompilationFlags(Compiler, Path, ImmutableMap<Path, Path>) - Method in class com.facebook.buck.cxx.toolchain.DebugPathSanitizer
-
- getCompilationFlags(Compiler, Path, ImmutableMap<Path, Path>) - Method in class com.facebook.buck.cxx.toolchain.PrefixMapDebugPathSanitizer
-
- getCompilationUnit() - Method in class com.facebook.buck.jvm.java.plugin.adapter.CompilationUnitTreeProxyImpl
-
- getCompilationUnit() - Method in class com.facebook.buck.jvm.java.plugin.api.TaskEventMirror
-
- getCompile() - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg
-
- getCompile() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getCompileAgainst() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getCompileAgainst() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getCompileAgainst() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getCompileAgainst() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getCompileAgainst() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getCompileAgainst() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getCompileAgainst() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getCompileAgainst() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getCompileAgainst() - Method in interface com.facebook.buck.jvm.java.JvmLibraryArg
-
- getCompileAgainst() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getCompileAgainst() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getCompileAgainst() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getCompileAgainst() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getCompileBuildTarget(BuildTarget, HaskellPlatform, Linker.LinkableDepType, boolean) - Static method in class com.facebook.buck.features.haskell.HaskellDescriptionUtils
-
- getCompileBuildTarget(BuildTarget, CxxPlatform, CrateType) - Static method in class com.facebook.buck.features.rust.RustCompileUtils
-
- getCompileDeps(HaskellPlatform) - Method in interface com.facebook.buck.features.haskell.HaskellCompileDep
-
- getCompiledSources() - Method in class com.facebook.buck.features.python.PythonCompileRule
-
- getCompiledTestsLibrary() - Method in class com.facebook.buck.jvm.java.JavaTest
-
Returns the underlying java library containing the compiled tests.
- getCompiledTestsLibrary() - Method in class com.facebook.buck.jvm.java.JavaTestRunner
-
- getCompileForceCache() - Method in class com.facebook.buck.swift.SwiftBuckConfig
-
- getCompileInput(HaskellPlatform, Linker.LinkableDepType, boolean) - Method in interface com.facebook.buck.features.haskell.HaskellCompileDep
-
- getCompiler() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getCompiler(AndroidLibraryDescription.JvmLanguage, JavacFactory, TargetConfiguration) - Method in interface com.facebook.buck.android.AndroidLibraryCompilerFactory
-
- getCompiler() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getCompiler(AndroidLibraryDescription.JvmLanguage, JavacFactory, TargetConfiguration) - Method in class com.facebook.buck.android.DefaultAndroidLibraryCompilerFactory
-
- getCompiler() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getCompiler() - Method in class com.facebook.buck.android.toolchain.ndk.NdkCxxPlatformTargetConfiguration
-
- getCompiler(CxxPlatform, CxxSource.Type) - Static method in class com.facebook.buck.cxx.CxxSourceTypes
-
- getCompiler(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getCompiler() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getCompiler() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getCompiler() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getCompiler() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getCompiler() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getCompiler() - Method in interface com.facebook.buck.jvm.java.JvmLibraryArg
-
- getCompiler() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getCompiler() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getCompiler() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getCompiler() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getCompilerClassName() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getCompilerClassName() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getCompilerClassName() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getCompilerClassName() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getCompilerClassName() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getCompilerClassName() - Method in class com.facebook.buck.jvm.java.JavacSpec
-
- getCompilerClassName() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getCompilerClassName() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getCompilerClassName() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getCompilerClassName() - Method in interface com.facebook.buck.jvm.java.JvmLibraryArg
-
- getCompilerClassName() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getCompilerClassName() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getCompilerClassName() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getCompilerClassName() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getCompilerDebugPathSanitizer() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getCompilerDeps() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getCompilerFlags(NdkCompilerType) - Method in class com.facebook.buck.android.toolchain.ndk.NdkCxxPlatformTargetConfiguration
-
- getCompilerFlags(NdkCompilerType) - Method in enum com.facebook.buck.android.toolchain.ndk.TargetCpuType
-
- getCompilerFlags() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getCompilerFlags() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getCompilerFlags() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getCompilerFlags() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getCompilerFlags() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
- getCompilerFlags() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getCompilerFlags() - Method in class com.facebook.buck.cxx.CxxSourceRuleFactory
-
- getCompilerFlags() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getCompilerFlags() - Method in class com.facebook.buck.features.dotnet.CsharpLibraryDescriptionArg
-
- getCompilerFlags() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getCompilerFlags() - Method in class com.facebook.buck.features.go.GoBinaryDescriptionArg
-
- getCompilerFlags() - Method in class com.facebook.buck.features.go.GoLibraryDescriptionArg
-
- getCompilerFlags() - Method in class com.facebook.buck.features.go.GoTestDescriptionArg
-
- getCompilerFlags() - Method in interface com.facebook.buck.features.go.HasGoLinkable
-
- getCompilerFlags() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getCompilerFlags() - Method in class com.facebook.buck.features.haskell.HaskellBinaryDescriptionArg
-
- getCompilerFlags(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getCompilerFlags() - Method in class com.facebook.buck.features.haskell.HaskellGhciDescriptionArg
-
- getCompilerFlags() - Method in class com.facebook.buck.features.haskell.HaskellLibraryDescriptionArg
-
- getCompilerFlags() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getCompilerFlags() - Method in class com.facebook.buck.features.ocaml.OcamlBinaryDescriptionArg
-
- getCompilerFlags() - Method in class com.facebook.buck.features.ocaml.OcamlLibraryDescriptionArg
-
- getCompilerFlags() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getCompilerFlags() - Method in class com.facebook.buck.jvm.scala.ScalaBuckConfig
-
- getCompilerFlags() - Method in class com.facebook.buck.swift.SwiftBuckConfig
-
- getCompilerFlags() - Method in class com.facebook.buck.swift.SwiftLibraryDescriptionArg
-
- getCompilerInvocationFlags() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getCompilerMajorVersion(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getCompilerOutputPath() - Method in class com.facebook.buck.features.project.intellij.model.IjModule
-
- getCompilerOutputPath(TargetNode<? extends JvmLibraryArg>) - Method in interface com.facebook.buck.features.project.intellij.model.IjModuleFactoryResolver
-
- getCompilerOutputPath() - Method in class com.facebook.buck.features.project.intellij.ModuleBuildContext
-
- getCompilerParameters(BuildContext, ProjectFilesystem, BuildTarget) - Method in class com.facebook.buck.jvm.java.JarBuildStepsFactory
-
- getCompilerPlugins(TargetConfiguration) - Method in class com.facebook.buck.jvm.scala.ScalaBuckConfig
-
- getCompilerSource(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getCompilerType() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
CxxToolProvider.Type
of the compiler.
- getCompilerType() - Method in class com.facebook.buck.event.CompilerErrorEvent
-
- getCompileTimeClasspathSourcePaths() - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getCompileTimeClasspathSourcePaths() - Method in class com.facebook.buck.jvm.java.JarBuildStepsFactory
-
- getComponents() - Method in class com.facebook.buck.features.python.PythonBinary
-
- getComponents() - Method in class com.facebook.buck.features.python.PythonMappedComponents
-
- getComponentsRuleKey() - Method in class com.facebook.buck.features.python.PythonMappedComponents
-
- getCompressionLevel() - Method in class com.facebook.buck.util.zip.CustomZipEntry
-
- getCompressPngs() - Method in class com.facebook.buck.apple.AppleAssetCatalogsCompilationOptions
-
- getCompressTraces() - Method in class com.facebook.buck.event.chrome_trace.ChromeTraceBuckConfig
-
- getComputationMode() - Method in class com.facebook.buck.core.rules.analysis.config.RuleAnalysisConfig
-
- getComputationName() - Method in class com.facebook.buck.cli.AbstractPerfCommand
-
- getComputationName() - Method in class com.facebook.buck.cli.PerfActionGraphCommand
-
- getComputationName() - Method in class com.facebook.buck.cli.PerfManifestCommand
-
- getComputationName() - Method in class com.facebook.buck.cli.PerfMbrPrepareRemoteExecutionCommand
-
- getComputationName() - Method in class com.facebook.buck.cli.PerfMbrSerializationCommand
-
- getComputationName() - Method in class com.facebook.buck.cli.PerfRuleKeyCommand
-
- GetComputerNameEx(int, char[], IntByReference) - Method in interface com.facebook.buck.util.network.hostname.HostnameFetchingWin32Library
-
- getConcurrencyLimit(BuckConfig) - Method in class com.facebook.buck.cli.AbstractCommand
-
- getConcurrencyLimit() - Method in class com.facebook.buck.core.build.execution.context.ExecutionContext
-
- getConcurrencyLimit() - Method in class com.facebook.buck.core.resources.ResourcesConfig
-
Construct a default ConcurrencyLimit instance from this config.
- getConcurrentInstallEnabled(Optional<BuckEventBus>) - Method in class com.facebook.buck.android.AndroidInstallConfig
-
- getConditions() - Method in class com.facebook.buck.core.select.Selector
-
- getConfidenceIntervalOffset() - Method in class com.facebook.buck.util.Statistics
-
Get the 97.5% z-score.
- getConfig() - Method in class com.facebook.buck.cli.ProjectGeneratorParameters
-
- getConfig() - Method in class com.facebook.buck.core.config.BuckConfig
-
- getConfigDefaultCxxPlatform(CxxBuckConfig, ImmutableMap<Flavor, UnresolvedCxxPlatform>, UnresolvedCxxPlatform) - Static method in class com.facebook.buck.cxx.toolchain.impl.CxxPlatforms
-
Returns the configured default cxx platform.
- getConfigFile(TargetConfiguration) - Method in class com.facebook.buck.infer.InferConfig
-
- getConfigJsonFile() - Method in interface com.facebook.buck.doctor.config.BuildLogEntry
-
- getConfigOverrides(ImmutableMap<CellName, AbsPath>) - Method in class com.facebook.buck.cli.AbstractCommand
-
- getConfigOverrides(ImmutableMap<CellName, AbsPath>) - Method in class com.facebook.buck.cli.AbstractContainerCommand
-
- getConfigOverrides(ImmutableMap<CellName, AbsPath>) - Method in interface com.facebook.buck.cli.Command
-
- getConfigOverrides() - Method in interface com.facebook.buck.doctor.config.UserLocalConfiguration
-
- getConfigs() - Method in class com.facebook.buck.android.resources.ResTableTypeSpec
-
- getConfigs() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getConfigs() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getConfigs() - Method in interface com.facebook.buck.apple.AppleNativeTargetDescriptionArg
-
- getConfigs() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getConfigs() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getConfigs() - Method in class com.facebook.buck.parser.api.BuildFileManifest
-
- getConfigs() - Method in interface com.facebook.buck.parser.api.FileManifest
-
- getConfigs() - Method in class com.facebook.buck.parser.api.PackageFileManifest
-
- getConfigsMap() - Method in class com.facebook.buck.util.config.Config
-
A map of Paths to the RawConfig that came from that config file.
- getConfigurationDeps(AndroidPlatformArg) - Method in class com.facebook.buck.android.toolchain.platform.AndroidPlatformDescription
-
- getConfigurationDeps(T) - Method in interface com.facebook.buck.core.description.BaseDescription
-
- getConfigurationDeps() - Method in class com.facebook.buck.core.model.targetgraph.impl.TargetNodeImpl
-
- getConfigurationDeps() - Method in interface com.facebook.buck.core.model.targetgraph.TargetNode
-
Provides a set of configuration targets that were used during the construction of this node.
- getConfigurationDeps(ConfigSettingArg) - Method in class com.facebook.buck.core.rules.configsetting.ConfigSettingDescription
-
- getConfigurationDeps(ConstraintSettingArg) - Method in class com.facebook.buck.core.rules.platform.ConstraintSettingDescription
-
- getConfigurationDeps(ConstraintValueArg) - Method in class com.facebook.buck.core.rules.platform.ConstraintValueDescription
-
- getConfigurationDeps(PlatformArg) - Method in class com.facebook.buck.core.rules.platform.PlatformDescription
-
- getConfigurationRuleRegistry() - Method in class com.facebook.buck.android.ConstraintBasedAndroidNativeTargetConfigurationMatcher
-
- getConfigurationRuleRegistry() - Method in interface com.facebook.buck.core.rules.BuildRuleCreationContext
-
- getConfigurationRuleRegistry() - Method in interface com.facebook.buck.core.rules.BuildRuleCreationContextWithTargetGraph
-
- getConfigurationRuleResolver() - Method in interface com.facebook.buck.core.rules.config.registry.ConfigurationRuleRegistry
-
Provides generic access to configuration rules.
- getConfigurationTarget() - Method in class com.facebook.buck.core.model.ConfigurationForConfigurationTargets
-
- getConfigurationTarget() - Method in class com.facebook.buck.core.model.ErrorTargetConfiguration
-
- getConfigurationTarget() - Method in class com.facebook.buck.core.model.RuleBasedTargetConfiguration
-
- getConfigurationTarget() - Method in class com.facebook.buck.core.model.TargetConfiguration
-
- getConfigurationTarget() - Method in class com.facebook.buck.core.model.UnconfiguredTargetConfiguration
-
- getConfiguredBuckOut() - Method in class com.facebook.buck.io.filesystem.BuckPaths
-
The relative path to the directory where Buck will generate its files.
- getConfiguredVersion(String) - Method in class com.facebook.buck.features.python.PythonBuckConfig
-
- getConflictingHeaderBasenameWhitelist() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getConflictingHeaderBasenameWhitelist() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getConnectedDevices() - Method in class com.facebook.buck.apple.device.AppleDeviceHelper
-
Runs the helper program to enumerate all currently-connected devices.
- getConnectTimeoutSeconds() - Method in class com.facebook.buck.artifact_cache.config.HttpCacheEntry
-
- getConsole() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getConsole() - Method in class com.facebook.buck.cli.ProjectGeneratorParameters
-
- getConsole() - Method in class com.facebook.buck.command.BuildExecutorArgs
-
- getConsole() - Method in class com.facebook.buck.core.build.execution.context.ExecutionContext
-
- getConsoleHandlerState() - Method in class com.facebook.buck.log.GlobalStateManager
-
- getConsoleLogBuildRuleFailuresInline() - Method in class com.facebook.buck.core.build.engine.config.CachingBuildEngineBuckConfig
-
- getConstraintResolver() - Method in interface com.facebook.buck.core.rules.config.registry.ConfigurationRuleRegistry
-
Allows to get access to configuration rules that represent constraint_setting
and
constraint_value
rules.
- getConstraintSetting(BuildTarget, DependencyStack) - Method in interface com.facebook.buck.core.model.platform.ConstraintResolver
-
- getConstraintSetting() - Method in class com.facebook.buck.core.model.platform.ConstraintValue
-
- getConstraintSetting() - Method in class com.facebook.buck.core.rules.platform.ConstraintSettingRule
-
- getConstraintSetting() - Method in class com.facebook.buck.core.rules.platform.ConstraintValueArg
-
- getConstraintSetting(BuildTarget, DependencyStack) - Method in class com.facebook.buck.core.rules.platform.RuleBasedConstraintResolver
-
- getConstraintSetting(BuildTarget, DependencyStack) - Method in class com.facebook.buck.core.rules.platform.ThrowingConstraintResolver
-
Unconditionally throw
- getConstraintValue(BuildTarget, DependencyStack) - Method in interface com.facebook.buck.core.model.platform.ConstraintResolver
-
- getConstraintValue() - Method in class com.facebook.buck.core.rules.platform.ConstraintValueRule
-
- getConstraintValue(BuildTarget, DependencyStack) - Method in class com.facebook.buck.core.rules.platform.RuleBasedConstraintResolver
-
- getConstraintValue(BuildTarget, DependencyStack) - Method in class com.facebook.buck.core.rules.platform.ThrowingConstraintResolver
-
Unconditionally throw
- getConstraintValues() - Method in class com.facebook.buck.core.model.platform.impl.ConstraintBasedPlatform
-
- getConstraintValues() - Method in class com.facebook.buck.core.rules.configsetting.ConfigSettingArg
-
- getConstraintValues() - Method in class com.facebook.buck.core.rules.platform.PlatformArg
-
- getConstructorArg() - Method in class com.facebook.buck.core.model.targetgraph.impl.TargetNodeImpl
-
- getConstructorArg() - Method in interface com.facebook.buck.core.model.targetgraph.TargetNode
-
- getConstructorArgDescriptor(Class<T>) - Method in class com.facebook.buck.rules.coercer.DefaultTypeCoercerFactory
-
- getConstructorArgDescriptor(Class<T>) - Method in interface com.facebook.buck.rules.coercer.TypeCoercerFactory
-
Returns an unpopulated DTO object, and the build method which must be called with it when it is
finished being populated.
- getConstructorArgType() - Method in class com.facebook.buck.android.AndroidAarDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.android.AndroidAppModularityDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.android.AndroidBinaryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.android.AndroidBuildConfigDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.android.AndroidBundleDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.android.AndroidInstrumentationApkDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.android.AndroidInstrumentationTestDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.android.AndroidLibraryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.android.AndroidManifestDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.android.AndroidPrebuiltAarDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.android.AndroidResourceDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.android.ApkGenruleDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.android.GenAidlDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.android.NdkLibraryDescription
-
Deprecated.
- getConstructorArgType() - Method in class com.facebook.buck.android.NdkToolchainDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.android.PrebuiltNativeLibraryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.android.RobolectricTestDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.android.toolchain.platform.AndroidPlatformDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.apple.AppleAssetCatalogDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.apple.AppleBinaryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.apple.AppleBundleDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.apple.AppleLibraryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.apple.ApplePackageDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.apple.AppleResourceDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.apple.AppleTestDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.apple.AppleToolchainDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.apple.AppleToolchainSetDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.apple.CoreDataModelDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.apple.PrebuiltAppleFrameworkDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.apple.SceneKitAssetsDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.apple.XcodePostbuildScriptDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.apple.XcodePrebuildScriptDescription
-
- getConstructorArgType() - Method in interface com.facebook.buck.core.description.BaseDescription
-
The type of the constructor argument that is used by this description to create a rule
- getConstructorArgType() - Method in class com.facebook.buck.core.rules.configsetting.ConfigSettingDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.core.rules.knowntypes.RuleDescriptor
-
- getConstructorArgType() - Method in class com.facebook.buck.core.rules.platform.ConstraintSettingDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.core.rules.platform.ConstraintValueDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.core.rules.platform.PlatformDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.core.starlark.rule.SkylarkDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.core.test.rule.impl.ExternalTestRunnerDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.core.toolchain.rule.LegacyToolchainRuleDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.cxx.CxxBinaryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.cxx.CxxGenruleDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.cxx.CxxLibraryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.cxx.CxxPrecompiledHeaderDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.cxx.CxxTestDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.cxx.CxxToolchainDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.d.DBinaryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.d.DLibraryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.d.DTestDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.dotnet.CsharpLibraryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.dotnet.PrebuiltDotnetLibraryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.dotnet.PrebuiltDotnetLibraryRuleDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.filegroup.FilegroupDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.go.CgoLibraryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.go.GoBinaryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.go.GoLibraryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.go.GoTestDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.go.GoTestRunnerDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.go.PrebuiltGoLibraryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.gwt.GwtBinaryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.halide.HalideLibraryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.haskell.HaskellBinaryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.haskell.HaskellGhciDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.haskell.HaskellHaddockDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.haskell.HaskellLibraryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.haskell.HaskellPrebuiltLibraryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.js.JsBundleDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.js.JsBundleGenruleDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.js.JsLibraryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.lua.LuaBinaryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.lua.LuaLibraryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.ocaml.OcamlBinaryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.ocaml.OcamlLibraryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.ocaml.PrebuiltOcamlLibraryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.python.PrebuiltPythonLibraryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.python.PythonBinaryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.python.PythonLibraryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.python.PythonTestDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.python.PythonTestRunnerDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.rust.PrebuiltRustLibraryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.rust.RustBinaryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.rust.RustLibraryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.rust.RustTestDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.features.zip.rules.ZipFileDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.file.HttpArchiveDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.file.HttpFileDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.file.RemoteFileDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.jvm.java.JarGenruleDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.jvm.java.JavaAnnotationProcessorDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.jvm.java.JavaBinaryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.jvm.java.JavaPluginDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.jvm.java.JavaTestDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.jvm.java.KeystoreDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.jvm.java.PrebuiltJarDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.shell.CommandAliasDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.shell.ExportFileDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.shell.GenruleDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.shell.ShBinaryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.shell.ShTestDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.shell.TestSuiteDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.shell.WorkerToolDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.swift.SwiftLibraryDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.swift.SwiftToolchainDescription
-
- getConstructorArgType() - Method in class com.facebook.buck.versions.VersionedAliasDescription
-
- getContacts() - Method in class com.facebook.buck.android.AndroidInstrumentationTest
-
- getContacts() - Method in class com.facebook.buck.android.AndroidInstrumentationTestDescriptionArg
-
- getContacts() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getContacts() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getContacts() - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg
-
- getContacts() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getContacts() - Method in class com.facebook.buck.apple.AppleTest
-
- getContacts() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getContacts() - Method in class com.facebook.buck.apple.AppleTestX
-
- getContacts() - Method in interface com.facebook.buck.core.description.arg.HasContacts
-
- getContacts() - Method in class com.facebook.buck.core.rules.tool.RuleAnalysisLegacyTestBuildRuleView
-
- getContacts() - Method in class com.facebook.buck.core.starlark.rule.SkylarkDescriptionArg
-
- getContacts() - Method in class com.facebook.buck.core.test.rule.ExternalTestRunnerTestSpec
-
- getContacts() - Method in interface com.facebook.buck.core.test.rule.TestRule
-
- getContacts() - Method in class com.facebook.buck.cxx.CxxTest
-
- getContacts() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getContacts() - Method in class com.facebook.buck.features.d.DTest
-
- getContacts() - Method in class com.facebook.buck.features.d.DTestDescriptionArg
-
- getContacts() - Method in class com.facebook.buck.features.go.GoTest
-
- getContacts() - Method in class com.facebook.buck.features.go.GoTestDescriptionArg
-
- getContacts() - Method in class com.facebook.buck.features.go.GoTestX
-
- getContacts() - Method in class com.facebook.buck.features.python.PythonTest
-
- getContacts() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getContacts() - Method in class com.facebook.buck.features.python.PythonTestX
-
- getContacts() - Method in class com.facebook.buck.features.rust.RustTest
-
- getContacts() - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg
-
- getContacts() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getContacts() - Method in class com.facebook.buck.jvm.java.JavaTest
-
- getContacts() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getContacts() - Method in class com.facebook.buck.jvm.java.JavaTestX
-
- getContacts() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getContacts() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getContacts() - Method in class com.facebook.buck.shell.ShTest
-
- getContacts() - Method in class com.facebook.buck.shell.ShTestDescriptionArg
-
- getContacts() - Method in class com.facebook.buck.test.TestResults
-
- getContainer() - Method in interface com.facebook.buck.jvm.java.classes.FileLike
-
Returns the containing file for this file-like entry.
- getContainerClass(Field) - Static method in class com.facebook.buck.util.Types
-
- getContainerCommandPrefix() - Method in class com.facebook.buck.cli.AbstractContainerCommand
-
- getContainerCommandPrefix() - Method in class com.facebook.buck.cli.AuditCommand
-
- getContainerCommandPrefix() - Method in class com.facebook.buck.cli.AuditMbrCommand
-
- getContainerCommandPrefix() - Method in class com.facebook.buck.cli.BuckCommand
-
- getContainerCommandPrefix() - Method in class com.facebook.buck.cli.PerfCasCommand
-
- getContainerCommandPrefix() - Method in class com.facebook.buck.cli.PerfCommand
-
- getContainerCommandPrefix() - Method in class com.facebook.buck.cli.PerfMbrCommand
-
- getContainerCommandPrefix() - Method in class com.facebook.buck.cli.ServerCommand
-
- getContainerPortal() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXContainerItemProxy
-
- getContainerRelativePath() - Method in class com.facebook.buck.apple.xcode.XCScheme.BuildableReference
-
- getContent() - Method in class com.facebook.buck.event.ExperimentEvent
-
- getContent(SourcePathResolverAdapter) - Method in class com.facebook.buck.rules.args.WriteToFileArg
-
Get the expanded content to write to the file.
- getContentAddressedStorage() - Method in class com.facebook.buck.remoteexecution.grpc.GrpcRemoteExecutionClients
-
- getContentAddressedStorage() - Method in interface com.facebook.buck.remoteexecution.RemoteExecutionClients
-
- getContentAddressedStorage() - Method in class com.facebook.buck.remoteexecution.util.OutOfProcessIsolatedExecutionClients
-
- getContentHashes() - Method in interface com.facebook.buck.util.cache.JarContentHasher
-
- getContentLength() - Method in class com.facebook.buck.artifact_cache.HttpArtifactCacheBinaryProtocol.FetchResponse
-
- getContentLength() - Method in class com.facebook.buck.artifact_cache.HttpArtifactCacheBinaryProtocol.StoreRequest
-
- getContentRoots(IjModule) - Method in class com.facebook.buck.features.project.intellij.IjProjectTemplateDataPreparer
-
- getContents() - Method in class com.facebook.buck.util.cache.JarHashCodeAndFileType
-
Return hash values for all files in an archive (like a JAR)
- getContentsAsString(Charset) - Method in class com.facebook.buck.util.CapturingPrintStream
-
- getContext() - Method in exception com.facebook.buck.core.build.engine.impl.BuildRuleFailedException
-
- getContext() - Method in exception com.facebook.buck.core.exceptions.BuckUncheckedExecutionException
-
- getContext() - Method in interface com.facebook.buck.core.exceptions.ExceptionWithContext
-
- getContext() - Method in exception com.facebook.buck.step.StepFailedException
-
- getContext() - Method in class com.facebook.buck.util.ContextualProcessExecutor
-
- getContext() - Method in class com.facebook.buck.util.perf.ProcessTracker.ProcessResourceConsumptionEvent
-
- getCopySceneKitAssets() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
copySceneKitAssets binary.
- getCopySceneKitAssets() - Method in class com.facebook.buck.apple.toolchain.AppleCxxPlatform
-
- getCopyStdlibToFrameworks() - Method in class com.facebook.buck.swift.SwiftBuckConfig
-
If enabled, swift-stdlib-tool will be run on .framework bundles, copying the Swift standard
library into them.
- getCopyStep() - Method in class com.facebook.buck.android.FilterResourcesSteps
-
- getCoreKey() - Method in class com.facebook.buck.rules.keys.config.RuleKeyConfiguration
-
- getCoreSimulatorServicePath(UserIdFetcher) - Method in class com.facebook.buck.apple.simulator.AppleCoreSimulatorServiceController
-
Returns the path on disk to the running Core Simulator service, if any.
- getCount() - Method in class com.facebook.buck.counters.SamplingCounter
-
- getCount() - Method in class com.facebook.buck.log.LogConfigSetup
-
- getCount() - Method in class com.facebook.buck.rules.keys.hasher.CountingRuleKeyHasher
-
- getCounters() - Method in class com.facebook.buck.counters.CounterRegistry.AsyncCounterRegistrationEvent
-
- getCounters() - Method in class com.facebook.buck.parser.DaemonicParserState
-
- getCountersFirstFlushIntervalMillis() - Method in class com.facebook.buck.counters.CounterBuckConfig
-
- getCountersFlushIntervalMillis() - Method in class com.facebook.buck.counters.CounterBuckConfig
-
- getCoverageExcludes() - Method in class com.facebook.buck.test.config.TestBuckConfig
-
- getCoverageExcludes() - Method in class com.facebook.buck.test.TestRunningOptions
-
- getCoverageIncludes() - Method in class com.facebook.buck.test.config.TestBuckConfig
-
- getCoverageIncludes() - Method in class com.facebook.buck.test.TestRunningOptions
-
- getCoverageMode() - Method in class com.facebook.buck.features.go.GoTestDescriptionArg
-
- getCoverageReportFormats() - Method in class com.facebook.buck.test.TestRunningOptions
-
- getCoverageReportTitle() - Method in class com.facebook.buck.test.TestRunningOptions
-
- getCoveredByDepFilePredicate(SourcePathResolverAdapter) - Method in interface com.facebook.buck.core.rules.attr.SupportsDependencyFileRuleKey
-
Returns a predicate that can tell whether a given path is covered by dep-file or not.
- getCoveredByDepFilePredicate(SourcePathResolverAdapter) - Method in class com.facebook.buck.cxx.CxxPreprocessAndCompile
-
- getCoveredByDepFilePredicate(SourcePathResolverAdapter) - Method in class com.facebook.buck.jvm.java.CalculateSourceAbi
-
- getCoveredByDepFilePredicate(SourcePathResolverAdapter) - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getCoveredByDepFilePredicate(SourcePathRuleFinder) - Method in class com.facebook.buck.jvm.java.JarBuildStepsFactory
-
Returns a predicate indicating whether a SourcePath is covered by the depfile.
- getCoveredSources() - Method in class com.facebook.buck.features.go.GoTestCoverSource
-
- getCpp() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getCpp() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getCppflags() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getCppflags() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getCpu() - Method in class com.facebook.buck.util.concurrent.ResourceAmounts
-
- getCpuFilters() - Method in class com.facebook.buck.android.AndroidBinary
-
- getCpuFilters() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getCpuFilters() - Method in class com.facebook.buck.android.AndroidBundle
-
- getCpuFilters() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getCpuFilters() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getCpuReal() - Method in class com.facebook.buck.util.ProcessResourceConsumption
-
- getCpuSys() - Method in class com.facebook.buck.util.ProcessResourceConsumption
-
- getCpuTotal() - Method in class com.facebook.buck.util.ProcessResourceConsumption
-
- getCpuUser() - Method in class com.facebook.buck.util.ProcessResourceConsumption
-
- getCrashed() - Method in interface com.facebook.buck.apple.AbstractIdbTestResult
-
Boolean that shows if the test crashed or not
- getCrate() - Method in class com.facebook.buck.features.rust.PrebuiltRustLibraryDescriptionArg
-
- getCrate() - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg
-
- getCrate() - Method in interface com.facebook.buck.features.rust.RustCommonArgs
-
- getCrate() - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg
-
- getCrate() - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg
-
- getCrateRoot() - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg
-
- getCrateRoot() - Method in interface com.facebook.buck.features.rust.RustCommonArgs
-
- getCrateRoot(SourcePathResolverAdapter, String, ImmutableSet<String>, Stream<Path>) - Static method in class com.facebook.buck.features.rust.RustCompileUtils
-
Given a list of sources, return the one which is the root based on the defaults and user
parameters.
- getCrateRoot() - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg
-
- getCrateRoot() - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg
-
- getCrateType() - Method in enum com.facebook.buck.features.rust.RustBinaryDescription.Type
-
- getCreationMillis() - Method in class com.facebook.buck.util.DirectoryCleaner.PathStats
-
- getCriticalPathReportNodes() - Method in class com.facebook.buck.event.listener.CriticalPathEventListener
-
Return all the critical path nodes for reports
- getCsharpCompiler() - Method in class com.facebook.buck.features.dotnet.DotnetBuckConfig
-
- getCuda() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getCuda() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getCudaflags() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getCudaflags() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getCudapp() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getCudapp() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getCudappflags() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getCudappflags() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getCurrentCellName() - Method in interface com.facebook.buck.core.cell.CellPathResolver
-
Cell name resolver works in context of some cell.
- getCurrentCellName() - Method in interface com.facebook.buck.core.cell.nameresolver.CellNameResolver
-
Cell name resolver works in context of some cell.
- getCurrentMemoryBytesUsageByPool() - Method in class com.facebook.buck.util.perf.PerfStatsTracking.MemoryPerfStatsEvent
-
- getCurrentRevisionId() - Method in interface com.facebook.buck.doctor.config.SourceControlInfo
-
- getCurrentRevisionId() - Method in interface com.facebook.buck.util.versioncontrol.CommonFastVersionControlStats
-
- getCurrentVersion() - Method in class com.facebook.buck.apple.xcode.xcodeproj.XCVersionGroup
-
- getCurrentVersionFile() - Method in class com.facebook.buck.io.filesystem.BuckPaths
-
The version the buck output directory was created for
- getCurrentVersionPath() - Method in class com.facebook.buck.features.apple.projectV2.CoreDataResource.VersionInformation
-
- getCustomBehavior() - Method in class com.facebook.buck.rules.modern.FieldInfo
-
- getCustomLinkingDeps(BuildRuleArg) - Method in interface com.facebook.buck.apple.AppleCustomLinkingDepsDescription
-
- getCustomLinkingDeps(BuildRuleArg) - Method in class com.facebook.buck.features.halide.HalideLibraryDescription
-
- getCwd() - Method in class com.facebook.buck.core.test.rule.ExternalTestRunnerTestSpec
-
- getCwd() - Method in class com.facebook.buck.support.fix.BuckRunSpec
-
The PWD where the command should be run from
- getCxx() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getCxx() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getCxxBuckConfig() - Method in class com.facebook.buck.cxx.CxxSourceRuleFactory
-
- getCxxCompiler() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
C++ compiler binary.
- getCxxCompilerFlags() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
C++ compiler flags.
- getCxxDeps() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
Override parent class's deps to include exported deps.
- getCxxDeps() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
Override parent class's deps to include exported deps.
- getCxxDeps() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
Override parent class's deps to include exported deps.
- getCxxDeps() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getCxxDeps() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
- getCxxDeps() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
Override parent class's deps to include exported deps.
- getCxxDeps() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
Override parent class's deps to include exported deps.
- getCxxDeps() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getCxxDeps() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getCxxDeps() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getCxxDeps() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getCxxDeps() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getCxxDeps() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getCxxflags() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getCxxflags() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getCxxFlavors(BuckConfig) - Static method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
Constructs set of flavors given in a .buckconfig file, as is specified by section names of the
form cxx#{flavor name}.
- getCxxHeaderDirs() - Method in class com.facebook.buck.features.haskell.HaskellPrebuiltLibraryDescriptionArg
-
- getCxxIncludePaths() - Method in class com.facebook.buck.cxx.PreprocessorFlags
-
- getCxxLibrary(String, TargetConfiguration) - Method in class com.facebook.buck.features.python.PythonBuckConfig
-
- getCxxLibrary() - Method in class com.facebook.buck.features.python.toolchain.impl.LazyPythonPlatform
-
- getCxxLibrary() - Method in interface com.facebook.buck.features.python.toolchain.PythonPlatform
-
- getCxxLibraryWhitelist() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getCxxLibraryWhitelist() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getCxxLibraryWhitelist() - Method in interface com.facebook.buck.jvm.java.JavaTestDescription.CoreArg
-
- getCxxLibraryWhitelist() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getCxxLibraryWhitelist() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getCxxLibraryWhitelist() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getCxxLink() - Method in class com.facebook.buck.cxx.CxxLinkAndCompileRules
-
- getCxxPlatform() - Method in class com.facebook.buck.android.toolchain.ndk.impl.ProviderBackedUnresolvedNdkCxxPlatform
-
- getCxxPlatform() - Method in class com.facebook.buck.android.toolchain.ndk.impl.StaticUnresolvedNdkCxxPlatform
-
- getCxxPlatform() - Method in interface com.facebook.buck.android.toolchain.ndk.NdkCxxPlatform
-
- getCxxPlatform() - Method in interface com.facebook.buck.android.toolchain.ndk.UnresolvedNdkCxxPlatform
-
- getCxxPlatform() - Method in class com.facebook.buck.apple.toolchain.AppleCxxPlatform
-
- getCxxPlatform() - Method in class com.facebook.buck.cxx.CxxBinary
-
- getCxxPlatform() - Method in class com.facebook.buck.cxx.CxxSourceRuleFactory
-
- getCxxPlatform(CxxPlatformsProvider, BuildTarget, Optional<Flavor>) - Static method in class com.facebook.buck.cxx.toolchain.impl.CxxPlatforms
-
Returns the configured cxx platform for a particular target.
- getCxxPlatform() - Method in class com.facebook.buck.cxx.toolchain.impl.StaticUnresolvedCxxPlatform
-
- getCxxPlatform() - Method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableCacheKey
-
- getCxxPlatform() - Method in class com.facebook.buck.features.lua.LuaPlatform
-
- getCxxPlatform() - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg
-
- getCxxPlatform() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getCxxpp() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getCxxpp() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getCxxppflags() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getCxxppflags() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getCxxPreprocessorDeps(CxxPlatform, BuildRuleResolver) - Method in class com.facebook.buck.apple.PrebuiltAppleFramework
-
- getCxxPreprocessorDeps(CxxPlatform, BuildRuleResolver) - Method in class com.facebook.buck.cxx.CxxLibraryGroup
-
- getCxxPreprocessorDeps(CxxPlatform, BuildRuleResolver) - Method in interface com.facebook.buck.cxx.CxxPreprocessorDep
-
- getCxxPreprocessorDeps(CxxPlatform, BuildRuleResolver) - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescription.CustomPrebuiltCxxLibrary
-
- getCxxPreprocessorDeps(CxxPlatform, BuildRuleResolver) - Method in class com.facebook.buck.cxx.PreInclude
-
- getCxxPreprocessorDeps(CxxPlatform, BuildRuleResolver) - Method in class com.facebook.buck.features.halide.HalideLibrary
-
- getCxxPreprocessorDeps(CxxPlatform, BuildRuleResolver) - Method in class com.facebook.buck.features.lua.SystemLuaCxxLibrary
-
- getCxxPreprocessorInput(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.apple.PrebuiltAppleFramework
-
- getCxxPreprocessorInput(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.cxx.CxxLibraryGroup
-
- getCxxPreprocessorInput(BuildTarget, ActionGraphBuilder, boolean, CxxPlatform, HeaderVisibility, CxxPreprocessables.IncludeType, Multimap<CxxSource.Type, String>, Iterable<FrameworkPath>) - Static method in class com.facebook.buck.cxx.CxxPreprocessables
-
- getCxxPreprocessorInput(CxxPlatform, ActionGraphBuilder) - Method in interface com.facebook.buck.cxx.CxxPreprocessorDep
-
Returns the preprocessor input that represents this rule's public (exported) declarations.
- getCxxPreprocessorInput() - Method in class com.facebook.buck.cxx.CxxSourceRuleFactory
-
- getCxxPreprocessorInput(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescription.CustomPrebuiltCxxLibrary
-
- getCxxPreprocessorInput(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.cxx.PreInclude
-
- getCxxPreprocessorInput(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.features.halide.HalideLibrary
-
- getCxxPreprocessorInput(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.features.lua.SystemLuaCxxLibrary
-
- getCxxRuntime() - Method in class com.facebook.buck.android.NdkToolchainDescriptionArg
-
Ndk runtime type.
- getCxxRuntime() - Method in interface com.facebook.buck.android.toolchain.ndk.NdkCxxPlatform
-
- getCxxRuntimeType() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getCxxRuntimeType() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getCxxRuntimeType() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getCxxRuntimeType() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getCxxRuntimeType() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
- getCxxRuntimeType() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getCxxRuntimeType() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getCxxRuntimeType() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getCxxRuntimeType() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getCxxRuntimeType() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getCxxRuntimeType() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getCxxSharedRuntimePath() - Method in interface com.facebook.buck.android.toolchain.ndk.NdkCxxPlatform
-
- getCxxToolchain() - Method in class com.facebook.buck.android.NdkToolchainDescriptionArg
-
Target for the cxx toolchain part of the ndk toolchain.
- getCxxToolchain() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
Target for the cxx toolchain which should be used for this SDK.
- getCycle() - Method in exception com.facebook.buck.core.util.graph.CycleException
-
- getDaemonicParserState() - Method in class com.facebook.buck.support.state.BuckGlobalState
-
- getDaemonUptime() - Method in class com.facebook.buck.event.CommandEvent
-
- getData() - Method in class com.facebook.buck.core.test.rule.CoercedTestRunnerSpec
-
- getData() - Method in class com.facebook.buck.core.test.rule.TestRunnerSpec
-
- getData() - Method in class com.facebook.buck.features.project.intellij.IjDependencyListBuilder.DependencyEntry
-
- getData(Protocol.Digest) - Method in class com.facebook.buck.remoteexecution.util.LocalContentAddressedStorage
-
Looks up some data.
- getData(MerkleTreeNodeCache.MerkleTreeNode) - Method in class com.facebook.buck.remoteexecution.util.MerkleTreeNodeCache
-
Gets the
Protocol
encoded data for the provided tree.
- getData() - Method in interface com.facebook.buck.rules.modern.Deserializer.DataProvider
-
- getData() - Method in class com.facebook.buck.slb.LoadBalancedServiceEvent
-
- getData() - Method in class com.facebook.buck.slb.LoadBalancerPingEvent
-
- getData() - Method in class com.facebook.buck.slb.ServerHealthManagerEvent
-
- getDataForRequest(Request) - Method in interface com.facebook.buck.httpserver.TemplateHandlerDelegate
-
- getDataForRequest(Request) - Method in class com.facebook.buck.httpserver.TraceHandlerDelegate
-
- getDataForRequest(Request) - Method in class com.facebook.buck.httpserver.TracesHandlerDelegate
-
- getDataPointsCount() - Method in class com.facebook.buck.event.FileHashCacheEvent
-
- getDb() - Method in class com.facebook.buck.features.haskell.HaskellPrebuiltLibraryDescriptionArg
-
- getDebugMode() - Method in class com.facebook.buck.rules.coercer.ManifestEntries
-
- getDebugPathSanitizerLimit() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getDebugURLString(RESessionID) - Method in class com.facebook.buck.remoteexecution.config.RemoteExecutionConfig
-
- getDecimalStringAsLong(ByteBuffer, int) - Static method in class com.facebook.buck.cxx.toolchain.objectfile.ObjectFileScrubbers
-
- getDeclaredClass() - Method in class com.facebook.buck.core.rules.providers.impl.BuiltInProviderInfo
-
- getDeclaredClass() - Method in class com.facebook.buck.core.starlark.compatible.BuckStarlarkStructObject
-
- getDeclaredDeps() - Method in class com.facebook.buck.android.AndroidBinary
-
- getDeclaredDeps() - Method in class com.facebook.buck.android.AndroidBundle
-
- getDeclaredDeps() - Method in class com.facebook.buck.apple.AppleDebuggableBinary
-
- getDeclaredDeps() - Method in class com.facebook.buck.core.model.targetgraph.impl.TargetNodeImpl
-
- getDeclaredDeps() - Method in interface com.facebook.buck.core.model.targetgraph.TargetNode
-
- getDeclaredDeps() - Method in interface com.facebook.buck.core.rules.attr.HasDeclaredAndExtraDeps
-
- getDeclaredDeps() - Method in class com.facebook.buck.core.rules.BuildRuleParams
-
- getDeclaredDeps() - Method in class com.facebook.buck.core.rules.impl.AbstractBuildRuleWithDeclaredAndExtraDeps
-
- getDeclaredMethods(TypeElement, CharSequence) - Method in interface com.facebook.buck.jvm.java.lang.model.ElementsExtended
-
- getDeclaredMethods(TypeElement, CharSequence) - Method in class com.facebook.buck.jvm.java.plugin.adapter.ElementsExtendedImpl
-
- getDeclaredPlatforms() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getDefault(ToolchainProvider) - Static method in class com.facebook.buck.jvm.java.JavacFactory
-
Creates a JavacFactory for the default Java toolchain.
- getDefaultBuildConfigFields() - Static method in class com.facebook.buck.android.BuildConfigs
-
Returns a list of fields (with values) that every BuildConfig.java
should declare.
- getDefaultBuildFileSyntax() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getDefaultClangVersionForNdk(String) - Static method in class com.facebook.buck.android.toolchain.ndk.impl.NdkCxxPlatforms
-
- getDefaultCompilerTypeForNdk(String) - Static method in class com.facebook.buck.android.toolchain.ndk.impl.NdkCxxPlatforms
-
- getDefaultConditionValue() - Method in class com.facebook.buck.core.select.Selector
-
Returns the default value - value to use when none of the conditions match.
- getDefaultConfigurationFiles(Path) - Static method in class com.facebook.buck.util.config.Configs
-
Gets all configuration files that should be used for parsing the project configuration
- getDefaultConfigurationFiles(AbsPath) - Static method in class com.facebook.buck.util.config.Configs
-
- getDefaultCxxPlatform() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getDefaultCxxPlatform() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getDefaultCxxPlatform() - Method in class com.facebook.buck.jvm.java.JavaBinaryDescriptionArg
-
- getDefaultCxxPlatform() - Method in class com.facebook.buck.jvm.java.JavaBuckConfig
-
- getDefaultCxxPlatform() - Method in interface com.facebook.buck.jvm.java.JavaTestDescription.CoreArg
-
- getDefaultCxxPlatform() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getDefaultCxxPlatform() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getDefaultCxxPlatform() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getDefaultCxxRuntimeForNdk(String) - Static method in class com.facebook.buck.android.toolchain.ndk.impl.NdkCxxPlatforms
-
- getDefaultDebugInfoFormatForBinaries() - Method in class com.facebook.buck.apple.AppleConfig
-
- getDefaultDebugInfoFormatForLibraries() - Method in class com.facebook.buck.apple.AppleConfig
-
- getDefaultDebugInfoFormatForTests() - Method in class com.facebook.buck.apple.AppleConfig
-
- getDefaultFlavors() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getDefaultFlavors() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getDefaultFlavors() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getDefaultFlavors() - Method in interface com.facebook.buck.core.model.HasDefaultFlavors
-
- getDefaultFlavors() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getDefaultFlavors() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
- getDefaultFlavors() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getDefaultFlavors() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getDefaultFlavors() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getDefaultFlavors() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getDefaultFlavors() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getDefaultFlavors() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getDefaultFlavorsForRuleType(RuleType) - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getDefaultFlavorsMode() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getDefaultGccVersionForNdk(String) - Static method in class com.facebook.buck.android.toolchain.ndk.impl.NdkCxxPlatforms
-
- getDefaultHaskellPlatform() - Method in interface com.facebook.buck.features.haskell.HaskellPlatformsProvider
-
- getDefaultIncludes() - Method in class com.facebook.buck.parser.config.ParserConfig
-
A (possibly empty) sequence of paths to files that should be included by default when
evaluating a build file.
- getDefaultIncludes() - Method in class com.facebook.buck.parser.options.ProjectBuildFileParserOptions
-
- getDefaultInfo() - Method in class com.facebook.buck.core.rules.providers.collect.impl.LegacyProviderInfoCollectionImpl
-
- getDefaultInfo() - Method in class com.facebook.buck.core.rules.providers.collect.impl.ProviderInfoCollectionImpl
-
- getDefaultInfo() - Method in interface com.facebook.buck.core.rules.providers.collect.ProviderInfoCollection
-
- getDefaultInitPy() - Method in class com.facebook.buck.features.python.PythonPackageComponents
-
- getDefaultJavacOptions(TargetConfiguration) - Method in class com.facebook.buck.jvm.java.JavaBuckConfig
-
- getDefaultJavaCxxPlatform() - Method in interface com.facebook.buck.jvm.java.toolchain.JavaCxxPlatformProvider
-
- getDefaultJavaOptions() - Method in class com.facebook.buck.jvm.java.JavaBuckConfig
-
- getDefaultJavaOptions(ToolchainProvider) - Static method in class com.facebook.buck.jvm.java.toolchain.JavaOptionsProvider
-
- getDefaultJavaOptionsForTests() - Method in class com.facebook.buck.jvm.java.JavaBuckConfig
-
- getDefaultJavaOptionsForTests(ToolchainProvider) - Static method in class com.facebook.buck.jvm.java.toolchain.JavaOptionsProvider
-
- getDefaultLuaPlatform() - Method in interface com.facebook.buck.features.lua.LuaPlatformsProvider
-
- getDefaultMaximumNumberOfThreads() - Method in class com.facebook.buck.command.config.BuildBuckConfig
-
- getDefaultMetaVariable() - Method in class com.facebook.buck.cli.ConsumeAllOptionsHandler
-
- getDefaultMetaVariable() - Method in class com.facebook.buck.cli.PairedStringOptionHandler
-
- getDefaultMetaVariable() - Method in class com.facebook.buck.cli.QueryMultiSetOptionHandler
-
Returns "STRING[]"
.
- getDefaultMetaVariable() - Method in class com.facebook.buck.cli.SingleStringSetOptionHandler
-
- getDefaultMetaVariable() - Method in class com.facebook.buck.cli.StringSetOptionHandler
-
- getDefaultMetaVariable() - Method in class com.facebook.buck.cli.TestCommand.CoverageReportFormatsHandler
-
- getDefaultMetaVariable() - Method in class com.facebook.buck.cli.TestSelectorOptions.TestSelectorsOptionHandler
-
- getDefaultMetaVariable() - Method in class com.facebook.buck.features.project.intellij.IjProjectSubCommand.AggregationModeOptionHandler
-
- getDefaultPathPredicate(ProjectFilesystem) - Static method in class com.facebook.buck.util.cache.impl.DefaultFileHashCache
-
This predicate matches files that might be result of builds or files that are explicitly
ignored.
- getDefaultPlatform() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getDefaultPlatform() - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg
-
- getDefaultPlatform() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getDefaultPlatform() - Method in class com.facebook.buck.apple.ApplePackageDescriptionArg
-
- getDefaultPlatform() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getDefaultPlatform() - Method in interface com.facebook.buck.core.description.arg.HasDefaultPlatform
-
- getDefaultPlatform() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getDefaultPlatform() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getDefaultPlatform() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getDefaultPlatform() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getDefaultPlatform() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getDefaultPlatform() - Method in class com.facebook.buck.features.go.GoToolchain
-
- getDefaultPlatform() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getDefaultPlatform() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getDefaultPlatform() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getDefaultPlatform() - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg
-
- getDefaultPlatform() - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg
-
- getDefaultPlatform() - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg
-
- getDefaultPlatform() - Method in interface com.facebook.buck.infer.toolchain.InferToolchain
-
- getDefaultPlatformTarget(ProjectFilesystem, AndroidBuildToolsLocation, AndroidSdkLocation, Optional<Supplier<Tool>>, Optional<ToolProvider>, AdbToolchain) - Static method in class com.facebook.buck.android.toolchain.impl.AndroidPlatformTargetProducer
-
- getDefaultPythonPlatform(ToolchainProvider, PythonBuckConfig, ProcessExecutor, TargetConfiguration) - Method in class com.facebook.buck.features.python.toolchain.impl.PythonPlatformsProviderFactory
-
- getDefaultPythonPlatformFlavor() - Method in class com.facebook.buck.features.python.PythonBuckConfig
-
- getDefaultPythonPlatformSection() - Method in class com.facebook.buck.features.python.PythonBuckConfig
-
- getDefaultRawExcludedLabelSelectors() - Method in class com.facebook.buck.test.config.TestBuckConfig
-
- getDefaultReexportAllHeaderDependencies() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getDefaultResourceAmounts() - Method in class com.facebook.buck.core.build.engine.config.ResourceAwareSchedulingInfo
-
- getDefaultResourceAmounts() - Method in class com.facebook.buck.core.resources.ResourcesConfig
-
- getDefaultRuleKeyFactory() - Method in class com.facebook.buck.rules.keys.RuleKeyFactories
-
- getDefaultRuleKeyFactoryCacheRecycler() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getDefaultRuleKeyFactoryCacheRecycler() - Method in interface com.facebook.buck.cli.MainRunner.ParserAndCaches
-
- getDefaultRuleKeyFactoryCacheRecycler() - Method in class com.facebook.buck.support.state.BuckGlobalState
-
- getDefaultRustPlatform() - Method in interface com.facebook.buck.features.rust.RustToolchain
-
- getDefaults() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getDefaults() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getDefaults() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getDefaults() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getDefaults() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
- getDefaults() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getDefaults() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getDefaults() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getDefaults() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getDefaults() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getDefaults() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getDefaultSection() - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getDefaultSection() - Method in class com.facebook.buck.features.python.PythonBuckConfig
-
- getDefaultSharedLibrarySoname(BuildTarget, CxxPlatform, ProjectFilesystem) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
Default shared library soname for a target
- getDefaultStrategyConfig() - Method in class com.facebook.buck.rules.modern.config.ModernBuildRuleConfig
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.android.AndroidAppModularityDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.android.AndroidBuildConfigDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.android.AndroidInstrumentationApkDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.android.AndroidInstrumentationTestDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.android.AndroidManifestDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.android.AndroidPrebuiltAarDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.android.AndroidResourceDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.android.ApkGenruleDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.android.GenAidlDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.android.NdkLibraryDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.android.NdkToolchainDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.android.PrebuiltNativeLibraryDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.apple.AppleAssetCatalogDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.apple.ApplePackageDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.apple.AppleResourceDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.apple.AppleToolchainSetDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.apple.AppleWrapperResourceArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.apple.PrebuiltAppleFrameworkDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.apple.XcodeScriptDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in interface com.facebook.buck.core.description.arg.BuildRuleArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.core.model.targetgraph.impl.ImmutableUnconfiguredTargetNode
-
- getDefaultTargetPlatform() - Method in interface com.facebook.buck.core.model.targetgraph.raw.UnconfiguredTargetNode
-
Value of default_target_platform
attribute.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.core.starlark.rule.SkylarkDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.core.test.rule.impl.ExternalTestRunnerDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.core.toolchain.rule.LegacyToolchainDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.cxx.CxxGenruleDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.cxx.CxxPrecompiledHeaderDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.d.DBinaryDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.d.DLibraryDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.d.DTestDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.dotnet.CsharpLibraryDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.dotnet.PrebuiltDotnetLibraryDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.filegroup.FileGroupDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.go.GoBinaryDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.go.GoLibraryDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.go.GoTestDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.go.GoTestRunnerDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.go.PrebuiltGoLibraryDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.gwt.GwtBinaryDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.haskell.HaskellBinaryDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.haskell.HaskellGhciDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.haskell.HaskellHaddockDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.haskell.HaskellLibraryDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.haskell.HaskellPrebuiltLibraryDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.js.JsBundleDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.js.JsLibraryDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.lua.LuaBinaryDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.lua.LuaLibraryDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.ocaml.OcamlBinaryDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.ocaml.OcamlLibraryDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.ocaml.PrebuiltOcamlLibraryDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.python.PrebuiltPythonLibraryDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.python.PythonLibraryDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.python.PythonTestRunnerDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.rust.PrebuiltRustLibraryDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.features.zip.rules.ZipFileDescriptionArg
-
- getDefaultTargetPlatform() - Method in class com.facebook.buck.file.HttpArchiveDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.file.HttpFileDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.file.RemoteFileDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.jvm.java.JarGenruleDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.jvm.java.JavaAnnotationProcessorDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.jvm.java.JavaBinaryDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.jvm.java.JavaPluginDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.jvm.java.KeystoreDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.jvm.java.PrebuiltJarDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.shell.CommandAliasDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.shell.ExportFileDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.shell.GenruleDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.shell.ShBinaryDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.shell.ShTestDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.shell.TestSuiteDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.shell.WorkerToolDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.swift.SwiftLibraryDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.swift.SwiftToolchainDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTargetPlatform() - Method in class com.facebook.buck.versions.VersionedAliasDescriptionArg
-
The name of build target default "new" platform: it is used when a platform is not specified
either globally or in a target which used this target as a dependency.
- getDefaultTestRuleTimeoutMs() - Method in class com.facebook.buck.test.config.TestBuckConfig
-
The timeout to apply to entire test rules.
- getDefaultTestRunner() - Method in enum com.facebook.buck.jvm.java.TestType
-
- getDefaultTestTimeoutMillis() - Method in class com.facebook.buck.core.build.execution.context.ExecutionContext
-
- getDefaultTestTimeoutMillis() - Method in class com.facebook.buck.test.config.TestBuckConfig
-
- getDefaultTestType() - Method in class com.facebook.buck.cxx.CxxTestDescription
-
- getDefaultUnresolvedCxxPlatform() - Method in class com.facebook.buck.cxx.toolchain.CxxPlatformsProvider
-
- getDefiningPath() - Method in interface com.facebook.buck.rules.visibility.VisibilityPattern
-
- getDelayMilliseconds(int) - Method in interface com.facebook.buck.remoteexecution.grpc.retry.Backoff.Strategy
-
Return the amount of time to wait in milliseconds before attempting to retry an operation.
- getDelegate() - Method in class com.facebook.buck.android.exopackage.AdbConfig
-
- getDelegate() - Method in class com.facebook.buck.apple.AppleConfig
-
- getDelegate() - Method in interface com.facebook.buck.artifact_cache.CacheDecorator
-
- getDelegate() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getDelegate() - Method in class com.facebook.buck.artifact_cache.LoggingArtifactCacheDecorator
-
- getDelegate() - Method in class com.facebook.buck.artifact_cache.RetryingCacheDecorator
-
- getDelegate() - Method in class com.facebook.buck.artifact_cache.TwoLevelArtifactCacheDecorator
-
- getDelegate() - Method in class com.facebook.buck.cli.CleanCommandBuckConfig
-
- getDelegate() - Method in class com.facebook.buck.command.config.BuildBuckConfig
-
- getDelegate() - Method in class com.facebook.buck.command.config.ConfigIgnoredByDaemon
-
- getDelegate() - Method in interface com.facebook.buck.core.config.ConfigView
-
- getDelegate() - Method in class com.facebook.buck.core.exceptions.config.ErrorHandlingBuckConfig
-
- getDelegate() - Method in class com.facebook.buck.core.graph.transformation.executor.config.DepsAwareExecutorConfig
-
- getDelegate() - Method in class com.facebook.buck.core.model.actiongraph.computation.ActionGraphConfig
-
- getDelegate() - Method in class com.facebook.buck.core.resources.ResourcesConfig
-
- getDelegate() - Method in class com.facebook.buck.core.rulekey.config.RuleKeyConfig
-
- getDelegate() - Method in class com.facebook.buck.core.rules.analysis.config.RuleAnalysisConfig
-
- getDelegate() - Method in class com.facebook.buck.core.sourcepath.ForwardingBuildTargetSourcePath
-
- getDelegate() - Method in class com.facebook.buck.counters.CounterBuckConfig
-
- getDelegate() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getDelegate() - Method in class com.facebook.buck.doctor.config.DoctorConfig
-
- getDelegate() - Method in class com.facebook.buck.event.chrome_trace.ChromeTraceBuckConfig
-
- getDelegate() - Method in class com.facebook.buck.event.listener.ScribeEventListenerConfig
-
- getDelegate() - Method in class com.facebook.buck.features.d.DBuckConfig
-
- getDelegate() - Method in class com.facebook.buck.features.dotnet.DotnetBuckConfig
-
- getDelegate() - Method in class com.facebook.buck.features.go.GoBuckConfig
-
- getDelegate() - Method in class com.facebook.buck.features.python.PythonBuckConfig
-
- getDelegate() - Method in class com.facebook.buck.infer.InferConfig
-
- getDelegate() - Method in class com.facebook.buck.jvm.groovy.GroovyBuckConfig
-
- getDelegate() - Method in class com.facebook.buck.jvm.java.JavaBuckConfig
-
- getDelegate() - Method in class com.facebook.buck.jvm.kotlin.KotlinBuckConfig
-
- getDelegate() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getDelegate() - Method in class com.facebook.buck.rules.tool.config.ToolConfig
-
- getDelegate() - Method in class com.facebook.buck.sandbox.SandboxConfig
-
- getDelegate() - Method in class com.facebook.buck.support.build.report.BuildReportConfig
-
- getDelegate() - Method in class com.facebook.buck.support.cli.config.CliConfig
-
- getDelegate() - Method in class com.facebook.buck.support.fix.FixBuckConfig
-
- getDelegate() - Method in class com.facebook.buck.support.log.LogBuckConfig
-
- getDelegate() - Method in class com.facebook.buck.swift.SwiftBuckConfig
-
- getDelegate() - Method in class com.facebook.buck.test.config.TestBuckConfig
-
- getDelegate() - Method in class com.facebook.buck.util.ContextualProcessExecutor
-
- getDelegateConfig() - Method in class com.facebook.buck.rules.modern.config.HybridLocalBuildStrategyConfig
-
- getDelegateDetails() - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- getDelegateDetails() - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
- getDelegateJobs() - Method in class com.facebook.buck.rules.modern.config.HybridLocalBuildStrategyConfig
-
- getDeniedToReadPaths() - Method in class com.facebook.buck.sandbox.SandboxProperties
-
Paths that are not allowed to be read during process execution.
- getDensities() - Method in class com.facebook.buck.android.FilterResourcesSteps.ResourceFilter
-
- getDep(KeyType) - Method in interface com.facebook.buck.core.graph.transformation.ComputationEnvironment
-
- getDependencies() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXTarget
-
- getDependencies() - Method in interface com.facebook.buck.core.build.action.BuildEngineAction
-
- getDependencies() - Method in class com.facebook.buck.core.rules.actions.AbstractAction
-
- getDependencies() - Method in class com.facebook.buck.core.rules.impl.AbstractBuildRule
-
- getDependencies(IjModule) - Method in class com.facebook.buck.features.project.intellij.IjProjectTemplateDataPreparer
-
- getDependencies() - Method in class com.facebook.buck.features.project.intellij.model.IjModule
-
- getDependencies() - Method in class com.facebook.buck.features.project.intellij.ModuleBuildContext
-
- getDependenciesPassTheirTests() - Method in interface com.facebook.buck.event.external.elements.TestResultsExternalInterface
-
- getDependenciesPassTheirTests() - Method in class com.facebook.buck.test.TestResults
-
- getDependencyStack() - Method in interface com.facebook.buck.core.exceptions.ExceptionWithHumanReadableMessage
-
Get the dependency stack associated with this error
- getDependencyStack() - Method in exception com.facebook.buck.core.exceptions.HumanReadableException
-
- getDependencyStack() - Method in exception com.facebook.buck.core.model.targetgraph.NoSuchTargetException
-
- getDependencyTrackingMode() - Method in class com.facebook.buck.cxx.toolchain.ClangCompiler
-
- getDependencyTrackingMode() - Method in interface com.facebook.buck.cxx.toolchain.Compiler
-
- getDependencyTrackingMode() - Method in class com.facebook.buck.cxx.toolchain.DefaultCompiler
-
- getDependencyTrackingMode() - Method in class com.facebook.buck.cxx.toolchain.GccCompiler
-
- getDependencyTrackingMode() - Method in class com.facebook.buck.cxx.toolchain.WindowsCompiler
-
- getDependencyTrackingMode() - Method in class com.facebook.buck.cxx.toolchain.WindowsMl64Compiler
-
- getDependentLibrariesFor(IjModule) - Method in class com.facebook.buck.features.project.intellij.IjModuleGraph
-
- getDependentModulesFor(IjModule) - Method in class com.facebook.buck.features.project.intellij.IjModuleGraph
-
- getDepFilePath(BuildTarget, ProjectFilesystem) - Static method in class com.facebook.buck.jvm.java.CompilerOutputPaths
-
- getDepFileRelativePath() - Method in class com.facebook.buck.jvm.java.UnusedDependenciesFinder
-
- getDepFileRuleKey() - Method in interface com.facebook.buck.core.rulekey.BuildRuleKeys
-
- getDepFileRuleKeyFactory() - Method in class com.facebook.buck.rules.keys.RuleKeyFactories
-
- getDepResults(BuildRule, ExecutionContext) - Method in class com.facebook.buck.core.build.engine.impl.CachingBuildEngine.DefaultBuildRuleBuilderDelegate
-
- getDeps() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.android.AndroidAppModularityDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.android.AndroidInstrumentationApkDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.android.AndroidManifestDescriptionArg
-
A collection of dependencies that includes android_library rules.
- getDeps() - Method in class com.facebook.buck.android.AndroidPrebuiltAarDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.android.AndroidResourceDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.android.GenAidlDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.android.NdkLibraryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.android.PrebuiltNativeLibraryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.apple.PrebuiltAppleFrameworkDescriptionArg
-
- getDeps() - Method in interface com.facebook.buck.core.description.arg.HasDeclaredDeps
-
- getDeps() - Method in interface com.facebook.buck.core.graph.transformation.ComputationEnvironment
-
- getDeps(ComputationIdentifier<ResultType>) - Method in interface com.facebook.buck.core.graph.transformation.ComputationEnvironment
-
- getDeps() - Method in class com.facebook.buck.core.model.targetgraph.raw.UnconfiguredTargetNodeWithDeps
-
List of build targets that this node depends on.
- getDeps(SourcePathRuleFinder) - Method in interface com.facebook.buck.core.rules.attr.HasCustomDepsLogic
-
Deprecated.
- getDeps(AddsToRuleKey, SourcePathRuleFinder) - Static method in class com.facebook.buck.core.rules.common.BuildableSupport
-
Streams dependencies based on everything added to its rulekey.
- getDeps() - Method in class com.facebook.buck.core.rules.platform.PlatformArg
-
- getDeps() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.cxx.CxxDeps
-
- getDeps(SourcePathRuleFinder) - Method in class com.facebook.buck.cxx.CxxHeaders
-
- getDeps() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.cxx.CxxPrecompiledHeaderDescriptionArg
-
- getDeps(BuildRuleResolver) - Method in class com.facebook.buck.cxx.CxxPreprocessorInput
-
- getDeps(SourcePathRuleFinder) - Method in class com.facebook.buck.cxx.CxxSymlinkTreeHeaders
-
- getDeps() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescriptionArg
-
- getDeps(SourcePathRuleFinder) - Method in class com.facebook.buck.cxx.PreprocessorFlags
-
- getDeps() - Method in class com.facebook.buck.features.d.DBinaryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.d.DLibraryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.d.DTestDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.dotnet.CsharpLibraryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.go.GoBinaryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.go.GoLibraryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.go.GoTestDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.go.PrebuiltGoLibraryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.gwt.GwtBinaryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.haskell.HaskellBinaryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.haskell.HaskellGhciDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.haskell.HaskellHaddockDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.haskell.HaskellLibraryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.haskell.HaskellPrebuiltLibraryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.js.JsBundleDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.js.JsLibraryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.lua.LuaBinaryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.lua.LuaLibraryDescriptionArg
-
- getDeps(CxxPlatform, ImmutableSortedSet<BuildTarget>, PatternMatchedCollection<ImmutableSortedSet<BuildTarget>>) - Static method in class com.facebook.buck.features.lua.LuaUtil
-
- getDeps() - Method in class com.facebook.buck.features.ocaml.OcamlBinaryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.ocaml.OcamlLibraryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.ocaml.PrebuiltOcamlLibraryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.python.PrebuiltPythonLibraryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.python.PythonLibraryDescriptionArg
-
- getDeps(SourcePathRuleFinder) - Method in class com.facebook.buck.features.python.PythonPackageComponents
-
- getDeps() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getDeps(PythonPlatform, CxxPlatform, ImmutableSortedSet<BuildTarget>, PatternMatchedCollection<ImmutableSortedSet<BuildTarget>>) - Static method in class com.facebook.buck.features.python.PythonUtil
-
- getDeps() - Method in class com.facebook.buck.features.rust.PrebuiltRustLibraryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.jvm.java.DefaultJavaLibraryRules.Builder
-
- getDeps() - Method in class com.facebook.buck.jvm.java.JavaAnnotationProcessorDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.jvm.java.JavaBinaryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.jvm.java.JavaLibraryDeps
-
- getDeps() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.jvm.java.JavaPluginDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.jvm.java.KeystoreDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.jvm.java.PrebuiltJarDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.jvm.java.UnusedDependenciesFinder
-
- getDeps() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getDeps(SourcePathRuleFinder) - Method in class com.facebook.buck.rules.coercer.FrameworkPath
-
- getDeps() - Method in class com.facebook.buck.rules.keys.InputBasedRuleKeyFactory.Result
-
- getDeps(T, Consumer<BuildRule>) - Method in interface com.facebook.buck.rules.modern.CustomFieldDeps
-
- getDeps() - Method in class com.facebook.buck.shell.ShBinaryDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.shell.ShTestDescriptionArg
-
- getDeps() - Method in class com.facebook.buck.swift.SwiftLibraryDescriptionArg
-
- getDepsAwareExecutorSupplier() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getDepsCollection(AddsToRuleKey, SourcePathRuleFinder) - Static method in class com.facebook.buck.core.rules.common.BuildableSupport
-
Derives dependencies based on everything added to its rulekey.
- getDepsFor(IjProjectElement) - Method in class com.facebook.buck.features.project.intellij.IjModuleGraph
-
- getDepsForTransitiveClasspathEntries() - Method in class com.facebook.buck.android.AndroidBinary
-
- getDepsForTransitiveClasspathEntries() - Method in class com.facebook.buck.android.AndroidResource
-
- getDepsForTransitiveClasspathEntries() - Method in interface com.facebook.buck.jvm.core.HasClasspathDeps
-
- getDepsForTransitiveClasspathEntries() - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getDepsForTransitiveClasspathEntries() - Method in class com.facebook.buck.jvm.java.JavaBinary
-
- getDepsForTransitiveClasspathEntries() - Method in class com.facebook.buck.jvm.java.PrebuiltJar
-
- getDepsQuery() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getDepsQuery() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getDepsQuery() - Method in interface com.facebook.buck.core.description.arg.HasDepsQuery
-
- getDepsQuery() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getDepsQuery() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getDepsQuery() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getDepsQuery() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getDepsQuery() - Method in class com.facebook.buck.features.haskell.HaskellBinaryDescriptionArg
-
- getDepsQuery() - Method in class com.facebook.buck.features.haskell.HaskellGhciDescriptionArg
-
- getDepsQuery() - Method in class com.facebook.buck.features.haskell.HaskellHaddockDescriptionArg
-
- getDepsQuery() - Method in class com.facebook.buck.features.js.JsLibraryDescriptionArg
-
- getDepsSupplier() - Method in class com.facebook.buck.core.graph.transformation.executor.DepsAwareTask
-
- getDepsWithCacheMisses() - Method in class com.facebook.buck.core.build.engine.BuildResult
-
- getDerivedArtifactVerifier(BuildTarget, ProjectFilesystem, AddsToRuleKey, BuildableContext) - Static method in class com.facebook.buck.rules.modern.impl.ModernBuildableSupport
-
Derives an ArtifactVerifier from the @AddToRuleKey annotated fields.
- getDerivedArtifactVerifier(BuildTarget, ProjectFilesystem, AddsToRuleKey) - Static method in class com.facebook.buck.rules.modern.impl.ModernBuildableSupport
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.android.AabBuilderStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.android.aapt.MiniAapt
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.android.AndroidModuleConsistencyStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.android.ApkBuilderStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.android.ApkInstallStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.android.CompileStringsStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.android.ConcatStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.android.dalvik.EstimateDexWeightStep
-
- getDescription() - Method in class com.facebook.buck.android.FilterResourcesSteps.ResourceFilter
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.android.GenerateBuildConfigStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.android.GenerateManifestStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.android.GetStringsFilesStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.android.IntraDexReorderStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.android.MergeAndroidResourcesStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.android.ReplaceManifestPlaceholdersStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.android.SmartDexingStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.android.SplitZipStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.android.WriteAppModuleMetadataStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.apple.IdbRunTestsStep
-
- getDescription() - Method in class com.facebook.buck.core.model.targetgraph.impl.TargetNodeImpl
-
- getDescription() - Method in interface com.facebook.buck.core.model.targetgraph.TargetNode
-
- getDescription() - Method in class com.facebook.buck.core.model.UserFlavor
-
- getDescription() - Method in class com.facebook.buck.core.rules.knowntypes.RuleDescriptor
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.cxx.MachoDylibStubScrubContentsStep
-
- getDescription() - Method in interface com.facebook.buck.event.external.events.StepEventExternalInterface
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.features.ocaml.OcamlBuildStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.features.ocaml.OcamlDebugLauncherStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.features.python.MovePythonWhlDataStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.features.python.PythonRunTestsStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.features.zip.rules.CopyToZipStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.file.DownloadStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.json.JsonConcatenateStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.jvm.java.AccumulateClassNamesStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.jvm.java.CalculateClassAbiStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.jvm.java.CopyResourcesStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.jvm.java.DiffAbisStep
-
- getDescription(ImmutableList<String>, ImmutableSortedSet<Path>, Path) - Method in class com.facebook.buck.jvm.java.ExternalJavac
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.jvm.java.JarDirectoryStep
-
- getDescription(ImmutableList<String>, ImmutableSortedSet<Path>, Path) - Method in interface com.facebook.buck.jvm.java.Javac
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.jvm.java.JavacStep
-
- getDescription(ImmutableList<String>, ImmutableSortedSet<Path>, Path) - Method in class com.facebook.buck.jvm.java.Jsr199Javac
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.jvm.java.UnusedDependenciesFinder
-
- getDescription(ImmutableList<String>, ImmutableSortedSet<Path>, Path) - Method in class com.facebook.buck.jvm.kotlin.ExternalKotlinc
-
- getDescription(ImmutableList<String>, ImmutableSortedSet<Path>, Path) - Method in class com.facebook.buck.jvm.kotlin.JarBackedReflectedKotlinc
-
- getDescription(ImmutableList<String>, ImmutableSortedSet<Path>, Path) - Method in interface com.facebook.buck.jvm.kotlin.Kotlinc
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.jvm.kotlin.KotlincStep
-
- getDescription() - Method in exception com.facebook.buck.remoteexecution.util.MultiThreadedBlobUploader.CorruptArtifactException
-
- getDescription(ThrowableCauseIterable) - Static method in exception com.facebook.buck.remoteexecution.util.MultiThreadedBlobUploader.CorruptArtifactException
-
Returns CorruptArtifactException throwable if any of the causes in the
ThrowableCauseIterable
are CorruptArtifactException.
- getDescription(ExecutionContext) - Method in class com.facebook.buck.shell.RunTestAndRecordResultStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.shell.ShellStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.shell.WorkerShellStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.step.AbstractExecutionStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.step.AbstractTestStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.step.ConditionalStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.step.fs.CopyStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.step.fs.FileScrubberStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.step.fs.FindAndReplaceStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.step.fs.MakeExecutableStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.step.fs.MkdirStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.step.fs.MoveStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.step.fs.RmStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.step.fs.StringTemplateStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.step.fs.SymCopyStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.step.fs.SymlinkFileStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.step.fs.SymlinkTreeMergeStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.step.fs.SymlinkTreeStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.step.fs.TouchStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.step.fs.WriteFileStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.step.fs.XzStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.step.fs.ZstdStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.step.impl.ActionExecutionStep
-
- getDescription(ExecutionContext) - Method in interface com.facebook.buck.step.Step
-
- getDescription() - Method in class com.facebook.buck.step.StepEvent
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.unarchive.UntarStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.unarchive.UnzipStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.zip.RepackZipEntriesStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.zip.ZipScrubberStep
-
- getDescription(ExecutionContext) - Method in class com.facebook.buck.zip.ZipStep
-
- getDescriptionClass() - Method in class com.facebook.buck.features.project.intellij.lang.android.AndroidBinaryModuleRule
-
- getDescriptionClass() - Method in class com.facebook.buck.features.project.intellij.lang.android.AndroidLibraryModuleRule
-
- getDescriptionClass() - Method in class com.facebook.buck.features.project.intellij.lang.android.AndroidResourceModuleRule
-
- getDescriptionClass() - Method in class com.facebook.buck.features.project.intellij.lang.android.RobolectricTestModuleRule
-
- getDescriptionClass() - Method in class com.facebook.buck.features.project.intellij.lang.cxx.CxxLibraryModuleRule
-
- getDescriptionClass() - Method in class com.facebook.buck.features.project.intellij.lang.cxx.CxxTestModuleRule
-
- getDescriptionClass() - Method in class com.facebook.buck.features.project.intellij.lang.groovy.GroovyLibraryModuleRule
-
- getDescriptionClass() - Method in class com.facebook.buck.features.project.intellij.lang.groovy.GroovyTestModuleRule
-
- getDescriptionClass() - Method in class com.facebook.buck.features.project.intellij.lang.java.JavaBinaryModuleRule
-
- getDescriptionClass() - Method in class com.facebook.buck.features.project.intellij.lang.java.JavaLibraryModuleRule
-
- getDescriptionClass() - Method in class com.facebook.buck.features.project.intellij.lang.java.JavaTestModuleRule
-
- getDescriptionClass() - Method in class com.facebook.buck.features.project.intellij.lang.kotlin.KotlinLibraryModuleRule
-
- getDescriptionClass() - Method in class com.facebook.buck.features.project.intellij.lang.kotlin.KotlinTestModuleRule
-
- getDescriptionClass() - Method in class com.facebook.buck.features.project.intellij.lang.python.PythonLibraryModuleRule
-
- getDescriptionClass() - Method in class com.facebook.buck.features.project.intellij.lang.python.PythonTestModuleRule
-
- getDescriptionClass() - Method in class com.facebook.buck.features.project.intellij.lang.scala.ScalaLibraryModuleRule
-
- getDescriptionClass() - Method in class com.facebook.buck.features.project.intellij.lang.scala.ScalaTestModuleRule
-
- getDescriptionClass() - Method in interface com.facebook.buck.features.project.intellij.model.IjModuleRule
-
- getDescriptions(DescriptionCreationContext) - Method in class com.facebook.buck.android.AndroidDescriptionsProvider
-
- getDescriptions() - Method in class com.facebook.buck.android.toolchain.platform.AndroidPlatformDescriptionProvider
-
- getDescriptions(DescriptionCreationContext) - Method in class com.facebook.buck.apple.AppleDescriptionProvider
-
- getDescriptions(DescriptionCreationContext) - Method in interface com.facebook.buck.core.model.targetgraph.DescriptionProvider
-
- getDescriptions() - Method in interface com.facebook.buck.core.rules.config.ConfigurationRuleDescriptionProvider
-
- getDescriptions() - Method in class com.facebook.buck.core.rules.configsetting.ConfigSettingRuleDescriptionProvider
-
- getDescriptions() - Method in class com.facebook.buck.core.rules.knowntypes.KnownNativeRuleTypes
-
- getDescriptions() - Method in class com.facebook.buck.core.rules.platform.ConstraintRulesDescriptionProvider
-
- getDescriptions() - Method in class com.facebook.buck.core.rules.platform.PlatformRuleDescriptionProvider
-
- getDescriptions(DescriptionCreationContext) - Method in class com.facebook.buck.core.test.rule.impl.TestRunnerDescriptionsProvider
-
- getDescriptions(DescriptionCreationContext) - Method in class com.facebook.buck.core.toolchain.rule.LegacyToolchainDescriptionProvider
-
- getDescriptions(DescriptionCreationContext) - Method in class com.facebook.buck.cxx.CxxDescriptionsProvider
-
- getDescriptions(DescriptionCreationContext) - Method in class com.facebook.buck.features.apple.common.XCodeDescriptionProvider
-
- getDescriptions(DescriptionCreationContext) - Method in class com.facebook.buck.features.d.DDescriptionsProvider
-
- getDescriptions(DescriptionCreationContext) - Method in class com.facebook.buck.features.dotnet.DotNetRuleProvider
-
- getDescriptions(DescriptionCreationContext) - Method in class com.facebook.buck.features.filegroup.FilegroupDescriptionsProvider
-
- getDescriptions(DescriptionCreationContext) - Method in class com.facebook.buck.features.go.GoDescriptionsProvider
-
- getDescriptions(DescriptionCreationContext) - Method in class com.facebook.buck.features.gwt.GwtDescriptionsProvider
-
- getDescriptions(DescriptionCreationContext) - Method in class com.facebook.buck.features.halide.HalideDescriptionsProvider
-
- getDescriptions(DescriptionCreationContext) - Method in class com.facebook.buck.features.haskell.HaskellDescriptionsProvider
-
- getDescriptions(DescriptionCreationContext) - Method in class com.facebook.buck.features.js.JsDescriptionsProvider
-
- getDescriptions(DescriptionCreationContext) - Method in class com.facebook.buck.features.lua.LuaDescriptionsProvider
-
- getDescriptions(DescriptionCreationContext) - Method in class com.facebook.buck.features.ocaml.OcamlDescriptionsProvider
-
- getDescriptions(DescriptionCreationContext) - Method in class com.facebook.buck.features.python.PythonDescriptionsProvider
-
- getDescriptions(DescriptionCreationContext) - Method in class com.facebook.buck.features.rust.RustDescriptionsProvider
-
- getDescriptions(DescriptionCreationContext) - Method in class com.facebook.buck.features.zip.rules.ZipDescriptionProvider
-
- getDescriptions(DescriptionCreationContext) - Method in class com.facebook.buck.file.FileDescriptionsProvider
-
- getDescriptions(DescriptionCreationContext) - Method in class com.facebook.buck.jvm.groovy.GroovyDescriptionsProvider
-
- getDescriptions(DescriptionCreationContext) - Method in class com.facebook.buck.jvm.java.JavaDescriptionsProvider
-
- getDescriptions(DescriptionCreationContext) - Method in class com.facebook.buck.jvm.java.rules.JavaDescriptionProvider
-
- getDescriptions(DescriptionCreationContext) - Method in class com.facebook.buck.jvm.kotlin.KotlinDescriptionsProvider
-
- getDescriptions(DescriptionCreationContext) - Method in class com.facebook.buck.jvm.scala.ScalaDescriptionsProvider
-
- getDescriptions() - Method in class com.facebook.buck.parser.options.ProjectBuildFileParserOptions
-
- getDescriptions(DescriptionCreationContext) - Method in class com.facebook.buck.shell.ShellDescriptionsProvider
-
- getDescriptions(DescriptionCreationContext) - Method in class com.facebook.buck.swift.SwiftDescriptionsProvider
-
- getDescriptions(DescriptionCreationContext) - Method in class com.facebook.buck.versions.VersionDescriptionsProvider
-
- getDescriptionsByRule() - Method in class com.facebook.buck.core.rules.knowntypes.KnownNativeRuleTypes
-
- getDescriptorByName(String) - Method in class com.facebook.buck.core.rules.knowntypes.HybridKnownRuleTypes
-
- getDescriptorByName(String) - Method in class com.facebook.buck.core.rules.knowntypes.KnownNativeRuleTypes
-
- getDescriptorByName(String) - Method in interface com.facebook.buck.core.rules.knowntypes.KnownRuleTypes
-
Get rule type, constructor arg and description object for by rule name.
- getDescriptorByName(String) - Method in class com.facebook.buck.core.starlark.knowntypes.KnownUserDefinedRuleTypes
-
- getDescriptorByNameChecked(String, Class<T>) - Method in interface com.facebook.buck.core.rules.knowntypes.KnownRuleTypes
-
- getDesiredLink() - Method in class com.facebook.buck.step.fs.SymlinkFileStep
-
- getDestination() - Method in class com.facebook.buck.apple.AppleResourceDescriptionArg
-
- getDestination() - Method in class com.facebook.buck.apple.SourcePathWithAppleBundleDestination
-
- getDestination() - Method in interface com.facebook.buck.apple.xcode.xcodeproj.CopyFilePhaseDestinationSpec
-
- getDestinationBase() - Method in class com.facebook.buck.features.apple.common.CopyInXcode
-
- getDestinationFile() - Method in class com.facebook.buck.step.fs.XzStep
-
- getDestinationPath() - Method in class com.facebook.buck.features.apple.common.CopyInXcode
-
- getDestinationSpecifier() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getDesugarDeps() - Method in class com.facebook.buck.android.DexProducedFromJavaLibrary
-
- getDetailsForLogging() - Method in class com.facebook.buck.edenfs.EdenProjectFilesystemDelegate
-
- getDetailsForLogging() - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystemDelegate
-
- getDetailsForLogging() - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystemDelegate
-
- getDeveloperCertificateFingerprints() - Method in class com.facebook.buck.apple.toolchain.ProvisioningProfileMetadata
-
SHA1 hashes of the certificates in the "DeveloperCertificates" section.
- getDeveloperPath() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
Developer directory of the toolchain
- getDeveloperPath() - Method in class com.facebook.buck.apple.toolchain.AppleSdkPaths
-
Absolute path to the active DEVELOPER_DIR.
- getDeviceAbis() - Method in interface com.facebook.buck.android.exopackage.AndroidDevice
-
- getDeviceAbis() - Method in class com.facebook.buck.android.exopackage.RealAndroidDevice
-
- getDeviceKind(AppleDevice) - Method in class com.facebook.buck.apple.simulator.AppleDeviceController
-
- getDevices(boolean) - Method in class com.facebook.buck.android.AdbHelper
-
- getDevices(boolean) - Method in interface com.facebook.buck.android.exopackage.AndroidDevicesHelper
-
- getDexCompression() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getDexCompression() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getDexDirectory() - Method in class com.facebook.buck.android.PreDexSplitDexMerge
-
- getDexDirectorySourcePath() - Method in class com.facebook.buck.android.PreDexSplitDexMerge
-
- getDexFile() - Method in class com.facebook.buck.android.ModuleInfo
-
- getDexFilesInfo() - Method in interface com.facebook.buck.android.HasDexFiles
-
- getDexFilesInfo() - Method in class com.facebook.buck.android.PreDexSingleDexMerge
-
- getDexFilesInfo() - Method in class com.facebook.buck.android.PreDexSplitDexMerge
-
- getDexGroupLibLimit() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getDexGroupLibLimit() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getDexInfo() - Method in class com.facebook.buck.android.exopackage.ExopackageInfo
-
- getDexInputHashes() - Method in class com.facebook.buck.android.HashInputJarsToDexStep
-
- getDexInputHashes() - Method in interface com.facebook.buck.android.SmartDexingStep.DexInputHashesProvider
-
- getDexReorderDataDumpFile() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getDexReorderDataDumpFile() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getDexReorderDataDumpFile() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getDexReorderToolFile() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getDexReorderToolFile() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getDexReorderToolFile() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getDexTool() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getDexTool() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getDexTool() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getDexTool() - Method in class com.facebook.buck.android.AndroidInstrumentationApkDescriptionArg
-
- getDexWithClasses() - Method in class com.facebook.buck.android.PreDexSplitDexGroup
-
- getDiagnostic() - Method in class com.facebook.buck.io.watchman.WatchmanDiagnosticEvent
-
- getDiagnosticData() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.Finished
-
- getDiagnosticKindForSourceOnlyAbiCompatibility() - Method in enum com.facebook.buck.jvm.java.abi.AbiGenerationMode
-
- getDiagnostics() - Method in interface com.facebook.buck.json.BuildFilePythonResult
-
- getDictionary() - Method in class com.facebook.buck.parser.syntax.SelectorValue
-
Return a map with select choices and appropriate values
- getDiff() - Method in interface com.facebook.buck.doctor.config.SourceControlInfo
-
- getDiff() - Method in class com.facebook.buck.event.ParsingEvent.EnvVariableChange
-
- getDiff() - Method in interface com.facebook.buck.util.versioncontrol.FullVersionControlStats
-
- getDigest() - Method in class com.facebook.buck.remoteexecution.grpc.GrpcProtocol.GrpcOutputFile
-
- getDigest() - Method in interface com.facebook.buck.remoteexecution.interfaces.Protocol.DirectoryNode
-
- getDigest() - Method in interface com.facebook.buck.remoteexecution.interfaces.Protocol.FileNode
-
- getDigest() - Method in interface com.facebook.buck.remoteexecution.interfaces.Protocol.OutputFile
-
- getDigest() - Method in interface com.facebook.buck.remoteexecution.UploadDataSupplier
-
- getDigest() - Method in class com.facebook.buck.remoteexecution.util.MerkleTreeNodeCache.NodeData
-
- getDirCacheEntries() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheEntries
-
- getDirCacheStoreExecutor() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getDirectories() - Method in class com.facebook.buck.core.files.DirectoryList
-
- getDirectories() - Method in enum com.facebook.buck.features.dotnet.FrameworkVersion
-
- getDirectoriesList() - Method in interface com.facebook.buck.remoteexecution.interfaces.Protocol.Directory
-
- getDirectory() - Method in interface com.facebook.buck.android.exopackage.ExopackageInfo.DexInfo
-
- getDirectory() - Method in interface com.facebook.buck.android.exopackage.ExopackageInfo.NativeLibsInfo
-
- getDirectory() - Method in class com.facebook.buck.cxx.CxxCompilationDatabaseEntry
-
- getDirectory() - Method in class com.facebook.buck.remoteexecution.util.MerkleTreeNodeCache.NodeData
-
- getDirectory() - Method in class com.facebook.buck.util.ProcessExecutorParams
-
If present, the current working directory for the launched process.
- getDirectoryContents(Path) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- getDirectoryContents(Path) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystemView
-
- getDirectoryContents(Path) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
Deprecated.
- getDirectoryContents(Path) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystemView
-
Gets a list of paths of the contents of the given directory, obeying the ignores.
- getDirectoryList() - Method in class com.facebook.buck.core.files.FileTree
-
List of files, folders and symlinks in the desired directory
- getDirectoryListCaches() - Method in class com.facebook.buck.support.state.BuckGlobalState
-
Return a map of all directory list caches for each cell which is a key.
- getDirs() - Method in class com.facebook.buck.apple.AppleAssetCatalogDescriptionArg
-
- getDirs() - Method in class com.facebook.buck.apple.AppleResourceDescriptionArg
-
- getDirsContainingResourceDirs() - Method in class com.facebook.buck.apple.AppleBundleResources
-
Directories whose contents should be copied into the root of the resources subdirectory.
- getDirtyFiles() - Method in interface com.facebook.buck.doctor.config.SourceControlInfo
-
- getDisablePreDex() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getDisablePreDex() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getDisablePreDex() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getDisallowAllDuplicates() - Method in class com.facebook.buck.jvm.java.JarParameters
-
- getDisallowAllDuplicates() - Method in class com.facebook.buck.jvm.java.JavaBinaryDescriptionArg
-
- getDiskIO() - Method in class com.facebook.buck.util.concurrent.ResourceAmounts
-
- getDist() - Method in class com.facebook.buck.infer.InferConfig
-
- getDistBinary() - Method in class com.facebook.buck.infer.InferConfig
-
- getDllName() - Method in class com.facebook.buck.features.dotnet.CsharpLibraryDescriptionArg
-
- getDoc() - Method in class com.facebook.buck.core.starlark.rule.attr.Attribute
-
The docstring to use for this attribute
- getDoc() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.BoolAttribute
-
- getDoc() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.DepAttribute
-
- getDoc() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.DepListAttribute
-
- getDoc() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.IntAttribute
-
- getDoc() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.IntListAttribute
-
- getDoc() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.OutputAttribute
-
- getDoc() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.OutputListAttribute
-
- getDoc() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.SourceAttribute
-
- getDoc() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.SourceListAttribute
-
- getDoc() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.SourceSortedSetAttribute
-
- getDoc() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.StringAttribute
-
- getDoc() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.StringListAttribute
-
- getDoc() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.StringSortedSetAttribute
-
- getDoc() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.UnconfiguredDepListAttribute
-
- getDoc() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.UnconfiguredOptionalDepAttribute
-
- getDoesNotAffectAbi() - Method in class com.facebook.buck.jvm.java.ResolvedJavacPluginProperties
-
- getDraftCompile() - Method in class com.facebook.buck.features.gwt.GwtBinaryDescriptionArg
-
If true
, the GWT Compiler's -draftCompile
flag will be set.
- getDstSubfolderSpec() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXCopyFilesBuildPhase
-
- getDsymOutputPath(BuildTarget, ProjectFilesystem) - Static method in class com.facebook.buck.apple.AppleDsym
-
- getDsymutil() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
dsymutil binary.
- getDsymutil() - Method in class com.facebook.buck.apple.toolchain.AppleCxxPlatform
-
- getDtNeeded(ProcessExecutor, Tool, SourcePathResolverAdapter, Path) - Static method in class com.facebook.buck.android.relinker.Symbols
-
- getDtoDescriptor() - Method in class com.facebook.buck.core.rules.knowntypes.RuleDescriptor
-
- getDummyRDotJava() - Method in class com.facebook.buck.android.AndroidLibrary.Builder
-
- getDummyRDotJavaPath(TargetNode<?>) - Method in interface com.facebook.buck.features.project.intellij.model.IjModuleFactoryResolver
-
- getDummyRDotJavaTarget(BuildTarget) - Static method in class com.facebook.buck.android.AndroidLibraryGraphEnhancer
-
- getDuplicateResourceBehavior() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getDuplicateResourceBehavior() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getDuplicateResourceBehavior() - Method in interface com.facebook.buck.android.HasDuplicateAndroidResourceTypes
-
- getDuplicateResourceWhitelist() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getDuplicateResourceWhitelist() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getDuplicateResourceWhitelist() - Method in interface com.facebook.buck.android.HasDuplicateAndroidResourceTypes
-
- getDuplicatesLogLevel() - Method in class com.facebook.buck.jvm.java.JarParameters
-
- getDuplicatesLogLevel() - Method in class com.facebook.buck.jvm.java.JavaBuckConfig
-
- getDuration() - Method in interface com.facebook.buck.apple.AbstractIdbTestResult
-
Time spent executing the test
- getDuration() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent
-
- getDuration() - Method in class com.facebook.buck.event.BuckInitializationDurationEvent
-
- getDuration() - Method in class com.facebook.buck.shell.ShellStep
-
- getDurationInMillis() - Method in class com.facebook.buck.support.jvm.GCCollectionEvent
-
- getDurationName() - Method in class com.facebook.buck.event.CompilerPluginDurationEvent
-
- getDwarfFilenameForDsymTarget(BuildTarget) - Static method in class com.facebook.buck.apple.AppleDsym
-
- getDxExecutable() - Method in class com.facebook.buck.android.toolchain.AndroidPlatformTarget
-
- getDxExecutorService() - Method in interface com.facebook.buck.android.toolchain.DxToolchain
-
Executor service exclusively for the smart dexing step.
- getDxMaxHeapSize() - Method in class com.facebook.buck.android.DxConfig
-
- getDxMaxThreadCount() - Method in class com.facebook.buck.android.DxConfig
-
- getDxThreadCount() - Method in class com.facebook.buck.android.DxConfig
-
- getDxThreadCount() - Method in class com.facebook.buck.jvm.java.JavaBuckConfig
-
- getDynamicSymbols(ProcessExecutor, Tool, SourcePathResolverAdapter, Path) - Static method in class com.facebook.buck.android.relinker.Symbols
-
- getEdgeCount() - Method in class com.facebook.buck.core.util.graph.MutableDirectedGraph
-
- getEdgeId(String) - Method in interface com.facebook.buck.log.TraceInfoProvider
-
- getEdges() - Method in class com.facebook.buck.cxx.toolchain.objectfile.MachoExportTrieNode
-
- getEdition() - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg
-
- getEdition() - Method in interface com.facebook.buck.features.rust.RustCommonArgs
-
- getEdition() - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg
-
- getEdition() - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg
-
- getEffectiveBannedDuplicateResourceTypes() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getEffectiveBannedDuplicateResourceTypes() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getEffectiveBannedDuplicateResourceTypes() - Method in interface com.facebook.buck.android.HasDuplicateAndroidResourceTypes
-
- getElapsedTime() - Method in class com.facebook.buck.event.ActionGraphPerfStatEvent
-
- getElapsedTimeMillis() - Method in class com.facebook.buck.core.test.event.TestStatusMessageEvent.Finished
-
- getElapsedTimeMs() - Method in interface com.facebook.buck.event.listener.CriticalPathReportableNode
-
- getElapsedTimeMs() - Method in interface com.facebook.buck.event.listener.FileSerializationOutputRuleDepsListener.RuleExecutionTimeData
-
- getElapsedTimeMs() - Method in class com.facebook.buck.event.listener.util.EventInterval
-
- getElapsedTimeNano() - Method in class com.facebook.buck.core.build.event.BuildRuleExecutionEvent.Finished
-
- getElement() - Method in interface com.facebook.buck.core.exceptions.DependencyStack.Element
-
- getElement() - Method in interface com.facebook.buck.core.exceptions.DependencyStack.ProvidesElement
-
- getElement() - Method in interface com.facebook.buck.core.model.targetgraph.TargetNode
-
- getElement() - Method in class com.facebook.buck.core.model.UnconfiguredBuildTarget
-
- getElements() - Method in class com.facebook.buck.jvm.java.abi.source.FrontendOnlyJavacTask
-
- getElements() - Method in class com.facebook.buck.jvm.java.plugin.adapter.BuckJavacTask
-
- getElements() - Method in class com.facebook.buck.jvm.java.plugin.adapter.BuckJavacTaskProxyImpl
-
- getElements() - Method in interface com.facebook.buck.jvm.java.plugin.api.BuckJavacTaskProxy
-
- getElements() - Method in class com.facebook.buck.parser.syntax.ListWithSelects
-
Ordered list of elements in expression, can be native type or
SelectorValue
- getElf32Addr(ByteBuffer) - Static method in class com.facebook.buck.cxx.toolchain.elf.Elf.Elf32
-
- getElf32Half(ByteBuffer) - Static method in class com.facebook.buck.cxx.toolchain.elf.Elf.Elf32
-
- getElf32Sword(ByteBuffer) - Static method in class com.facebook.buck.cxx.toolchain.elf.Elf.Elf32
-
- getElf32Word(ByteBuffer) - Static method in class com.facebook.buck.cxx.toolchain.elf.Elf.Elf32
-
- getElf64Addr(ByteBuffer) - Static method in class com.facebook.buck.cxx.toolchain.elf.Elf.Elf64
-
- getElf64Half(ByteBuffer) - Static method in class com.facebook.buck.cxx.toolchain.elf.Elf.Elf64
-
- getElf64Sxword(ByteBuffer) - Static method in class com.facebook.buck.cxx.toolchain.elf.Elf.Elf64
-
- getElf64Word(ByteBuffer) - Static method in class com.facebook.buck.cxx.toolchain.elf.Elf.Elf64
-
- getElf64Xword(ByteBuffer) - Static method in class com.facebook.buck.cxx.toolchain.elf.Elf.Elf64
-
- getEmbeddedCellsBuckOutBaseDir() - Method in class com.facebook.buck.io.filesystem.BuckPaths
-
- getEmitSwiftdocs() - Method in class com.facebook.buck.swift.SwiftBuckConfig
-
If enabled, a .swiftdoc file will be generated along with the .swiftmodule file.
- getEmoji() - Method in enum com.facebook.buck.doctor.config.DoctorSuggestion.StepStatus
-
- getEmptyInitTarget(BuildTarget) - Static method in class com.facebook.buck.features.python.PythonBinaryDescription
-
- getEnabled() - Method in class com.facebook.buck.event.listener.ScribeEventListenerConfig
-
If false (default) then Buck events are not logged to Scribe
- getEnabled() - Method in class com.facebook.buck.support.build.report.BuildReportConfig
-
- getEnabledBuildRuleFinishedStatuses() - Method in class com.facebook.buck.event.listener.ScribeEventListenerConfig
-
- getEnableFailingCommandTruncation() - Method in class com.facebook.buck.support.cli.config.CliConfig
-
- getEnableObjcInterop() - Method in class com.facebook.buck.swift.SwiftLibraryDescriptionArg
-
- getEnablePackageFiles() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getEnableParallelParsing() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getEnableParserProfiling() - Method in class com.facebook.buck.cli.AbstractCommand
-
- getEnableParserProfiling() - Method in class com.facebook.buck.cli.ProjectGeneratorParameters
-
- getEnableProfiling() - Method in class com.facebook.buck.parser.options.ProjectBuildFileParserOptions
-
- getEnableSandbox() - Method in class com.facebook.buck.android.ApkGenruleDescriptionArg
-
- getEnableSandbox() - Method in class com.facebook.buck.cxx.CxxGenruleDescriptionArg
-
- getEnableSandbox() - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg
-
- getEnableSandbox() - Method in class com.facebook.buck.jvm.java.JarGenruleDescriptionArg
-
- getEnableSandbox() - Method in interface com.facebook.buck.shell.AbstractGenruleDescription.CommonArg
-
- getEnableSandbox() - Method in class com.facebook.buck.shell.GenruleDescriptionArg
-
- getEnableShowOutputWarning() - Method in class com.facebook.buck.support.cli.config.CliConfig
-
- getEnableTargetCompatibilityChecks() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getEnableWriteToCas() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getEndIndex() - Method in interface com.facebook.buck.core.macros.MacroMatchResult
-
- getEndpointExtraRequestArgs() - Method in class com.facebook.buck.doctor.config.DoctorConfig
-
- getEndpointExtraRequestHeaders() - Method in class com.facebook.buck.doctor.config.DoctorConfig
-
- getEndpointMessage() - Method in interface com.facebook.buck.doctor.config.DoctorEndpointRequest
-
- getEndpointTimeoutMs() - Method in class com.facebook.buck.doctor.config.DoctorConfig
-
- getEndpointTimeoutMs() - Method in class com.facebook.buck.support.build.report.BuildReportConfig
-
- getEndpointUrl() - Method in class com.facebook.buck.doctor.config.DoctorConfig
-
- getEndpointUrl() - Method in class com.facebook.buck.support.build.report.BuildReportConfig
-
- getEndTime() - Method in class com.facebook.buck.event.listener.util.EventInterval
-
- getEnforceBuckPackageBoundary() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getEntitlements() - Method in class com.facebook.buck.apple.toolchain.ProvisioningProfileMetadata
-
Key/value pairs of the "Entitlements" dictionary in the embedded plist.
- getEntitlementsFile() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getEntitlementsFile() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getEntitlementsFile() - Method in interface com.facebook.buck.apple.HasEntitlementsFile
-
- getEntries() - Method in class com.facebook.buck.support.cli.config.AliasConfig
-
- getEntriesForSection(String) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getEntriesToExclude() - Method in class com.facebook.buck.features.zip.rules.ZipFileDescriptionArg
-
- getEntriesToJar() - Method in class com.facebook.buck.jvm.java.JarParameters
-
- getEntry() - Method in class com.facebook.buck.features.js.JsBundleDescriptionArg
-
- getEntry() - Method in class com.facebook.buck.util.zip.JarEntrySupplier
-
- getEntryCount() - Method in class com.facebook.buck.android.resources.ResTableType
-
- getEntryCount() - Method in class com.facebook.buck.android.resources.ResTableTypeSpec
-
- getEntryName() - Method in interface com.facebook.buck.util.zip.collect.FileZipEntrySource
-
- getEntryName() - Method in interface com.facebook.buck.util.zip.collect.ZipEntrySource
-
The name of the destination entry.
- getEntryName() - Method in interface com.facebook.buck.util.zip.collect.ZipEntrySourceFromZip
-
The name of the entry
- getEntryOwner() - Method in class com.facebook.buck.util.zip.JarEntrySupplier
-
- getEntryPosition() - Method in interface com.facebook.buck.util.zip.collect.ZipEntrySourceFromZip
-
Position of the entry in the list of entries.
- getEntryValueOffset(int) - Method in class com.facebook.buck.android.resources.ResTableType
-
- getEnum(String, String, Class<T>) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getEnum(String, String, Class<T>) - Method in class com.facebook.buck.util.config.Config
-
- getEnv() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getEnv() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getEnv() - Method in class com.facebook.buck.core.test.rule.ExternalTestRunnerTestSpec
-
- getEnv(SourcePathResolverAdapter) - Method in class com.facebook.buck.cxx.CxxTest
-
- getEnv() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getEnv() - Method in class com.facebook.buck.features.go.GoTestDescriptionArg
-
- getEnv() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getEnv() - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg
-
- getEnv() - Method in interface com.facebook.buck.features.rust.RustCommonArgs
-
- getEnv() - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg
-
- getEnv() - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg
-
- getEnv() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getEnv() - Method in interface com.facebook.buck.jvm.java.JavaTestDescription.CoreArg
-
- getEnv() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getEnv() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getEnv() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getEnv() - Method in class com.facebook.buck.parser.api.BuildFileManifest
-
- getEnv() - Method in interface com.facebook.buck.parser.api.FileManifest
-
- getEnv() - Method in class com.facebook.buck.parser.api.PackageFileManifest
-
- getEnv() - Method in class com.facebook.buck.shell.CommandAliasDescriptionArg
-
- getEnv() - Method in class com.facebook.buck.shell.ShTest
-
- getEnv() - Method in class com.facebook.buck.shell.ShTestDescriptionArg
-
- getEnv() - Method in class com.facebook.buck.shell.WorkerToolDescriptionArg
-
- getEnv() - Method in class com.facebook.buck.step.AbstractTestStep
-
- getenv(String) - Method in class com.facebook.buck.util.environment.DefaultExecutionEnvironment
-
- getenv(String) - Method in interface com.facebook.buck.util.environment.ExecutionEnvironment
-
Gets the environment variable indicated by the specified key.
- getEnvironment() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getEnvironment() - Method in class com.facebook.buck.core.build.engine.BuildEngineBuildContext
-
- getEnvironment() - Method in class com.facebook.buck.core.build.execution.context.ExecutionContext
-
- getEnvironment() - Method in class com.facebook.buck.core.config.BuckConfig
-
- getEnvironment() - Method in class com.facebook.buck.core.rules.actions.ActionExecutionContext
-
- getEnvironment(SourcePathResolverAdapter) - Method in class com.facebook.buck.core.rules.tool.RunInfoLegacyTool
-
- getEnvironment(SourcePathResolverAdapter) - Method in class com.facebook.buck.core.toolchain.tool.DelegatingTool
-
- getEnvironment(SourcePathResolverAdapter) - Method in class com.facebook.buck.core.toolchain.tool.impl.CommandTool
-
- getEnvironment(SourcePathResolverAdapter) - Method in class com.facebook.buck.core.toolchain.tool.impl.HashedFileTool
-
- getEnvironment(SourcePathResolverAdapter) - Method in class com.facebook.buck.core.toolchain.tool.impl.VersionedTool
-
- getEnvironment(SourcePathResolverAdapter) - Method in interface com.facebook.buck.core.toolchain.tool.Tool
-
- getEnvironment() - Method in interface com.facebook.buck.core.toolchain.ToolchainCreationContext
-
- getEnvironment() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getEnvironment() - Method in class com.facebook.buck.features.python.toolchain.impl.LazyPythonPlatform
-
- getEnvironment(SourcePathResolverAdapter) - Method in class com.facebook.buck.features.python.toolchain.PythonEnvironment
-
- getEnvironment() - Method in interface com.facebook.buck.features.python.toolchain.PythonPlatform
-
- getEnvironment(SourcePathResolverAdapter) - Method in class com.facebook.buck.infer.InferDistTool
-
- getEnvironment(SourcePathResolverAdapter) - Method in class com.facebook.buck.jvm.groovy.Groovyc
-
- getEnvironment(SourcePathResolverAdapter) - Method in class com.facebook.buck.jvm.java.ExternalJavac
-
- getEnvironment() - Method in interface com.facebook.buck.jvm.java.JavacExecutionContext
-
- getEnvironment(SourcePathResolverAdapter) - Method in class com.facebook.buck.jvm.java.Jsr199Javac
-
- getEnvironment(SourcePathResolverAdapter) - Method in class com.facebook.buck.jvm.kotlin.ExternalKotlinc
-
- getEnvironment(SourcePathResolverAdapter) - Method in class com.facebook.buck.jvm.kotlin.JarBackedReflectedKotlinc
-
- getEnvironment() - Method in interface com.facebook.buck.remoteexecution.interfaces.Protocol.Command
-
- getEnvironment() - Method in class com.facebook.buck.rules.macros.WorkerMacroArg
-
- getEnvironment() - Method in class com.facebook.buck.skylark.parser.EnvironmentData
-
- getEnvironment() - Method in class com.facebook.buck.util.ProcessExecutorParams
-
If present, the map of environment variables used for the launched process.
- getEnvironmentExpansionSeparator() - Method in class com.facebook.buck.android.ApkGenruleDescriptionArg
-
- getEnvironmentExpansionSeparator() - Method in class com.facebook.buck.cxx.CxxGenruleDescriptionArg
-
- getEnvironmentExpansionSeparator() - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg
-
- getEnvironmentExpansionSeparator() - Method in class com.facebook.buck.jvm.java.JarGenruleDescriptionArg
-
- getEnvironmentExpansionSeparator() - Method in interface com.facebook.buck.shell.AbstractGenruleDescription.CommonArg
-
- getEnvironmentExpansionSeparator() - Method in class com.facebook.buck.shell.GenruleDescriptionArg
-
- getEnvironmentForProcess(ExecutionContext, WorkerProcessParams) - Method in class com.facebook.buck.worker.WorkerProcessPoolFactory
-
- getEnvironmentOverrides() - Method in class com.facebook.buck.test.TestRunningOptions
-
- getEnvironmentVariable(String) - Method in class com.facebook.buck.android.toolchain.common.BaseAndroidToolchainResolver
-
- getEnvironmentVariables(ExecutionContext) - Method in class com.facebook.buck.android.redex.ReDexStep
-
- getEnvironmentVariables(ExecutionContext) - Method in class com.facebook.buck.android.StripStep
-
- getEnvironmentVariables(ExecutionContext) - Method in class com.facebook.buck.apple.LibtoolStep
-
- getEnvironmentVariables() - Method in class com.facebook.buck.apple.xcode.XCScheme.LaunchAction
-
- getEnvironmentVariables() - Method in class com.facebook.buck.apple.xcode.XCScheme.ProfileAction
-
- getEnvironmentVariables() - Method in class com.facebook.buck.apple.xcode.XCScheme.TestAction
-
- getEnvironmentVariables() - Method in interface com.facebook.buck.core.rules.actions.lib.args.CommandLine
-
- getEnvironmentVariables() - Method in interface com.facebook.buck.core.rules.actions.lib.args.CommandLineArgs
-
- getEnvironmentVariables() - Method in class com.facebook.buck.core.rules.providers.lib.RunInfo
-
- getEnvironmentVariables() - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg
-
- getEnvironmentVariables(ExecutionContext) - Method in class com.facebook.buck.features.d.DCompileStep
-
- getEnvironmentVariables(ExecutionContext) - Method in class com.facebook.buck.features.go.CGoCompileStep
-
- getEnvironmentVariables(ExecutionContext) - Method in class com.facebook.buck.features.go.CGoGenerateImportStep
-
- getEnvironmentVariables(ExecutionContext) - Method in class com.facebook.buck.features.go.GoAssembleStep
-
- getEnvironmentVariables(ExecutionContext) - Method in class com.facebook.buck.features.go.GoCompileStep
-
- getEnvironmentVariables(ExecutionContext) - Method in class com.facebook.buck.features.go.GoLinkStep
-
- getEnvironmentVariables(ExecutionContext) - Method in class com.facebook.buck.features.go.GoListStep
-
- getEnvironmentVariables(ExecutionContext) - Method in class com.facebook.buck.features.go.GoPackStep
-
- getEnvironmentVariables(ExecutionContext) - Method in class com.facebook.buck.features.go.GoTestCoverStep
-
- getEnvironmentVariables(ExecutionContext) - Method in class com.facebook.buck.features.go.GoTestMainStep
-
- getEnvironmentVariables(ExecutionContext) - Method in class com.facebook.buck.features.halide.HalideCompilerStep
-
- getEnvironmentVariables(ExecutionContext) - Method in class com.facebook.buck.features.ocaml.OcamlCCompileStep
-
- getEnvironmentVariables(ExecutionContext) - Method in class com.facebook.buck.features.ocaml.OcamlLinkStep
-
- getEnvironmentVariables(ExecutionContext) - Method in class com.facebook.buck.features.ocaml.OcamlMLCompileStep
-
- getEnvironmentVariables(ExecutionContext) - Method in class com.facebook.buck.features.ocaml.OcamlNativePluginStep
-
- getEnvironmentVariables(ExecutionContext) - Method in class com.facebook.buck.features.python.PexStep
-
- getEnvironmentVariables(ExecutionContext) - Method in class com.facebook.buck.jvm.java.JUnitStep
-
- getEnvironmentVariables(ExecutionContext) - Method in class com.facebook.buck.jvm.scala.ScalacStep
-
- getEnvironmentVariables(ExecutionContext) - Method in class com.facebook.buck.shell.AbstractGenruleStep
-
- getEnvironmentVariables(ExecutionContext) - Method in class com.facebook.buck.shell.DefaultShellStep
-
- getEnvironmentVariables(ExecutionContext) - Method in class com.facebook.buck.shell.ShellStep
-
Returns the environment variables to include when running this
ShellStep
.
- getEnvironmentVariables() - Method in class com.facebook.buck.shell.WorkerShellStep
-
Returns the environment variables to use when expanding the job arguments that get sent to the
process.
- getEnvp() - Method in class com.facebook.buck.support.fix.BuckRunSpec
-
A mapping of environment variables that should be set when invoking the command
- getEnvVarFieldNameForField(String) - Static method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getEnvVarValue() - Method in enum com.facebook.buck.features.go.GoArch
-
Returns the environment variable to be used for GOARCH to Go tools.
- getEnvVarValue() - Method in enum com.facebook.buck.features.go.GoOs
-
Returns the environment variable to be used for GOOS to Go tools.
- getEnvVarValueForArm() - Method in enum com.facebook.buck.features.go.GoArch
-
Returns the environment variable to be used for GOARM to Go tools.
- getError() - Method in class com.facebook.buck.core.build.engine.manifest.ManifestLoadResult
-
- getError() - Method in class com.facebook.buck.event.CompilerErrorEvent
-
- getError() - Method in interface com.facebook.buck.event.external.events.CompilerErrorEventExternalInterface
-
- getErrorMessage() - Method in class com.facebook.buck.android.exopackage.RealAndroidDevice.ErrorParsingReceiver
-
- getErrorMessage() - Method in interface com.facebook.buck.artifact_cache.HttpArtifactCacheEvent.HttpArtifactCacheEventFetchData
-
- getErrorMessage() - Method in interface com.facebook.buck.artifact_cache.HttpArtifactCacheEvent.HttpArtifactCacheEventStoreData
-
- getErrorMessage() - Method in interface com.facebook.buck.doctor.config.DoctorEndpointResponse
-
- getErrorMessage() - Method in interface com.facebook.buck.doctor.config.DoctorJsonResponse
-
- getErrorMessage() - Method in class com.facebook.buck.log.ErrorLogRecord
-
- getErrorMessageAugmentations() - Method in class com.facebook.buck.core.exceptions.config.ErrorHandlingBuckConfig
-
List of error message replacements to make things more friendly for humans
- getErrorMessageFormat() - Method in class com.facebook.buck.artifact_cache.config.HttpCacheEntry
-
- getErrorMessageForUnknownField(String) - Method in class com.facebook.buck.core.rules.providers.impl.UserDefinedProviderInfo
-
- getErrorMessageForUnknownField(String) - Method in class com.facebook.buck.core.starlark.compatible.BuckStarlarkStructObject
-
- getErrorMessageForUnknownField(String) - Method in class com.facebook.buck.core.starlark.rule.SkylarkRuleContextAttr
-
- getErrorMessageLimit() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getErrorMessageLimit() - Method in class com.facebook.buck.artifact_cache.config.HttpCacheEntry
-
- getErrorPercentage(long, int) - Method in class com.facebook.buck.slb.ServerHealthState
-
- getErrorReport(SourcePathResolverAdapter, Path) - Method in interface com.facebook.buck.cxx.UntrackedHeaderReporter
-
- getErrors() - Method in class com.facebook.buck.apple.AppleAssetCatalogsCompilationOptions
-
- getErrors() - Method in class com.facebook.buck.core.model.targetgraph.raw.UnconfiguredTargetNodeWithDepsPackage
-
Errors that occurred parsing this package.
- getErrors() - Method in class com.facebook.buck.parser.api.BuildFileManifest
-
- getErrors() - Method in interface com.facebook.buck.parser.api.FileManifest
-
- getErrors() - Method in class com.facebook.buck.parser.api.PackageFileManifest
-
- getEscapedArgumentsListAsString(List<String>) - Static method in class com.facebook.buck.cli.AbstractQueryCommand
-
- getEstimate(InputStream) - Static method in class com.facebook.buck.android.dalvik.DalvikStatsTool
-
Estimates the footprint that a given class will have in the LinearAlloc buffer of Android's
Dalvik VM.
- getEstimatedAmounts() - Static method in class com.facebook.buck.util.concurrent.ResourceAmountsEstimator
-
- getEstimatedArgsCount() - Method in interface com.facebook.buck.core.rules.actions.lib.args.CommandLineArgs
-
- getEstimatedArgsCount() - Method in class com.facebook.buck.core.rules.providers.lib.RunInfo
-
- getEstimatedProgressOfCreatingActionGraph() - Method in class com.facebook.buck.event.listener.AbstractConsoleEventBusListener
-
- getEstimatedProgressOfCreatingActionGraph() - Method in class com.facebook.buck.event.listener.util.ProgressEstimator
-
- getEstimatedProgressOfGeneratingProjectFiles() - Method in class com.facebook.buck.event.listener.AbstractConsoleEventBusListener
-
- getEstimatedProgressOfGeneratingProjectFiles() - Method in class com.facebook.buck.event.listener.util.ProgressEstimator
-
- getEstimatedProgressOfParsingBuckFiles() - Method in class com.facebook.buck.event.listener.AbstractConsoleEventBusListener
-
- getEstimatedProgressOfParsingBuckFiles() - Method in class com.facebook.buck.event.listener.util.ProgressEstimator
-
- getEventBus() - Method in class com.facebook.buck.core.build.context.BuildContext
-
- getEventBus() - Method in class com.facebook.buck.core.build.engine.BuildEngineBuildContext
-
- getEventBus() - Method in class com.facebook.buck.core.rules.analysis.impl.RuleAnalysisContextImpl
-
- getEventBus() - Method in interface com.facebook.buck.core.rules.analysis.RuleAnalysisContext
-
- getEventHandler() - Method in class com.facebook.buck.skylark.packages.PackageContext
-
- getEventId() - Method in class com.facebook.buck.event.SimplePerfEvent
-
- getEventInfo() - Method in class com.facebook.buck.event.SimplePerfEvent
-
- getEventKey() - Method in class com.facebook.buck.event.AbstractBuckEvent
-
- getEventKey() - Method in interface com.facebook.buck.event.BuckEvent
-
- getEventListeners(Map<ExecutorPool, ListeningExecutorService>, ScheduledExecutorService) - Method in class com.facebook.buck.cli.AbstractCommand
-
- getEventListeners(Map<ExecutorPool, ListeningExecutorService>, ScheduledExecutorService) - Method in class com.facebook.buck.cli.AbstractContainerCommand
-
- getEventListeners(Map<ExecutorPool, ListeningExecutorService>, ScheduledExecutorService) - Method in class com.facebook.buck.cli.BuildCommand
-
- getEventListeners(Map<ExecutorPool, ListeningExecutorService>, ScheduledExecutorService) - Method in interface com.facebook.buck.cli.Command
-
If any of these listeners also extends Closeable, it will be closed by Main.
- getEventName() - Method in class com.facebook.buck.artifact_cache.ArtifactCacheConnectEvent.Finished
-
- getEventName() - Method in class com.facebook.buck.artifact_cache.ArtifactCacheConnectEvent.Started
-
- getEventName() - Method in class com.facebook.buck.artifact_cache.ArtifactCacheEvent
-
- getEventName() - Method in class com.facebook.buck.artifact_cache.CacheCountersSummaryEvent
-
- getEventName() - Method in class com.facebook.buck.artifact_cache.DirArtifactCacheEvent.Finished
-
- getEventName() - Method in class com.facebook.buck.artifact_cache.DirArtifactCacheEvent.Started
-
- getEventName() - Method in class com.facebook.buck.artifact_cache.HttpArtifactCacheEvent.Finished
-
- getEventName() - Method in class com.facebook.buck.artifact_cache.HttpArtifactCacheEvent.Scheduled
-
- getEventName() - Method in class com.facebook.buck.artifact_cache.HttpArtifactCacheEvent.Shutdown
-
- getEventName() - Method in class com.facebook.buck.artifact_cache.HttpArtifactCacheEvent.Started
-
- getEventName() - Method in class com.facebook.buck.artifact_cache.RuleKeyCacheResultEvent
-
- getEventName() - Method in class com.facebook.buck.artifact_cache.SQLiteArtifactCacheEvent.Finished
-
- getEventName() - Method in class com.facebook.buck.artifact_cache.SQLiteArtifactCacheEvent.Started
-
- getEventName() - Method in class com.facebook.buck.core.build.event.BuildEvent.BuildReport
-
- getEventName() - Method in class com.facebook.buck.core.build.event.BuildEvent.Finished
-
- getEventName() - Method in class com.facebook.buck.core.build.event.BuildEvent.RuleCountCalculated
-
- getEventName() - Method in class com.facebook.buck.core.build.event.BuildEvent.Started
-
- getEventName() - Method in class com.facebook.buck.core.build.event.BuildEvent.UnskippedRuleCountUpdated
-
- getEventName() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent
-
- getEventName() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.WillBuildLocally
-
- getEventName() - Method in class com.facebook.buck.core.build.event.BuildRuleExecutionEvent.Event
-
- getEventName() - Method in class com.facebook.buck.core.build.event.FinalizingBuildRuleEvent
-
- getEventName() - Method in class com.facebook.buck.core.test.event.IndividualTestEvent.Finished
-
- getEventName() - Method in class com.facebook.buck.core.test.event.IndividualTestEvent.Started
-
- getEventName() - Method in class com.facebook.buck.core.test.event.TestRunEvent.Finished
-
- getEventName() - Method in class com.facebook.buck.core.test.event.TestRunEvent.Started
-
- getEventName() - Method in class com.facebook.buck.core.test.event.TestStatusMessageEvent.Finished
-
- getEventName() - Method in class com.facebook.buck.core.test.event.TestStatusMessageEvent.Started
-
- getEventName() - Method in class com.facebook.buck.core.test.event.TestSummaryEvent.Finished
-
- getEventName() - Method in class com.facebook.buck.core.test.event.TestSummaryEvent.Started
-
- getEventName() - Method in class com.facebook.buck.counters.CounterRegistry.AsyncCounterRegistrationEvent
-
- getEventName() - Method in class com.facebook.buck.counters.CountersSnapshotEvent
-
- getEventName() - Method in class com.facebook.buck.event.ActionGraphEvent.Cache
-
- getEventName() - Method in class com.facebook.buck.event.ActionGraphEvent.Finished
-
- getEventName() - Method in class com.facebook.buck.event.ActionGraphEvent.IncrementalLoad
-
- getEventName() - Method in class com.facebook.buck.event.ActionGraphEvent.Started
-
- getEventName() - Method in class com.facebook.buck.event.ActionGraphPerfStatEvent
-
- getEventName() - Method in class com.facebook.buck.event.ArtifactCompressionEvent.Finished
-
- getEventName() - Method in class com.facebook.buck.event.ArtifactCompressionEvent.Started
-
- getEventName() - Method in class com.facebook.buck.event.BuckInitializationDurationEvent
-
- getEventName() - Method in class com.facebook.buck.event.CacheStatsEvent
-
- getEventName() - Method in class com.facebook.buck.event.CommandEvent.Finished
-
- getEventName() - Method in class com.facebook.buck.event.CommandEvent.Interrupted
-
- getEventName() - Method in class com.facebook.buck.event.CommandEvent.Started
-
- getEventName() - Method in class com.facebook.buck.event.CompilerErrorEvent
-
- getEventName() - Method in class com.facebook.buck.event.CompilerPluginDurationEvent.Finished
-
- getEventName() - Method in class com.facebook.buck.event.CompilerPluginDurationEvent.Started
-
- getEventName() - Method in class com.facebook.buck.event.ConsoleEvent
-
- getEventName() - Method in class com.facebook.buck.event.DaemonEvent
-
- getEventName() - Method in class com.facebook.buck.event.ExperimentEvent
-
- getEventName() - Method in interface com.facebook.buck.event.external.events.BuckEventExternalInterface
-
- getEventName() - Method in class com.facebook.buck.event.FileHashCacheEvent
-
- getEventName() - Method in class com.facebook.buck.event.FileHashCacheEvent.InvalidationFinished
-
- getEventName() - Method in class com.facebook.buck.event.FileHashCacheEvent.InvalidationStarted
-
- getEventName() - Method in class com.facebook.buck.event.FlushConsoleEvent
-
- getEventName() - Method in class com.facebook.buck.event.InstallEvent.Finished
-
- getEventName() - Method in class com.facebook.buck.event.InstallEvent.Started
-
- getEventName() - Method in class com.facebook.buck.event.LeafEvents.SimpleLeafEvent
-
- getEventName() - Method in class com.facebook.buck.event.listener.PerfTimesEventListener.PerfTimesEvent
-
- getEventName() - Method in class com.facebook.buck.event.listener.stats.cache.CacheRateStatsKeeper.CacheRateStatsUpdateEvent
-
- getEventName() - Method in class com.facebook.buck.event.NetworkEvent.BytesReceivedEvent
-
- getEventName() - Method in class com.facebook.buck.event.ParsingEvent
-
- getEventName() - Method in class com.facebook.buck.event.ProgressEvent.BuildProgressUpdated
-
- getEventName() - Method in class com.facebook.buck.event.ProgressEvent.ParsingProgressUpdated
-
- getEventName() - Method in class com.facebook.buck.event.ProgressEvent.ProjectGenerationProgressUpdated
-
- getEventName() - Method in class com.facebook.buck.event.ProjectGenerationEvent.Finished
-
- getEventName() - Method in class com.facebook.buck.event.ProjectGenerationEvent.Processed
-
- getEventName() - Method in class com.facebook.buck.event.ProjectGenerationEvent.Started
-
- getEventName() - Method in class com.facebook.buck.event.RuleKeyCalculationEvent.Event
-
- getEventName() - Method in class com.facebook.buck.event.StartActivityEvent.Finished
-
- getEventName() - Method in class com.facebook.buck.event.StartActivityEvent.Started
-
- getEventName() - Method in class com.facebook.buck.event.UninstallEvent.Finished
-
- getEventName() - Method in class com.facebook.buck.event.UninstallEvent.Started
-
- getEventName() - Method in class com.facebook.buck.event.WatchmanStatusEvent
-
- getEventName() - Method in class com.facebook.buck.file.downloader.impl.DownloadEvent.Finished
-
- getEventName() - Method in class com.facebook.buck.file.downloader.impl.DownloadEvent.Started
-
- getEventName() - Method in class com.facebook.buck.file.downloader.impl.DownloadProgressEvent
-
- getEventName() - Method in class com.facebook.buck.io.watchman.WatchmanDiagnosticEvent
-
- getEventName() - Method in class com.facebook.buck.json.ProjectBuildFileParseEvents.Finished
-
- getEventName() - Method in class com.facebook.buck.json.ProjectBuildFileParseEvents.Started
-
- getEventName() - Method in class com.facebook.buck.jvm.java.AnnotationProcessingEvent.Finished
-
- getEventName() - Method in class com.facebook.buck.jvm.java.AnnotationProcessingEvent.Started
-
- getEventName() - Method in class com.facebook.buck.jvm.java.tracing.JavacPhaseEvent.Finished
-
- getEventName() - Method in class com.facebook.buck.jvm.java.tracing.JavacPhaseEvent.Started
-
- getEventName() - Method in class com.facebook.buck.parser.events.ParseBuckFileEvent.Finished
-
- getEventName() - Method in class com.facebook.buck.parser.events.ParseBuckFileEvent.Started
-
- getEventName() - Method in class com.facebook.buck.parser.events.ParseBuckProfilerReportEvent
-
- getEventName() - Method in class com.facebook.buck.parser.ParseEvent.Finished
-
- getEventName() - Method in class com.facebook.buck.parser.ParseEvent.Started
-
- getEventName() - Method in class com.facebook.buck.remoteexecution.event.CasBlobDownloadEvent
-
- getEventName() - Method in class com.facebook.buck.remoteexecution.event.CasBlobUploadEvent
-
- getEventName() - Method in class com.facebook.buck.remoteexecution.event.LocalFallbackEvent
-
- getEventName() - Method in class com.facebook.buck.remoteexecution.event.RemoteBuildRuleExecutionEvent
-
- getEventName() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent
-
- getEventName() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionSessionEvent.Finished
-
- getEventName() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionSessionEvent.Started
-
- getEventName() - Method in class com.facebook.buck.rules.modern.builders.HybridLocalEvent
-
- getEventName() - Method in class com.facebook.buck.slb.LoadBalancedServiceEvent
-
- getEventName() - Method in class com.facebook.buck.slb.LoadBalancerPingEvent
-
- getEventName() - Method in class com.facebook.buck.slb.ServerHealthManagerEvent
-
- getEventName() - Method in class com.facebook.buck.step.StepEvent.Finished
-
- getEventName() - Method in class com.facebook.buck.step.StepEvent.Started
-
- getEventName() - Method in class com.facebook.buck.support.jvm.GCMajorCollectionEvent
-
- getEventName() - Method in class com.facebook.buck.support.jvm.GCMinorCollectionEvent
-
- getEventName() - Method in class com.facebook.buck.test.external.ExternalTestRunEvent.Finished
-
- getEventName() - Method in class com.facebook.buck.test.external.ExternalTestRunEvent.Started
-
- getEventName() - Method in class com.facebook.buck.test.external.ExternalTestSpecCalculationEvent.Finished
-
- getEventName() - Method in class com.facebook.buck.test.external.ExternalTestSpecCalculationEvent.Started
-
- getEventName() - Method in class com.facebook.buck.test.TestRuleEvent.Finished
-
- getEventName() - Method in class com.facebook.buck.test.TestRuleEvent.Started
-
- getEventName() - Method in class com.facebook.buck.util.environment.NetworkInfo.Event
-
- getEventName() - Method in class com.facebook.buck.util.perf.PerfStatsTracking.PerfStatsEvent
-
- getEventName() - Method in class com.facebook.buck.util.perf.ProcessTracker.ProcessResourceConsumptionEvent
-
- getEventName() - Method in class com.facebook.buck.util.versioncontrol.FastVersionControlStatsEvent
-
- getEventName() - Method in class com.facebook.buck.util.versioncontrol.VersionControlStatsEvent
-
- getEventName() - Method in class com.facebook.buck.versions.VersionedTargetGraphEvent.Cache
-
- getEventName() - Method in class com.facebook.buck.versions.VersionedTargetGraphEvent.Finished
-
- getEventName() - Method in class com.facebook.buck.versions.VersionedTargetGraphEvent.Started
-
- getEventName() - Method in class com.facebook.buck.versions.VersionedTargetGraphEvent.Timeout
-
- getEventNanoTime() - Method in interface com.facebook.buck.event.listener.CriticalPathReportableNode
-
- getEvents() - Method in class com.facebook.buck.event.listener.ScribeEventListenerConfig
-
- getEventsBetween(long, long, Iterable<EventInterval>) - Static method in class com.facebook.buck.event.listener.AbstractConsoleEventBusListener
-
Filter a list of events and return the subset that fall between the given start and end
timestamps.
- getEventSink() - Method in interface com.facebook.buck.jvm.java.JavacExecutionContext
-
- getEventsOutputPath() - Method in class com.facebook.buck.cli.AbstractCommand
-
- getEventType() - Method in class com.facebook.buck.event.SimplePerfEvent
-
- getEvictionCount() - Method in class com.facebook.buck.util.cache.CacheStats
-
- getExactOptional(BuildTarget) - Method in class com.facebook.buck.core.model.targetgraph.TargetGraph
-
Returns the target node for the exact given target, if it exists in the graph.
- getException() - Method in interface com.facebook.buck.core.rules.actions.ActionExecutionResult.ActionExecutionFailure
-
- getException() - Method in interface com.facebook.buck.slb.LoadBalancedServiceEvent.LoadBalancedServiceEventData
-
- getException() - Method in interface com.facebook.buck.slb.LoadBalancerPingEvent.PerServerPingData
-
- getExclude() - Method in class com.facebook.buck.skylark.io.GlobSpec
-
Wildcards of paths that should be skipped from the glob expansion.
- getExcludeDirectories() - Method in class com.facebook.buck.skylark.io.GlobSpec
-
Whether directories should be excluded from the glob expansion.
- getExcludedResourcePaths() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getExcludedRoots() - Method in class com.facebook.buck.cxx.OmnibusRoots
-
- getExcludeIncompatibleTargets() - Method in class com.facebook.buck.cli.AbstractCommand
-
- getExcludeIncompatibleTargets() - Method in class com.facebook.buck.cli.UnconfiguredQueryCommand
-
- getExcludes() - Method in class com.facebook.buck.features.project.intellij.aggregation.AggregationModule
-
A set of paths that need to be excluded from the final
IjModule
.
- getExcludeTestPatterns() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getExe() - Method in class com.facebook.buck.shell.CommandAliasDescriptionArg
-
- getExe() - Method in class com.facebook.buck.shell.WorkerToolDescriptionArg
-
- getExecutable() - Method in class com.facebook.buck.file.HttpFileDescriptionArg
-
- getExecutable(Path, ImmutableMap<String, String>) - Method in class com.facebook.buck.io.ExecutableFinder
-
- getExecutable() - Method in class com.facebook.buck.shell.GenruleDescriptionArg
-
- getExecutableCommand(OutputLabel) - Method in class com.facebook.buck.apple.AppleBundle
-
- getExecutableCommand(OutputLabel) - Method in interface com.facebook.buck.core.rules.tool.BinaryBuildRule
-
Command to execute the output of this rule.
- getExecutableCommand(OutputLabel) - Method in class com.facebook.buck.core.rules.tool.RuleAnalysisLegacyBinaryBuildRuleView
-
- getExecutableCommand(OutputLabel) - Method in class com.facebook.buck.cxx.CxxBinary
-
- getExecutableCommand(OutputLabel) - Method in class com.facebook.buck.cxx.CxxTest
-
- getExecutableCommand(OutputLabel) - Method in class com.facebook.buck.features.d.DBinary
-
- getExecutableCommand(OutputLabel) - Method in class com.facebook.buck.features.go.GoBinary
-
- getExecutableCommand(OutputLabel) - Method in class com.facebook.buck.features.go.GoTest
-
- getExecutableCommand(OutputLabel) - Method in class com.facebook.buck.features.go.GoTestX
-
- getExecutableCommand(OutputLabel) - Method in class com.facebook.buck.features.haskell.HaskellBinary
-
- getExecutableCommand(OutputLabel) - Method in class com.facebook.buck.features.haskell.HaskellGhciRule
-
- getExecutableCommand(OutputLabel) - Method in class com.facebook.buck.features.lua.LuaBinary
-
- getExecutableCommand(OutputLabel) - Method in class com.facebook.buck.features.ocaml.OcamlBinary
-
- getExecutableCommand(OutputLabel) - Method in class com.facebook.buck.features.python.PythonInPlaceBinary
-
- getExecutableCommand(OutputLabel) - Method in class com.facebook.buck.features.python.PythonPackagedBinary
-
- getExecutableCommand(OutputLabel) - Method in class com.facebook.buck.features.python.PythonTest
-
- getExecutableCommand(OutputLabel) - Method in class com.facebook.buck.features.rust.RustTest
-
- getExecutableCommand(OutputLabel) - Method in class com.facebook.buck.file.HttpFileBinary
-
- getExecutableCommand(OutputLabel) - Method in class com.facebook.buck.file.RemoteFileBinary
-
- getExecutableCommand(OutputLabel) - Method in class com.facebook.buck.jvm.java.JarFattener
-
- getExecutableCommand(OutputLabel) - Method in class com.facebook.buck.jvm.java.JarGenrule
-
- getExecutableCommand(OutputLabel) - Method in class com.facebook.buck.jvm.java.JavaBinary
-
- getExecutableCommand(OutputLabel) - Method in class com.facebook.buck.shell.CommandAlias
-
- getExecutableCommand(OutputLabel) - Method in class com.facebook.buck.shell.GenruleBinary
-
- getExecutableCommand(OutputLabel) - Method in class com.facebook.buck.shell.ShBinary
-
- getExecutableCommand(OutputLabel) - Method in class com.facebook.buck.shell.ShTest
-
- getExecutableFinder() - Method in class com.facebook.buck.android.toolchain.ndk.AndroidNdk
-
- getExecutableFinder() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getExecutableFinder() - Method in interface com.facebook.buck.core.toolchain.ToolchainCreationContext
-
- getExecutableName() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getExecutableName() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getExecutableName() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getExecutableName() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getExecutableName() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
- getExecutableName() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getExecutableName() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getExecutableName() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getExecutableName() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getExecutableName() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getExecutableName() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getExecutableName() - Method in class com.facebook.buck.util.perf.ProcessTracker.ProcessResourceConsumptionEvent
-
- getExecutableSuffixes(Platform, ImmutableMap<String, String>) - Static method in class com.facebook.buck.io.ExecutableFinder
-
- getExecutedActionMetadata() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.Terminal
-
- getExecutedCommand() - Method in interface com.facebook.buck.step.StepExecutionResult
-
- getExecutionContext() - Method in class com.facebook.buck.cli.AbstractCommand
-
- getExecutionContext() - Method in class com.facebook.buck.command.Build
-
- getExecutionContext() - Method in interface com.facebook.buck.core.build.engine.BuildStrategyContext
-
- getExecutionContext() - Method in class com.facebook.buck.core.build.engine.DelegatingBuildStrategyContext
-
- getExecutionContextBuilder(CommandRunnerParams) - Method in class com.facebook.buck.cli.AbstractCommand
-
- getExecutionContextBuilder(CommandRunnerParams) - Method in class com.facebook.buck.cli.BuildCommand
-
- getExecutionContextBuilder(CommandRunnerParams) - Method in class com.facebook.buck.cli.InstallCommand
-
- getExecutionContextBuilder(CommandRunnerParams) - Method in class com.facebook.buck.cli.TestCommand
-
- getExecutionContextBuilder(CommandRunnerParams) - Method in class com.facebook.buck.cli.UninstallCommand
-
- getExecutionDurationMs() - Method in class com.facebook.buck.remoteexecution.event.RemoteBuildRuleExecutionEvent
-
- getExecutionStarted() - Method in interface com.facebook.buck.remoteexecution.RemoteExecutionServiceClient.ExecutionHandle
-
- getExecutor() - Method in class com.facebook.buck.parser.ParsingContext
-
An executor used during parsing request to perform async computations
- getExecutor() - Method in class com.facebook.buck.remoteexecution.grpc.retry.RetryPolicy
-
- getExecutor() - Method in class com.facebook.buck.slb.HybridThriftOverHttpServiceImplArgs
-
- getExecutorCollectionLabel() - Method in class com.facebook.buck.event.listener.BuildThreadStateRenderer
-
- getExecutorCollectionLabel() - Method in interface com.facebook.buck.event.listener.MultiStateRenderer
-
- getExecutorCollectionLabel() - Method in class com.facebook.buck.event.listener.RemoteExecutionStateRenderer
-
- getExecutorCollectionLabel() - Method in class com.facebook.buck.event.listener.TestThreadStateRenderer
-
- getExecutorCount() - Method in class com.facebook.buck.event.listener.BuildThreadStateRenderer
-
- getExecutorCount() - Method in interface com.facebook.buck.event.listener.MultiStateRenderer
-
- getExecutorCount() - Method in class com.facebook.buck.event.listener.RemoteExecutionStateRenderer
-
- getExecutorCount() - Method in class com.facebook.buck.event.listener.TestThreadStateRenderer
-
- getExecutors() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getExecutors() - Method in class com.facebook.buck.command.BuildExecutorArgs
-
- getExecutors() - Method in class com.facebook.buck.core.build.execution.context.ExecutionContext
-
- getExecutorService() - Method in class com.facebook.buck.cli.CommandThreadManager
-
- getExecutorService() - Method in interface com.facebook.buck.core.build.engine.BuildStrategyContext
-
- getExecutorService() - Method in class com.facebook.buck.core.build.engine.DelegatingBuildStrategyContext
-
- getExecutorType() - Method in class com.facebook.buck.core.graph.transformation.executor.config.DepsAwareExecutorConfig
-
- getExistenceOfInterestPredicate(SourcePathResolverAdapter) - Method in interface com.facebook.buck.core.rules.attr.SupportsDependencyFileRuleKey
-
Returns a predicate that can tell whether the existence of a given path may be of interest to
compiler.
- getExistenceOfInterestPredicate(SourcePathResolverAdapter) - Method in class com.facebook.buck.cxx.CxxPreprocessAndCompile
-
- getExistenceOfInterestPredicate(SourcePathResolverAdapter) - Method in class com.facebook.buck.jvm.java.CalculateSourceAbi
-
- getExistenceOfInterestPredicate(SourcePathResolverAdapter) - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getExistenceOfInterestPredicate() - Method in class com.facebook.buck.jvm.java.JarBuildStepsFactory
-
- getExistingFile() - Method in class com.facebook.buck.step.fs.SymlinkFileStep
-
- getExitCode() - Method in class com.facebook.buck.core.build.event.BuildEvent.Finished
-
- getExitCode() - Method in interface com.facebook.buck.doctor.config.BuildLogEntry
-
- getExitCode() - Method in class com.facebook.buck.event.CommandEvent.Finished
-
- getExitCode() - Method in class com.facebook.buck.event.CommandEvent.Interrupted
-
- getExitCode() - Method in class com.facebook.buck.remoteexecution.event.LocalFallbackEvent.Finished
-
- getExitCode() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.Terminal
-
- getExitCode() - Method in interface com.facebook.buck.remoteexecution.RemoteExecutionServiceClient.ExecutionResult
-
- getExitCode() - Method in class com.facebook.buck.step.StepEvent.Finished
-
- getExitCode() - Method in interface com.facebook.buck.step.StepExecutionResult
-
- getExitCode() - Method in exception com.facebook.buck.step.StepFailedException
-
- getExitCode() - Method in class com.facebook.buck.support.fix.BuckFixSpec
-
The exit code of the command
- getExitCode() - Method in class com.facebook.buck.test.external.ExternalTestRunEvent.Finished
-
- getExitCode() - Method in class com.facebook.buck.util.ProcessExecutor.Result
-
- getExitCode() - Method in interface com.facebook.buck.worker.WorkerJobResult
-
- getExitCode() - Method in class com.facebook.buck.worker.WorkerProcessProtocol.CommandResponse
-
- getExitCodeFromResult(ExecutionContext, ProcessExecutor.Result) - Method in class com.facebook.buck.jvm.java.JUnitStep
-
- getExitCodeFromResult(ExecutionContext, ProcessExecutor.Result) - Method in class com.facebook.buck.shell.ShellStep
-
- getExopackageInfo() - Method in class com.facebook.buck.android.HasInstallableApk.ApkInfo
-
- getExopackageModes() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getExopackageModes() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getExopackageModes() - Method in interface com.facebook.buck.android.HasExopackageArgs
-
- getExpandedArgs() - Method in class com.facebook.buck.support.fix.BuckFixSpec
-
The fully evaluated arguments to this buck invocation.
- getExpandedCommandArgs() - Method in interface com.facebook.buck.doctor.config.BuildLogEntry
-
- getExpandedSourcePaths(ProjectFilesystem, ProjectFilesystemFactory, ImmutableSet<Path>, Optional<Path>) - Method in interface com.facebook.buck.jvm.kotlin.Kotlinc
-
- getExpanders() - Method in class com.facebook.buck.rules.macros.StringWithMacrosConverter
-
- getExpandVariablesBasedOn() - Method in class com.facebook.buck.apple.xcode.XCScheme.LaunchAction
-
- getExpandVariablesBasedOn() - Method in class com.facebook.buck.apple.xcode.XCScheme.ProfileAction
-
- getExpandVariablesBasedOn() - Method in class com.facebook.buck.apple.xcode.XCScheme.TestAction
-
- getExpandVariablesBasedOn() - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg
-
- getExpectedHashCode() - Method in class com.facebook.buck.artifact_cache.HttpArtifactCacheBinaryProtocol.MetadataAndPayloadReadResult
-
- getExperimentalArgs() - Method in class com.facebook.buck.features.gwt.GwtBinaryDescriptionArg
-
In practice, these may be values such as -XenableClosureCompiler
, -XdisableClassMetadata
, -XdisableCastChecking
, or -XfragmentMerge
.
- getExperimentGroups(String, String, Class<T>) - Method in class com.facebook.buck.core.config.BuckConfig
-
Returns the probabilities for each group in an experiment.
- getExpirationDate() - Method in class com.facebook.buck.apple.toolchain.ProvisioningProfileMetadata
-
- getExplanation() - Method in class com.facebook.buck.test.selectors.PatternTestSelector
-
- getExplanation() - Method in class com.facebook.buck.test.selectors.SimpleTestSelector
-
- getExplanation() - Method in interface com.facebook.buck.test.selectors.TestSelector
-
- getExplanation() - Method in class com.facebook.buck.test.selectors.TestSelectorList
-
- getExplicitFileType() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXFileReference
-
- getExplicitRunnablePath() - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg
-
- getExportedCompilerFlags() - Method in class com.facebook.buck.features.haskell.HaskellPrebuiltLibraryDescriptionArg
-
- getExportedCxxDeps() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getExportedCxxDeps() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getExportedCxxDeps() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getExportedCxxDeps() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
- getExportedCxxDeps() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getExportedCxxDeps() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getExportedDeps() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getExportedDeps() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getExportedDeps() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getExportedDeps() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getExportedDeps() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getExportedDeps() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getExportedDeps() - Method in interface com.facebook.buck.core.rules.attr.ExportDependencies
-
- getExportedDeps() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
- getExportedDeps() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getExportedDeps() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getExportedDeps() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescriptionArg
-
- getExportedDeps() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getExportedDeps() - Method in class com.facebook.buck.features.go.GoLibraryDescriptionArg
-
- getExportedDeps() - Method in class com.facebook.buck.features.go.PrebuiltGoLibraryDescriptionArg
-
- getExportedDeps() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getExportedDeps() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getExportedDeps() - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getExportedDeps() - Method in class com.facebook.buck.jvm.java.JavaLibraryDeps
-
- getExportedDeps() - Method in interface com.facebook.buck.jvm.java.JavaLibraryDescription.CoreArg
-
- getExportedDeps() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getExportedDeps() - Method in class com.facebook.buck.jvm.java.JavaTest
-
- getExportedDeps() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getExportedDeps() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getExportedDeps() - Method in class com.facebook.buck.jvm.java.JavaTestX
-
- getExportedDeps() - Method in class com.facebook.buck.jvm.java.PrebuiltJar
-
- getExportedDeps() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getExportedDeps() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getExportedDeps() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getExportedDeps() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getExportedDepsClosure(BuildTarget) - Method in class com.facebook.buck.features.project.intellij.ExportedDepsClosureResolver
-
- getExportedHeaders() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getExportedHeaders() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getExportedHeaders() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getExportedHeaders() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
- getExportedHeaders() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getExportedHeaders() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getExportedHeaderStyle() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getExportedHeaderStyle() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getExportedHeaderStyle() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getExportedHeaderStyle() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
- getExportedHeaderStyle() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getExportedLangPlatformPreprocessorFlags() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getExportedLangPlatformPreprocessorFlags() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getExportedLangPlatformPreprocessorFlags() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getExportedLangPlatformPreprocessorFlags() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
- getExportedLangPlatformPreprocessorFlags() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getExportedLangPlatformPreprocessorFlags() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getExportedLangPreprocessorFlags() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getExportedLangPreprocessorFlags() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getExportedLangPreprocessorFlags() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getExportedLangPreprocessorFlags() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
- getExportedLangPreprocessorFlags() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getExportedLangPreprocessorFlags() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getExportedLinkerFlags() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getExportedLinkerFlags() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getExportedLinkerFlags() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getExportedLinkerFlags() - Method in class com.facebook.buck.apple.PrebuiltAppleFrameworkDescriptionArg
-
- getExportedLinkerFlags() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
- getExportedLinkerFlags() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getExportedLinkerFlags(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.cxx.CxxLibraryGroup
-
- getExportedLinkerFlags() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getExportedLinkerFlags(CxxPlatform, ActionGraphBuilder) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.LegacyNativeLinkableGroup
-
Deprecated.
- getExportedLinkerFlags(ActionGraphBuilder) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.NativeLinkable
-
- getExportedLinkerFlags(ActionGraphBuilder) - Method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableInfo
-
- getExportedLinkerFlags(ActionGraphBuilder) - Method in class com.facebook.buck.cxx.toolchain.nativelink.PlatformLockedNativeLinkableGroup
-
- getExportedLinkerFlags() - Method in class com.facebook.buck.features.haskell.HaskellPrebuiltLibraryDescriptionArg
-
- getExportedName() - Method in class com.facebook.buck.core.starlark.rule.SkylarkUserDefinedRule
-
Get the exported name of the function within an extension file.
- getExportedPlatformDeps() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getExportedPlatformDeps() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getExportedPlatformDeps() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getExportedPlatformDeps() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
- getExportedPlatformDeps() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getExportedPlatformDeps() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getExportedPlatformDeps() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescriptionArg
-
- getExportedPlatformHeaders() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getExportedPlatformHeaders() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getExportedPlatformHeaders() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getExportedPlatformHeaders() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
- getExportedPlatformHeaders() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getExportedPlatformHeaders() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getExportedPlatformLinkerFlags() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getExportedPlatformLinkerFlags() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getExportedPlatformLinkerFlags() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getExportedPlatformLinkerFlags() - Method in class com.facebook.buck.apple.PrebuiltAppleFrameworkDescriptionArg
-
- getExportedPlatformLinkerFlags() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
- getExportedPlatformLinkerFlags() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getExportedPlatformLinkerFlags() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getExportedPlatformPreprocessorFlags() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getExportedPlatformPreprocessorFlags() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getExportedPlatformPreprocessorFlags() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getExportedPlatformPreprocessorFlags() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
- getExportedPlatformPreprocessorFlags() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getExportedPlatformPreprocessorFlags() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getExportedPostLinkerFlags() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getExportedPostLinkerFlags() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getExportedPostLinkerFlags() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getExportedPostLinkerFlags() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
- getExportedPostLinkerFlags() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getExportedPostLinkerFlags(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.cxx.CxxLibraryGroup
-
- getExportedPostLinkerFlags() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getExportedPostLinkerFlags(CxxPlatform, ActionGraphBuilder) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.LegacyNativeLinkableGroup
-
Deprecated.
- getExportedPostLinkerFlags(ActionGraphBuilder) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.NativeLinkable
-
- getExportedPostLinkerFlags(ActionGraphBuilder) - Method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableInfo
-
- getExportedPostLinkerFlags(ActionGraphBuilder) - Method in class com.facebook.buck.cxx.toolchain.nativelink.PlatformLockedNativeLinkableGroup
-
- getExportedPostPlatformLinkerFlags() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getExportedPostPlatformLinkerFlags() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getExportedPostPlatformLinkerFlags() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getExportedPostPlatformLinkerFlags() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
- getExportedPostPlatformLinkerFlags() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getExportedPostPlatformLinkerFlags() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getExportedPreprocessorFlags() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getExportedPreprocessorFlags() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getExportedPreprocessorFlags() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getExportedPreprocessorFlags() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
- getExportedPreprocessorFlags() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getExportedPreprocessorFlags() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getExportedPreprocessorFlags() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescriptionArg
-
- getExportedProvidedDeps() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getExportedProvidedDeps() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getExportedProvidedDeps() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getExportedProvidedDeps() - Method in interface com.facebook.buck.core.description.arg.HasProvidedDeps
-
- getExportedProvidedDeps() - Method in interface com.facebook.buck.core.rules.attr.ExportDependencies
-
- getExportedProvidedDeps() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getExportedProvidedDeps() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getExportedProvidedDeps() - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getExportedProvidedDeps() - Method in class com.facebook.buck.jvm.java.JavaLibraryDeps
-
- getExportedProvidedDeps() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getExportedProvidedDeps() - Method in class com.facebook.buck.jvm.java.JavaTest
-
- getExportedProvidedDeps() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getExportedProvidedDeps() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getExportedProvidedDeps() - Method in class com.facebook.buck.jvm.java.JavaTestX
-
- getExportedProvidedDeps() - Method in class com.facebook.buck.jvm.java.PrebuiltJar
-
- getExportedProvidedDeps() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getExportedProvidedDeps() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getExportedProvidedDeps() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getExportedProvidedDeps() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getExportedRules(Iterable<? extends BuildRule>) - Static method in class com.facebook.buck.core.rules.common.BuildRules
-
- getExportedSymbolsFromString(String) - Method in class com.facebook.buck.jvm.java.JavaFileParser
-
- getExportHeader() - Method in class com.facebook.buck.features.go.CGoGenSource
-
- getExportInfo() - Method in class com.facebook.buck.cxx.toolchain.objectfile.MachoExportTrieNode
-
- getExportInfoOffset() - Method in class com.facebook.buck.cxx.toolchain.objectfile.MachoDyldInfoCommand
-
- getExportInfoSize() - Method in class com.facebook.buck.cxx.toolchain.objectfile.MachoDyldInfoCommand
-
- getExpression() - Method in class com.facebook.buck.query.QueryEnvironment.Argument
-
- getExpressionToEval(ImmutableList<QueryEnvironment.Argument<NODE_TYPE>>) - Method in class com.facebook.buck.query.FilterFunction
-
- getExpressionToEval(ImmutableList<QueryEnvironment.Argument<T>>) - Method in class com.facebook.buck.query.KindFunction
-
- getExtension() - Method in class com.facebook.buck.apple.AppleBundle
-
- getExtension() - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg
-
- getExtension() - Method in interface com.facebook.buck.apple.HasAppleBundleFields
-
- getExtension() - Method in class com.facebook.buck.core.artifact.SourceArtifactImpl
-
- getExtension() - Method in interface com.facebook.buck.core.starlark.rule.artifact.SkylarkArtifactApi
-
- getExtension(CxxPlatform) - Method in class com.facebook.buck.features.lua.CxxLuaExtension
-
- getExtension() - Method in class com.facebook.buck.features.lua.LuaPlatform
-
- getExtension(PythonPlatform, CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.features.python.CxxPythonExtension
-
- getExtension() - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg
-
- getExtension() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getExtension() - Method in enum com.facebook.buck.util.unarchive.ArchiveFormat
-
Get the extension (including '.') for this archive type
- getExtensions(Class<T>) - Method in class com.facebook.buck.core.plugin.impl.DefaultBuckPluginManager
-
- getExtensions() - Method in enum com.facebook.buck.cxx.CxxSource.Type
-
- getExternalAttributes() - Method in class com.facebook.buck.util.zip.CustomZipEntry
-
- getExternalLinkerFlags() - Method in class com.facebook.buck.features.go.GoBinaryDescriptionArg
-
- getExternalLinkerFlags() - Method in class com.facebook.buck.features.go.GoTestDescriptionArg
-
- getExternalLinkerFlags() - Method in interface com.facebook.buck.features.go.HasGoLinkable
-
- getExternalNamesInRootCell() - Method in class com.facebook.buck.core.cell.impl.DefaultCellPathResolver
-
This gives the names as they are specified in the root cell.
- getExternalTestRunner() - Method in class com.facebook.buck.test.config.TestBuckConfig
-
- getExternalTestRunnerSpec(ExecutionContext, TestRunningOptions, BuildContext) - Method in class com.facebook.buck.android.AndroidInstrumentationTest
-
- getExternalTestRunnerSpec(ExecutionContext, TestRunningOptions, BuildContext) - Method in class com.facebook.buck.apple.AppleTest
-
- getExternalTestRunnerSpec(ExecutionContext, TestRunningOptions, BuildContext) - Method in class com.facebook.buck.core.rules.tool.RuleAnalysisLegacyTestBuildRuleView
-
- getExternalTestRunnerSpec(ExecutionContext, TestRunningOptions, BuildContext) - Method in interface com.facebook.buck.core.test.rule.ExternalTestRunnerRule
-
- getExternalTestRunnerSpec(ExecutionContext, TestRunningOptions, BuildContext) - Method in interface com.facebook.buck.core.test.rule.TestXRule
-
This shouldn't be overriden as the default implementation is sufficient.
- getExternalTestRunnerSpec(ExecutionContext, TestRunningOptions, BuildContext) - Method in class com.facebook.buck.cxx.CxxTest
-
- getExternalTestRunnerSpec(ExecutionContext, TestRunningOptions, BuildContext) - Method in class com.facebook.buck.features.d.DTest
-
- getExternalTestRunnerSpec(ExecutionContext, TestRunningOptions, BuildContext) - Method in class com.facebook.buck.features.go.GoTest
-
- getExternalTestRunnerSpec(ExecutionContext, TestRunningOptions, BuildContext) - Method in class com.facebook.buck.features.python.PythonTest
-
- getExternalTestRunnerSpec(ExecutionContext, TestRunningOptions, BuildContext) - Method in class com.facebook.buck.features.rust.RustTest
-
- getExternalTestRunnerSpec(ExecutionContext, TestRunningOptions, BuildContext) - Method in class com.facebook.buck.jvm.java.JavaTest
-
- getExternalTestRunnerSpec(ExecutionContext, TestRunningOptions, BuildContext) - Method in class com.facebook.buck.shell.ShTest
-
- getExtraArgs() - Method in class com.facebook.buck.core.toolchain.tool.impl.VersionedTool
-
Additional flags that we pass to the tool, but which do *not* contribute to the rule key.
- getExtraArguments() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getExtraArguments() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getExtraArguments() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getExtraArguments() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getExtraArguments() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getExtraArguments() - Method in class com.facebook.buck.jvm.java.JavacOptions
-
- getExtraArguments() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getExtraArguments() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getExtraArguments() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getExtraArguments() - Method in interface com.facebook.buck.jvm.java.JvmLibraryArg
-
- getExtraArguments() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getExtraArguments() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getExtraArguments() - Method in interface com.facebook.buck.jvm.scala.ScalaLibraryDescription.CoreArg
-
- getExtraArguments() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getExtraArguments() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getExtraClasspath() - Method in class com.facebook.buck.android.AndroidClasspathProvider
-
- getExtraClasspath() - Method in class com.facebook.buck.jvm.java.ExtraClasspathProvider.EmptyExtraClasspathProvider
-
- getExtraClasspath() - Method in interface com.facebook.buck.jvm.java.ExtraClasspathProvider
-
- getExtraClasspathProvider(ToolchainProvider, TargetConfiguration) - Method in class com.facebook.buck.jvm.groovy.GroovyConfiguredCompilerFactory
-
- getExtraClasspathProvider(ToolchainProvider, TargetConfiguration) - Method in class com.facebook.buck.jvm.java.ConfiguredCompilerFactory
-
- getExtraClasspathProvider(ToolchainProvider, TargetConfiguration) - Method in class com.facebook.buck.jvm.java.JavaConfiguredCompilerFactory
-
- getExtraClasspathProvider(ToolchainProvider, TargetConfiguration) - Method in class com.facebook.buck.jvm.kotlin.KotlinConfiguredCompilerFactory
-
- getExtraClasspathProvider(ToolchainProvider, TargetConfiguration) - Method in class com.facebook.buck.jvm.scala.ScalaConfiguredCompilerFactory
-
- getExtraCompilerOutputModulesPath() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getExtraData() - Method in class com.facebook.buck.util.environment.BuildEnvironmentDescription
-
- getExtraDeps() - Method in class com.facebook.buck.core.model.targetgraph.impl.TargetNodeImpl
-
- getExtraDeps() - Method in interface com.facebook.buck.core.model.targetgraph.TargetNode
-
- getExtraDeps() - Method in class com.facebook.buck.core.rules.BuildRuleParams
-
- getExtraFiles() - Method in interface com.facebook.buck.doctor.ExtraInfoCollector.ExtraInfoResult
-
- getExtraFilteredResources() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getExtraFilteredResources() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getExtraFilteredResources() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getExtraFlags() - Method in class com.facebook.buck.apple.AppleAssetCatalogsCompilationOptions
-
- getExtraGroovycArguments() - Method in interface com.facebook.buck.jvm.groovy.GroovyLibraryDescription.CoreArg
-
- getExtraGroovycArguments() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getExtraGroovycArguments() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getExtraInfo() - Method in interface com.facebook.buck.doctor.DefectReporter.DefectReport
-
- getExtraInfoCommand() - Method in class com.facebook.buck.doctor.config.DoctorConfig
-
- getExtraJson() - Method in interface com.facebook.buck.features.js.HasExtraJson
-
A JSON string, optionally containing macros.
- getExtraJson() - Method in class com.facebook.buck.features.js.JsBundleDescriptionArg
-
A JSON string, optionally containing macros.
- getExtraJson() - Method in class com.facebook.buck.features.js.JsLibraryDescriptionArg
-
A JSON string, optionally containing macros.
- getExtraJson(HasExtraJson, BuildTarget, ActionGraphBuilder, CellPathResolver) - Static method in class com.facebook.buck.features.js.JsUtil
-
- getExtraLibraryDependencies() - Method in class com.facebook.buck.features.project.intellij.model.IjModule
-
- getExtraLibraryDependencies() - Method in class com.facebook.buck.features.project.intellij.ModuleBuildContext
-
- getExtraModuleDependencies() - Method in class com.facebook.buck.features.project.intellij.model.IjModule
-
- getExtraModuleDependencies() - Method in class com.facebook.buck.features.project.intellij.ModuleBuildContext
-
- getExtraNdkCFlags() - Method in class com.facebook.buck.android.AndroidBuckConfig
-
- getExtraNdkCxxFlags() - Method in class com.facebook.buck.android.AndroidBuckConfig
-
- getExtraNdkLdFlags() - Method in class com.facebook.buck.android.AndroidBuckConfig
-
- getExtraOutputsDeriver() - Method in class com.facebook.buck.cxx.toolchain.linker.impl.DarwinLinker
-
- getExtraOutputsDeriver() - Method in class com.facebook.buck.cxx.toolchain.linker.impl.GnuLinker
-
- getExtraOutputsDeriver() - Method in class com.facebook.buck.cxx.toolchain.linker.impl.WindowsLinker
-
- getExtraOutputsDeriver() - Method in interface com.facebook.buck.cxx.toolchain.linker.Linker
-
- getExtraPlatformPaths() - Method in class com.facebook.buck.apple.AppleConfig
-
- getExtraSchemes() - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg
-
- getExtraScriptTemplates() - Method in class com.facebook.buck.features.haskell.HaskellGhciDescriptionArg
-
- getExtraShallowTargets() - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg
-
- getExtraTargets() - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg
-
- getExtraTests() - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg
-
- getExtraToolchainPaths() - Method in class com.facebook.buck.apple.AppleConfig
-
- getExtraXcodeFiles() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
extra_xcode_sources will add the files to the list of files in the project and won't add them
to an Xcode target.
- getExtraXcodeFiles() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
extra_xcode_sources will add the files to the list of files in the project and won't add them
to an Xcode target.
- getExtraXcodeFiles() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
extra_xcode_sources will add the files to the list of files in the project and won't add them
to an Xcode target.
- getExtraXcodeFiles() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
extra_xcode_sources will add the files to the list of files in the project and won't add them
to an Xcode target.
- getExtraXcodeFiles() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
extra_xcode_sources will add the files to the list of files in the project and won't add them
to an Xcode target.
- getExtraXcodeSources() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
extra_xcode_sources will add the files to the list of files to be compiled in the Xcode
target.
- getExtraXcodeSources() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
extra_xcode_sources will add the files to the list of files to be compiled in the Xcode
target.
- getExtraXcodeSources() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
extra_xcode_sources will add the files to the list of files to be compiled in the Xcode
target.
- getExtraXcodeSources() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
extra_xcode_sources will add the files to the list of files to be compiled in the Xcode
target.
- getExtraXcodeSources() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
extra_xcode_sources will add the files to the list of files to be compiled in the Xcode
target.
- getFactory() - Method in class com.facebook.buck.features.project.intellij.lang.android.AndroidResourceFolder
-
- getFactory() - Method in class com.facebook.buck.features.project.intellij.model.folders.ExcludeFolder
-
- getFactory() - Method in class com.facebook.buck.features.project.intellij.model.folders.IjFolder
-
- getFactory() - Method in enum com.facebook.buck.features.project.intellij.model.folders.IjResourceFolderType
-
- getFactory() - Method in class com.facebook.buck.features.project.intellij.model.folders.JavaResourceFolder
-
- getFactory() - Method in class com.facebook.buck.features.project.intellij.model.folders.JavaTestResourceFolder
-
- getFactory() - Method in class com.facebook.buck.features.project.intellij.model.folders.SourceFolder
-
- getFactory() - Method in class com.facebook.buck.features.project.intellij.model.folders.TestFolder
-
- getFactory() - Method in enum com.facebook.buck.slb.ThriftProtocol
-
- getFailed() - Method in interface com.facebook.buck.event.listener.stats.cache.NetworkStatsTracker.RemoteArtifactUploadStats
-
- getFailOnLegacyAaptErrors() - Method in class com.facebook.buck.android.AndroidBuckConfig
-
Whether to fail (vs warn) on legacy aapt2 compile errors.
- getFailure() - Method in class com.facebook.buck.core.build.engine.BuildResult
-
- getFailure(ListenableFuture<?>) - Static method in class com.facebook.buck.util.concurrent.MoreFutures
-
Returns the failure for a ListenableFuture
.
- getFailureCount() - Method in interface com.facebook.buck.event.external.elements.TestCaseSummaryExternalInterface
-
- getFailureCount() - Method in class com.facebook.buck.event.listener.stats.cache.RemoteCacheUploadStats
-
- getFailureCount() - Method in class com.facebook.buck.test.TestCaseSummary
-
- getFailureCount() - Method in class com.facebook.buck.test.TestResults
-
- getFailureInfo() - Method in interface com.facebook.buck.apple.AbstractIdbTestResult
-
Object that represents the failure information
- getFailureOptional() - Method in class com.facebook.buck.core.build.engine.BuildResult
-
- getFailures() - Method in class com.facebook.buck.test.TestResults
-
- getFailureUploadCount() - Method in class com.facebook.buck.artifact_cache.CacheCountersSummary
-
- getFakeTime() - Static method in class com.facebook.buck.util.zip.ZipConstants
-
- getFallbackFinder() - Method in class com.facebook.buck.jvm.java.ResourcesRootPackageFinder
-
- getFatLto() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getFatLto() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getFatLto() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getFatLto() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getFatLto() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getFatLto() - Method in class com.facebook.buck.cxx.CxxLinkOptions
-
- getFatLto() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getFatLto() - Method in interface com.facebook.buck.cxx.LinkableCxxConstructorArg
-
- getFatLto() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getFatLto() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getFeatures() - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg
-
- getFeatures() - Method in interface com.facebook.buck.features.rust.RustCommonArgs
-
- getFeatures() - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg
-
- getFeatures() - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg
-
- getFetchBuilder() - Method in class com.facebook.buck.artifact_cache.HttpArtifactCacheEvent.Finished.Builder
-
- getFetchData() - Method in class com.facebook.buck.artifact_cache.HttpArtifactCacheEvent.Finished
-
- getFetchResult() - Method in interface com.facebook.buck.artifact_cache.HttpArtifactCacheEvent.HttpArtifactCacheEventFetchData
-
- getFetchTimeMs() - Method in class com.facebook.buck.log.PerfTimesStats
-
- getField() - Method in class com.facebook.buck.rules.modern.FieldInfo
-
- getFieldInfos() - Method in interface com.facebook.buck.rules.modern.ClassInfo
-
- getFieldInfos() - Method in class com.facebook.buck.rules.modern.impl.DefaultClassInfo
-
- getFieldNames() - Method in class com.facebook.buck.core.rules.providers.impl.UserDefinedProviderInfo
-
- getFieldNames() - Method in class com.facebook.buck.core.starlark.compatible.BuckStarlarkStructObject
-
- getFieldNames() - Method in class com.facebook.buck.core.starlark.rule.SkylarkRuleContextAttr
-
- getFile() - Method in interface com.facebook.buck.apple.AbstractIdbFailureInfo
-
String that represents the file which caused the failure
- getFile() - Method in class com.facebook.buck.cxx.CxxCompilationDatabaseEntry
-
- getFile(Cell, AbsPath) - Method in interface com.facebook.buck.parser.FileParsePipeline
-
- getFileAttributesForZipEntry(Path) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- getFileAttributesForZipEntry(Path) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
getFileAttributesForZipEntry is similar to getPosixFileMode, but returns a number adjusted for
use in zip files.
- getFileAttributeView(Path, Class<V>, LinkOption...) - Method in class com.facebook.buck.core.filesystems.BuckFileSystemProvider
-
- getFileChangesIgnoredReport() - Method in class com.facebook.buck.doctor.AbstractReport
-
- getFileChangesIgnoredReport() - Method in interface com.facebook.buck.doctor.DefectReporter.DefectReport
-
- getFileChangesIgnoredReport() - Method in class com.facebook.buck.doctor.DoctorInteractiveReport
-
- getFileContents() - Method in class com.facebook.buck.file.WriteFile
-
- getFileEventBus() - Method in class com.facebook.buck.support.state.BuckGlobalState
-
Global event bus used to process file invalidation events.
- getFileExtension(Path) - Static method in class com.facebook.buck.io.file.MorePaths
-
- getFileExtensions() - Static method in enum com.facebook.buck.util.unarchive.ArchiveFormat
-
Get all available file extensions
- getFileForOutput(JavaFileManager.Location, String, String, FileObject) - Method in class com.facebook.buck.jvm.java.JavaInMemoryFileManager
-
- getFileHashCache() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getFileHashCache() - Method in interface com.facebook.buck.core.build.engine.delegate.CachingBuildEngineDelegate
-
- getFileHashCache() - Method in class com.facebook.buck.core.build.engine.delegate.LocalCachingBuildEngineDelegate
-
- getFileHashCacheMode() - Method in class com.facebook.buck.command.config.BuildBuckConfig
-
- getFileHashCaches() - Method in class com.facebook.buck.support.state.BuckGlobalState
-
- getFileInputStream(Protocol.Digest) - Method in class com.facebook.buck.remoteexecution.util.LocalContentAddressedStorage
-
Get a file input stream to a Digest
- getFileJob(Cell, AbsPath) - Method in interface com.facebook.buck.parser.FileParsePipeline
-
Asynchronously obtain all
TargetNode
s from a build file.
- getFileJob(Cell, AbsPath) - Method in class com.facebook.buck.parser.GenericFileParsePipeline
-
- getFileName() - Method in class com.facebook.buck.core.filesystems.BuckUnixPath
-
- getFilename() - Method in class com.facebook.buck.event.WatchmanStatusEvent.FileCreation
-
- getFilename() - Method in class com.facebook.buck.event.WatchmanStatusEvent.FileDeletion
-
- getFileName() - Method in interface com.facebook.buck.json.BuildFileParseExceptionStackTraceEntry
-
- getFileName() - Method in interface com.facebook.buck.json.BuildFileSyntaxError
-
- getFileName(Function<SourcePath, Path>) - Method in class com.facebook.buck.rules.coercer.FrameworkPath
-
- getFilenamePath() - Method in class com.facebook.buck.android.PackagedResource
-
Use this combined with file hash as unique ID when hashing is enabled.
- getFileNameWithoutClassSuffix(FileLike) - Static method in class com.facebook.buck.jvm.java.classes.FileLikes
-
- getFileOwners(ImmutableList<String>) - Method in class com.facebook.buck.cli.BuckQueryEnvironment
-
- getFileOwners(ImmutableList<String>) - Method in interface com.facebook.buck.query.QueryEnvironment
-
Returns the targets that own one or more of the given files.
- getFileOwners(ImmutableList<String>) - Method in class com.facebook.buck.query.TargetVariablesQueryEnvironment
-
- getFileOwners(ImmutableList<String>) - Method in class com.facebook.buck.rules.query.GraphEnhancementQueryEnvironment
-
- getFilePath() - Method in class com.facebook.buck.features.project.intellij.model.ModuleIndexEntry
-
- getFilepathLengthLimited() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getFilepathLengthLimited() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
Whether to use shorter intermediate files.
- getFilepathLengthLimited() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getFilePaths() - Method in class com.facebook.buck.skylark.io.GlobSpecWithResult
-
return the file paths that the glob operation returned.
- getFileRef() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXBuildFile
-
- getFileReference() - Method in class com.facebook.buck.features.apple.projectV2.ProjectFileWriter.Result
-
- getFiles() - Method in class com.facebook.buck.apple.AppleResourceDescriptionArg
-
- getFiles() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXBuildPhase
-
- getFiles() - Method in class com.facebook.buck.core.files.DirectoryList
-
- getFilesExamined() - Method in interface com.facebook.buck.util.cache.FileHashCache.FileHashCacheVerificationResult
-
- getFileSize(Path) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- getFileSize(Path) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
- getFilesList() - Method in interface com.facebook.buck.remoteexecution.interfaces.Protocol.Directory
-
- getFilesToCopyInXcode() - Method in class com.facebook.buck.features.apple.project.ProjectGenerator
-
- getFilesToInstall() - Method in class com.facebook.buck.android.exopackage.DexExoHelper
-
- getFilesToInstall() - Method in class com.facebook.buck.android.exopackage.ModuleExoHelper
-
- getFilesToInstall() - Method in class com.facebook.buck.android.exopackage.NativeExoHelper
-
- getFilesToInstall(ImmutableMap<String, Path>) - Static method in class com.facebook.buck.android.exopackage.ResourcesExoHelper
-
- getFilesToInstall() - Method in class com.facebook.buck.android.exopackage.ResourcesExoHelper
-
- getFileStore(Path) - Method in class com.facebook.buck.core.filesystems.BuckFileSystemProvider
-
- getFileStores() - Method in class com.facebook.buck.core.filesystems.BuckFileSystem
-
- getFilesUnderPath(Path) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- getFilesUnderPath(Path, Predicate<Path>) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- getFilesUnderPath(Path, Predicate<Path>, EnumSet<FileVisitOption>) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- getFilesUnderPath(Path, EnumSet<FileVisitOption>) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystemView
-
- getFilesUnderPath(Path, Predicate<Path>, EnumSet<FileVisitOption>) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystemView
-
- getFilesUnderPath(Path) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
Deprecated.
- getFilesUnderPath(Path, Predicate<Path>) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
Deprecated.
- getFilesUnderPath(Path, Predicate<Path>, EnumSet<FileVisitOption>) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
Deprecated.
- getFilesUnderPath(Path, EnumSet<FileVisitOption>) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystemView
-
- getFilesUnderPath(Path, Predicate<Path>, EnumSet<FileVisitOption>) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystemView
-
Returns a list of files under the given path relative to the root of this view, filtered both
blacklist and the given filter.
- getFilesystem() - Method in interface com.facebook.buck.core.cell.Cell
-
- getFilesystem() - Method in class com.facebook.buck.core.config.BuckConfig
-
- getFileSystem(URI) - Method in class com.facebook.buck.core.filesystems.BuckFileSystemProvider
-
- getFileSystem() - Method in class com.facebook.buck.core.filesystems.BuckUnixPath
-
- getFileSystem() - Method in interface com.facebook.buck.core.filesystems.PathWrapper
-
- getFilesystem() - Method in class com.facebook.buck.core.model.targetgraph.impl.TargetNodeImpl
-
- getFilesystem() - Method in interface com.facebook.buck.core.model.targetgraph.TargetNode
-
- getFilesystem() - Method in class com.facebook.buck.core.sourcepath.PathSourcePath
-
- getFilesystem(SourcePath) - Method in class com.facebook.buck.core.sourcepath.resolver.impl.AbstractSourcePathResolver
-
- getFilesystem(SourcePath) - Method in interface com.facebook.buck.core.sourcepath.resolver.SourcePathResolver
-
- getFilesystem(SourcePath) - Method in class com.facebook.buck.core.sourcepath.resolver.SourcePathResolverAdapter
-
- getFilesystem() - Method in interface com.facebook.buck.core.toolchain.ToolchainCreationContext
-
- getFileSystem() - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
- getFilesystem() - Method in class com.facebook.buck.step.fs.SymlinkFileStep
-
- getFilesystem() - Method in class com.facebook.buck.util.cache.impl.DefaultFileHashCache
-
- getFilesystem() - Method in interface com.facebook.buck.util.cache.ProjectFileHashCache
-
- getFilesystem() - Method in class com.facebook.buck.util.unarchive.DirectoryCreator
-
- getFilesystemViewForSourceFiles() - Method in interface com.facebook.buck.core.cell.Cell
-
- getFileTreeCaches() - Method in class com.facebook.buck.support.state.BuckGlobalState
-
Return a map of file tree caches for each cell which is a key.
- getFileUrl() - Method in class com.facebook.buck.features.project.intellij.model.ModuleIndexEntry
-
- getFilter() - Method in class com.facebook.buck.rules.macros.CxxGenruleFilterAndTargetsMacro
-
- getFilterSteps() - Method in class com.facebook.buck.features.go.FilteredSourceFiles
-
- getFinalRName() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getFinalRName() - Method in interface com.facebook.buck.android.AndroidLibraryDescription.CoreArg
-
- getFinalRName() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getFingerprint() - Method in class com.facebook.buck.apple.toolchain.CodeSignIdentity
-
Returns the identity's certificate hash, defined to be unique for each identity.
- getFinish() - Method in class com.facebook.buck.event.listener.util.EventInterval
-
- getFinishEvent() - Method in class com.facebook.buck.event.listener.TimeCostEntry
-
- getFirst() - Method in class com.facebook.buck.util.types.Pair
-
- getFirstManifestPath() - Method in class com.facebook.buck.features.project.intellij.model.IjModuleAndroidFacet
-
- getFirstNonOptionalType(Field) - Static method in class com.facebook.buck.util.Types
-
Get the first complete
Type
in a signature that's non-optional, complete with the
information from the
ParameterizedType
.
- getFirstOrderClasspath(Set<QueryTarget>) - Method in class com.facebook.buck.rules.query.GraphEnhancementQueryEnvironment
-
- getFirstResourcePackageFromDependencies(IjModule) - Method in class com.facebook.buck.features.project.intellij.IjProjectTemplateDataPreparer
-
- getFixScript() - Method in class com.facebook.buck.support.fix.FixBuckConfig
-
Get the script to run when buck fix is invoked
- getFixScriptContact() - Method in class com.facebook.buck.support.fix.FixBuckConfig
-
Get the contact to use to tell users who to contact when `buck fix` fails
- getFixScriptMessage() - Method in class com.facebook.buck.support.fix.FixBuckConfig
-
Get the message to show when invoking `buck fix`
- getFlagMacros() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getFlags() - Method in class com.facebook.buck.android.NdkLibraryDescriptionArg
-
- getFlags() - Method in class com.facebook.buck.core.sourcepath.SourceWithFlags
-
- getFlags(ImmutableList<T>, PatternMatchedCollection<ImmutableList<T>>, CxxPlatform) - Static method in class com.facebook.buck.cxx.CxxFlags
-
- getFlags() - Method in class com.facebook.buck.cxx.CxxSource
-
- getFlags(Compiler) - Method in enum com.facebook.buck.cxx.toolchain.PicType
-
- getFlags() - Method in class com.facebook.buck.features.haskell.HaskellCompileRule
-
- getFlagsForColorDiagnostics() - Method in class com.facebook.buck.cxx.toolchain.ClangCompiler
-
- getFlagsForColorDiagnostics() - Method in interface com.facebook.buck.cxx.toolchain.Compiler
-
- getFlagsForColorDiagnostics() - Method in class com.facebook.buck.cxx.toolchain.DefaultCompiler
-
- getFlagsForColorDiagnostics() - Method in class com.facebook.buck.cxx.toolchain.GccCompiler
-
- getFlagsForReproducibleBuild(String, Path) - Method in class com.facebook.buck.cxx.toolchain.ClangClCompiler
-
- getFlagsForReproducibleBuild(String, Path) - Method in class com.facebook.buck.cxx.toolchain.ClangCompiler
-
- getFlagsForReproducibleBuild(String, Path) - Method in class com.facebook.buck.cxx.toolchain.ClangWindowsCompiler
-
- getFlagsForReproducibleBuild(String, Path) - Method in interface com.facebook.buck.cxx.toolchain.Compiler
-
- getFlagsForReproducibleBuild(String, Path) - Method in class com.facebook.buck.cxx.toolchain.DefaultCompiler
-
- getFlagsWithMacrosWithPlatformMacroExpansion(ImmutableList<StringWithMacros>, PatternMatchedCollection<ImmutableList<StringWithMacros>>, CxxPlatform) - Static method in class com.facebook.buck.cxx.CxxFlags
-
- getFlagsWithPlatformMacroExpansion(ImmutableList<String>, PatternMatchedCollection<ImmutableList<String>>, CxxPlatform) - Static method in class com.facebook.buck.cxx.CxxFlags
-
- getFlavor() - Method in enum com.facebook.buck.apple.AppleDebugFormat
-
- getFlavor() - Method in enum com.facebook.buck.apple.AppleLibraryDescription.Type
-
- getFlavor() - Method in class com.facebook.buck.apple.toolchain.AppleCxxPlatform
-
- getFlavor() - Method in class com.facebook.buck.apple.toolchain.impl.ProviderBackedUnresolvedAppleCxxPlatform
-
- getFlavor() - Method in class com.facebook.buck.apple.toolchain.impl.StaticUnresolvedAppleCxxPlatform
-
- getFlavor() - Method in interface com.facebook.buck.core.model.FlavorConvertible
-
- getFlavor(Set<Flavor>) - Method in class com.facebook.buck.core.model.FlavorDomain
-
- getFlavor(FlavorSet) - Method in class com.facebook.buck.core.model.FlavorDomain
-
- getFlavor(BuildTarget) - Method in class com.facebook.buck.core.model.FlavorDomain
-
- getFlavor() - Method in enum com.facebook.buck.cxx.CxxInferEnhancer.InferFlavors
-
- getFlavor() - Method in enum com.facebook.buck.cxx.CxxLibraryDescription.MetadataType
-
- getFlavor() - Method in enum com.facebook.buck.cxx.CxxLibraryDescription.Type
-
- getFlavor() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getFlavor() - Method in enum com.facebook.buck.cxx.toolchain.HeaderMode
-
- getFlavor() - Method in enum com.facebook.buck.cxx.toolchain.HeaderVisibility
-
- getFlavor() - Method in class com.facebook.buck.cxx.toolchain.impl.StaticUnresolvedCxxPlatform
-
- getFlavor() - Method in enum com.facebook.buck.cxx.toolchain.LinkerMapMode
-
- getFlavor() - Method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableCacheKey
-
- getFlavor() - Method in class com.facebook.buck.cxx.toolchain.ProviderBasedUnresolvedCxxPlatform
-
- getFlavor() - Method in enum com.facebook.buck.cxx.toolchain.StripStyle
-
- getFlavor() - Method in interface com.facebook.buck.cxx.toolchain.UnresolvedCxxPlatform
-
- getFlavor() - Method in enum com.facebook.buck.features.haskell.HaskellBinaryDescription.Type
-
- getFlavor() - Method in enum com.facebook.buck.features.haskell.HaskellLibraryDescription.Type
-
- getFlavor() - Method in class com.facebook.buck.features.lua.LuaPlatform
-
- getFlavor() - Method in enum com.facebook.buck.features.python.CxxPythonExtensionDescription.Type
-
- getFlavor() - Method in class com.facebook.buck.features.python.toolchain.impl.LazyPythonPlatform
-
- getFlavor() - Method in interface com.facebook.buck.features.python.toolchain.PythonPlatform
-
- getFlavor() - Method in class com.facebook.buck.features.rust.ConfigBasedUnresolvedRustPlatform
-
- getFlavor() - Method in enum com.facebook.buck.features.rust.CrateType
-
- getFlavor() - Method in enum com.facebook.buck.features.rust.RustBinaryDescription.Type
-
- getFlavor() - Method in interface com.facebook.buck.features.rust.UnresolvedRustPlatform
-
- getFlavor() - Method in enum com.facebook.buck.swift.SwiftLibraryDescription.Type
-
- getFlavor() - Method in class com.facebook.buck.swift.toolchain.impl.StaticUnresolvedSwiftPlatform
-
- getFlavorAndValue(Set<Flavor>) - Method in class com.facebook.buck.core.model.FlavorDomain
-
- getFlavorAndValue(FlavorSet) - Method in class com.facebook.buck.core.model.FlavorDomain
-
- getFlavorAndValue(BuildTarget) - Method in class com.facebook.buck.core.model.FlavorDomain
-
- getFlavoredConfigs() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getFlavoredStrategyConfig(String) - Method in class com.facebook.buck.rules.modern.config.ModernBuildRuleStrategyConfigFromSection
-
- getFlavorPostfix() - Method in class com.facebook.buck.core.model.BuildTarget
-
An empty string when there are no flavors, or hash followed by comma-separated flavors.
- getFlavors() - Method in class com.facebook.buck.core.model.BuildTarget
-
- getFlavors() - Method in class com.facebook.buck.core.model.FlavorDomain
-
- getFlavors() - Method in class com.facebook.buck.core.model.UnconfiguredBuildTarget
-
- getFlavorsAsString() - Method in class com.facebook.buck.core.model.BuildTarget
-
- getFlavorSet() - Method in class com.facebook.buck.core.model.UnconfiguredBuildTarget
-
Set of flavors used with that build target.
- getFloat(String, String) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getFloat(String, String) - Method in class com.facebook.buck.util.config.Config
-
- getFlushEventsBeforeExit() - Method in class com.facebook.buck.support.cli.config.CliConfig
-
- getFolderFactory() - Method in enum com.facebook.buck.features.project.intellij.FolderTypeWithPackageInfo
-
- getFolders() - Method in class com.facebook.buck.features.project.intellij.model.ContentRoot
-
- getFolders() - Method in class com.facebook.buck.features.project.intellij.model.IjModule
-
- getFolderTypeClass() - Method in enum com.facebook.buck.features.project.intellij.FolderTypeWithPackageInfo
-
- getForAction(String, String) - Method in interface com.facebook.buck.remoteexecution.interfaces.MetadataProvider
-
- getForAllPlatforms(BuildRuleResolver) - Method in class com.facebook.buck.cxx.CxxDeps
-
- getForArchiveMember(Path, Path) - Method in class com.facebook.buck.util.cache.DelegatingFileHashCacheEngine
-
- getForArchiveMember(Path, Path) - Method in interface com.facebook.buck.util.cache.FileHashCacheEngine
-
- getForArchiveMember(Path, Path) - Method in class com.facebook.buck.util.cache.impl.DefaultFileHashCache
-
- getForArchiveMember(Path, Path) - Method in class com.facebook.buck.util.cache.impl.StackedFileHashCache
-
- getForArchiveMember(ProjectFilesystem, Path, Path) - Method in class com.facebook.buck.util.cache.impl.StackedFileHashCache
-
- getForArchiveMember(Path, Path) - Method in class com.facebook.buck.util.cache.impl.StatsTrackingFileHashCacheEngine
-
- getForArchiveMember(Path, Path) - Method in interface com.facebook.buck.util.hashing.FileHashLoader
-
- getForArchiveMember(ProjectFilesystem, Path, Path) - Method in interface com.facebook.buck.util.hashing.FileHashLoader
-
- getForArchiveMember(Path, Path) - Method in class com.facebook.buck.util.hashing.FilePathHashLoader
-
- getForArchiveMember(Path, Path) - Method in interface com.facebook.buck.util.hashing.ProjectFileHashLoader
-
- getForceLinkWhole() - Method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableCacheKey
-
- getForCell(CellName) - Method in class com.facebook.buck.core.cell.CellConfig
-
Retrieve the Cell-view of the raw config.
- getForceLoadLibraryPath(boolean) - Method in class com.facebook.buck.apple.AppleConfig
-
- getForceStatic() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getForceStatic() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getForceStatic() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getForceStatic() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
- getForceStatic() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getForkMode() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getForkMode() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getForkMode() - Method in interface com.facebook.buck.jvm.java.JavaTestDescription.CoreArg
-
- getForkMode() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getForkMode() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getForkMode() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getFormatFromFilename(String) - Static method in enum com.facebook.buck.util.unarchive.ArchiveFormat
-
Gets the archive format based on a file
- getFormatFromShortName(String) - Static method in enum com.facebook.buck.util.unarchive.ArchiveFormat
-
Gets the archive format based on a short name
- getFormatString() - Method in class com.facebook.buck.rules.args.FormatArg
-
- getFormattedDateTime() - Method in class com.facebook.buck.util.trace.BuildTraces.TraceAttributes
-
- getFramework() - Method in class com.facebook.buck.apple.PrebuiltAppleFrameworkDescriptionArg
-
- getFramework() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getFrameworkPaths() - Method in class com.facebook.buck.cxx.PreprocessorFlags
-
Directories set via -F
.
- getFrameworks() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getFrameworks() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getFrameworks() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getFrameworks() - Method in class com.facebook.buck.apple.PrebuiltAppleFrameworkDescriptionArg
-
- getFrameworks() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getFrameworks() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getFrameworks() - Method in class com.facebook.buck.cxx.CxxPreprocessorInput
-
- getFrameworks() - Method in class com.facebook.buck.cxx.CxxSourceRuleFactory
-
- getFrameworks() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getFrameworks() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getFrameworks() - Method in interface com.facebook.buck.cxx.toolchain.HasSystemFrameworkAndLibraries
-
- getFrameworks() - Method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableInput
-
- getFrameworks() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getFrameworks() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getFrameworks() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getFrameworks() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getFrameworks() - Method in class com.facebook.buck.swift.SwiftLibraryDescriptionArg
-
- getFrameworkVer() - Method in class com.facebook.buck.features.dotnet.CsharpLibraryDescriptionArg
-
- getFreeCompilerArgs() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
A list of additional compiler arguments.
- getFreeCompilerArgs() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
A list of additional compiler arguments.
- getFreeCompilerArgs() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
A list of additional compiler arguments.
- getFreeCompilerArgs() - Method in interface com.facebook.buck.jvm.kotlin.KotlinLibraryDescription.CoreArg
-
A list of additional compiler arguments.
- getFreeCompilerArgs() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
A list of additional compiler arguments.
- getFreeCompilerArgs() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
A list of additional compiler arguments.
- getFreeMemoryBytes() - Method in class com.facebook.buck.util.perf.PerfStatsTracking.MemoryPerfStatsEvent
-
- getFreshActionGraph(TargetGraphCreationResult) - Method in class com.facebook.buck.core.model.actiongraph.computation.ActionGraphProvider
-
- getFreshActionGraph(TargetNodeToBuildRuleTransformer, TargetGraphCreationResult) - Method in class com.facebook.buck.core.model.actiongraph.computation.ActionGraphProvider
-
- getFriendPaths() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getFriendPaths() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getFriendPaths() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getFriendPaths() - Method in interface com.facebook.buck.jvm.kotlin.KotlinLibraryDescription.CoreArg
-
- getFriendPaths() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getFriendPaths() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getFromCache(BuildEngineAction) - Method in class com.facebook.buck.rules.keys.DefaultRuleKeyFactory
-
- getFromCache(BuildEngineAction) - Method in interface com.facebook.buck.rules.keys.RuleKeyFactory
-
Returns a RULE_KEY
from an internal cache, if possible.
- getFrontendConfig() - Method in class com.facebook.buck.doctor.config.DoctorConfig
-
- getFrontendConfig() - Method in class com.facebook.buck.util.network.RemoteLogBuckConfig
-
- getFullDurationMillis() - Method in class com.facebook.buck.remoteexecution.event.LocalFallbackEvent.Finished
-
- getFullUrl(URI, String) - Static method in class com.facebook.buck.slb.SingleUriService
-
- getFullyQualifiedBuildTargets(String, String, TargetConfiguration) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getFullyQualifiedName() - Method in class com.facebook.buck.core.model.BuildTarget
-
If this build target is cell//third_party/java/guava:guava-latest, then this would return
"cell//third_party/java/guava:guava-latest".
- getFullyQualifiedName() - Method in class com.facebook.buck.core.model.UnconfiguredBuildTarget
-
Fully qualified name of unconfigured build target, for example
cell//some/target:name#flavor1,flavor2
- getFullyQualifiedName() - Method in class com.facebook.buck.core.model.UnflavoredBuildTarget
-
- getFullyQualifiedName() - Method in interface com.facebook.buck.core.rules.BuildRule
-
- getFullyQualifiedName() - Method in interface com.facebook.buck.core.rules.HasNameAndType
-
- getFullyQualifiedName() - Method in class com.facebook.buck.rules.keys.FieldValueExtractor
-
- getFullyQualifiedName() - Method in interface com.facebook.buck.rules.keys.ValueExtractor
-
- getFullyQualifiedName() - Method in class com.facebook.buck.rules.keys.ValueMethodValueExtractor
-
- getFunctionName() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getFunctionName() - Method in interface com.facebook.buck.json.BuildFileParseExceptionStackTraceEntry
-
- getFunctions() - Method in class com.facebook.buck.cli.BuckQueryEnvironment
-
- getFunctions() - Method in interface com.facebook.buck.query.QueryEnvironment
-
Returns the set of query functions implemented by this query environment.
- getFunctions() - Method in class com.facebook.buck.query.TargetVariablesQueryEnvironment
-
- getFunctions() - Method in class com.facebook.buck.rules.query.GraphEnhancementQueryEnvironment
-
- getFuture(SupportsPipelining<?>) - Method in class com.facebook.buck.core.build.engine.impl.BuildRulePipelinesRunner
-
- getFuture() - Method in interface com.facebook.buck.core.build.engine.impl.RunnableWithFuture
-
- getFuture() - Method in class com.facebook.buck.slb.ClientSideSlb.ServerPing
-
- getFwdDeps(Iterable<QueryBuildTarget>) - Method in class com.facebook.buck.cli.BuckQueryEnvironment
-
- getFwdDeps(Iterable<NODE_TYPE>) - Method in interface com.facebook.buck.query.QueryEnvironment
-
Returns the direct forward dependencies of the specified targets.
- getFwdDeps(Iterable<NODE_TYPE>) - Method in class com.facebook.buck.query.TargetVariablesQueryEnvironment
-
- getFwdDeps(Iterable<QueryBuildTarget>) - Method in class com.facebook.buck.rules.query.GraphEnhancementQueryEnvironment
-
- getGccVersion() - Method in interface com.facebook.buck.android.toolchain.ndk.NdkCxxPlatformCompiler
-
- getGenDir(ProjectFilesystem, BuildTarget) - Static method in class com.facebook.buck.core.model.impl.BuildPaths
-
Return a relative path to a file in the buck-out/gen/ directory, formatted with the target
short name.
- getGenDir() - Method in class com.facebook.buck.io.filesystem.BuckPaths
-
- getGeneralDelegate() - Method in class com.facebook.buck.io.filesystem.ProjectFilesystemDelegatePair
-
- getGenerateAbi() - Method in class com.facebook.buck.jvm.java.PrebuiltJarDescriptionArg
-
- getGeneratedAnnotationSourcePath() - Method in interface com.facebook.buck.jvm.core.JavaLibrary
-
- getGeneratedAnnotationSourcePath() - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getGeneratedAnnotationSourcePath() - Method in class com.facebook.buck.jvm.java.PrebuiltJar
-
- getGeneratedFilesListFilename() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getGeneratedGoSource() - Method in class com.facebook.buck.features.go.CGoLibrary
-
returns .go files produced by cgo tool
- getGeneratedMakefilePath(BuildTarget, ProjectFilesystem) - Static method in class com.facebook.buck.android.NdkLibraryDescription
-
Deprecated.
- getGeneratedProjectToGeneratedTargets() - Method in class com.facebook.buck.features.apple.project.ProjectGenerator
-
- getGeneratedSourceCodeFolders() - Method in class com.facebook.buck.features.project.intellij.model.IjModule
-
- getGeneratedSourceCodeFolders() - Method in class com.facebook.buck.features.project.intellij.ModuleBuildContext
-
- getGeneratedSourceFolders(IjModule) - Method in class com.facebook.buck.features.project.intellij.IjProjectTemplateDataPreparer
-
- getGeneratedSourcePath() - Method in class com.facebook.buck.features.project.intellij.model.IjModuleAndroidFacet
-
- getGenericType() - Method in class com.facebook.buck.core.starlark.rule.attr.Attribute
-
Get the generic type of CoercedType
.
- getGenPath(ProjectFilesystem, BuildTarget, String) - Static method in class com.facebook.buck.core.model.impl.BuildTargetPaths
-
Deprecated.
Return a relative path to a file in the buck-out/gen/ directory.
- getGenPathForBaseName(ProjectFilesystem, BuildTarget) - Static method in class com.facebook.buck.core.model.impl.BuildTargetPaths
-
Deprecated.
A folder where all targets in the file of target are created.
- getGenrule(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.cxx.CxxGenrule
-
Get the genrule
- getGenruleType() - Method in class com.facebook.buck.shell.AbstractGenruleDescription
-
- getGhciBinDep() - Method in class com.facebook.buck.features.haskell.HaskellGhciDescriptionArg
-
- getGhciBinutils(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getGhciCc(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getGhciCpp(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getGhciCxx(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getGhciGhc(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getGhciInit() - Method in class com.facebook.buck.features.haskell.HaskellGhciDescriptionArg
-
- getGhciIServ(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getGhciIServProf(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getGhciIservScriptTemplate(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getGhciLib(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getGhciPackager(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getGhciPlatformPreloadDeps() - Method in class com.facebook.buck.features.haskell.HaskellBinaryDescriptionArg
-
- getGhciPlatformPreloadDeps() - Method in class com.facebook.buck.features.haskell.HaskellLibraryDescriptionArg
-
- getGhciPreloadDeps() - Method in class com.facebook.buck.features.haskell.HaskellBinaryDescriptionArg
-
- getGhciPreloadDeps() - Method in class com.facebook.buck.features.haskell.HaskellLibraryDescriptionArg
-
- getGhciScriptTemplate(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getGlobalID() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXObject
-
- getGlobalState() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getGlobber() - Method in class com.facebook.buck.skylark.packages.PackageContext
-
Returns a globber instance that can resolve paths relative to current package.
- getGlobHandler() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getGlobManifest() - Method in class com.facebook.buck.parser.api.BuildFileManifest
-
- getGlobManifestWithResult() - Method in class com.facebook.buck.skylark.parser.ParseResult
-
- getGlobSpec() - Method in class com.facebook.buck.skylark.io.GlobSpecWithResult
-
return the GlobSpec for this glob operation.
- getGoAssemblerFlags() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getGoCompilerFlags() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getGoFiles() - Method in class com.facebook.buck.features.go.CGoGenSource
-
- getGoSrcs() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getGraph() - Method in class com.facebook.buck.android.apkmodule.APKModuleGraph
-
Lazy generate the graph on first use
- getGraph() - Method in class com.facebook.buck.parser.ParseEvent.Finished
-
- getGraphBuilder() - Method in class com.facebook.buck.command.Build
-
- getGraphMinimumDepth(int) - Method in class com.facebook.buck.features.project.intellij.aggregation.AggregationMode
-
- getGroovycTarget(TargetConfiguration) - Method in class com.facebook.buck.jvm.groovy.GroovyBuckConfig
-
- getGroup() - Method in class com.facebook.buck.features.project.intellij.model.ModuleIndexEntry
-
- getGroup(String, String, Map<T, Double>) - Static method in class com.facebook.buck.util.randomizedtrial.RandomizedTrial
-
Returns a group for trial with given name.
- getGroup(String, String, Class<T>) - Static method in class com.facebook.buck.util.randomizedtrial.RandomizedTrial
-
Returns a group for trial with given name.
- getGroupIndex() - Method in class com.facebook.buck.android.PreDexSplitDexGroup
-
- getGroupStable(String, Class<T>) - Static method in class com.facebook.buck.util.randomizedtrial.RandomizedTrial
-
Returns a group for trial with given name.
- getGroupStable(String, Map<T, Double>) - Static method in class com.facebook.buck.util.randomizedtrial.RandomizedTrial
-
Returns a group for trial with given name.
- getGrpcStatus() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.Terminal
-
- getGtestDefaultTestMainDep(TargetConfiguration) - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getGtestDep(TargetConfiguration) - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getGwtJar() - Method in class com.facebook.buck.jvm.java.PrebuiltJarDescriptionArg
-
- getHaddock(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getHaddockFlags() - Method in class com.facebook.buck.features.haskell.HaskellHaddockDescriptionArg
-
- getHaddockFlags() - Method in class com.facebook.buck.features.haskell.HaskellLibraryDescriptionArg
-
- getHaddockInput(HaskellPlatform) - Method in interface com.facebook.buck.features.haskell.HaskellCompileDep
-
- getHaddockOutputDirs() - Method in class com.facebook.buck.features.haskell.HaskellHaddockLibRule
-
- getHaddockSource(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getHalideTargetForPlatform(CxxPlatform) - Method in class com.facebook.buck.features.halide.HalideBuckConfig
-
- getHandlers() - Method in class com.facebook.buck.core.util.log.Logger
-
- getHandshakeCertificates() - Method in class com.facebook.buck.artifact_cache.ClientCertificateHandler
-
- getHangMonitor() - Method in class com.facebook.buck.cli.HangMonitor.AutoStartInstance
-
- getHash() - Method in class com.facebook.buck.remoteexecution.grpc.GrpcProtocol.GrpcDigest
-
- getHash() - Method in interface com.facebook.buck.remoteexecution.interfaces.Protocol.Digest
-
- getHash() - Method in class com.facebook.buck.util.sha1.Sha1HashCode
-
- getHashCode() - Method in class com.facebook.buck.core.rulekey.RuleKey
-
- getHashCode() - Method in class com.facebook.buck.file.FileHash
-
Get the original hash code object used to create this
FileHash
object
- getHashCode() - Method in class com.facebook.buck.util.cache.HashCodeAndFileType
-
- getHashedBuckOutLinkMode() - Method in class com.facebook.buck.command.config.BuildBuckConfig
-
- getHashEntries() - Method in class com.facebook.buck.jvm.java.JarParameters
-
- getHasher() - Method in class com.facebook.buck.rules.keys.DefaultRuleKeyScopedHasher
-
- getHashFunction() - Method in class com.facebook.buck.file.FileHash
-
Get the hash function for this type of hash
- getHashFunction() - Method in class com.facebook.buck.remoteexecution.grpc.GrpcProtocol
-
- getHashFunction() - Method in interface com.facebook.buck.remoteexecution.interfaces.Protocol
-
- getHashPath() - Method in interface com.facebook.buck.android.exopackage.ExopackagePathAndHash
-
- getHaskellPlatforms() - Method in interface com.facebook.buck.features.haskell.HaskellPlatformsProvider
-
- getHasWhitelistedStrings() - Method in class com.facebook.buck.android.AndroidResourceDescriptionArg
-
- getHeader(MappedByteBuffer) - Static method in class com.facebook.buck.cxx.toolchain.objectfile.Machos
-
Returns the Mach-O header provided the file is Mach-O, otherwise throws an exception.
- getHeaderDirs() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getHeaderMap() - Method in class com.facebook.buck.cxx.CxxHeaders
-
- getHeaderMap() - Method in class com.facebook.buck.cxx.CxxHeadersDir
-
- getHeaderMap() - Method in class com.facebook.buck.cxx.CxxRawHeaders
-
- getHeaderMap() - Method in class com.facebook.buck.cxx.CxxSymlinkTreeHeaders
-
- getHeaderMapSourcePath() - Method in class com.facebook.buck.cxx.HeaderSymlinkTreeWithHeaderMap
-
- getHeaderMapSourcePath() - Method in class com.facebook.buck.cxx.toolchain.HeaderSymlinkTree
-
- getHeaderMode() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getHeaderMode() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getHeaderModeForPlatform(BuildRuleResolver, TargetConfiguration, CxxPlatform, boolean) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- getHeaderNamespace() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getHeaderNamespace() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getHeaderNamespace() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getHeaderNamespace() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getHeaderNamespace() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
- getHeaderNamespace() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getHeaderNamespace() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getHeaderNamespace() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getHeaderNamespace() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getHeaderNamespace() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getHeaderNamespace() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getHeaderNamespace() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getHeaderPathPrefix() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getHeaderPathPrefix(AppleNativeTargetDescriptionArg, BuildTarget) - Static method in class com.facebook.buck.apple.AppleDescriptions
-
- getHeaderPathPrefix() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getHeaderPathPrefix() - Method in interface com.facebook.buck.apple.AppleNativeTargetDescriptionArg
-
- getHeaderPathPrefix() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getHeaders() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getHeaders() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getHeaders() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getHeaders() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getHeaders() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
- getHeaders() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getHeaders() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getHeaders() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getHeaders() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getHeaders() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getHeaders() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getHeaderSize() - Method in class com.facebook.buck.android.resources.ResChunk
-
- getHeaderSourcePath() - Method in class com.facebook.buck.cxx.PreInclude
-
- getHeadersWhitelist() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
A list of regexes which match headers (belonging to the toolchain) to exempt from untracked
header verification.
- getHeaderSymlinkTreeFlavor(HeaderVisibility) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- getHeaderSymlinkTreePath(ProjectFilesystem, BuildTarget, HeaderVisibility, Flavor...) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- getHeaderSymlinkTreeSuffix(HeaderVisibility) - Static method in class com.facebook.buck.apple.AppleHeaderVisibilities
-
- getHeaderVerification() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getHeaderVerificationOrIgnore() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getHgCmd() - Method in class com.facebook.buck.util.versioncontrol.VersionControlBuckConfig
-
- getHiddenImplicitAttributes() - Method in class com.facebook.buck.core.starlark.rule.SkylarkUserDefinedRule
-
- getHideSucceededRulesInLogMode() - Method in class com.facebook.buck.event.listener.SuperConsoleConfig
-
- getHighlightedBuildIds() - Method in interface com.facebook.buck.doctor.DefectReporter.DefectReport
-
- getHighlightedResetSequence() - Method in class com.facebook.buck.util.Ansi
-
- getHighlightedWarningSequence() - Method in class com.facebook.buck.util.Ansi
-
- getHint() - Method in class com.facebook.buck.core.starlark.coercer.SkylarkParamInfo
-
- getHint() - Method in interface com.facebook.buck.rules.coercer.ParamInfo
-
- getHint() - Method in class com.facebook.buck.rules.coercer.ReflectionParamInfo
-
- getHip() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getHip() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getHipflags() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getHipflags() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getHippp() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getHippp() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getHipppflags() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getHipppflags() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getHitCount() - Method in class com.facebook.buck.util.cache.CacheStats
-
- getHost() - Method in interface com.facebook.buck.apple.simulator.AppleDevice
-
String that represents the host of the device
- getHostConfiguration() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getHostFlavor() - Static method in class com.facebook.buck.cxx.toolchain.impl.CxxPlatforms
-
- getHostname() - Method in class com.facebook.buck.util.environment.BuildEnvironmentDescription
-
- getHostname() - Method in class com.facebook.buck.util.environment.DefaultExecutionEnvironment
-
- getHostname() - Method in interface com.facebook.buck.util.environment.ExecutionEnvironment
-
- getHostname() - Static method in class com.facebook.buck.util.network.hostname.HostnameFetching
-
- gethostname(byte[], int) - Static method in class com.facebook.buck.util.network.hostname.HostnameFetchingPosixLibrary
-
- getHostnameVerifier() - Method in class com.facebook.buck.artifact_cache.ClientCertificateHandler
-
- getHostPlatform() - Method in class com.facebook.buck.cli.AbstractCommand
-
- getHostPlatform() - Method in class com.facebook.buck.cli.AbstractContainerCommand
-
- getHostPlatform() - Method in interface com.facebook.buck.cli.Command
-
- getHostPlatform() - Method in class com.facebook.buck.cli.UnconfiguredQueryCommand
-
- getHostPlatform() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getHostPlatform() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getHostToReportToRemoteCacheServer() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getHttpCacheEntries() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheEntries
-
- getHttpFetchConcurrency() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getHttpMaxConcurrentWrites() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getHttpWriterShutdownTimeout() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getHumanReadableErrorMessage() - Method in interface com.facebook.buck.core.exceptions.ExceptionWithHumanReadableMessage
-
- getHumanReadableErrorMessage() - Method in exception com.facebook.buck.core.exceptions.HumanReadableException
-
- getHumanReadableErrorMessage() - Method in exception com.facebook.buck.core.model.targetgraph.NoSuchTargetException
-
- getHumanReadableErrorMessage() - Method in exception com.facebook.buck.parser.exceptions.BuildFileParseException
-
- getHumanReadableErrorMessage() - Method in exception com.facebook.buck.parser.exceptions.MissingBuildFileException
-
- getHumanReadableErrorMessage() - Method in exception com.facebook.buck.parser.exceptions.NoSuchBuildTargetException
-
- getHumanReadableErrorMessage() - Method in exception com.facebook.buck.query.QueryException
-
- getHumanReadableOrLocalizedMessage(Throwable) - Static method in class com.facebook.buck.util.MoreExceptions
-
- getHumanReadableSize(double, SizeUnit) - Static method in enum com.facebook.buck.util.unit.SizeUnit
-
- getHybridLocalConfig() - Method in class com.facebook.buck.rules.modern.config.ModernBuildRuleConfig
-
- getHybridLocalConfig() - Method in interface com.facebook.buck.rules.modern.config.ModernBuildRuleStrategyConfig
-
- getHybridLocalConfig() - Method in class com.facebook.buck.rules.modern.config.ModernBuildRuleStrategyConfigFromSection
-
- getHybridThriftEndpoint() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getHybridThriftPath() - Method in class com.facebook.buck.slb.HybridThriftOverHttpServiceImplArgs
-
- getIbtool() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
ibtool binary.
- getIbtool() - Method in class com.facebook.buck.apple.toolchain.AppleCxxPlatform
-
- getIbtoolFlags() - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg
-
- getIbtoolModuleFlag() - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg
-
- getID() - Method in class com.facebook.buck.core.rules.actions.AbstractAction
-
- getID() - Method in interface com.facebook.buck.core.rules.actions.Action
-
- getID() - Method in class com.facebook.buck.core.rules.analysis.action.ActionAnalysisData.ID
-
- getID() - Method in interface com.facebook.buck.core.rules.analysis.action.ActionAnalysisDataKey
-
- getId() - Method in class com.facebook.buck.features.haskell.HaskellPrebuiltLibraryDescriptionArg
-
- getId() - Method in enum com.facebook.buck.features.project.intellij.lang.android.AndroidProjectType
-
- getId() - Method in class com.facebook.buck.support.jvm.GCCollectionEvent
-
- getIdbPath() - Method in class com.facebook.buck.apple.AppleConfig
-
Gets the path to the executable file of idb
- getIdeaConfigDir() - Method in class com.facebook.buck.features.project.intellij.IjProjectPaths
-
- getIdeallyRelativePath(SourcePath) - Method in class com.facebook.buck.core.sourcepath.resolver.impl.AbstractSourcePathResolver
-
- getIdeallyRelativePath(SourcePath) - Method in interface com.facebook.buck.core.sourcepath.resolver.SourcePathResolver
-
- getIdeallyRelativePath(SourcePath) - Method in class com.facebook.buck.core.sourcepath.resolver.SourcePathResolverAdapter
-
- getIdentifier() - Method in enum com.facebook.buck.android.aapt.RDotTxtEntry.CustomDrawableType
-
Get the string identifier (currently a single character) for the custom drawable type.
- getIdentifier() - Method in class com.facebook.buck.android.device.TargetDevice
-
- getIdentifier() - Method in interface com.facebook.buck.apple.toolchain.AppleToolchain
-
The identifier of the toolchain.
- getIdentifier() - Method in class com.facebook.buck.apple.xcode.xcodeproj.ProductType
-
- getIdentifier() - Method in class com.facebook.buck.core.files.DirectoryListComputation
-
- getIdentifier() - Method in class com.facebook.buck.core.files.DirectoryListKey
-
- getIdentifier() - Method in class com.facebook.buck.core.files.FileTreeComputation
-
- getIdentifier() - Method in class com.facebook.buck.core.files.FileTreeKey
-
- getIdentifier() - Method in interface com.facebook.buck.core.graph.transformation.composition.ComposedComputation
-
- getIdentifier() - Method in class com.facebook.buck.core.graph.transformation.composition.LeftComposingComputation
-
- getIdentifier() - Method in class com.facebook.buck.core.graph.transformation.composition.RightComposingComputation
-
- getIdentifier() - Method in interface com.facebook.buck.core.graph.transformation.GraphComputation
-
- getIdentifier() - Method in class com.facebook.buck.core.graph.transformation.model.ComposedKey
-
- getIdentifier() - Method in interface com.facebook.buck.core.graph.transformation.model.ComputeKey
-
- getIdentifier() - Method in class com.facebook.buck.core.parser.BuildTargetPatternToBuildPackagePathComputation
-
- getIdentifier() - Method in class com.facebook.buck.core.parser.BuildTargetPatternToBuildPackagePathKey
-
- getIdentifier() - Method in class com.facebook.buck.core.parser.WatchmanBuildPackageComputation
-
- getIdentifier() - Method in class com.facebook.buck.core.rules.analysis.impl.LegacyCompatibleRuleAnalysisComputation
-
- getIdentifier() - Method in class com.facebook.buck.core.rules.analysis.impl.RuleAnalysisComputation
-
- getIdentifier() - Method in class com.facebook.buck.core.rules.analysis.RuleAnalysisKey
-
- getIdentifier(Label, String) - Static method in class com.facebook.buck.core.starlark.rule.names.UserDefinedRuleNames
-
Creates an identifier that can be used in buck.type
in the parser
- getIdentifier() - Method in class com.facebook.buck.parser.manifest.BuildPackagePathToBuildFileManifestComputation
-
- getIdentifier() - Method in class com.facebook.buck.parser.manifest.BuildPackagePathToBuildFileManifestKey
-
- getIdentifier() - Method in class com.facebook.buck.parser.targetnode.BuildPackagePathToUnconfiguredTargetNodePackageComputation
-
- getIdentifier() - Method in class com.facebook.buck.parser.targetnode.BuildPackagePathToUnconfiguredTargetNodePackageKey
-
- getIdentifier() - Method in class com.facebook.buck.parser.targetnode.BuildTargetToUnconfiguredTargetNodeComputation
-
- getIdentifier() - Method in class com.facebook.buck.parser.targetnode.BuildTargetToUnconfiguredTargetNodeKey
-
- getIdentifier() - Method in class com.facebook.buck.parser.targetnode.UnconfiguredTargetNodeToUnconfiguredTargetNodeWithDepsComputation
-
- getIdentifier() - Method in class com.facebook.buck.parser.targetnode.UnconfiguredTargetNodeToUnconfiguredTargetNodeWithDepsKey
-
- getIdentitiesSupplier() - Method in interface com.facebook.buck.apple.toolchain.CodeSignIdentityStore
-
- getIfPresent(TargetGraph) - Method in class com.facebook.buck.core.model.actiongraph.computation.ActionGraphCache
-
- getIfPresent(Path) - Method in class com.facebook.buck.util.cache.DelegatingFileHashCacheEngine
-
- getIfPresent(Path) - Method in interface com.facebook.buck.util.cache.FileHashCacheEngine
-
- getIfPresent(Path) - Method in class com.facebook.buck.util.cache.impl.DefaultFileHashCache
-
- getIfPresent(Path) - Method in class com.facebook.buck.util.filesystem.FileSystemMap
-
Gets the value associated with the given path, if found, or `null` otherwise.
- getIfPresent(Path) - Method in interface com.facebook.buck.util.hashing.ProjectFileHashLoader
-
- getIgnoredTargetLabels() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
Labels that indicate targets that need to be ignored during project generation.
- getIgnorePaths() - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- getIgnorePaths() - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
- getIgnorePaths() - Method in class com.facebook.buck.parser.options.ProjectBuildFileParserOptions
-
- getIgnorePaths() - Method in interface com.facebook.buck.remoteexecution.config.RemoteExecutionStrategyConfig
-
- getIgnoreUndefinedSymbolsFlags() - Method in class com.facebook.buck.cxx.toolchain.linker.impl.DarwinLinker
-
- getIgnoreUndefinedSymbolsFlags() - Method in class com.facebook.buck.cxx.toolchain.linker.impl.GnuLinker
-
- getIgnoreUndefinedSymbolsFlags() - Method in class com.facebook.buck.cxx.toolchain.linker.impl.WindowsLinker
-
- getIgnoreUndefinedSymbolsFlags() - Method in interface com.facebook.buck.cxx.toolchain.linker.Linker
-
- getIjName() - Method in class com.facebook.buck.features.project.intellij.model.folders.ExcludeFolder
-
- getIjName() - Method in class com.facebook.buck.features.project.intellij.model.folders.IjFolder
-
- getIjName() - Method in class com.facebook.buck.features.project.intellij.model.folders.InclusiveFolder
-
- getIjResourceFolderType() - Method in enum com.facebook.buck.features.project.intellij.FolderTypeWithPackageInfo
-
- getIjResourceFolderType() - Method in class com.facebook.buck.features.project.intellij.model.folders.IjSourceFolder
-
- getImlModuleType() - Method in enum com.facebook.buck.features.project.intellij.model.IjModuleType
-
- getImmediateClasspaths() - Method in class com.facebook.buck.android.AndroidAar
-
- getImmediateClasspaths() - Method in class com.facebook.buck.android.AndroidBinary
-
- getImmediateClasspaths() - Method in class com.facebook.buck.android.AndroidBundle
-
- getImmediateClasspaths() - Method in class com.facebook.buck.android.ApkGenrule
-
- getImmediateClasspaths() - Method in interface com.facebook.buck.jvm.core.HasClasspathEntries
-
Returns the classpaths for only this rule, not its deps.
- getImmediateClasspaths() - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getImmediateClasspaths() - Method in class com.facebook.buck.jvm.java.JarFattener
-
- getImmediateClasspaths() - Method in class com.facebook.buck.jvm.java.JavaBinary
-
- getImmediateClasspaths() - Method in class com.facebook.buck.jvm.java.JavaTest
-
- getImmediateClasspaths() - Method in class com.facebook.buck.jvm.java.PrebuiltJar
-
- getImplementation() - Method in class com.facebook.buck.core.starlark.rule.SkylarkDescriptionArg
-
- getImplementation(ExecutableElement, TypeElement) - Method in interface com.facebook.buck.jvm.java.lang.model.ElementsExtended
-
- getImplementation(ExecutableElement, TypeElement) - Method in class com.facebook.buck.jvm.java.plugin.adapter.ElementsExtendedImpl
-
- getImplicitlyLoadedSymbols() - Method in class com.facebook.buck.skylark.packages.PackageContext
-
Gets objects that were implciitly loaded
- getImplicitNativeRulesState() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getImplicitNativeRulesState() - Method in class com.facebook.buck.parser.options.ProjectBuildFileParserOptions
-
- getImplicitPreCoercionValue() - Method in class com.facebook.buck.core.starlark.coercer.SkylarkParamInfo
-
- getImplicitPreCoercionValue() - Method in interface com.facebook.buck.rules.coercer.ParamInfo
-
- getImplicitPreCoercionValue() - Method in class com.facebook.buck.rules.coercer.ReflectionParamInfo
-
- getImportDirs() - Method in class com.facebook.buck.features.haskell.HaskellPrebuiltLibraryDescriptionArg
-
- getImportLib() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getImportLibs() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescriptionArg
-
Import libraries references in the shared link args above.
- getImportPath() - Method in class com.facebook.buck.android.GenAidlDescriptionArg
-
- getImportString() - Method in class com.facebook.buck.parser.implicit.ImplicitInclude
-
- getInclude() - Method in class com.facebook.buck.skylark.io.GlobSpec
-
Wildcards of paths that should be returned.
- getIncludeBuildConfigClass() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getIncludedFiles(Path) - Method in interface com.facebook.buck.parser.api.FileParser
-
Collects the loaded files and extensions when parsing the parseFile
build spec.
- getIncludedFiles(Path) - Method in class com.facebook.buck.parser.api.ForwardingProjectBuildFileParserDecorator
-
- getIncludedFiles(Path) - Method in class com.facebook.buck.parser.ConcurrentProjectBuildFileParser
-
- getIncludedFiles(Path) - Method in class com.facebook.buck.parser.HybridProjectBuildFileParser
-
- getIncludedFiles(Path) - Method in class com.facebook.buck.parser.PythonDslProjectBuildFileParser
-
- getIncludeDir() - Method in class com.facebook.buck.features.ocaml.PrebuiltOcamlLibraryDescriptionArg
-
- getIncludeDirectories() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
A list of include directories to be added to the compile command for compiling this cxx target.
- getIncludeDirectories() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
A list of include directories to be added to the compile command for compiling this cxx target.
- getIncludeDirectories() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
A list of include directories to be added to the compile command for compiling this cxx target.
- getIncludeDirectories() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
A list of include directories to be added to the compile command for compiling this cxx target.
- getIncludeDirectories() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
A list of include directories to be added to the compile command for compiling this cxx target.
- getIncludeDirectories() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
A list of include directories to be added to the compile command for compiling this cxx target.
- getIncludeDirectories() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
A list of include directories to be added to the compile command for compiling this cxx target.
- getIncludeDirectories() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getIncludeDirectories() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getIncludeDirectories() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getIncludeDirectories() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getIncludeDirs() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescriptionArg
-
- getIncludedPaths() - Method in interface com.facebook.buck.doctor.DefectReporter.DefectReport
-
- getIncludedRoots() - Method in class com.facebook.buck.cxx.OmnibusRoots
-
- getIncludeLibDir(OcamlPlatform) - Method in class com.facebook.buck.features.ocaml.OcamlLibrary
-
- getIncludePathFlags(SourcePathResolverAdapter, PathShortener, Function<FrameworkPath, Path>, Preprocessor) - Method in class com.facebook.buck.cxx.PreprocessorFlags
-
- getIncludeRoot() - Method in class com.facebook.buck.cxx.CxxSymlinkTreeHeaders
-
- getIncludeRuntime() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
Include Kotlin runtime in to resulting .jar
- getIncludeRuntime() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
Include Kotlin runtime in to resulting .jar
- getIncludeRuntime() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
Include Kotlin runtime in to resulting .jar
- getIncludeRuntime() - Method in interface com.facebook.buck.jvm.kotlin.KotlinLibraryDescription.CoreArg
-
Include Kotlin runtime in to resulting .jar
- getIncludeRuntime() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
Include Kotlin runtime in to resulting .jar
- getIncludeRuntime() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
Include Kotlin runtime in to resulting .jar
- getIncludes() - Method in class com.facebook.buck.core.model.targetgraph.raw.UnconfiguredTargetNodeWithDepsPackage
-
Set of extension files read during parsing.
- getIncludes() - Method in class com.facebook.buck.cxx.CxxPreprocessorInput
-
- getIncludes() - Method in class com.facebook.buck.cxx.CxxSourceRuleFactory
-
- getIncludes() - Method in class com.facebook.buck.cxx.PreprocessorFlags
-
Directories set via -I
.
- getIncludes() - Method in class com.facebook.buck.features.d.DLibrary
-
- getIncludes() - Method in class com.facebook.buck.parser.api.BuildFileManifest
-
- getIncludes() - Method in interface com.facebook.buck.parser.api.FileManifest
-
- getIncludes() - Method in class com.facebook.buck.parser.api.PackageFileManifest
-
- getIncludeSourcePath() - Method in class com.facebook.buck.cxx.HeaderSymlinkTreeWithHeaderMap
-
- getIncludeSourcePath() - Method in class com.facebook.buck.cxx.toolchain.HeaderSymlinkTree
-
Get path to use as an include path to get access to the files in the tree.
- getIncludeStdErr() - Method in interface com.facebook.buck.test.config.TestResultSummaryVerbosity
-
- getIncludeStdOut() - Method in interface com.facebook.buck.test.config.TestResultSummaryVerbosity
-
- getIncludesVectorDrawables() - Method in class com.facebook.buck.android.AndroidInstrumentationApkDescriptionArg
-
- getIncludeTestPatterns() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getIncludeType() - Method in class com.facebook.buck.cxx.CxxHeaders
-
- getIncludeType() - Method in class com.facebook.buck.cxx.CxxHeadersDir
-
- getIncludeType() - Method in class com.facebook.buck.cxx.CxxRawHeaders
-
- getIncludeType() - Method in class com.facebook.buck.cxx.CxxSymlinkTreeHeaders
-
- getIncomingNodesFor(T) - Method in class com.facebook.buck.core.util.graph.DirectedAcyclicGraph
-
- getIncomingNodesFor(T) - Method in class com.facebook.buck.core.util.graph.MutableDirectedGraph
-
- getIncomingNodesFor(T) - Method in interface com.facebook.buck.core.util.graph.TraversableGraph
-
- getIncrementalActionGraphExperimentGroups() - Method in class com.facebook.buck.core.model.actiongraph.computation.ActionGraphConfig
-
- getIncrementalActionGraphMode() - Method in class com.facebook.buck.core.model.actiongraph.computation.ActionGraphConfig
-
- getIndependentShlibInterfacesLdflags() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getIndex() - Method in class com.facebook.buck.core.model.targetgraph.MergedTargetGraph
-
- getIndex(Object, Location, StarlarkContext) - Method in class com.facebook.buck.core.rules.providers.collect.impl.LegacyProviderInfoCollectionImpl
-
- getIndex(Object, Location, StarlarkContext) - Method in class com.facebook.buck.core.rules.providers.collect.impl.ProviderInfoCollectionImpl
-
- getIndex(Object, Location, StarlarkContext) - Method in class com.facebook.buck.core.starlark.rule.data.SkylarkDependency
-
- getIndex() - Method in interface com.facebook.buck.cxx.toolchain.elf.Elf.ElfSectionLookupResult
-
- getInferTopLevel() - Method in class com.facebook.buck.cxx.toolchain.InferBuckConfig
-
- getInfoPlist() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getInfoPlist() - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg
-
- getInfoPlist() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getInfoPlist() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getInfoPlist() - Method in interface com.facebook.buck.apple.HasAppleBundleFields
-
- getInfoPlistPath() - Method in class com.facebook.buck.apple.AppleBundle
-
- getInfoPlistSubstitutions() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getInfoPlistSubstitutions() - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg
-
- getInfoPlistSubstitutions() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getInfoPlistSubstitutions() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getInfoPlistSubstitutions() - Method in interface com.facebook.buck.apple.HasAppleBundleFields
-
- getInitialCause(Throwable) - Static method in class com.facebook.buck.util.MoreThrowables
-
If throwable has a non-empty cause, returns throwable at the bottom of the stack.
- getInitialError() - Method in class com.facebook.buck.log.ErrorLogRecord
-
- getInitialErrorMsg() - Method in class com.facebook.buck.log.ErrorLogRecord
-
- getInitTimeMs() - Method in class com.facebook.buck.log.PerfTimesStats
-
- getInlineMethods() - Method in class com.facebook.buck.jvm.java.abi.StubJarEntry
-
- getInner() - Method in class com.facebook.buck.jvm.java.abi.source.FrontendOnlyJavacTaskProxyImpl
-
- getInner() - Method in class com.facebook.buck.jvm.java.plugin.adapter.BuckJavacTaskProxyImpl
-
- getInner() - Method in class com.facebook.buck.jvm.java.plugin.adapter.TaskListenerProxy
-
- getInplaceBinaryInterpreterFlags() - Method in class com.facebook.buck.features.python.toolchain.impl.LazyPythonPlatform
-
- getInplaceBinaryInterpreterFlags() - Method in interface com.facebook.buck.features.python.toolchain.PythonPlatform
-
- getInput() - Method in class com.facebook.buck.cxx.CxxPreprocessAndCompile
-
- getInput() - Method in class com.facebook.buck.cxx.CxxThinLTOOpt
-
- getInput() - Method in interface com.facebook.buck.jvm.java.classes.FileLike
-
Opens a new input stream for the entry.
- getInputBasedRuleKeyFactory() - Method in class com.facebook.buck.rules.keys.RuleKeyFactories
-
- getInputClass() - Method in class com.facebook.buck.rules.macros.AbsoluteOutputMacroExpander
-
- getInputClass() - Method in class com.facebook.buck.rules.macros.AbstractLocationMacroExpander
-
- getInputClass() - Method in class com.facebook.buck.rules.macros.ArgExpander
-
- getInputClass() - Method in class com.facebook.buck.rules.macros.ClasspathAbiMacroExpander
-
- getInputClass() - Method in class com.facebook.buck.rules.macros.ClasspathMacroExpander
-
- getInputClass() - Method in class com.facebook.buck.rules.macros.EnvironmentVariableMacroExpander
-
- getInputClass() - Method in class com.facebook.buck.rules.macros.ExecutableMacroExpander
-
- getInputClass() - Method in class com.facebook.buck.rules.macros.LocationMacroExpander
-
- getInputClass() - Method in class com.facebook.buck.rules.macros.LocationPlatformMacroExpander
-
- getInputClass() - Method in interface com.facebook.buck.rules.macros.MacroExpander
-
- getInputClass() - Method in class com.facebook.buck.rules.macros.MavenCoordinatesMacroExpander
-
- getInputClass() - Method in class com.facebook.buck.rules.macros.OutputMacroExpander
-
- getInputClass() - Method in class com.facebook.buck.rules.macros.QueryOutputsMacroExpander
-
- getInputClass() - Method in class com.facebook.buck.rules.macros.QueryPathsMacroExpander
-
- getInputClass() - Method in class com.facebook.buck.rules.macros.QueryTargetsAndOutputsMacroExpander
-
- getInputClass() - Method in class com.facebook.buck.rules.macros.QueryTargetsMacroExpander
-
- getInputClass() - Method in class com.facebook.buck.rules.macros.StringExpander
-
- getInputClass() - Method in class com.facebook.buck.rules.macros.WorkerMacroExpander
-
- getInputFileListPaths() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXShellScriptBuildPhase
-
Returns the list (possibly empty) of .xcfilelist files that contain inputs for the script
- getInputFileLists() - Method in class com.facebook.buck.apple.XcodeScriptDescriptionArg
-
- getInputPaths() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXShellScriptBuildPhase
-
Returns the list (possibly empty) of files passed as input to the shell script.
- getInputRootDigest() - Method in interface com.facebook.buck.remoteexecution.interfaces.Protocol.Action
-
- getInputRuleKey() - Method in interface com.facebook.buck.core.rulekey.BuildRuleKeys
-
- getInputRuleKeyCacheCheckTimestamps() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.Finished
-
- getInputs() - Method in class com.facebook.buck.apple.XcodeScriptDescriptionArg
-
- getInputs(QueryBuildTarget) - Method in class com.facebook.buck.cli.BuckQueryEnvironment
-
- getInputs() - Method in class com.facebook.buck.core.model.targetgraph.impl.TargetNodeImpl
-
- getInputs() - Method in interface com.facebook.buck.core.model.targetgraph.TargetNode
-
Cell root-relative paths.
- getInputs() - Method in class com.facebook.buck.core.rules.actions.AbstractAction
-
- getInputs() - Method in interface com.facebook.buck.core.rules.actions.Action
-
- getInputs() - Method in class com.facebook.buck.features.project.intellij.model.folders.IjFolder
-
- getInputs() - Method in class com.facebook.buck.jvm.java.ResolvedJavacPluginProperties
-
- getInputs(NODE_TYPE) - Method in interface com.facebook.buck.query.QueryEnvironment
-
- getInputs(NODE_TYPE) - Method in class com.facebook.buck.query.TargetVariablesQueryEnvironment
-
- getInputs() - Method in interface com.facebook.buck.rules.keys.DependencyFileRuleKeyFactory.RuleKeyAndInputs
-
- getInputs(T, Consumer<SourcePath>) - Method in interface com.facebook.buck.rules.modern.CustomFieldInputs
-
- getInputs(T) - Method in class com.facebook.buck.rules.modern.impl.InputsMapBuilder
-
Computes the "inputs" graph of rule key appendables.
- getInputs(ModernBuildRule<?>) - Method in class com.facebook.buck.rules.modern.impl.InputsMapBuilder
-
- getInputs(T, ClassInfo<T>) - Method in class com.facebook.buck.rules.modern.impl.InputsMapBuilder
-
See getInputs(T instance) above.
- getInputs(QueryBuildTarget) - Method in class com.facebook.buck.rules.query.GraphEnhancementQueryEnvironment
-
- getInputsAfterBuildingLocally(BuildContext, CellPathResolver) - Method in interface com.facebook.buck.core.rules.attr.SupportsDependencyFileRuleKey
-
Returns a list of source paths that were actually used for the rule.
- getInputsAfterBuildingLocally(BuildContext, CellPathResolver) - Method in class com.facebook.buck.cxx.CxxPreprocessAndCompile
-
- getInputsAfterBuildingLocally(BuildContext, CellPathResolver) - Method in class com.facebook.buck.jvm.java.CalculateSourceAbi
-
- getInputsAfterBuildingLocally(BuildContext, CellPathResolver) - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getInputsAfterBuildingLocally(BuildContext, ProjectFilesystem, SourcePathRuleFinder, CellPathResolver, BuildTarget) - Method in class com.facebook.buck.jvm.java.JarBuildStepsFactory
-
- getInputsForTraces(String) - Method in class com.facebook.buck.util.trace.BuildTraces
-
- getInputSizeLimit() - Method in class com.facebook.buck.rules.keys.InputBasedRuleKeyFactory
-
- getInputSizeLimit() - Method in interface com.facebook.buck.rules.keys.RuleKeyFactory
-
- getInputStream(Artifact) - Method in class com.facebook.buck.core.artifact.ArtifactFilesystem
-
- getInputStream() - Method in class com.facebook.buck.io.unixsocket.UnixDomainSocket
-
- getInputStream() - Method in interface com.facebook.buck.io.watchman.Transport
-
Returns an input stream for reading messages
- getInputStream() - Method in class com.facebook.buck.io.windowspipe.WindowsNamedPipe
-
- getInputStream(Path) - Method in class com.facebook.buck.remoteexecution.util.OutputsCollector.FilesystemBackedDelegate
-
- getInputStreamForRelativePath(Path) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- getInputStreamForRelativePath(Path) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
- getInputStreamSupplier() - Method in class com.facebook.buck.util.zip.JarEntrySupplier
-
- getInputTarget() - Method in class com.facebook.buck.features.apple.project.XCodeProjectCommandHelper.Result
-
- getInputTarget() - Method in class com.facebook.buck.features.apple.projectV2.XCodeProjectCommandHelper.Result
-
- getInsecure() - Method in class com.facebook.buck.remoteexecution.config.RemoteExecutionConfig
-
- getInstallableApk() - Method in class com.facebook.buck.android.ApkGenrule
-
- getInstallDeviceInfo() - Method in class com.facebook.buck.event.InstallEvent.Finished
-
- getInstallHelpers() - Method in class com.facebook.buck.android.AndroidBinary
-
- getInstallHelpers() - Method in class com.facebook.buck.android.AndroidBundle
-
- getInstallHelpers() - Method in class com.facebook.buck.android.AndroidInstrumentationApk
-
- getInstallHelpers() - Method in interface com.facebook.buck.core.rules.attr.HasInstallHelpers
-
- getInstallTimeMs() - Method in class com.facebook.buck.log.PerfTimesStats
-
- getInstance() - Static method in class com.facebook.buck.android.FilterResourcesSteps.DefaultDrawableFinder
-
- getInstance(String) - Static method in class com.facebook.buck.event.api.BuckTracing
-
Gets an instance of
BuckTracing
for tracing in the given plugin.
- getInstance() - Static method in class com.facebook.buck.util.DefaultFilteredDirectoryCopier
-
- getInstance() - Static method in class com.facebook.buck.util.ProcessHelper
-
Gets the singleton instance of this class.
- getInstance() - Static method in class com.facebook.buck.util.ProcessRegistry
-
Gets the singleton instance of this class.
- getInstanceKey() - Method in interface com.facebook.buck.shell.WorkerTool
-
- getInstrumentationTestRunner() - Method in interface com.facebook.buck.android.AndroidManifestReader
-
- getInstrumentationTestRunner() - Method in class com.facebook.buck.android.DefaultAndroidManifestReader
-
- getInteger(String, String) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getInteger() - Method in class com.facebook.buck.query.QueryEnvironment.Argument
-
- getInteger(String, String) - Method in class com.facebook.buck.util.config.Config
-
- getIntellijModuleSdkName() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getIntellijPluginLabels() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getInterfaces() - Method in class com.facebook.buck.features.haskell.HaskellCompileRule
-
- getInterfaces() - Method in class com.facebook.buck.features.haskell.HaskellHaddockLibRule
-
- getInterfaces(TypeElement) - Static method in class com.facebook.buck.jvm.java.lang.model.MoreElements
-
- getInternal(BuildTarget) - Method in class com.facebook.buck.core.model.targetgraph.TargetGraph
-
- getInternal(BuildTarget) - Method in class com.facebook.buck.versions.VersionedTargetGraph
-
- getInterpolatedFixScript(ImmutableList<String>, Path, Path) - Method in class com.facebook.buck.support.fix.FixBuckConfig
-
Gets the full script to invoke in `buck fix`.
- getInterpolatedFixScriptMessage(ImmutableList<String>, String) - Method in class com.facebook.buck.support.fix.FixBuckConfig
-
Gets the message to print to users when `buck fix` is invoked and performs some substitutions
- getInterpreter(String) - Method in class com.facebook.buck.features.python.PythonBuckConfig
-
- getInterpreterName() - Method in class com.facebook.buck.features.python.toolchain.PythonVersion
-
- getInterval() - Method in class com.facebook.buck.event.listener.stats.parse.ParseStatsTracker
-
Get the parse interval.
- getInts() - Method in class com.facebook.buck.event.ScubaData
-
- getIntValue() - Method in enum com.facebook.buck.apple.xcode.xcodeproj.PBXContainerItemProxy.ProxyType
-
- getInvalidationCount() - Method in class com.facebook.buck.util.cache.CacheStats
-
- getInvalidator() - Method in class com.facebook.buck.core.files.DirectoryListCache
-
- getInvalidator() - Method in class com.facebook.buck.core.files.FileTreeCache
-
- getInvalidator() - Method in class com.facebook.buck.parser.manifest.BuildFileManifestCache
-
- getInvocationInfo() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getInvocationType() - Method in class com.facebook.buck.artifact_cache.ArtifactCacheEvent
-
- getIoBytesRead() - Method in class com.facebook.buck.util.ProcessResourceConsumption
-
- getIoBytesWritten() - Method in class com.facebook.buck.util.ProcessResourceConsumption
-
- getIoTotal() - Method in class com.facebook.buck.util.ProcessResourceConsumption
-
- getIs_local() - Method in interface com.facebook.buck.apple.simulator.AppleDevice
-
String that indicates if the device is local or remote ("true" or "false")
- getIsAppClip() - Method in class com.facebook.buck.apple.AppleBundle
-
- getIsAppClip() - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg
-
- getIsAppClip() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getIsAppClip() - Method in interface com.facebook.buck.apple.HasAppleBundleFields
-
- getIsAsset() - Method in class com.facebook.buck.android.NdkLibraryDescriptionArg
-
- getIsAsset() - Method in class com.facebook.buck.android.PrebuiltNativeLibraryDescriptionArg
-
- getIsBestServerCount() - Method in class com.facebook.buck.event.listener.LoadBalancerEventsListener.ServerCounters
-
- getIsCacheable() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getIsCacheable() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getIsCacheable() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getIsCacheable() - Method in class com.facebook.buck.android.ApkGenruleDescriptionArg
-
- getIsDaemon() - Method in class com.facebook.buck.log.ErrorLogRecord
-
- getIsDaemon() - Method in class com.facebook.buck.log.InvocationInfo
-
- getIsExecutable() - Method in class com.facebook.buck.remoteexecution.grpc.GrpcProtocol.GrpcOutputFile
-
- getIsExecutable() - Method in interface com.facebook.buck.remoteexecution.interfaces.Protocol.FileNode
-
- getIsExecutable() - Method in interface com.facebook.buck.remoteexecution.interfaces.Protocol.OutputFile
-
- getIsFixScript() - Method in class com.facebook.buck.support.fix.BuckRunSpec
-
Whether the program is a 'fix' script or not
- getIsRemoteExecution() - Method in class com.facebook.buck.log.ErrorLogRecord
-
- getIsRemoteExecution() - Method in class com.facebook.buck.log.InvocationInfo
-
- getIsRemoteRunnable() - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg
-
- getIsRequestSuccessful() - Method in interface com.facebook.buck.doctor.DefectReporter.DefectSubmitResult
-
If value is empty then no request was made and report was saved locally.
- getIsResourceFolder() - Method in class com.facebook.buck.features.project.intellij.model.folders.IjSourceFolder
-
- getIsSimulator() - Method in class com.facebook.buck.apple.toolchain.ApplePlatform
-
- getIsSimulator() - Method in class com.facebook.buck.swift.toolchain.SwiftTargetTriple
-
- getIsSuperConsoleEnabled() - Method in class com.facebook.buck.log.ErrorLogRecord
-
- getIsTestSource() - Method in class com.facebook.buck.features.project.intellij.model.folders.IjSourceFolder
-
- getIsUiTest() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getJacocoOutputDir(ProjectFilesystem) - Static method in class com.facebook.buck.jvm.java.JacocoConstants
-
- getJarContents() - Method in class com.facebook.buck.jvm.core.DefaultJavaAbiInfo
-
- getJarContents() - Method in class com.facebook.buck.jvm.core.EmptyJavaAbiInfo
-
- getJarContents() - Method in interface com.facebook.buck.jvm.core.JavaAbiInfo
-
- getJarFilesThatMayContainResources() - Method in class com.facebook.buck.android.ModuleInfo
-
- getJarManifest(Path) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- getJarManifest(Path) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
- getJarPath() - Method in class com.facebook.buck.jvm.java.JarParameters
-
- getJarRelativePath() - Method in interface com.facebook.buck.util.cache.JarContentHasher
-
- getJarSignature(String) - Static method in class com.facebook.buck.android.agent.util.AgentUtil
-
- getJavaAnnotationProcessorParams() - Method in class com.facebook.buck.jvm.java.JavacOptions
-
- getJavaBuckConfig() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getJavac() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getJavac() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getJavac() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getJavac() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getJavac() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getJavac() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getJavac() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getJavac() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getJavac() - Method in interface com.facebook.buck.jvm.java.JvmLibraryArg
-
- getJavac() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getJavac() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getJavac() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getJavac() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getJavacInvocation(SourcePathResolverAdapter, ProjectFilesystem, ExecutionContext) - Method in class com.facebook.buck.jvm.java.JavacPipelineState
-
Get the invocation instance.
- getJavacJar() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getJavacJar() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getJavacJar() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getJavacJar() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getJavacJar() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getJavacJar() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getJavacJar() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getJavacJar() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getJavacJar() - Method in interface com.facebook.buck.jvm.java.JvmLibraryArg
-
- getJavacJar() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getJavacJar() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getJavacJar() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getJavacJar() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getJavacJarPath() - Method in class com.facebook.buck.jvm.java.JavacSpec
-
- getJavacLanguageLevelOptions() - Method in class com.facebook.buck.jvm.java.JavaBuckConfig
-
- getJavacOptions() - Method in class com.facebook.buck.jvm.java.JavacToJarStepFactory
-
- getJavacOptions() - Method in interface com.facebook.buck.jvm.java.toolchain.JavacOptionsProvider
-
- getJavacPath() - Method in class com.facebook.buck.jvm.java.JavacSpec
-
- getJavacPluginJsr199Fields(SourcePathResolverAdapter, ProjectFilesystem) - Method in class com.facebook.buck.jvm.java.ResolvedJavacPluginProperties
-
Get the javac plugin fields.
- getJavacProvider() - Method in class com.facebook.buck.jvm.java.JavacSpec
-
- getJavacProvider() - Method in interface com.facebook.buck.jvm.java.toolchain.JavaToolchain
-
- getJavacSource() - Method in class com.facebook.buck.jvm.java.JavacSpec
-
- getJavacSpec(TargetConfiguration) - Method in class com.facebook.buck.jvm.java.JavaBuckConfig
-
- getJavacSpec(SourcePathRuleFinder) - Method in interface com.facebook.buck.jvm.java.JvmLibraryArg
-
- getJavadocUrl() - Method in class com.facebook.buck.android.AndroidPrebuiltAarDescriptionArg
-
- getJavadocUrl() - Method in class com.facebook.buck.jvm.java.PrebuiltJar
-
- getJavadocUrl() - Method in class com.facebook.buck.jvm.java.PrebuiltJarDescriptionArg
-
- getJavadocUrls() - Method in class com.facebook.buck.features.project.intellij.model.IjLibrary
-
- getJavaFileForOutput(JavaFileManager.Location, String, JavaFileObject.Kind, FileObject) - Method in class com.facebook.buck.jvm.java.JavaInMemoryFileManager
-
- getJavaFileObjects(File...) - Method in class com.facebook.buck.jvm.java.ForwardingStandardJavaFileManager
-
- getJavaFileObjects(String...) - Method in class com.facebook.buck.jvm.java.ForwardingStandardJavaFileManager
-
- getJavaFileObjects(File...) - Method in class com.facebook.buck.jvm.java.JavaInMemoryFileManager
-
- getJavaFileObjects(String...) - Method in class com.facebook.buck.jvm.java.JavaInMemoryFileManager
-
- getJavaFileObjectsFromFiles(Iterable<? extends File>) - Method in class com.facebook.buck.jvm.java.ForwardingStandardJavaFileManager
-
- getJavaFileObjectsFromFiles(Iterable<? extends File>) - Method in class com.facebook.buck.jvm.java.JavaInMemoryFileManager
-
- getJavaFileObjectsFromStrings(Iterable<String>) - Method in class com.facebook.buck.jvm.java.ForwardingStandardJavaFileManager
-
- getJavaFileObjectsFromStrings(Iterable<String>) - Method in class com.facebook.buck.jvm.java.JavaInMemoryFileManager
-
- getJavaLanguageLevel() - Method in class com.facebook.buck.features.project.intellij.ModuleBuildContext
-
- getJavaLibrariesToDex() - Method in interface com.facebook.buck.android.packageable.AndroidPackageableCollection
-
JavaLibrary
rules whose output will be dexed and included in the package.
- getJavaLibraryBuildTarget() - Method in class com.facebook.buck.android.DexProducedFromJavaLibrary
-
- getJavaModuleSdkName() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getJavaModuleSdkType() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getJavaPackage() - Method in class com.facebook.buck.android.AndroidBuildConfig
-
- getJavaPackageFinder() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getJavaPackageFinder() - Method in class com.facebook.buck.core.build.context.BuildContext
-
- getJavaPackageFinder() - Method in class com.facebook.buck.core.build.execution.context.ExecutionContext
-
- getJavaPackageFinder(BuckConfig) - Method in class com.facebook.buck.features.project.intellij.IjProjectCommandHelper
-
- getJavaPackageFinder() - Method in interface com.facebook.buck.jvm.java.JavacExecutionContext
-
- getJavaParameters() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
Generate metadata for Java 1.8 reflection on method parameters.
- getJavaParameters() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
Generate metadata for Java 1.8 reflection on method parameters.
- getJavaParameters() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
Generate metadata for Java 1.8 reflection on method parameters.
- getJavaParameters() - Method in interface com.facebook.buck.jvm.kotlin.KotlinLibraryDescription.CoreArg
-
Generate metadata for Java 1.8 reflection on method parameters.
- getJavaParameters() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
Generate metadata for Java 1.8 reflection on method parameters.
- getJavaParameters() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
Generate metadata for Java 1.8 reflection on method parameters.
- getJavaPluginParams() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getJavaPluginParams() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getJavaPluginParams() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getJavaPluginParams() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getJavaPluginParams() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getJavaPluginParams() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getJavaPluginParams() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getJavaPluginParams() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getJavaPluginParams() - Method in interface com.facebook.buck.jvm.java.JvmLibraryArg
-
- getJavaPluginParams() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getJavaPluginParams() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getJavaPluginParams() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getJavaPluginParams() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getJavaRuntimeLauncher(BuildRuleResolver, TargetConfiguration) - Method in class com.facebook.buck.jvm.java.JavaOptions
-
- getJavaRuntimeProvider() - Method in class com.facebook.buck.jvm.java.JavaOptions
-
- getJavaSrcs() - Method in interface com.facebook.buck.jvm.core.JavaLibrary
-
- getJavaSrcs() - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getJavaSrcs() - Method in class com.facebook.buck.jvm.java.PrebuiltJar
-
- getJavaTempDir() - Method in class com.facebook.buck.jvm.java.JavaBuckConfig
-
- getJavaTempDir() - Method in class com.facebook.buck.test.TestRunningOptions
-
- getJavaVersion() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getJavaVersion() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getJavaVersion() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getJavaVersion() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getJavaVersion() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getJavaVersion() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getJavaVersion() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getJavaVersion() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getJavaVersion() - Method in interface com.facebook.buck.jvm.java.JvmLibraryArg
-
- getJavaVersion() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getJavaVersion() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getJavaVersion() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getJavaVersion() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getJavaVersion() - Method in class com.facebook.buck.util.environment.BuildEnvironmentDescription
-
- getJdkHome() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
Path to JDK home directory to include into classpath, if differs from default JAVA_HOME
- getJdkHome() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
Path to JDK home directory to include into classpath, if differs from default JAVA_HOME
- getJdkHome() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
Path to JDK home directory to include into classpath, if differs from default JAVA_HOME
- getJdkHome() - Method in interface com.facebook.buck.jvm.kotlin.KotlinLibraryDescription.CoreArg
-
Path to JDK home directory to include into classpath, if differs from default JAVA_HOME
- getJdkHome() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
Path to JDK home directory to include into classpath, if differs from default JAVA_HOME
- getJdkHome() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
Path to JDK home directory to include into classpath, if differs from default JAVA_HOME
- getJobArgs(SourcePathResolverAdapter) - Method in class com.facebook.buck.rules.macros.WorkerMacroArg
-
- getJobArgs() - Method in interface com.facebook.buck.worker.WorkerJobParams
-
The arguments of the actual job once tool has started and ready to accept jobs.
- getJobsMultiplier() - Method in class com.facebook.buck.core.rules.schedule.RuleScheduleInfo
-
- getJoinedClasspath(SourcePathResolverAdapter, ProjectFilesystem, ImmutableList<ResolvedJavacPluginProperties>) - Static method in class com.facebook.buck.jvm.java.ResolvedJavacPluginProperties
-
- getJournalDir() - Method in class com.facebook.buck.io.filesystem.BuckPaths
-
- getJsBundle() - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg
-
- getJsDependenciesOutputs(ActionGraphBuilder) - Method in class com.facebook.buck.features.js.JsBundle
-
- getJsDependenciesOutputs(ActionGraphBuilder) - Method in class com.facebook.buck.features.js.JsBundleAndroid
-
- getJsDependenciesOutputs(ActionGraphBuilder) - Method in class com.facebook.buck.features.js.JsBundleGenrule
-
- getJsDependenciesOutputs(ActionGraphBuilder) - Method in interface com.facebook.buck.features.js.JsBundleOutputs
-
- getJsonAttributeFormat() - Method in class com.facebook.buck.support.cli.config.CliConfig
-
When printing out json representation of targets, what formatting should be applied
- getJsonProtocolVersion() - Method in class com.facebook.buck.util.environment.BuildEnvironmentDescription
-
- getJvmArgs(SourcePathResolverAdapter) - Method in class com.facebook.buck.android.RobolectricTestX
-
- getJvmArgs(SourcePathResolverAdapter) - Method in class com.facebook.buck.jvm.java.JavaTestX
-
- getJvmTarget() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
Target version of the generated JVM bytecode (1.6 or 1.8), default is 1.6
Possible values: "1.6", "1.8"
- getJvmTarget() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
Target version of the generated JVM bytecode (1.6 or 1.8), default is 1.6
Possible values: "1.6", "1.8"
- getJvmTarget() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
Target version of the generated JVM bytecode (1.6 or 1.8), default is 1.6
Possible values: "1.6", "1.8"
- getJvmTarget() - Method in interface com.facebook.buck.jvm.kotlin.KotlinLibraryDescription.CoreArg
-
Target version of the generated JVM bytecode (1.6 or 1.8), default is 1.6
Possible values: "1.6", "1.8"
- getJvmTarget() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
Target version of the generated JVM bytecode (1.6 or 1.8), default is 1.6
Possible values: "1.6", "1.8"
- getJvmTarget() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
Target version of the generated JVM bytecode (1.6 or 1.8), default is 1.6
Possible values: "1.6", "1.8"
- getKaptAnnotationGenPath(ProjectFilesystem, BuildTarget) - Static method in class com.facebook.buck.jvm.kotlin.KotlincToJarStepFactory
-
- getKaptAnnotationOutputPath(TargetNode<? extends JvmLibraryArg>) - Method in interface com.facebook.buck.features.project.intellij.model.IjModuleFactoryResolver
-
- getKaptApOptions() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getKaptApOptions() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getKaptApOptions() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getKaptApOptions() - Method in interface com.facebook.buck.jvm.kotlin.KotlinLibraryDescription.CoreArg
-
- getKaptApOptions() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getKaptApOptions() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getKeepResourcePattern() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getKeepResourcePattern() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getKeepResourcePattern() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getKey() - Method in class com.facebook.buck.artifact_cache.SecondLevelContentKey
-
- getKey() - Method in class com.facebook.buck.core.build.engine.manifest.Manifest
-
- getKey() - Method in interface com.facebook.buck.core.rules.actions.ActionWrapperData
-
- getKey() - Method in interface com.facebook.buck.core.rules.analysis.action.ActionAnalysisData
-
- getKey() - Method in class com.facebook.buck.core.rules.providers.impl.BuiltInProvider
-
- getKey() - Method in class com.facebook.buck.core.rules.providers.impl.UserDefinedProvider
-
- getKey() - Method in interface com.facebook.buck.core.rules.providers.Provider
-
Returns a serializable representation of this Provider
.
- getKeyFile() - Method in class com.facebook.buck.remoteexecution.config.RemoteExecutionConfig
-
client TLS private key in PEM format
- getKeypass() - Method in class com.facebook.buck.android.KeystoreProperties
-
- getKeys() - Method in class com.facebook.buck.android.resources.ResTablePackage
-
- getKeySeed() - Method in class com.facebook.buck.command.config.BuildBuckConfig
-
- getKeystore() - Method in class com.facebook.buck.android.AndroidBinary
-
- getKeystore() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getKeystore() - Method in class com.facebook.buck.android.AndroidBundle
-
- getKeystore() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getKeystore() - Method in class com.facebook.buck.android.KeystoreProperties
-
- getKind() - Method in class com.facebook.buck.core.model.RuleType
-
- getKind() - Method in class com.facebook.buck.core.parser.buildtargetpattern.BuildTargetPattern
-
Type of the parsed pattern
- getKind() - Method in class com.facebook.buck.cxx.toolchain.ElfSharedLibraryInterfaceParams
-
- getKind() - Method in class com.facebook.buck.cxx.toolchain.MachoDylibStubParams
-
- getKind() - Method in interface com.facebook.buck.cxx.toolchain.SharedLibraryInterfaceParams
-
- getKind() - Method in class com.facebook.buck.io.watchman.WatchmanMultiplePathEvent.Change
-
Kind of a file system change, like modification or deletion of the file
- getKind() - Method in class com.facebook.buck.io.watchman.WatchmanPathEvent
-
The kind of event that occurred.
- getKind() - Method in class com.facebook.buck.jvm.java.JarFileObject
-
- getKind() - Method in class com.facebook.buck.jvm.java.plugin.api.TaskEventMirror
-
- getKnownBuildDescriptions() - Method in class com.facebook.buck.core.rules.knowntypes.KnownNativeRuleTypes
-
- getKnownCells() - Method in interface com.facebook.buck.core.cell.nameresolver.CellNameResolver
-
Gets the mapping for all the available local names.
- getKnownCells() - Method in class com.facebook.buck.core.cell.nameresolver.DefaultCellNameResolver
-
- getKnownConfigurationDescriptions() - Method in class com.facebook.buck.core.rules.knowntypes.KnownNativeRuleTypes
-
- getKnownRoots() - Method in class com.facebook.buck.core.cell.AbstractCellPathResolver
-
- getKnownRoots() - Method in interface com.facebook.buck.core.cell.CellPathResolver
-
- getKnownRoots() - Method in class com.facebook.buck.core.cell.impl.DefaultCellPathResolver
-
- getKnownRootsOfAllCells() - Method in interface com.facebook.buck.core.cell.Cell
-
- getKnownRuleTypesProvider() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getKnownRuleTypesProvider() - Method in class com.facebook.buck.support.state.BuckGlobalState
-
- getKotlinc() - Method in class com.facebook.buck.jvm.kotlin.KotlinBuckConfig
-
- getKotlincPlugins() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getKotlincPlugins() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getKotlincPlugins() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getKotlincPlugins() - Method in interface com.facebook.buck.jvm.kotlin.KotlinLibraryDescription.CoreArg
-
- getKotlincPlugins() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getKotlincPlugins() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getKotlinHomeLibraries() - Method in class com.facebook.buck.jvm.kotlin.KotlinBuckConfig
-
- getKotlinJavaRuntimeLibrary() - Static method in class com.facebook.buck.features.project.intellij.model.IjLibraryFactory
-
- getKotlinJavaRuntimeLibraryTemplatePath() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getLabel(OutputLabel) - Method in class com.facebook.buck.core.model.OutputLabel.Internals
-
- getLabel() - Method in class com.facebook.buck.core.starlark.rule.SkylarkRuleContext
-
- getLabel() - Method in class com.facebook.buck.core.starlark.rule.SkylarkUserDefinedRule
-
Get the string representation of the label of extension file.
- getLabelPattern() - Method in class com.facebook.buck.core.linkgroup.CxxLinkGroupMappingTarget
-
- getLabels() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.android.AndroidAppModularityDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.android.AndroidBuildConfigDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.android.AndroidInstrumentationApkDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.android.AndroidInstrumentationTest
-
- getLabels() - Method in class com.facebook.buck.android.AndroidInstrumentationTestDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.android.AndroidManifestDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.android.AndroidPrebuiltAarDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.android.AndroidResourceDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.android.ApkGenruleDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.android.GenAidlDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.android.NdkLibraryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.android.NdkToolchainDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.android.PrebuiltNativeLibraryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.apple.AppleAssetCatalogDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.apple.ApplePackageDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.apple.AppleResourceDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.apple.AppleTest
-
- getLabels() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.apple.AppleTestX
-
- getLabels() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.apple.AppleToolchainSetDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.apple.AppleWrapperResourceArg
-
- getLabels() - Method in class com.facebook.buck.apple.PrebuiltAppleFrameworkDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.apple.XcodeScriptDescriptionArg
-
- getLabels() - Method in interface com.facebook.buck.core.description.arg.BuildRuleArg
-
- getLabels() - Method in class com.facebook.buck.core.rules.tool.RuleAnalysisLegacyTestBuildRuleView
-
- getLabels() - Method in class com.facebook.buck.core.starlark.rule.SkylarkDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.core.test.rule.ExternalTestRunnerTestSpec
-
- getLabels() - Method in class com.facebook.buck.core.test.rule.impl.ExternalTestRunnerDescriptionArg
-
- getLabels() - Method in interface com.facebook.buck.core.test.rule.TestRule
-
- getLabels() - Method in class com.facebook.buck.core.toolchain.rule.LegacyToolchainDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.cxx.CxxGenruleDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.cxx.CxxPrecompiledHeaderDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.cxx.CxxTest
-
- getLabels() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.d.DBinaryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.d.DLibraryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.d.DTest
-
- getLabels() - Method in class com.facebook.buck.features.d.DTestDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.dotnet.CsharpLibraryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.dotnet.PrebuiltDotnetLibraryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.filegroup.FileGroupDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.go.GoBinaryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.go.GoLibraryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.go.GoTest
-
- getLabels() - Method in class com.facebook.buck.features.go.GoTestDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.go.GoTestRunnerDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.go.GoTestX
-
- getLabels() - Method in class com.facebook.buck.features.go.PrebuiltGoLibraryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.gwt.GwtBinaryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.haskell.HaskellBinaryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.haskell.HaskellGhciDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.haskell.HaskellHaddockDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.haskell.HaskellLibraryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.haskell.HaskellPrebuiltLibraryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.js.JsBundleDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.js.JsLibraryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.lua.LuaBinaryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.lua.LuaLibraryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.ocaml.OcamlBinaryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.ocaml.OcamlLibraryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.ocaml.PrebuiltOcamlLibraryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.python.PrebuiltPythonLibraryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.python.PythonLibraryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.python.PythonTest
-
- getLabels() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.python.PythonTestRunnerDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.python.PythonTestX
-
- getLabels() - Method in class com.facebook.buck.features.rust.PrebuiltRustLibraryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.rust.RustTest
-
- getLabels() - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.features.zip.rules.ZipFileDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.file.HttpArchiveDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.file.HttpFileDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.file.RemoteFileDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.jvm.java.JarGenruleDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.jvm.java.JavaAnnotationProcessorDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.jvm.java.JavaBinaryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.jvm.java.JavaPluginDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.jvm.java.JavaTest
-
- getLabels() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.jvm.java.JavaTestX
-
- getLabels() - Method in class com.facebook.buck.jvm.java.KeystoreDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.jvm.java.PrebuiltJarDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.shell.CommandAliasDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.shell.ExportFileDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.shell.GenruleDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.shell.ShBinaryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.shell.ShTest
-
- getLabels() - Method in class com.facebook.buck.shell.ShTestDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.shell.TestSuiteDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.shell.WorkerToolDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.swift.SwiftLibraryDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.swift.SwiftToolchainDescriptionArg
-
- getLabels() - Method in class com.facebook.buck.test.TestResults
-
- getLabels() - Method in class com.facebook.buck.versions.VersionedAliasDescriptionArg
-
- getLabelToGeneratedSourcesMap() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getLangCompilerFlags() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getLangCompilerFlags() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getLangCompilerFlags() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getLangCompilerFlags() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getLangCompilerFlags() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
- getLangCompilerFlags() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getLangCompilerFlags() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getLangCompilerFlags() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getLangCompilerFlags() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getLangCompilerFlags() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getLangCompilerFlags() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getLangPlatformCompilerFlags() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getLangPlatformCompilerFlags() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getLangPlatformCompilerFlags() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getLangPlatformCompilerFlags() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getLangPlatformCompilerFlags() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
- getLangPlatformCompilerFlags() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getLangPlatformCompilerFlags() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getLangPlatformCompilerFlags() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getLangPlatformCompilerFlags() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getLangPlatformCompilerFlags() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getLangPlatformCompilerFlags() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getLangPlatformPreprocessorFlags() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getLangPlatformPreprocessorFlags() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getLangPlatformPreprocessorFlags() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getLangPlatformPreprocessorFlags() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getLangPlatformPreprocessorFlags() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
- getLangPlatformPreprocessorFlags() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getLangPlatformPreprocessorFlags() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getLangPlatformPreprocessorFlags() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getLangPlatformPreprocessorFlags() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getLangPlatformPreprocessorFlags() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getLangPlatformPreprocessorFlags() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getLangPreprocessorFlags() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getLangPreprocessorFlags() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getLangPreprocessorFlags() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getLangPreprocessorFlags() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getLangPreprocessorFlags() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
- getLangPreprocessorFlags() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getLangPreprocessorFlags() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getLangPreprocessorFlags() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getLangPreprocessorFlags() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getLangPreprocessorFlags() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getLangPreprocessorFlags() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getLanguage() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getLanguage() - Method in interface com.facebook.buck.android.AndroidKotlinCoreArg
-
- getLanguage() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getLanguage() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getLanguage() - Method in enum com.facebook.buck.cxx.CxxSource.Type
-
- getLanguageFlags(ImmutableList<String>, PatternMatchedCollection<ImmutableList<String>>, ImmutableMap<CxxSource.Type, ImmutableList<String>>, CxxPlatform) - Static method in class com.facebook.buck.cxx.CxxFlags
-
- getLanguageFlagsWithMacros(ImmutableList<StringWithMacros>, PatternMatchedCollection<ImmutableList<StringWithMacros>>, ImmutableMap<CxxSource.Type, ? extends Collection<StringWithMacros>>, ImmutableMap<CxxSource.Type, PatternMatchedCollection<ImmutableList<StringWithMacros>>>, CxxPlatform) - Static method in class com.facebook.buck.cxx.CxxFlags
-
- getLanguageLevel(IjProjectConfig, TargetNode<T>) - Static method in class com.facebook.buck.features.project.intellij.JavaLanguageLevelHelper
-
Get Java language level for a JVM library target
- getLanguageLevel() - Method in class com.facebook.buck.features.project.intellij.model.IjModule
-
- getLanguageLevelOptions() - Method in class com.facebook.buck.jvm.java.JavacOptions
-
- getLanguageVersion() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
Provide source compatibility with specified language version.
- getLanguageVersion() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
Provide source compatibility with specified language version.
- getLanguageVersion() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
Provide source compatibility with specified language version.
- getLanguageVersion() - Method in interface com.facebook.buck.jvm.kotlin.KotlinLibraryDescription.CoreArg
-
Provide source compatibility with specified language version.
- getLanguageVersion() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
Provide source compatibility with specified language version.
- getLanguageVersion() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
Provide source compatibility with specified language version.
- getLargeBlobs() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.InputsUploaded
-
- getLastAccessMillis() - Method in class com.facebook.buck.util.DirectoryCleaner.PathStats
-
- GetLastError() - Method in interface com.facebook.buck.io.windowsfs.WindowsFSLibrary
-
- GetLastError() - Method in interface com.facebook.buck.io.windowspipe.WindowsNamedPipeLibrary
-
- getLastException() - Method in class com.facebook.buck.slb.ServerHealthState
-
- getLastKnownFileType() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXFileReference
-
- getLastModified() - Method in class com.facebook.buck.jvm.java.JarFileObject
-
- getLastModifiedTime() - Method in interface com.facebook.buck.doctor.config.BuildLogEntry
-
- getLastModifiedTime(Path) - Method in interface com.facebook.buck.io.file.PathListing.PathModifiedTimeFetcher
-
- getLastModifiedTime(Path) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- getLastModifiedTime(Path) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
- getLastModifiedTime() - Method in class com.facebook.buck.util.trace.BuildTraces.TraceAttributes
-
- getLastModifiedTimeFetcher() - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- getLastNonTerminalState() - Method in class com.facebook.buck.remoteexecution.event.LocalFallbackEvent.Finished
-
- getLastNonTerminalState() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.Terminal
-
- getLastOutputDir() - Method in class com.facebook.buck.io.filesystem.BuckPaths
-
- getLastReportedErrorPercentage() - Method in class com.facebook.buck.slb.ServerHealthState
-
- getLastReportedLatency() - Method in class com.facebook.buck.slb.ServerHealthState
-
- getLastReportedSamples() - Method in class com.facebook.buck.slb.ServerHealthState
-
- getLatencyMicros() - Method in class com.facebook.buck.event.listener.LoadBalancerEventsListener.ServerCounters
-
- getLatencyMicros() - Method in interface com.facebook.buck.slb.LoadBalancedServiceEvent.LoadBalancedServiceEventData
-
- getLaunchAction() - Method in class com.facebook.buck.apple.xcode.XCScheme
-
- getLauncherActivities() - Method in interface com.facebook.buck.android.AndroidManifestReader
-
- getLauncherActivities() - Method in class com.facebook.buck.android.DefaultAndroidManifestReader
-
- getLaunchImage() - Method in class com.facebook.buck.apple.AppleAssetCatalogDescriptionArg
-
- getLaunchStyle() - Method in class com.facebook.buck.apple.xcode.XCScheme.LaunchAction
-
- getLaunchStyle() - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg
-
- getLazyBindInfoOffset() - Method in class com.facebook.buck.cxx.toolchain.objectfile.MachoDyldInfoCommand
-
- getLazyBindInfoSize() - Method in class com.facebook.buck.cxx.toolchain.objectfile.MachoDyldInfoCommand
-
- getLd() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getLdflags() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getLdflags() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getLdflags() - Method in class com.facebook.buck.cxx.toolchain.ElfSharedLibraryInterfaceParams
-
- getLdflags() - Method in class com.facebook.buck.cxx.toolchain.MachoDylibStubParams
-
- getLdflags() - Method in interface com.facebook.buck.cxx.toolchain.SharedLibraryInterfaceParams
-
- getLeft() - Method in class com.facebook.buck.util.types.Either
-
Returns the left value.
- getLeftOption() - Method in class com.facebook.buck.util.types.Either
-
Left value or empty otherwise.
- getLegacyFixScript() - Method in class com.facebook.buck.support.fix.FixBuckConfig
-
Get the previous script that JASABI fixes
- getLegacyName() - Method in class com.facebook.buck.core.cell.CellName
-
- getLegacyName() - Method in class com.facebook.buck.core.cell.name.CanonicalCellName
-
Returns the underlying name in the legacy Optional<String>
format.
- getLegacyTotallyUnsafe(UnresolvedCxxPlatform) - Static method in class com.facebook.buck.cxx.toolchain.impl.LegacyToolchainProvider
-
This definitely shouldn't exist.
- getLevel() - Method in class com.facebook.buck.core.util.log.Logger
-
- getLevel() - Method in class com.facebook.buck.event.ConsoleEvent
-
- getLevel() - Method in interface com.facebook.buck.io.watchman.WatchmanDiagnostic
-
- getLevel() - Method in enum com.facebook.buck.jvm.java.JavaBuckConfig.DuplicatesLogLevel
-
- getLevel() - Method in interface com.facebook.buck.test.TestStatusMessage
-
- getLevenshteinDistance(String, String) - Static method in class com.facebook.buck.util.string.MoreStrings
-
- getLibDir() - Method in class com.facebook.buck.features.ocaml.PrebuiltOcamlLibraryDescriptionArg
-
- getLibInclude(OcamlPlatform, boolean) - Static method in class com.facebook.buck.features.ocaml.OcamlRuleBuilder
-
- getLibName() - Method in class com.facebook.buck.features.ocaml.PrebuiltOcamlLibraryDescriptionArg
-
- getLibraries() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getLibraries() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getLibraries() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getLibraries() - Method in class com.facebook.buck.apple.PrebuiltAppleFrameworkDescriptionArg
-
- getLibraries() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getLibraries() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getLibraries() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getLibraries() - Method in class com.facebook.buck.cxx.Omnibus.OmnibusLibraries
-
- getLibraries() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getLibraries() - Method in interface com.facebook.buck.cxx.toolchain.HasSystemFrameworkAndLibraries
-
- getLibraries() - Method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableInput
-
- getLibraries() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getLibraries() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getLibraries() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getLibraries() - Method in class com.facebook.buck.features.project.intellij.IjModuleGraph
-
- getLibraries() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getLibraries() - Method in class com.facebook.buck.swift.SwiftLibraryDescriptionArg
-
- getLibrariesDir() - Method in class com.facebook.buck.features.project.intellij.IjProjectPaths
-
- getLibrariesToBeWritten() - Method in class com.facebook.buck.features.project.intellij.IjProjectTemplateDataPreparer
-
- getLibrary() - Method in class com.facebook.buck.features.go.GoTestDescriptionArg
-
- getLibrary() - Method in class com.facebook.buck.features.go.PrebuiltGoLibraryDescriptionArg
-
- getLibrary() - Method in class com.facebook.buck.features.project.intellij.IjDependencyListBuilder.DependencyEntry
-
- getLibrary(TargetNode<?>) - Method in class com.facebook.buck.features.project.intellij.model.IjLibraryFactory
-
Creates an IjLibrary.
- getLibraryAndroidManifestPath(TargetNode<AndroidLibraryDescription.CoreArg>) - Method in interface com.facebook.buck.features.project.intellij.model.IjModuleFactoryResolver
-
- getLibraryJarParameters(BuildContext, ProjectFilesystem, CompilerParameters) - Method in class com.facebook.buck.jvm.java.JarBuildStepsFactory
-
- getLibraryName() - Method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkTargetMode
-
- getLibraryPath() - Method in interface com.facebook.buck.android.NativeLibraryBuildRule
-
Returns the path to the directory containing .so
files organized by target CPU
architecture.
- getLibraryPath() - Method in class com.facebook.buck.android.NdkLibrary
-
- getLibraryPath() - Method in class com.facebook.buck.android.PrebuiltNativeLibrary
-
- getLibraryTarget(BuildTarget) - Static method in class com.facebook.buck.jvm.core.JavaAbis
-
Returns the library target for an abi target.
- getLibraryXmlFilePath(IjLibrary) - Method in class com.facebook.buck.features.project.intellij.IjProjectPaths
-
- getLibtool() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
libtool binary.
- getLibtool() - Method in class com.facebook.buck.apple.toolchain.AppleCxxPlatform
-
- getLibType(BuildTarget) - Static method in class com.facebook.buck.cxx.CxxLibraryDescription
-
- getLicenses() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.android.AndroidAppModularityDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.android.AndroidBuildConfigDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.android.AndroidInstrumentationApkDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.android.AndroidInstrumentationTestDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.android.AndroidManifestDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.android.AndroidPrebuiltAarDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.android.AndroidResourceDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.android.ApkGenruleDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.android.GenAidlDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.android.NdkLibraryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.android.NdkToolchainDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.android.PrebuiltNativeLibraryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.apple.AppleAssetCatalogDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.apple.ApplePackageDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.apple.AppleResourceDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.apple.AppleToolchainSetDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.apple.AppleWrapperResourceArg
-
- getLicenses() - Method in class com.facebook.buck.apple.PrebuiltAppleFrameworkDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.apple.XcodeScriptDescriptionArg
-
- getLicenses() - Method in interface com.facebook.buck.core.description.arg.BuildRuleArg
-
- getLicenses() - Method in class com.facebook.buck.core.starlark.rule.SkylarkDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.core.test.rule.impl.ExternalTestRunnerDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.core.toolchain.rule.LegacyToolchainDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.cxx.CxxGenruleDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.cxx.CxxPrecompiledHeaderDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.d.DBinaryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.d.DLibraryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.d.DTestDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.dotnet.CsharpLibraryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.dotnet.PrebuiltDotnetLibraryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.filegroup.FileGroupDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.go.GoBinaryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.go.GoLibraryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.go.GoTestDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.go.GoTestRunnerDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.go.PrebuiltGoLibraryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.gwt.GwtBinaryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.haskell.HaskellBinaryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.haskell.HaskellGhciDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.haskell.HaskellHaddockDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.haskell.HaskellLibraryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.haskell.HaskellPrebuiltLibraryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.js.JsBundleDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.js.JsLibraryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.lua.LuaBinaryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.lua.LuaLibraryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.ocaml.OcamlBinaryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.ocaml.OcamlLibraryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.ocaml.PrebuiltOcamlLibraryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.python.PrebuiltPythonLibraryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.python.PythonLibraryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.python.PythonTestRunnerDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.rust.PrebuiltRustLibraryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.features.zip.rules.ZipFileDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.file.HttpArchiveDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.file.HttpFileDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.file.RemoteFileDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.jvm.java.JarGenruleDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.jvm.java.JavaAnnotationProcessorDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.jvm.java.JavaBinaryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.jvm.java.JavaPluginDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.jvm.java.KeystoreDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.jvm.java.PrebuiltJarDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.shell.CommandAliasDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.shell.ExportFileDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.shell.GenruleDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.shell.ShBinaryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.shell.ShTestDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.shell.TestSuiteDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.shell.WorkerToolDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.swift.SwiftLibraryDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.swift.SwiftToolchainDescriptionArg
-
- getLicenses() - Method in class com.facebook.buck.versions.VersionedAliasDescriptionArg
-
- getLifecycleStatusString() - Method in enum com.facebook.buck.support.state.BuckGlobalStateLifecycleManager.LifecycleStatus
-
Get the string to be logged as an event, if an event should be logged.
- getLikelyActiveNetwork() - Method in class com.facebook.buck.util.environment.DefaultExecutionEnvironment
-
- getLikelyActiveNetwork() - Method in interface com.facebook.buck.util.environment.ExecutionEnvironment
-
- getLikelyActiveNetwork() - Static method in class com.facebook.buck.util.environment.MacNetworkConfiguration
-
Returns a string representing likely active network; eg 'Wired', 'WiFi:'.
- getLikelyActiveNetwork() - Static method in class com.facebook.buck.util.environment.NetworkInfo
-
- getLine() - Method in interface com.facebook.buck.apple.AbstractIdbFailureInfo
-
Integer that represents the line in which the failure occured
- getLine() - Method in class com.facebook.buck.util.network.AbstractBatchingLogger.BatchEntry
-
- getLinearAllocHardLimit() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getLinearAllocHardLimit() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getLineNumber() - Method in interface com.facebook.buck.json.BuildFileParseExceptionStackTraceEntry
-
- getLineNumber() - Method in interface com.facebook.buck.json.BuildFileSyntaxError
-
- getLineNumber() - Method in interface com.facebook.buck.util.xml.DocumentLocation
-
- getLinkableDeps() - Method in class com.facebook.buck.features.go.CGoLibrary
-
- getLinkDepsQueryWhole() - Method in interface com.facebook.buck.cxx.CxxBinaryDescription.CommonArg
-
- getLinkDepsQueryWhole() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getLinkDepsQueryWhole() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getLinkDepsQueryWhole() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getLinkDepsQueryWhole() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getLinkDepsQueryWhole() - Method in class com.facebook.buck.features.haskell.HaskellBinaryDescriptionArg
-
- getLinker() - Method in class com.facebook.buck.cxx.CxxLink
-
- getLinker() - Method in class com.facebook.buck.cxx.CxxThinLTOIndex
-
- getLinker() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
Linker binary.
- getLinker(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getLinkerExtraOutputs() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getLinkerExtraOutputs() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getLinkerExtraOutputs() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getLinkerExtraOutputs() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getLinkerExtraOutputs() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
- getLinkerExtraOutputs() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getLinkerExtraOutputs() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getLinkerExtraOutputs() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getLinkerExtraOutputs() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getLinkerExtraOutputs() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getLinkerExtraOutputs() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getLinkerFlags(NdkCompilerType) - Method in class com.facebook.buck.android.toolchain.ndk.NdkCxxPlatformTargetConfiguration
-
- getLinkerFlags(NdkCompilerType) - Method in enum com.facebook.buck.android.toolchain.ndk.TargetCpuType
-
- getLinkerFlags() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getLinkerFlags() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getLinkerFlags() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getLinkerFlags() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getLinkerFlags() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
- getLinkerFlags() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getLinkerFlags() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getLinkerFlags() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
Linker flags.
- getLinkerFlags() - Method in class com.facebook.buck.features.d.DBinaryDescriptionArg
-
- getLinkerFlags() - Method in class com.facebook.buck.features.d.DBuckConfig
-
- getLinkerFlags() - Method in class com.facebook.buck.features.d.DLibraryDescriptionArg
-
- getLinkerFlags() - Method in class com.facebook.buck.features.d.DTestDescriptionArg
-
- getLinkerFlags() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getLinkerFlags() - Method in class com.facebook.buck.features.go.GoBinaryDescriptionArg
-
- getLinkerFlags() - Method in class com.facebook.buck.features.go.GoTestDescriptionArg
-
- getLinkerFlags() - Method in interface com.facebook.buck.features.go.HasGoLinkable
-
- getLinkerFlags() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getLinkerFlags() - Method in class com.facebook.buck.features.haskell.HaskellBinaryDescriptionArg
-
- getLinkerFlags(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getLinkerFlags() - Method in class com.facebook.buck.features.haskell.HaskellGhciDescriptionArg
-
- getLinkerFlags() - Method in class com.facebook.buck.features.haskell.HaskellLibraryDescriptionArg
-
- getLinkerFlags() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getLinkerFlags() - Method in class com.facebook.buck.features.ocaml.OcamlBinaryDescriptionArg
-
- getLinkerFlags() - Method in class com.facebook.buck.features.ocaml.OcamlLibraryDescriptionArg
-
- getLinkerFlags() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getLinkerFlags() - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg
-
- getLinkerFlags() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getLinkerFlags() - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg
-
- getLinkerFlags(String) - Method in class com.facebook.buck.features.rust.RustBuckConfig
-
- getLinkerFlags() - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg
-
- getLinkerMapPath() - Method in class com.facebook.buck.cxx.CxxLink
-
- getLinkerMapPath() - Method in class com.facebook.buck.cxx.CxxThinLTOIndex
-
- getLinkerParseTimeDeps(TargetConfiguration) - Method in class com.facebook.buck.cxx.toolchain.impl.StaticUnresolvedCxxPlatform
-
- getLinkerParseTimeDeps(TargetConfiguration) - Method in class com.facebook.buck.cxx.toolchain.ProviderBasedUnresolvedCxxPlatform
-
- getLinkerParseTimeDeps(TargetConfiguration) - Method in interface com.facebook.buck.cxx.toolchain.UnresolvedCxxPlatform
-
This probably shouldn't exist.
- getLinkerPlatform(String) - Method in class com.facebook.buck.features.rust.RustBuckConfig
-
- getLinkerProvider(LinkerProvider.Type) - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
Construct a linker based on `ld` and `linker_platform` sections in the config.
- getLinkerSource(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getLinkerType() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
LinkerProvider.Type
of the linker.
- getLinkGroup() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
Defines the link group.
- getLinkGroup() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
Defines the link group.
- getLinkGroup() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
Defines the link group.
- getLinkGroup() - Method in class com.facebook.buck.core.linkgroup.CxxLinkGroupMapping
-
- getLinkGroup() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
Defines the link group.
- getLinkGroup() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
Defines the link group.
- getLinkGroup() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
Defines the link group.
- getLinkGroup() - Method in interface com.facebook.buck.cxx.LinkableCxxConstructorArg
-
Defines the link group.
- getLinkGroup() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getLinkGroup() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getLinkGroupMap() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
Defines the list of link group mappings.
- getLinkGroupMap() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
Defines the list of link group mappings.
- getLinkGroupMap() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
Defines the list of link group mappings.
- getLinkGroupMap() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
Defines the list of link group mappings.
- getLinkGroupMap() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
Defines the list of link group mappings.
- getLinkGroupMap() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
Defines the list of link group mappings.
- getLinkGroupMap() - Method in interface com.facebook.buck.cxx.LinkableCxxConstructorArg
-
Defines the list of link group mappings.
- getLinkGroupMap() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getLinkGroupMap() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getLinkGroupsEnabled() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getLinkGroupsEnabledSetting() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getLinkMode() - Method in class com.facebook.buck.features.go.GoBinaryDescriptionArg
-
- getLinkMode() - Method in class com.facebook.buck.features.go.GoTestDescriptionArg
-
- getLinkMode() - Method in interface com.facebook.buck.features.go.HasGoLinkable
-
- getLinkPaths(AppleSdk, AppleSdkPaths, String) - Static method in enum com.facebook.buck.swift.toolchain.impl.SwiftSdkLayoutType
-
Given the SDK layout and version, return the correct list of lib directory paths
- getLinkRule() - Method in class com.facebook.buck.cxx.CxxBinary
-
- getLinks() - Method in class com.facebook.buck.core.rules.impl.MappedSymlinkTree
-
- getLinkScheduleInfo() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getLinkStyle() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getLinkStyle() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getLinkStyle() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getLinkStyle() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getLinkStyle() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getLinkStyle() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getLinkStyle() - Method in interface com.facebook.buck.cxx.LinkableCxxConstructorArg
-
- getLinkStyle(NativeLinkableGroup.Linkage, Linker.LinkableDepType) - Static method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableGroups
-
- getLinkStyle(NativeLinkableGroup.Linkage, Linker.LinkableDepType, Optional<PicType>) - Static method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkables
-
- getLinkStyle(NativeLinkableGroup.Linkage, Linker.LinkableDepType) - Static method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkables
-
- getLinkStyle() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getLinkStyle() - Method in class com.facebook.buck.features.go.GoBinaryDescriptionArg
-
- getLinkStyle() - Method in class com.facebook.buck.features.go.GoTestDescriptionArg
-
- getLinkStyle() - Method in interface com.facebook.buck.features.go.HasGoLinkable
-
- getLinkStyle() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getLinkStyle() - Method in enum com.facebook.buck.features.haskell.HaskellBinaryDescription.Type
-
- getLinkStyle() - Method in class com.facebook.buck.features.haskell.HaskellBinaryDescriptionArg
-
- getLinkStyle() - Method in class com.facebook.buck.features.rust.PrebuiltRustLibraryDescriptionArg
-
- getLinkStyle() - Method in enum com.facebook.buck.features.rust.RustBinaryDescription.Type
-
- getLinkStyle() - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg
-
- getLinkStyle(BuildTarget, Optional<Linker.LinkableDepType>) - Static method in class com.facebook.buck.features.rust.RustCompileUtils
-
- getLinkStyle() - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg
-
- getLinkStyleForStubHeader(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getLinkWhole() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getLinkWhole() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getLinkWhole() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getLinkWhole() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
- getLinkWhole() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getLinkWhole() - Method in class com.facebook.buck.features.haskell.HaskellLibraryDescriptionArg
-
- getLinkWithoutSoname() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getLipo() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
lipo binary.
- getLipo() - Method in class com.facebook.buck.apple.toolchain.AppleCxxPlatform
-
- getListeningExecutorService() - Method in class com.facebook.buck.cli.CommandThreadManager
-
- getListWithoutComments(String, String) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getListWithoutComments(String, String, char) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getListWithoutComments(String, String) - Method in class com.facebook.buck.util.config.Config
-
- getListWithoutComments(String, String, char) - Method in class com.facebook.buck.util.config.Config
-
- getLittleEndianInt(ByteBuffer) - Static method in class com.facebook.buck.cxx.toolchain.objectfile.ObjectFileScrubbers
-
- getLittleEndianLong(ByteBuffer) - Static method in class com.facebook.buck.cxx.toolchain.objectfile.ObjectFileScrubbers
-
- getLittleEndianShort(ByteBuffer) - Static method in class com.facebook.buck.cxx.toolchain.objectfile.ObjectFileScrubbers
-
- getLldb() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
lldb binary.
- getLldb() - Method in class com.facebook.buck.apple.toolchain.AppleCxxPlatform
-
- getLoadBalancingType() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getLoadedCells() - Method in interface com.facebook.buck.core.cell.Cell
-
- getLoadedCells() - Method in class com.facebook.buck.core.cell.CellProvider
-
- getLoadedPaths() - Method in class com.facebook.buck.skylark.parser.EnvironmentData
-
- getLoadedPaths() - Method in class com.facebook.buck.skylark.parser.ParseResult
-
Returns a set of extension paths that were loaded explicitly or transitively when parsing
current build or package file.
- getLoadExceptionCount() - Method in class com.facebook.buck.util.cache.CacheStats
-
- getLoadPath() - Method in class com.facebook.buck.parser.implicit.ImplicitInclude
-
Returns the load path for the given path.
- getLoadSuccessCount() - Method in class com.facebook.buck.util.cache.CacheStats
-
- getLocalConfigsContents() - Method in interface com.facebook.buck.doctor.config.UserLocalConfiguration
-
- getLocalDelegateJobs() - Method in class com.facebook.buck.rules.modern.config.HybridLocalBuildStrategyConfig
-
- getLocales() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getLocales() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getLocales() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getLocalFallbackStats() - Method in class com.facebook.buck.remoteexecution.event.listener.RemoteExecutionEventListener
-
- getLocalFallbackStats() - Method in interface com.facebook.buck.remoteexecution.event.RemoteExecutionStatsProvider
-
Fetches stats regarding the local fallback.
- getLocalhost() - Method in class com.facebook.buck.core.config.BuckConfig
-
- getLocalizedStringFileName() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getLocalizedStringFileName() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getLocalizedStringFileName() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getLocalJobs() - Method in class com.facebook.buck.rules.modern.config.HybridLocalBuildStrategyConfig
-
- getLocallyExecutedRules() - Method in interface com.facebook.buck.remoteexecution.event.LocalFallbackStats
-
Get the number of actions that failed remotely and fallback'ed locally.
- getLocallySuccessfulRules() - Method in interface com.facebook.buck.remoteexecution.event.LocalFallbackStats
-
For all the actions that fallback'ed to run locally, the ones that finished successful.
- getLocalName() - Method in class com.facebook.buck.core.model.UnflavoredBuildTarget
-
- getLocalNameAndFlavors() - Method in class com.facebook.buck.core.parser.buildtargetpattern.BuildTargetPattern
-
Target name in case pattern is single build target pattern; otherwise an empty string
- getLocalResult() - Method in class com.facebook.buck.remoteexecution.event.LocalFallbackEvent.Finished
-
- getLocalWorkers() - Method in class com.facebook.buck.features.gwt.GwtBinaryDescriptionArg
-
This will be passed to the GWT Compiler's -localWorkers
flag.
- getLocation(JavaFileManager.Location) - Method in class com.facebook.buck.jvm.java.ForwardingStandardJavaFileManager
-
- getLocation(JavaFileManager.Location) - Method in class com.facebook.buck.jvm.java.JavaInMemoryFileManager
-
- getLogConfig() - Method in class com.facebook.buck.cli.AbstractCommand
-
- getLogConfig() - Method in class com.facebook.buck.cli.AbstractContainerCommand
-
- getLogConfig() - Method in interface com.facebook.buck.cli.Command
-
- getLogConfig() - Method in class com.facebook.buck.cli.DoctorCommand
-
- getLogDir() - Method in class com.facebook.buck.io.filesystem.BuckPaths
-
- getLogDir() - Method in class com.facebook.buck.log.LogConfigSetup
-
- getLogDirectoryPath() - Method in class com.facebook.buck.log.InvocationInfo
-
- getLogDirPath() - Method in interface com.facebook.buck.doctor.config.DoctorEndpointRequest
-
- getLogFileHandlerState() - Method in class com.facebook.buck.log.GlobalStateManager
-
- getLogFilePath() - Method in class com.facebook.buck.event.listener.RuleKeyLoggerListener
-
- getLogFilePath() - Method in class com.facebook.buck.log.InvocationInfo
-
- getLogFilePath() - Method in class com.facebook.buck.log.LogConfigSetup
-
- getLogFilePrefix() - Method in class com.facebook.buck.log.LogConfigSetup
-
- getLogger() - Method in class com.facebook.buck.log.ErrorLogRecord
-
- getLogLevel(String) - Method in interface com.facebook.buck.log.ConsoleHandlerState
-
- getLogPackageBoundaryExceptionViolations() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getLogs() - Method in interface com.facebook.buck.apple.AbstractIdbTestResult
-
Array of strings that show the logs of the test
- getLogs() - Method in class com.facebook.buck.log.ErrorLogRecord
-
- getLogs() - Method in class com.facebook.buck.support.fix.BuckFixSpec
-
Get a mapping of log short names to paths for those logs.
- getLogUploadMode() - Method in class com.facebook.buck.event.chrome_trace.ChromeTraceBuckConfig
-
Returns whether and when to upload logs.
- getLong(String, String) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getLong(String, String) - Method in class com.facebook.buck.util.config.Config
-
- getLua() - Method in class com.facebook.buck.features.lua.LuaPlatform
-
- getLuaCxxLibrary(BuildRuleResolver, TargetConfiguration) - Method in class com.facebook.buck.features.lua.LuaPlatform
-
- getLuaCxxLibraryTarget() - Method in class com.facebook.buck.features.lua.LuaPlatform
-
- getLuaPackageComponents(SourcePathResolverAdapter) - Method in interface com.facebook.buck.features.lua.LuaPackageable
-
- getLuaPackageDeps(CxxPlatform, BuildRuleResolver) - Method in interface com.facebook.buck.features.lua.LuaPackageable
-
- getLuaPlatforms() - Method in interface com.facebook.buck.features.lua.LuaPlatformsProvider
-
- getMachineReadableLog() - Method in interface com.facebook.buck.doctor.config.DoctorEndpointRequest
-
- getMachineReadableLogFile() - Method in interface com.facebook.buck.doctor.config.BuildLogEntry
-
- getMacro() - Method in class com.facebook.buck.rules.macros.MacroContainer
-
- getMacroClass() - Method in class com.facebook.buck.rules.macros.AbsoluteOutputMacro
-
- getMacroClass() - Method in interface com.facebook.buck.rules.macros.CcFlagsMacro
-
- getMacroClass() - Method in interface com.facebook.buck.rules.macros.CcMacro
-
- getMacroClass() - Method in class com.facebook.buck.rules.macros.ClasspathAbiMacro
-
- getMacroClass() - Method in class com.facebook.buck.rules.macros.ClasspathMacro
-
- getMacroClass() - Method in class com.facebook.buck.rules.macros.CppFlagsMacro
-
- getMacroClass() - Method in interface com.facebook.buck.rules.macros.CxxFlagsMacro
-
- getMacroClass() - Method in interface com.facebook.buck.rules.macros.CxxMacro
-
- getMacroClass() - Method in class com.facebook.buck.rules.macros.CxxppFlagsMacro
-
- getMacroClass() - Method in interface com.facebook.buck.rules.macros.EnvMacro
-
- getMacroClass() - Method in class com.facebook.buck.rules.macros.ExecutableMacro
-
- getMacroClass() - Method in class com.facebook.buck.rules.macros.ExecutableTargetMacro
-
- getMacroClass() - Method in class com.facebook.buck.rules.macros.LdflagsSharedFilterMacro
-
- getMacroClass() - Method in class com.facebook.buck.rules.macros.LdflagsSharedMacro
-
- getMacroClass() - Method in class com.facebook.buck.rules.macros.LdflagsStaticFilterMacro
-
- getMacroClass() - Method in class com.facebook.buck.rules.macros.LdflagsStaticMacro
-
- getMacroClass() - Method in class com.facebook.buck.rules.macros.LdflagsStaticPicFilterMacro
-
- getMacroClass() - Method in class com.facebook.buck.rules.macros.LdflagsStaticPicMacro
-
- getMacroClass() - Method in class com.facebook.buck.rules.macros.LdMacro
-
- getMacroClass() - Method in class com.facebook.buck.rules.macros.LocationMacro
-
- getMacroClass() - Method in class com.facebook.buck.rules.macros.LocationPlatformMacro
-
- getMacroClass() - Method in interface com.facebook.buck.rules.macros.Macro
-
- getMacroClass() - Method in class com.facebook.buck.rules.macros.MavenCoordinatesMacro
-
- getMacroClass() - Method in class com.facebook.buck.rules.macros.OutputMacro
-
- getMacroClass() - Method in interface com.facebook.buck.rules.macros.PlatformNameMacro
-
- getMacroClass() - Method in class com.facebook.buck.rules.macros.QueryOutputsMacro
-
- getMacroClass() - Method in class com.facebook.buck.rules.macros.QueryPathsMacro
-
- getMacroClass() - Method in class com.facebook.buck.rules.macros.QueryTargetsAndOutputsMacro
-
- getMacroClass() - Method in class com.facebook.buck.rules.macros.QueryTargetsMacro
-
- getMacroClass() - Method in class com.facebook.buck.rules.macros.WorkerMacro
-
- getMacroExpander(BuildRuleCreationContextWithTargetGraph, BuildTarget, CxxPlatform) - Static method in class com.facebook.buck.features.rust.RustCompileUtils
-
Return a macro expander for a string with macros
- getMacroHandler(BuildTarget, ProjectFilesystem, BuildRuleResolver, TargetGraph, CxxGenruleDescriptionArg) - Method in class com.facebook.buck.cxx.CxxGenruleDescription
-
- getMacroHandler(BuildTarget, ProjectFilesystem, BuildRuleResolver, TargetGraph, T) - Method in class com.facebook.buck.shell.AbstractGenruleDescription
-
- getMacroInput() - Method in interface com.facebook.buck.core.macros.MacroMatchResult
-
- getMacroPath(ProjectFilesystem, BuildTarget) - Static method in class com.facebook.buck.rules.args.WriteToFileArg
-
- getMacros() - Method in class com.facebook.buck.rules.macros.StringWithMacros
-
- getMacroType() - Method in interface com.facebook.buck.core.macros.MacroMatchResult
-
- getMain() - Method in class com.facebook.buck.features.haskell.HaskellBinaryDescriptionArg
-
- getMain() - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg
-
- getMain() - Method in class com.facebook.buck.shell.ShBinaryDescriptionArg
-
- getMainCellBuckPaths() - Method in class com.facebook.buck.io.filesystem.EmbeddedCellBuckOutInfo
-
- getMainCellRoot() - Method in class com.facebook.buck.io.filesystem.EmbeddedCellBuckOutInfo
-
- getMainClass() - Method in class com.facebook.buck.jvm.java.JarParameters
-
- getMainClass() - Method in class com.facebook.buck.jvm.java.JavaBinaryDescriptionArg
-
- getMainClass() - Method in class com.facebook.buck.jvm.java.JavaTestRunner
-
- getMainClass() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getMainConfigurationFile(Path) - Static method in class com.facebook.buck.util.config.Configs
-
- getMainGroup() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXProject
-
- getMainModule() - Method in class com.facebook.buck.features.lua.LuaBinaryDescriptionArg
-
- getMainModule() - Method in class com.facebook.buck.features.python.PythonBinary
-
- getMainModule() - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg
-
- getMainModule() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getMainModule() - Method in class com.facebook.buck.features.python.PythonTestRunner
-
- getMainModule() - Method in class com.facebook.buck.features.python.PythonTestRunnerDescriptionArg
-
- getMajorVersion() - Static method in class com.facebook.buck.jvm.java.version.JavaVersion
-
Returns the major version of the current JVM instance (e.g.
- getMajorVersionFromString(String) - Static method in class com.facebook.buck.jvm.java.version.JavaVersion
-
Returns the major version from a Java version string (e.g.
- getManagedThreadCount() - Method in class com.facebook.buck.core.resources.ResourcesConfig
-
- getManager() - Method in class com.facebook.buck.support.bgtasks.TaskManagerCommandScope
-
- getMandatory() - Method in class com.facebook.buck.core.starlark.rule.attr.Attribute
-
Whether this attribute is mandatory or not
- getMandatory() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.BoolAttribute
-
- getMandatory() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.DepAttribute
-
- getMandatory() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.DepListAttribute
-
- getMandatory() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.IntAttribute
-
- getMandatory() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.IntListAttribute
-
- getMandatory() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.OutputAttribute
-
- getMandatory() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.OutputListAttribute
-
- getMandatory() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.SourceAttribute
-
- getMandatory() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.SourceListAttribute
-
- getMandatory() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.SourceSortedSetAttribute
-
- getMandatory() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.StringAttribute
-
- getMandatory() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.StringListAttribute
-
- getMandatory() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.StringSortedSetAttribute
-
- getMandatory() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.UnconfiguredDepListAttribute
-
- getMandatory() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.UnconfiguredOptionalDepAttribute
-
- getMandatoryArguments() - Method in class com.facebook.buck.query.AllPathsFunction
-
- getMandatoryArguments() - Method in class com.facebook.buck.query.AttrFilterFunction
-
- getMandatoryArguments() - Method in class com.facebook.buck.query.AttrRegexFilterFunction
-
- getMandatoryArguments() - Method in class com.facebook.buck.query.BuildFileFunction
-
- getMandatoryArguments() - Method in class com.facebook.buck.query.DepsFunction.FirstOrderDepsFunction
-
- getMandatoryArguments() - Method in class com.facebook.buck.query.DepsFunction
-
- getMandatoryArguments() - Method in class com.facebook.buck.query.DepsFunction.LookupFunction
-
- getMandatoryArguments() - Method in class com.facebook.buck.query.FilterFunction
-
- getMandatoryArguments() - Method in class com.facebook.buck.query.InputsFunction
-
- getMandatoryArguments() - Method in class com.facebook.buck.query.KindFunction
-
- getMandatoryArguments() - Method in class com.facebook.buck.query.LabelsFunction
-
- getMandatoryArguments() - Method in class com.facebook.buck.query.OwnerFunction
-
- getMandatoryArguments() - Method in interface com.facebook.buck.query.QueryEnvironment.QueryFunction
-
The number of arguments that are required.
- getMandatoryArguments() - Method in class com.facebook.buck.query.RdepsFunction
-
- getMandatoryArguments() - Method in class com.facebook.buck.query.TestsOfFunction
-
- getMandatoryArguments() - Method in class com.facebook.buck.rules.query.ClasspathFunction
-
- getMandatorySectionByName(Object, String) - Method in class com.facebook.buck.cxx.toolchain.elf.Elf
-
- getManifest() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getManifest() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getManifest() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getManifest() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getManifest() - Method in class com.facebook.buck.android.AndroidInstrumentationApkDescriptionArg
-
- getManifest() - Method in interface com.facebook.buck.android.AndroidLibraryDescription.CoreArg
-
- getManifest() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getManifest() - Method in class com.facebook.buck.android.AndroidResourceDescriptionArg
-
- getManifest() - Method in class com.facebook.buck.core.build.engine.manifest.ManifestLoadResult
-
- getManifest(Path) - Method in class com.facebook.buck.json.TargetCountVerificationParserDecorator
-
- getManifest(Path) - Method in interface com.facebook.buck.parser.api.FileParser
-
Collect all information from a particular, along with metadata about the information, for
example which other files were also parsed.
- getManifest(Path) - Method in class com.facebook.buck.parser.api.ForwardingProjectBuildFileParserDecorator
-
- getManifest(Path) - Method in class com.facebook.buck.parser.ConcurrentProjectBuildFileParser
-
- getManifest(Path) - Method in class com.facebook.buck.parser.decorators.EventReportingProjectBuildFileParser
-
- getManifest(Path) - Method in class com.facebook.buck.parser.HybridProjectBuildFileParser
-
- getManifest(Path) - Method in class com.facebook.buck.parser.PythonDslProjectBuildFileParser
-
Collect all rules from a particular build file, along with meta rules about the rules, for
example which build files the rules depend on.
- getManifest(Path) - Method in class com.facebook.buck.skylark.parser.SkylarkPackageFileParser
-
- getManifest(Path) - Method in class com.facebook.buck.skylark.parser.SkylarkProjectBuildFileParser
-
- getManifest() - Method in class com.facebook.buck.util.zip.CustomJarOutputStream
-
- getManifest() - Method in interface com.facebook.buck.util.zip.JarEntryContainer
-
- getManifestCacheResult() - Method in class com.facebook.buck.core.build.engine.manifest.ManifestFetchResult
-
- getManifestEntries() - Method in class com.facebook.buck.android.AndroidBinary
-
- getManifestEntries() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getManifestEntries() - Method in class com.facebook.buck.android.AndroidBundle
-
- getManifestEntries() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getManifestEntries() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getManifestFetchResult() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.Finished
-
- getManifestFile() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getManifestFile() - Method in class com.facebook.buck.android.AndroidLibrary
-
- getManifestFile() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getManifestFile() - Method in class com.facebook.buck.android.AndroidResource
-
- getManifestFile() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getManifestFile() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getManifestFile() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getManifestFile() - Method in class com.facebook.buck.jvm.java.JarParameters
-
- getManifestFile() - Method in class com.facebook.buck.jvm.java.JavaBinaryDescriptionArg
-
- getManifestFile() - Method in interface com.facebook.buck.jvm.java.JavaLibraryDescription.CoreArg
-
- getManifestFile() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getManifestFile() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getManifestFile() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getManifestFile() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getManifestFile() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getManifestFile() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getManifestFile() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getManifestLoadError() - Method in class com.facebook.buck.core.build.engine.manifest.ManifestFetchResult
-
- getManifestLoadError() - Method in interface com.facebook.buck.core.build.engine.manifest.ManifestStoreResult
-
- getManifestPath() - Method in class com.facebook.buck.android.HasInstallableApk.ApkInfo
-
- getManifestPath(BuildRule) - Static method in class com.facebook.buck.core.build.engine.cache.manager.ManifestRuleKeyManager
-
- getManifestPaths() - Method in class com.facebook.buck.features.project.intellij.model.IjModuleAndroidFacet
-
- getManifestRuleKey() - Method in interface com.facebook.buck.core.rulekey.BuildRuleKeys
-
- getManifestRuleKeyCacheCheckTimestamps() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.Finished
-
- getManifestSkeleton() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getManifestSkeleton() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getManifestSkeleton() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getManifestSkeleton() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getManifestSkeleton() - Method in class com.facebook.buck.android.AndroidInstrumentationApkDescriptionArg
-
- getManifestStats() - Method in class com.facebook.buck.core.build.engine.manifest.ManifestFetchResult
-
- getManifestStats() - Method in interface com.facebook.buck.core.build.engine.manifest.ManifestStoreResult
-
- getManifestStoreResult() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.Finished
-
- getManuallyInvoked() - Method in class com.facebook.buck.support.fix.BuckFixSpec
-
Whether the fix script was requested explicitly (through `buck fix`), or automatically from
another command
- getMap(String) - Method in class com.facebook.buck.core.build.engine.buildinfo.DefaultOnDiskBuildInfo
-
- getMap(String) - Method in interface com.facebook.buck.core.build.engine.buildinfo.OnDiskBuildInfo
-
- getMap(String, String) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getMap(String, String, char, String) - Method in class com.facebook.buck.util.config.Config
-
Convert a string representation of a map to a binary ImmutableMap<String, String>
- getMap(String, String) - Method in class com.facebook.buck.util.config.Config
-
Convert a string representation of a map to a binary ImmutableMap<String, String>
,
using default separators
- getMappedPaths(Map<T, SourcePath>) - Method in class com.facebook.buck.core.sourcepath.resolver.impl.AbstractSourcePathResolver
-
- getMappedPaths(Map<T, SourcePath>) - Method in interface com.facebook.buck.core.sourcepath.resolver.SourcePathResolver
-
- getMappedPaths(Map<T, SourcePath>) - Method in class com.facebook.buck.core.sourcepath.resolver.SourcePathResolverAdapter
-
Returns a list of values and their associated
Path
instances by transforming the given
SourcePath
instances into
Path
instances.
- getMappedSrcs() - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg
-
- getMappedSrcs() - Method in interface com.facebook.buck.features.rust.RustCommonArgs
-
- getMappedSrcs() - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg
-
- getMappedSrcs() - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg
-
- getMappingTargets() - Method in class com.facebook.buck.core.linkgroup.CxxLinkGroupMapping
-
- getMatchingValues(String) - Method in class com.facebook.buck.rules.coercer.PatternMatchedCollection
-
- getMatchingValues(ImmutableMap<BuildTarget, Version>) - Method in class com.facebook.buck.rules.coercer.VersionMatchedCollection
-
- getMavenCoordinates(BuildRule) - Method in class com.facebook.buck.rules.macros.MavenCoordinatesMacroExpander
-
- getMavenCoords() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getMavenCoords() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getMavenCoords() - Method in class com.facebook.buck.android.AndroidPrebuiltAarDescriptionArg
-
- getMavenCoords() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getMavenCoords() - Method in interface com.facebook.buck.jvm.core.HasMavenCoordinates
-
Used to identify this library within a maven repository
- getMavenCoords() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getMavenCoords() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getMavenCoords() - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getMavenCoords() - Method in class com.facebook.buck.jvm.java.Javadoc
-
- getMavenCoords() - Method in interface com.facebook.buck.jvm.java.JavaLibraryDescription.CoreArg
-
- getMavenCoords() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getMavenCoords() - Method in class com.facebook.buck.jvm.java.JavaSourceJar
-
- getMavenCoords() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getMavenCoords() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getMavenCoords() - Method in class com.facebook.buck.jvm.java.MavenUberJar
-
- getMavenCoords() - Method in class com.facebook.buck.jvm.java.PrebuiltJar
-
- getMavenCoords() - Method in class com.facebook.buck.jvm.java.PrebuiltJarDescriptionArg
-
- getMavenCoords() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getMavenCoords() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getMavenCoords() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getMavenCoords() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getMavenDeps() - Method in class com.facebook.buck.jvm.java.JarShape.Summary
-
- getMavenDeps() - Method in class com.facebook.buck.jvm.java.Javadoc
-
- getMavenDeps() - Method in interface com.facebook.buck.jvm.java.MavenPublishable
-
When published, these will be listed in pom.xml as dependencies
- getMavenDeps() - Method in class com.facebook.buck.jvm.java.MavenUberJar
-
- getMavenDeps() - Method in class com.facebook.buck.jvm.java.MavenUberJar.SourceJar
-
- getMavenPomTemplate() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getMavenPomTemplate() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getMavenPomTemplate() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getMavenPomTemplate() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getMavenPomTemplate() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getMavenPomTemplate() - Method in interface com.facebook.buck.jvm.java.JavaLibraryDescription.CoreArg
-
- getMavenPomTemplate() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getMavenPomTemplate() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getMavenPomTemplate() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getMavenPomTemplate() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getMavenPomTemplate() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getMavenPomTemplate() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getMavenPomTemplate() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getMavenRepo() - Method in class com.facebook.buck.file.downloader.impl.DownloadConfig
-
- getMax() - Method in class com.facebook.buck.counters.SamplingCounter
-
- getMaxActionGraphCacheEntries() - Method in class com.facebook.buck.command.config.BuildBuckConfig
-
- getMaxBytesAfterDeletion() - Method in class com.facebook.buck.util.DirectoryCleanerArgs
-
- getMaxConcurrentActionComputations() - Method in interface com.facebook.buck.remoteexecution.config.RemoteExecutionStrategyConfig
-
- getMaxConcurrentExecutions() - Method in interface com.facebook.buck.remoteexecution.config.RemoteExecutionStrategyConfig
-
- getMaxConcurrentPendingUploads() - Method in interface com.facebook.buck.remoteexecution.config.RemoteExecutionStrategyConfig
-
- getMaxConcurrentResultHandling() - Method in interface com.facebook.buck.remoteexecution.config.RemoteExecutionStrategyConfig
-
- getMaxDebugLogLines() - Method in interface com.facebook.buck.test.config.TestResultSummaryVerbosity
-
- getMaxFetchRetries() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getMaximumResourceAmounts() - Method in class com.facebook.buck.core.resources.ResourcesConfig
-
- getMaximumTestOutputSize() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getMaximumValues() - Method in class com.facebook.buck.util.concurrent.ListeningMultiSemaphore
-
- getMaxInlinedSizeBytes() - Method in class com.facebook.buck.artifact_cache.config.SQLiteCacheEntry
-
- getMaxLogCount() - Static method in class com.facebook.buck.log.LogFileHandler
-
- getMaxLogSizeBytes() - Method in class com.facebook.buck.log.LogConfigSetup
-
- getMaxMemoryBytes() - Method in class com.facebook.buck.util.perf.PerfStatsTracking.MemoryPerfStatsEvent
-
- getMaxNumberOfRetries() - Method in class com.facebook.buck.file.downloader.impl.DownloadConfig
-
- getMaxPathCount() - Method in class com.facebook.buck.util.DirectoryCleanerArgs
-
- getMaxRetries() - Method in class com.facebook.buck.remoteexecution.grpc.retry.RetryPolicy
-
- getMaxSizeBytes() - Method in class com.facebook.buck.artifact_cache.config.DirCacheEntry
-
- getMaxSizeBytes() - Method in class com.facebook.buck.artifact_cache.config.SQLiteCacheEntry
-
- getMaxSizeBytes() - Static method in class com.facebook.buck.log.LogFileHandler
-
- getMaxStoreAttempts() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getMaxStoreSize() - Method in class com.facebook.buck.artifact_cache.config.HttpCacheEntry
-
- getMaxThreads() - Method in class com.facebook.buck.util.network.RemoteLogBuckConfig
-
- getMaxTotalSizeBytes() - Method in class com.facebook.buck.util.DirectoryCleanerArgs
-
- getMaxTraces() - Method in class com.facebook.buck.event.chrome_trace.ChromeTraceBuckConfig
-
- getMaxValueLength() - Method in class com.facebook.buck.apple.clang.HeaderMap
-
- getMaxWorkers() - Method in class com.facebook.buck.rules.macros.WorkerMacroArg
-
- getMaxWorkers() - Method in interface com.facebook.buck.shell.WorkerTool
-
- getMaxWorkers() - Method in class com.facebook.buck.shell.WorkerToolDescriptionArg
-
- getMaxWorkers() - Method in interface com.facebook.buck.worker.WorkerProcessParams
-
Maximum number of tools that pool can have.
- getMaxWorkerSizeToStealFrom() - Method in class com.facebook.buck.remoteexecution.config.RemoteExecutionConfig
-
- getMaxWorkersPerThreadPercent() - Method in class com.facebook.buck.shell.WorkerToolDescriptionArg
-
- getMaybeBuildTarget(String, String, TargetConfiguration) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getMaybeUnconfiguredBuildTarget(String, String) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getMd5Hash() - Method in class com.facebook.buck.artifact_cache.ThriftArtifactCacheProtocol.Response.ReadPayloadInfo
-
- getMean() - Method in class com.facebook.buck.util.Statistics
-
Get the mean.
- getMemberPath() - Method in class com.facebook.buck.core.io.ArchiveMemberPath
-
- getMemberPath() - Method in class com.facebook.buck.core.sourcepath.ArchiveMemberSourcePath
-
- getMemory() - Method in class com.facebook.buck.util.concurrent.ResourceAmounts
-
- getMemoryUsageAfterGC() - Method in class com.facebook.buck.support.jvm.GCCollectionEvent
-
- getMemoryUsageBeforeGC() - Method in class com.facebook.buck.support.jvm.GCCollectionEvent
-
- getMemResident() - Method in class com.facebook.buck.util.ProcessResourceConsumption
-
- getMemSize() - Method in class com.facebook.buck.util.ProcessResourceConsumption
-
- getMergeableEntitlements() - Method in class com.facebook.buck.apple.toolchain.ProvisioningProfileMetadata
-
- getMergedResources(StringResources) - Method in class com.facebook.buck.android.StringResources
-
- getMergeManifests() - Method in class com.facebook.buck.jvm.java.JarParameters
-
- getMergeManifests() - Method in class com.facebook.buck.jvm.java.JavaBinaryDescriptionArg
-
- getMessage() - Method in interface com.facebook.buck.apple.AbstractIdbFailureInfo
-
String that represents the failure message
- getMessage() - Method in exception com.facebook.buck.core.exceptions.BuckUncheckedExecutionException
-
- getMessage() - Method in interface com.facebook.buck.doctor.config.DoctorJsonResponse
-
- getMessage() - Method in class com.facebook.buck.event.ConsoleEvent
-
- getMessage() - Method in interface com.facebook.buck.event.external.elements.TestResultSummaryExternalInterface
-
- getMessage() - Method in interface com.facebook.buck.event.external.events.ConsoleEventExternalInterface
-
- getMessage() - Method in interface com.facebook.buck.io.watchman.WatchmanDiagnostic
-
- getMessage() - Method in class com.facebook.buck.log.ErrorLogRecord
-
- getMessage() - Method in class com.facebook.buck.parser.exceptions.ParsingError
-
- getMessage() - Method in exception com.facebook.buck.step.StepFailedException
-
- getMessage() - Method in class com.facebook.buck.test.TestResultSummary
-
- getMessage() - Method in interface com.facebook.buck.test.TestStatusMessage
-
- getMessage(boolean) - Method in class com.facebook.buck.util.ErrorLogger.DeconstructedException
-
Returns the message (and optionally stack trace) for the root cause.
- getMessage() - Method in class com.facebook.buck.util.PatternAndMessage
-
- getMessageDigest() - Method in class com.facebook.buck.remoteexecution.grpc.GrpcProtocol
-
- getMessageDigest() - Method in interface com.facebook.buck.remoteexecution.interfaces.Protocol
-
- getMessageForResult(String) - Method in class com.facebook.buck.util.ProcessExecutor.Result
-
- getMessageForUnexpectedResult(String) - Method in class com.facebook.buck.util.ProcessExecutor.Result
-
- getMessageOfTheDay() - Method in class com.facebook.buck.support.cli.config.CliConfig
-
- getMessager() - Method in class com.facebook.buck.jvm.java.plugin.adapter.BuckJavacTaskProxyImpl
-
- getMessager() - Method in interface com.facebook.buck.jvm.java.plugin.api.BuckJavacTaskProxy
-
- getMetadata() - Method in interface com.facebook.buck.android.exopackage.ExopackageInfo.DexInfo
-
- getMetadata() - Method in interface com.facebook.buck.android.exopackage.ExopackageInfo.NativeLibsInfo
-
- getMetadata() - Method in class com.facebook.buck.artifact_cache.ArtifactInfo
-
- getMetadata() - Method in class com.facebook.buck.artifact_cache.CacheResult
-
- getMetadata() - Method in class com.facebook.buck.artifact_cache.HttpArtifactCacheBinaryProtocol.MetadataAndPayloadReadResult
-
- getMetadata() - Method in interface com.facebook.buck.remoteexecution.grpc.GrpcHeaderHandler.StubAndResponseMetadata
-
- getMetadataForArtifact() - Method in class com.facebook.buck.core.build.engine.buildinfo.DefaultOnDiskBuildInfo
-
- getMetadataForArtifact() - Method in interface com.facebook.buck.core.build.engine.buildinfo.OnDiskBuildInfo
-
Returns the "build" metadata that is stored with a cache artifact ("artifact" metadata is
stored within the artifact itself).
- getMetadataProvider() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getMetadataToInstall() - Method in class com.facebook.buck.android.exopackage.DexExoHelper
-
- getMetadataToInstall() - Method in class com.facebook.buck.android.exopackage.ModuleExoHelper
-
- getMetadataToInstall() - Method in class com.facebook.buck.android.exopackage.NativeExoHelper
-
- getMetadataToInstall() - Method in class com.facebook.buck.android.exopackage.ResourcesExoHelper
-
- getMetadataTxtPath() - Method in class com.facebook.buck.android.PreDexSplitDexGroup
-
- getMetadataTxtPath() - Method in class com.facebook.buck.android.PreDexSplitDexMerge
-
- getMetadataTxtSourcePath() - Method in class com.facebook.buck.android.PreDexSplitDexMerge
-
- getMetaInfDirectory() - Method in class com.facebook.buck.features.project.intellij.model.IjModule
-
- getMetaInfDirectory() - Method in class com.facebook.buck.features.project.intellij.ModuleBuildContext
-
- getMetaInfDirectory() - Method in class com.facebook.buck.jvm.java.JavaBinaryDescriptionArg
-
- getMetaVariable(ResourceBundle) - Method in class com.facebook.buck.cli.TestCommand.CoverageReportFormatsHandler
-
- getMethodName() - Method in interface com.facebook.buck.apple.AbstractIdbTestResult
-
String that represents the name of the method of the test
- getMethodName() - Method in class com.facebook.buck.test.selectors.TestDescription
-
- getMethods() - Method in class com.facebook.buck.core.starlark.compatible.BuckStarlarkStructObject
-
- getMethods(Class<?>) - Static method in class com.facebook.buck.core.starlark.compatible.MethodLookup
-
- getMicroThreadUserTime() - Method in class com.facebook.buck.event.chrome_trace.ChromeTraceEvent
-
- getMicroTime() - Method in class com.facebook.buck.event.chrome_trace.ChromeTraceEvent
-
- getMin() - Method in class com.facebook.buck.counters.SamplingCounter
-
- getMinAmountOfEntriesToKeep() - Method in class com.facebook.buck.util.DirectoryCleanerArgs
-
- getMinAmountOfLogsToKeep() - Static method in class com.facebook.buck.log.LogFileHandler
-
- getMinAndroidSdkVersion() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getMinimizePrimaryDexSize() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getMinimizePrimaryDexSize() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getMinSdkVersion() - Method in class com.facebook.buck.features.project.intellij.model.IjModuleAndroidFacet
-
- getMinSdkVersion() - Method in class com.facebook.buck.rules.coercer.ManifestEntries
-
- getMinSdkVersions() - Method in class com.facebook.buck.features.project.intellij.model.IjModuleAndroidFacet
-
- getMinVersion() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
Target SDK version.
- getMinVersion() - Method in class com.facebook.buck.apple.toolchain.AppleCxxPlatform
-
- getMinVersionFlagPrefix() - Method in class com.facebook.buck.apple.toolchain.ApplePlatform
-
- getMissCount() - Method in class com.facebook.buck.util.cache.CacheStats
-
- getMissingHashes(Set<Protocol.Digest>) - Method in interface com.facebook.buck.remoteexecution.CasBlobUploader
-
- getMissingHashes(Set<Protocol.Digest>) - Method in class com.facebook.buck.remoteexecution.grpc.GrpcCasBlobUploader
-
- getMissingSymbolFromCompilerError(String) - Method in class com.facebook.buck.jvm.java.JavacErrorParser
-
- getMissingTargetLevenshteinDistance() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getMissMatchCount() - Method in class com.facebook.buck.util.cache.CacheStats
-
- getMode() - Method in class com.facebook.buck.artifact_cache.AbstractAsynchronousCache
-
- getMode() - Method in class com.facebook.buck.cxx.toolchain.HeaderVerification
-
- getMode() - Method in class com.facebook.buck.shell.ExportFileDescriptionArg
-
- getModel() - Method in class com.facebook.buck.maven.Pom
-
- getModule(CxxPlatform) - Method in class com.facebook.buck.features.lua.CxxLuaExtension
-
- getModule() - Method in class com.facebook.buck.features.project.intellij.IjDependencyListBuilder.DependencyEntry
-
- getModule() - Method in class com.facebook.buck.features.python.CxxPythonExtension
-
- getModuleBasePath() - Method in class com.facebook.buck.features.project.intellij.aggregation.AggregationModule
-
- getModuleBasePath() - Method in class com.facebook.buck.features.project.intellij.model.IjModule
-
- getModuleDependencies(String) - Method in interface com.facebook.buck.core.module.BuckModuleManager
-
- getModuleDependencies(String) - Method in class com.facebook.buck.core.module.impl.DefaultBuckModuleManager
-
- getModuleDeps() - Method in class com.facebook.buck.features.gwt.GwtBinaryDescriptionArg
-
- getModuleDir(IjModule) - Method in class com.facebook.buck.features.project.intellij.IjProjectPaths
-
- getModuleGroupName() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getModuleHash(Class<?>) - Method in interface com.facebook.buck.core.module.BuckModuleHashStrategy
-
- getModuleHash(Class<?>) - Method in interface com.facebook.buck.core.module.BuckModuleManager
-
- getModuleHash(String) - Method in interface com.facebook.buck.core.module.BuckModuleManager
-
- getModuleHash(PluginWrapper) - Method in class com.facebook.buck.core.module.impl.BuckModuleJarHashProvider
-
- getModuleHash(Class<?>) - Method in class com.facebook.buck.core.module.impl.DefaultBuckModuleHashStrategy
-
- getModuleHash(Class<?>) - Method in class com.facebook.buck.core.module.impl.DefaultBuckModuleManager
-
- getModuleHash(String) - Method in class com.facebook.buck.core.module.impl.DefaultBuckModuleManager
-
- getModuleHash(Class<?>) - Method in class com.facebook.buck.core.module.impl.NoOpBuckModuleHashStrategy
-
- getModuleIds() - Method in interface com.facebook.buck.core.module.BuckModuleManager
-
- getModuleIds() - Method in class com.facebook.buck.core.module.impl.DefaultBuckModuleManager
-
- getModuleImlFilePath(IjModule) - Method in class com.facebook.buck.features.project.intellij.IjProjectPaths
-
- getModuleIndexEntries() - Method in class com.facebook.buck.features.project.intellij.IjProjectTemplateDataPreparer
-
- getModuleInfo() - Method in class com.facebook.buck.android.exopackage.ExopackageInfo
-
- getModuleManifestSkeleton() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getModuleManifestSkeleton() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getModuleManifestSkeleton() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getModulemapMode() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
A modulemap mode, to override the one specified in .buckconfig.
- getModulemapMode() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
A modulemap mode, to override the one specified in .buckconfig.
- getModulemapMode() - Method in interface com.facebook.buck.apple.AppleNativeTargetDescriptionArg
-
A modulemap mode, to override the one specified in .buckconfig.
- getModulemapMode() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
A modulemap mode, to override the one specified in .buckconfig.
- getModuleMappedClasspathEntriesToDex() - Method in interface com.facebook.buck.android.packageable.AndroidPackageableCollection
-
Java classes to include in the package sorted into modules
- getModuleName() - Method in class com.facebook.buck.android.ModuleInfo
-
- getModuleName() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getModuleName() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getModuleName() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getModuleName() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
- getModuleName() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getModuleName(TargetNode<?>) - Static method in class com.facebook.buck.features.apple.projectV2.Utils
-
Gets the Swift or Cxx module name if the target node has the module name defined.
- getModuleName() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getModuleName() - Method in class com.facebook.buck.swift.SwiftCompile
-
- getModuleName() - Method in class com.facebook.buck.swift.SwiftLibraryDescriptionArg
-
- getModuleQualifiedPath(Path, IjModule) - Method in class com.facebook.buck.features.project.intellij.IjProjectPaths
-
- getModuleRelativePath(Path, IjModule) - Method in class com.facebook.buck.features.project.intellij.IjProjectPaths
-
- getModuleRuleByTargetNodeType(Class<?>) - Method in class com.facebook.buck.features.project.intellij.SupportedTargetTypeRegistry
-
- getModules() - Method in class com.facebook.buck.features.gwt.GwtBinaryDescriptionArg
-
- getModules() - Method in class com.facebook.buck.features.haskell.HaskellCompileRule
-
- getModules() - Method in class com.facebook.buck.features.project.intellij.aggregation.AggregationTree
-
- getModules() - Method in class com.facebook.buck.features.project.intellij.IjModuleGraph
-
- getModules() - Method in class com.facebook.buck.features.python.PythonPackageComponents
-
- getModulesToBeWritten() - Method in class com.facebook.buck.features.project.intellij.IjProjectTemplateDataPreparer
-
- getModuleType() - Method in class com.facebook.buck.features.project.intellij.aggregation.AggregationContext
-
- getModuleType() - Method in class com.facebook.buck.features.project.intellij.aggregation.AggregationModule
-
- getModuleType() - Method in class com.facebook.buck.features.project.intellij.model.IjModule
-
- getModuleType() - Method in class com.facebook.buck.features.project.intellij.ModuleBuildContext
-
- getMomc() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
momc binary.
- getMomc() - Method in class com.facebook.buck.apple.toolchain.AppleCxxPlatform
-
- getMtimeSortedMatchingDirectoryContents(Path, String) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
Returns the files inside pathRelativeToProjectRoot
which match globPattern
,
ordered in descending last modified time order.
- getMtimeSortedMatchingDirectoryContents(Path, String) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
Returns the files inside pathRelativeToProjectRoot
which match globPattern
,
ordered in descending last modified time order.
- getMultiCheckEnabled() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getMultiFetchBatchSize(int) - Method in class com.facebook.buck.artifact_cache.AbstractAsynchronousCache
-
Used to compute the number of keys to include in every multiFetchRequest.
- getMultiFetchBatchSize(int) - Method in class com.facebook.buck.artifact_cache.ThriftArtifactCache
-
- getMultiFetchLimit() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getMultiFetchType() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getMultiInstallMode() - Method in class com.facebook.buck.android.exopackage.AdbConfig
-
- getMutableObject() - Method in exception com.facebook.buck.core.starlark.compatible.MutableObjectException
-
- getN() - Method in class com.facebook.buck.util.Statistics
-
Get the count of values.
- getName() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.android.AndroidAppModularityDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.android.AndroidBuildConfigDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.android.AndroidInstrumentationApkDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.android.AndroidInstrumentationTestDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.android.AndroidManifestDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.android.AndroidPrebuiltAarDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.android.AndroidResourceDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.android.ApkGenruleDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.android.apkmodule.APKModule
-
- getName() - Method in class com.facebook.buck.android.GenAidlDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.android.NdkLibraryDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.android.NdkToolchainDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.android.PrebuiltNativeLibraryDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
Each rule has a name
- getName() - Method in interface com.facebook.buck.android.toolchain.AdbToolchain
-
- getName() - Method in interface com.facebook.buck.android.toolchain.AndroidBuildToolsLocation
-
- getName() - Method in class com.facebook.buck.android.toolchain.AndroidPlatformTarget
-
- getName() - Method in interface com.facebook.buck.android.toolchain.AndroidSdkLocation
-
- getName() - Method in interface com.facebook.buck.android.toolchain.DxToolchain
-
- getName() - Method in class com.facebook.buck.android.toolchain.ndk.AndroidNdk
-
- getName() - Method in class com.facebook.buck.android.toolchain.ndk.NdkCxxPlatformsProvider
-
- getName() - Method in class com.facebook.buck.android.toolchain.platform.AndroidPlatformArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.apple.AppleAssetCatalogDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.apple.ApplePackageDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.apple.AppleResourceDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.apple.AppleToolchainSetDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.apple.AppleWrapperResourceArg
-
Each rule has a name
- getName(Function<SourcePath, Path>) - Method in class com.facebook.buck.apple.GroupedSource
-
- getName() - Method in class com.facebook.buck.apple.PrebuiltAppleFrameworkDescriptionArg
-
Each rule has a name
- getName() - Method in interface com.facebook.buck.apple.simulator.AppleDevice
-
String that represents the name of the device (i.e., "iPhone X", "iPad Air", etc)
- getName() - Method in interface com.facebook.buck.apple.simulator.AppleSimulator
-
- getName() - Method in class com.facebook.buck.apple.toolchain.AppleCxxPlatformsProvider
-
- getName() - Method in interface com.facebook.buck.apple.toolchain.AppleDeveloperDirectoryForTestsProvider
-
- getName() - Method in interface com.facebook.buck.apple.toolchain.AppleDeveloperDirectoryProvider
-
- getName() - Method in class com.facebook.buck.apple.toolchain.ApplePlatform
-
The full name of the platform.
- getName() - Method in class com.facebook.buck.apple.toolchain.AppleSdk
-
The full name of the SDK.
- getName() - Method in interface com.facebook.buck.apple.toolchain.AppleSdkLocation
-
- getName() - Method in interface com.facebook.buck.apple.toolchain.AppleToolchainProvider
-
- getName() - Method in interface com.facebook.buck.apple.toolchain.CodeSignIdentityStore
-
- getName() - Method in class com.facebook.buck.apple.toolchain.ProvisioningProfileStore
-
- getName() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXBuildPhase
-
- getName() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXBuildStyle
-
- getName() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXProject
-
- getName() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXReference
-
- getName() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXTarget
-
- getName() - Method in class com.facebook.buck.apple.xcode.XCScheme
-
- getName() - Method in class com.facebook.buck.apple.XcodeScriptDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.artifact_cache.AbstractAsynchronousCache
-
- getName() - Method in class com.facebook.buck.artifact_cache.config.DirCacheEntry
-
- getName() - Method in class com.facebook.buck.artifact_cache.config.SQLiteCacheEntry
-
- getName() - Method in class com.facebook.buck.core.cell.CellName
-
- getName() - Method in class com.facebook.buck.core.cell.name.CanonicalCellName
-
Returns the name in a human-readable form.
- getName(Optional<String>) - Method in interface com.facebook.buck.core.cell.nameresolver.CellNameResolver
-
- getName(Optional<String>) - Method in class com.facebook.buck.core.cell.nameresolver.DefaultCellNameResolver
-
- getName() - Method in interface com.facebook.buck.core.description.arg.ConstructorArg
-
Each rule has a name
- getName(int) - Method in class com.facebook.buck.core.filesystems.BuckUnixPath
-
- getName() - Method in interface com.facebook.buck.core.model.Flavor
-
- getName() - Method in class com.facebook.buck.core.model.FlavorDomain
-
- getName() - Method in class com.facebook.buck.core.model.InternalFlavor
-
- getName() - Method in class com.facebook.buck.core.model.RuleType
-
- getName() - Method in class com.facebook.buck.core.model.UnconfiguredBuildTarget
-
Name of the build target, i.e.
- getName() - Method in class com.facebook.buck.core.model.UserFlavor
-
- getName() - Method in class com.facebook.buck.core.rules.configsetting.ConfigSettingArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.core.rules.platform.ConstraintSettingArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.core.rules.platform.ConstraintValueArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.core.rules.platform.PlatformArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.core.rules.providers.impl.UserDefinedProvider
-
- getName() - Method in class com.facebook.buck.core.starlark.compatible.BuckStarlarkFunction
-
- getName() - Method in class com.facebook.buck.core.starlark.rule.SkylarkDescriptionArg
-
- getName() - Method in class com.facebook.buck.core.starlark.rule.SkylarkUserDefinedRule
-
Ensure that we only get our name after this function has been exported
- getName() - Method in class com.facebook.buck.core.test.rule.impl.ExternalTestRunnerDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.core.toolchain.rule.LegacyToolchainDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.core.toolchain.tool.impl.VersionedTool
-
- getName() - Method in interface com.facebook.buck.core.toolchain.Toolchain
-
- getName() - Method in interface com.facebook.buck.core.toolchain.ToolchainDescriptor
-
- getName() - Method in class com.facebook.buck.counters.Counter
-
- getName() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.cxx.CxxGenruleDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.cxx.CxxPrecompiledHeaderDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.cxx.toolchain.CxxPlatformsProvider
-
- getName() - Method in enum com.facebook.buck.doctor.config.DoctorIssueCategory
-
- getName() - Method in class com.facebook.buck.event.chrome_trace.ChromeTraceEvent
-
- getName() - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.apple.projectV2.XcconfigBaseConfiguration
-
- getName() - Method in class com.facebook.buck.features.apple.projectV2.XcodeProductMetadata
-
- getName() - Method in class com.facebook.buck.features.d.DBinaryDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.d.DLibraryDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.d.DTestDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.dotnet.CsharpLibraryDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.dotnet.PrebuiltDotnetLibraryDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.filegroup.FileGroupDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.go.GoBinaryDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.go.GoLibraryDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.go.GoTestDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.go.GoTestRunnerDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.go.GoToolchain
-
- getName() - Method in class com.facebook.buck.features.go.PrebuiltGoLibraryDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.gwt.GwtBinaryDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.haskell.HaskellBinaryDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.haskell.HaskellGhciDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.haskell.HaskellHaddockDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.haskell.HaskellLibraryDescriptionArg
-
- getName() - Method in interface com.facebook.buck.features.haskell.HaskellPlatformsProvider
-
- getName() - Method in class com.facebook.buck.features.haskell.HaskellPrebuiltLibraryDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.js.JsBundleDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.js.JsLibraryDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.lua.LuaBinaryDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.lua.LuaLibraryDescriptionArg
-
- getName() - Method in interface com.facebook.buck.features.lua.LuaPlatformsProvider
-
- getName() - Method in class com.facebook.buck.features.ocaml.OcamlBinaryDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.ocaml.OcamlLibraryDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.ocaml.PrebuiltOcamlLibraryDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.project.intellij.model.IjLibrary
-
- getName() - Method in class com.facebook.buck.features.project.intellij.model.IjModule
-
- getName() - Method in interface com.facebook.buck.features.project.intellij.model.IjProjectElement
-
- getName() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.python.PrebuiltPythonLibraryDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.python.PythonLibraryDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.python.PythonTestRunnerDescriptionArg
-
- getName() - Method in interface com.facebook.buck.features.python.toolchain.PexToolProvider
-
- getName() - Method in interface com.facebook.buck.features.python.toolchain.PythonInterpreter
-
- getName() - Method in interface com.facebook.buck.features.python.toolchain.PythonPlatformsProvider
-
- getName() - Method in class com.facebook.buck.features.rust.PrebuiltRustLibraryDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg
-
- getName() - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg
-
- getName() - Method in interface com.facebook.buck.features.rust.RustToolchain
-
- getName() - Method in class com.facebook.buck.features.zip.rules.ZipFileDescriptionArg
-
- getName() - Method in interface com.facebook.buck.file.downloader.Downloader
-
- getName() - Method in class com.facebook.buck.file.HttpArchiveDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.file.HttpFileDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.file.RemoteFileDescriptionArg
-
Each rule has a name
- getName() - Method in interface com.facebook.buck.infer.toolchain.InferToolchain
-
- getName() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.jvm.java.JarFileObject
-
- getName() - Method in class com.facebook.buck.jvm.java.JarGenruleDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.jvm.java.JavaAnnotationProcessorDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.jvm.java.JavaBinaryDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.jvm.java.JavaPluginDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.jvm.java.KeystoreDescriptionArg
-
Each rule has a name
- getName() - Method in interface com.facebook.buck.jvm.java.plugin.adapter.BuckJavacPlugin
-
- getName() - Method in class com.facebook.buck.jvm.java.PrebuiltJarDescriptionArg
-
Each rule has a name
- getName() - Method in interface com.facebook.buck.jvm.java.toolchain.JavacOptionsProvider
-
- getName() - Method in interface com.facebook.buck.jvm.java.toolchain.JavaCxxPlatformProvider
-
- getName() - Method in class com.facebook.buck.jvm.java.toolchain.JavaOptionsProvider
-
- getName() - Method in interface com.facebook.buck.jvm.java.toolchain.JavaToolchain
-
- getName() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.query.AllPathsFunction
-
- getName() - Method in class com.facebook.buck.query.AttrFilterFunction
-
- getName() - Method in class com.facebook.buck.query.AttrRegexFilterFunction
-
- getName() - Method in class com.facebook.buck.query.BuildFileFunction
-
- getName() - Method in class com.facebook.buck.query.DepsFunction.FirstOrderDepsFunction
-
- getName() - Method in class com.facebook.buck.query.DepsFunction
-
- getName() - Method in class com.facebook.buck.query.DepsFunction.LookupFunction
-
- getName() - Method in class com.facebook.buck.query.FilterFunction
-
- getName() - Method in class com.facebook.buck.query.InputsFunction
-
- getName() - Method in class com.facebook.buck.query.KindFunction
-
- getName() - Method in class com.facebook.buck.query.LabelsFunction
-
- getName() - Method in class com.facebook.buck.query.OwnerFunction
-
- getName() - Method in interface com.facebook.buck.query.QueryEnvironment.QueryFunction
-
Name of the function as it appears in the query language.
- getName() - Method in class com.facebook.buck.query.RdepsFunction
-
- getName() - Method in class com.facebook.buck.query.TestsOfFunction
-
- getName() - Method in interface com.facebook.buck.remoteexecution.interfaces.Protocol.TreeNode
-
- getName() - Method in class com.facebook.buck.rules.coercer.AbstractParamInfo
-
- getName() - Method in class com.facebook.buck.rules.coercer.BuildConfigFields.Field
-
- getName(Function<SourcePath, Path>) - Method in class com.facebook.buck.rules.coercer.FrameworkPath
-
- getName() - Method in interface com.facebook.buck.rules.coercer.ParamInfo
-
- getName() - Method in class com.facebook.buck.rules.keys.FieldValueExtractor
-
- getName() - Method in interface com.facebook.buck.rules.keys.ValueExtractor
-
- getName() - Method in class com.facebook.buck.rules.keys.ValueMethodValueExtractor
-
- getName() - Method in class com.facebook.buck.rules.query.ClasspathFunction
-
- getName() - Method in class com.facebook.buck.shell.CommandAliasDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.shell.ExportFileDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.shell.GenruleDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.shell.ShBinaryDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.shell.ShTestDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.shell.TestSuiteDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.shell.WorkerToolDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.swift.SwiftLibraryDescriptionArg
-
Each rule has a name
- getName() - Method in class com.facebook.buck.swift.SwiftToolchainDescriptionArg
-
Each rule has a name
- getName() - Method in interface com.facebook.buck.swift.toolchain.SwiftPlatformsProvider
-
- getName() - Method in interface com.facebook.buck.versions.Version
-
- getName() - Method in class com.facebook.buck.versions.VersionedAliasDescriptionArg
-
Each rule has a name
- getNameCount() - Method in class com.facebook.buck.core.filesystems.BuckUnixPath
-
- getNameData() - Method in class com.facebook.buck.android.resources.ResTablePackage
-
- getNamedDeps() - Method in interface com.facebook.buck.features.rust.HasNamedDeclaredDeps
-
- getNamedDeps() - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg
-
- getNamedDeps() - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg
-
- getNamedDeps() - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg
-
- getNamedResources(SourcePathRuleFinder, ProjectFilesystem, ImmutableCollection<SourcePath>) - Static method in class com.facebook.buck.jvm.java.ResourcesParameters
-
- getNamedSources() - Method in class com.facebook.buck.rules.coercer.SourceSet
-
- getNamedSources() - Method in class com.facebook.buck.rules.coercer.SourceSortedSet
-
- getNamedSources() - Method in class com.facebook.buck.rules.coercer.SourceWithFlagsList
-
- getNameIfResolvable(Optional<String>) - Method in interface com.facebook.buck.core.cell.nameresolver.CellNameResolver
-
- getNameIfResolvable(Optional<String>) - Method in class com.facebook.buck.core.cell.nameresolver.DefaultCellNameResolver
-
- getNameString(BuckUnixPath, int) - Static method in class com.facebook.buck.core.filesystems.BuckUnixPath.InternalsForFastPaths
-
- getNameString(Path, int) - Static method in class com.facebook.buck.io.file.FastPaths
-
Gets a Path segment as a String.
- getNameToField() - Method in class com.facebook.buck.rules.coercer.BuildConfigFields
-
- getNameToPathMap() - Method in class com.facebook.buck.cxx.CxxSymlinkTreeHeaders
-
- getNameWithoutExtension(Path) - Static method in class com.facebook.buck.io.file.MorePaths
-
- getNanoDuration() - Method in class com.facebook.buck.util.timing.ClockDuration
-
- getNanoTime() - Method in class com.facebook.buck.event.AbstractBuckEvent
-
- getNanoTime() - Method in interface com.facebook.buck.event.BuckEvent
-
- getNativeCLibs() - Method in class com.facebook.buck.features.ocaml.PrebuiltOcamlLibraryDescriptionArg
-
- getNativeCompileDeps(OcamlPlatform) - Method in class com.facebook.buck.features.ocaml.OcamlLibrary
-
Dependencies for the native (ocamlopt) build
- getNativeLib() - Method in class com.facebook.buck.features.ocaml.PrebuiltOcamlLibraryDescriptionArg
-
- getNativeLibAssetsDirectories() - Method in interface com.facebook.buck.android.packageable.AndroidPackageableCollection
-
Directories containing native libraries to be used as assets.
- getNativeLibraries() - Method in class com.facebook.buck.features.python.PythonPackageComponents
-
- getNativeLibraries() - Method in class com.facebook.buck.jvm.java.JarFattener
-
- getNativeLibraries(Iterable<BuildRule>, CxxPlatform, ActionGraphBuilder) - Static method in class com.facebook.buck.jvm.java.JavaLibraryRules
-
- getNativeLibraryDirectories() - Method in class com.facebook.buck.android.ModuleInfo
-
- getNativeLibraryMergeCodeGenerator() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getNativeLibraryMergeCodeGenerator() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getNativeLibraryMergeCodeGenerator() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getNativeLibraryMergeGlue() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getNativeLibraryMergeGlue() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getNativeLibraryMergeGlue() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getNativeLibraryMergeLocalizedSymbols() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getNativeLibraryMergeLocalizedSymbols() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getNativeLibraryMergeLocalizedSymbols() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getNativeLibraryMergeMap() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getNativeLibraryMergeMap() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getNativeLibraryMergeMap() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getNativeLibraryProguardConfigGenerator() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getNativeLibraryProguardConfigGenerator() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getNativeLibraryProguardConfigGenerator() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getNativeLibs() - Method in class com.facebook.buck.android.PrebuiltNativeLibraryDescriptionArg
-
- getNativeLibsDirectories() - Method in interface com.facebook.buck.android.packageable.AndroidPackageableCollection
-
Directories containing native libraries.
- getNativeLibsDirectoriesForSystemLoader() - Method in interface com.facebook.buck.android.packageable.AndroidPackageableCollection
-
Directories containing native libraries which must be loadable by the system loader.
- getNativeLibsInfo() - Method in class com.facebook.buck.android.exopackage.ExopackageInfo
-
- getNativeLibsSymlinkTreeTarget(BuildTarget) - Static method in class com.facebook.buck.features.lua.LuaBinaryDescription
-
- getNativeLinkable(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.cxx.PrebuiltCxxLibrary
-
- getNativeLinkable(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.cxx.PreInclude
-
- getNativeLinkable(CxxPlatform, ActionGraphBuilder) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.LegacyNativeLinkableGroup
-
- getNativeLinkable(CxxPlatform, ActionGraphBuilder) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableGroup
-
- getNativeLinkable(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.features.d.DLibrary
-
- getNativeLinkable(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.features.halide.HalideLibrary
-
- getNativeLinkable(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.features.lua.SystemLuaCxxLibrary
-
- getNativeLinkable(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.swift.SwiftRuntimeNativeLinkableGroup
-
- getNativeLinkableAssets() - Method in interface com.facebook.buck.android.packageable.NativeLinkableEnhancementResult
-
Native libraries to be packaged as assets by platform.
- getNativeLinkableCache(LegacyNativeLinkableGroup) - Static method in interface com.facebook.buck.cxx.toolchain.nativelink.LegacyNativeLinkableGroup
-
- getNativeLinkableCompatibilityCache() - Method in class com.facebook.buck.apple.PrebuiltAppleFramework
-
- getNativeLinkableCompatibilityCache() - Method in class com.facebook.buck.cxx.CxxLibraryGroup
-
- getNativeLinkableCompatibilityCache() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescription.CustomPrebuiltCxxLibrary
-
- getNativeLinkableCompatibilityCache() - Method in interface com.facebook.buck.cxx.toolchain.nativelink.LegacyNativeLinkableGroup
-
- getNativeLinkableDeps(BuildRuleResolver) - Method in class com.facebook.buck.apple.PrebuiltAppleFramework
-
- getNativeLinkableDeps(BuildRuleResolver) - Method in class com.facebook.buck.cxx.CxxLibraryGroup
-
- getNativeLinkableDeps(BuildRuleResolver) - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescription.CustomPrebuiltCxxLibrary
-
- getNativeLinkableDeps(BuildRuleResolver) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.LegacyNativeLinkableGroup
-
- getNativeLinkableDeps(ActionGraphBuilder) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.NativeLinkable
-
- getNativeLinkableDeps(ActionGraphBuilder) - Method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableInfo
-
- getNativeLinkableDeps(ActionGraphBuilder) - Method in class com.facebook.buck.cxx.toolchain.nativelink.PlatformLockedNativeLinkableGroup
-
- getNativeLinkableDepsForPlatform(CxxPlatform, BuildRuleResolver) - Method in class com.facebook.buck.apple.PrebuiltAppleFramework
-
- getNativeLinkableDepsForPlatform(CxxPlatform, BuildRuleResolver) - Method in class com.facebook.buck.cxx.CxxLibraryGroup
-
- getNativeLinkableDepsForPlatform(CxxPlatform, BuildRuleResolver) - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescription.CustomPrebuiltCxxLibrary
-
- getNativeLinkableDepsForPlatform(CxxPlatform, BuildRuleResolver) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.LegacyNativeLinkableGroup
-
Deprecated.
- getNativeLinkableExportedDeps(BuildRuleResolver) - Method in class com.facebook.buck.apple.PrebuiltAppleFramework
-
- getNativeLinkableExportedDeps() - Method in interface com.facebook.buck.cxx.CxxLibraryDescriptionDelegate.ConfiguredDelegate
-
Provides the ability for the plugin to provide additional NativeLinkable
s that will
be exported.
- getNativeLinkableExportedDeps(BuildRuleResolver) - Method in class com.facebook.buck.cxx.CxxLibraryGroup
-
- getNativeLinkableExportedDeps(BuildRuleResolver) - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescription.CustomPrebuiltCxxLibrary
-
- getNativeLinkableExportedDeps(BuildRuleResolver) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.LegacyNativeLinkableGroup
-
- getNativeLinkableExportedDeps(ActionGraphBuilder) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.NativeLinkable
-
- getNativeLinkableExportedDeps(ActionGraphBuilder) - Method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableInfo
-
- getNativeLinkableExportedDeps(ActionGraphBuilder) - Method in class com.facebook.buck.cxx.toolchain.nativelink.PlatformLockedNativeLinkableGroup
-
- getNativeLinkableExportedDepsForPlatform(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.cxx.CxxLibraryGroup
-
- getNativeLinkableExportedDepsForPlatform(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescription.CustomPrebuiltCxxLibrary
-
- getNativeLinkableExportedDepsForPlatform(CxxPlatform, ActionGraphBuilder) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.LegacyNativeLinkableGroup
-
Deprecated.
- getNativeLinkableInput(CxxPlatform, Linker.LinkableDepType, boolean, ActionGraphBuilder, TargetConfiguration) - Method in class com.facebook.buck.apple.PrebuiltAppleFramework
-
- getNativeLinkableInput(CxxPlatform, Linker.LinkableDepType, boolean, ActionGraphBuilder, TargetConfiguration) - Method in class com.facebook.buck.cxx.CxxLibraryGroup
-
- getNativeLinkableInput(CxxPlatform, Linker.LinkableDepType, boolean, ActionGraphBuilder, TargetConfiguration) - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescription.CustomPrebuiltCxxLibrary
-
- getNativeLinkableInput(CxxPlatform, Linker.LinkableDepType, boolean, ActionGraphBuilder, TargetConfiguration) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.LegacyNativeLinkableGroup
-
Deprecated.
- getNativeLinkableInput(CxxPlatform, Linker.LinkableDepType, ActionGraphBuilder, TargetConfiguration) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.LegacyNativeLinkableGroup
-
Deprecated.
- getNativeLinkableInput(Linker.LinkableDepType, boolean, ActionGraphBuilder, TargetConfiguration) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.NativeLinkable
-
Return input that *dependents* should put on their link line when linking against this
linkable.
- getNativeLinkableInput(Linker.LinkableDepType, ActionGraphBuilder, TargetConfiguration) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.NativeLinkable
-
Return input that *dependents* should put on their link line when linking against this
linkable.
- getNativeLinkableInput(Linker.LinkableDepType, boolean, ActionGraphBuilder, TargetConfiguration) - Method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableInfo
-
- getNativeLinkableInput(Linker.LinkableDepType, NativeLinkable, ActionGraphBuilder, TargetConfiguration) - Static method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkables
-
- getNativeLinkableInput(Linker.LinkableDepType, boolean, ActionGraphBuilder, TargetConfiguration) - Method in class com.facebook.buck.cxx.toolchain.nativelink.PlatformLockedNativeLinkableGroup
-
- getNativeLinkableInput(OcamlPlatform) - Method in class com.facebook.buck.features.ocaml.OcamlLibrary
-
- getNativeLinkableRoots(Iterable<? extends T>, Function<? super T, Optional<Iterable<? extends T>>>) - Static method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableGroups
-
- getNativeLinkables() - Method in interface com.facebook.buck.android.packageable.AndroidPackageableCollection
-
Native libraries mapped from modules.
- getNativeLinkables() - Method in interface com.facebook.buck.android.packageable.NativeLinkableEnhancementResult
-
Native libraries by platform.
- getNativeLinkables(ActionGraphBuilder, Iterable<? extends NativeLinkable>, Linker.LinkableDepType, Predicate<? super NativeLinkable>, Optional<LinkableListFilter>) - Static method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkables
-
Extract from the dependency graph all the libraries which must be considered for linking.
- getNativeLinkables(ActionGraphBuilder, Iterable<? extends NativeLinkable>, Linker.LinkableDepType, Predicate<? super NativeLinkable>) - Static method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkables
-
Extract from the dependency graph all the libraries which must be considered for linking.
- getNativeLinkables(ActionGraphBuilder, Iterable<? extends NativeLinkable>, Linker.LinkableDepType) - Static method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkables
-
Extract from the dependency graph all the libraries which must be considered for linking.
- getNativeLinkables(ActionGraphBuilder, Iterable<? extends NativeLinkable>, Linker.LinkableDepType, Optional<LinkableListFilter>) - Static method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkables
-
Extract from the dependency graph all the libraries which must be considered for linking.
- getNativeLinkablesAssets() - Method in interface com.facebook.buck.android.packageable.AndroidPackageableCollection
-
Native libraries to be packaged as assets.
- getNativeLinkStrategy() - Method in class com.facebook.buck.features.lua.LuaPlatform
-
- getNativeLinkStrategy() - Method in class com.facebook.buck.features.python.PythonBuckConfig
-
- getNativeLinkTarget(CxxPlatform, ActionGraphBuilder) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.LegacyNativeLinkableGroup
-
Deprecated.
- getNativeLinkTarget(ActionGraphBuilder, boolean) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.NativeLinkable
-
- getNativeLinkTarget(ActionGraphBuilder, boolean) - Method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableInfo
-
- getNativeLinkTarget(ActionGraphBuilder, boolean) - Method in class com.facebook.buck.cxx.toolchain.nativelink.PlatformLockedNativeLinkableGroup
-
- getNativeLinkTarget(PythonPlatform, CxxPlatform, ActionGraphBuilder, boolean) - Method in class com.facebook.buck.features.python.CxxPythonExtension
-
- getNativeLinkTargetDeps(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.cxx.CxxLibraryGroup
-
- getNativeLinkTargetDeps(CxxPlatform, ActionGraphBuilder) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.LegacyNativeLinkTargetGroup
-
- getNativeLinkTargetDeps(ActionGraphBuilder) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.NativeLinkTarget
-
- getNativeLinkTargetDeps(ActionGraphBuilder) - Method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkTargetInfo
-
- getNativeLinkTargetDeps(ActionGraphBuilder) - Method in class com.facebook.buck.cxx.toolchain.nativelink.PlatformLockedNativeLinkTargetGroup
-
- getNativeLinkTargetInput(CxxPlatform, ActionGraphBuilder, SourcePathResolverAdapter, boolean) - Method in class com.facebook.buck.cxx.CxxLibraryGroup
-
- getNativeLinkTargetInput(CxxPlatform, ActionGraphBuilder, SourcePathResolverAdapter, boolean) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.LegacyNativeLinkTargetGroup
-
- getNativeLinkTargetInput(ActionGraphBuilder, SourcePathResolverAdapter) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.NativeLinkTarget
-
- getNativeLinkTargetInput(ActionGraphBuilder, SourcePathResolverAdapter) - Method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkTargetInfo
-
- getNativeLinkTargetInput(ActionGraphBuilder, SourcePathResolverAdapter) - Method in class com.facebook.buck.cxx.toolchain.nativelink.PlatformLockedNativeLinkTargetGroup
-
- getNativeLinkTargetMode(CxxPlatform) - Method in class com.facebook.buck.cxx.CxxLibraryGroup
-
- getNativeLinkTargetMode(CxxPlatform) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.LegacyNativeLinkTargetGroup
-
- getNativeLinkTargetMode() - Method in interface com.facebook.buck.cxx.toolchain.nativelink.NativeLinkTarget
-
- getNativeLinkTargetMode() - Method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkTargetInfo
-
- getNativeLinkTargetMode() - Method in class com.facebook.buck.cxx.toolchain.nativelink.PlatformLockedNativeLinkTargetGroup
-
- getNativeLinkTargetOutputPath() - Method in class com.facebook.buck.cxx.CxxLibraryGroup
-
- getNativeLinkTargetOutputPath() - Method in interface com.facebook.buck.cxx.toolchain.nativelink.LegacyNativeLinkTargetGroup
-
- getNativeLinkTargetOutputPath() - Method in interface com.facebook.buck.cxx.toolchain.nativelink.NativeLinkTarget
-
- getNativeLinkTargetOutputPath() - Method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkTargetInfo
-
- getNativeLinkTargetOutputPath() - Method in class com.facebook.buck.cxx.toolchain.nativelink.PlatformLockedNativeLinkTargetGroup
-
- getNativeModule() - Method in class com.facebook.buck.skylark.parser.BuckGlobals
-
Returns a native module with built-in functions and Buck rules.
- getNativePlatforms() - Method in class com.facebook.buck.android.toolchain.platform.AndroidPlatformArg
-
- getNativePlugin() - Method in class com.facebook.buck.features.ocaml.OcamlLibraryDescriptionArg
-
- getNativeRuleTypes(Cell) - Method in class com.facebook.buck.core.rules.knowntypes.provider.KnownRuleTypesProvider
-
Get details for just rules implemented in Buck itself, rather than user defined rules
- getNativeStarterLibrary() - Method in class com.facebook.buck.features.lua.LuaBinaryDescriptionArg
-
- getNativeStarterLibrary() - Method in class com.facebook.buck.features.lua.LuaPlatform
-
- getNativeTypesByName() - Method in class com.facebook.buck.core.rules.knowntypes.KnownNativeRuleTypes
-
- getNdkAppPlatformForCpuAbi(String) - Method in class com.facebook.buck.android.AndroidBuckConfig
-
Returns the CPU specific app platform, or the fallback one if set.
- getNdkBuildExecutable() - Method in class com.facebook.buck.android.toolchain.ndk.AndroidNdk
-
- getNdkClangVersion() - Method in class com.facebook.buck.android.AndroidBuckConfig
-
- getNdkCompiler() - Method in class com.facebook.buck.android.AndroidBuckConfig
-
- getNdkCpuAbiAppPlatformMap() - Method in class com.facebook.buck.android.AndroidBuckConfig
-
- getNdkCpuAbiFallbackAppPlatform() - Method in class com.facebook.buck.android.AndroidBuckConfig
-
- getNdkCpuAbis() - Method in class com.facebook.buck.android.AndroidBuckConfig
-
- getNdkCxxPlatform(Flavor) - Method in class com.facebook.buck.android.NdkToolchainBuildRule
-
- getNdkCxxPlatform(Flavor) - Method in interface com.facebook.buck.android.toolchain.ndk.ProvidesNdkCxxPlatform
-
- getNdkCxxPlatforms() - Method in class com.facebook.buck.android.toolchain.ndk.NdkCxxPlatformsProvider
-
- getNdkCxxRuntime() - Method in class com.facebook.buck.android.AndroidBuckConfig
-
- getNdkCxxRuntimeType() - Method in class com.facebook.buck.android.AndroidBuckConfig
-
- getNdkCxxToolchainTargetForAbi(NdkTargetArchAbi, TargetConfiguration) - Method in class com.facebook.buck.android.AndroidBuckConfig
-
Gets the ndk_toolchain target for the abi if it is specified in the config.
- getNdkGccVersion() - Method in class com.facebook.buck.android.AndroidBuckConfig
-
- getNdkOrThrow() - Method in class com.facebook.buck.android.toolchain.ndk.impl.AndroidNdkResolver
-
- getNdkPath() - Method in class com.facebook.buck.android.AndroidBuckConfig
-
- getNdkPath() - Method in class com.facebook.buck.android.NdkToolchainDescriptionArg
-
Path to Ndk.
- getNdkRepositoryPath() - Method in class com.facebook.buck.android.AndroidBuckConfig
-
- getNdkRootPath() - Method in class com.facebook.buck.android.toolchain.ndk.AndroidNdk
-
- getNdkSearchOrder() - Method in class com.facebook.buck.android.AndroidBuckConfig
-
Defines the order of search of the Android NDK.
- getNdkUnifiedHeaders() - Method in class com.facebook.buck.android.AndroidBuckConfig
-
- getNdkVersion() - Method in class com.facebook.buck.android.AndroidBuckConfig
-
- getNdkVersion() - Method in class com.facebook.buck.android.toolchain.ndk.AndroidNdk
-
- getNdkVersion() - Method in class com.facebook.buck.android.toolchain.ndk.impl.AndroidNdkResolver
-
- getNeededCoverage() - Method in class com.facebook.buck.core.test.rule.ExternalTestRunnerTestSpec
-
- getNeededCoverage() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getNeededCoverageRatioPercentage() - Method in class com.facebook.buck.rules.coercer.NeededCoverageSpec
-
Gets the coverage ratio that is required for a test
- getNestedPlatforms() - Method in class com.facebook.buck.android.toolchain.platform.AndroidMultiPlatform
-
- getNestedPlatforms() - Method in interface com.facebook.buck.core.model.platform.MultiPlatform
-
Access nested platforms, for example, per-CPU platforms for Android platform
- getNestedPlatformsByCpuType() - Method in class com.facebook.buck.android.toolchain.platform.AndroidMultiPlatform
-
Android platform is a multiplatform which maps knows CPUs to nested platforms.
- getNestingKind() - Method in class com.facebook.buck.jvm.java.JarFileObject
-
- getNetwork() - Method in class com.facebook.buck.util.environment.NetworkInfo.Event
-
- getNetworkIO() - Method in class com.facebook.buck.util.concurrent.ResourceAmounts
-
- getNetworkStatsLine(BuildEvent.Finished) - Method in class com.facebook.buck.event.listener.AbstractConsoleEventBusListener
-
- getNeverMarkAsUnusedDependency() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getNeverMarkAsUnusedDependency() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getNeverMarkAsUnusedDependency() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getNeverMarkAsUnusedDependency() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getNeverMarkAsUnusedDependency() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getNeverMarkAsUnusedDependency() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getNeverMarkAsUnusedDependency() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getNeverMarkAsUnusedDependency() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getNeverMarkAsUnusedDependency() - Method in interface com.facebook.buck.jvm.java.JvmLibraryArg
-
- getNeverMarkAsUnusedDependency() - Method in class com.facebook.buck.jvm.java.PrebuiltJarDescriptionArg
-
- getNeverMarkAsUnusedDependency() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getNeverMarkAsUnusedDependency() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getNeverMarkAsUnusedDependency() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getNeverMarkAsUnusedDependency() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getNewCellPathResolver() - Method in interface com.facebook.buck.core.cell.Cell
-
- getNewCellPathResolver() - Method in interface com.facebook.buck.core.cell.CellPathResolver
-
- getNewCellPathResolver() - Method in class com.facebook.buck.core.cell.CellPathResolverView
-
- getNewCellPathResolver() - Method in class com.facebook.buck.core.cell.impl.DefaultCellPathResolver
-
- getNewScope(BuildId, boolean) - Method in class com.facebook.buck.support.bgtasks.AsyncBackgroundTaskManager
-
- getNewScope(BuildId, boolean) - Method in class com.facebook.buck.support.bgtasks.BackgroundTaskManager
-
- getNewValue() - Method in interface com.facebook.buck.command.config.ConfigDifference.ConfigChange
-
- getNioPath(Path) - Method in class com.facebook.buck.io.filesystem.skylark.SkylarkFilesystem
-
- getNm() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getNm() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
nm binary.
- getNoAsNeededSharedLibsFlags() - Method in class com.facebook.buck.cxx.toolchain.linker.impl.DarwinLinker
-
- getNoAsNeededSharedLibsFlags() - Method in class com.facebook.buck.cxx.toolchain.linker.impl.GnuLinker
-
- getNoAsNeededSharedLibsFlags() - Method in class com.facebook.buck.cxx.toolchain.linker.impl.WindowsLinker
-
- getNoAsNeededSharedLibsFlags() - Method in interface com.facebook.buck.cxx.toolchain.linker.Linker
-
- getNode(Cell, UnconfiguredBuildTarget) - Method in interface com.facebook.buck.parser.BuildTargetParsePipeline
-
- getNode(Cell, BuildTarget, DependencyStack) - Method in class com.facebook.buck.parser.UnconfiguredTargetNodeToTargetNodeParsePipeline
-
- getNode(BuildTarget) - Method in class com.facebook.buck.versions.AbstractVersionedTargetGraphBuilder
-
- getNodeCopier() - Method in class com.facebook.buck.core.model.targetgraph.impl.TargetNodeImpl
-
- getNodeCopier() - Method in interface com.facebook.buck.core.model.targetgraph.TargetNode
-
- getNodeCount() - Method in class com.facebook.buck.core.util.graph.MutableDirectedGraph
-
- getNodeCount() - Method in class com.facebook.buck.event.ActionGraphEvent.Finished
-
- getNodeJob(Cell, UnconfiguredBuildTarget) - Method in interface com.facebook.buck.parser.BuildTargetParsePipeline
-
- getNodeJob(Cell, UnconfiguredBuildTarget) - Method in class com.facebook.buck.parser.BuildTargetRawNodeParsePipeline
-
- getNodeJob(Cell, UnconfiguredBuildTarget, DependencyStack) - Method in class com.facebook.buck.parser.UnconfiguredTargetNodePipeline
-
Get build target by name, load if necessary
- getNodeJob(Cell, BuildTarget, DependencyStack) - Method in class com.facebook.buck.parser.UnconfiguredTargetNodeToTargetNodeParsePipeline
-
Get build target by name, load if necessary
- getNodeOptional(BuildTarget) - Method in class com.facebook.buck.versions.AbstractVersionedTargetGraphBuilder
-
- getNodes() - Method in class com.facebook.buck.core.model.actiongraph.ActionGraph
-
NOTE: This may contain duplicate nodes.
- getNodes() - Method in class com.facebook.buck.core.model.targetgraph.MergedTargetNode
-
- getNodes() - Method in class com.facebook.buck.core.util.graph.DirectedAcyclicGraph
-
- getNodes() - Method in class com.facebook.buck.core.util.graph.MutableDirectedGraph
-
- getNodes() - Method in interface com.facebook.buck.core.util.graph.TraversableGraph
-
- getNodes() - Method in class com.facebook.buck.features.project.intellij.IjModuleGraph
-
- getNodesFromQueryTargets(Collection<QueryBuildTarget>) - Method in class com.facebook.buck.cli.BuckQueryEnvironment
-
- getNodesWithNoIncomingEdges() - Method in class com.facebook.buck.core.util.graph.DirectedAcyclicGraph
-
- getNodesWithNoIncomingEdges() - Method in class com.facebook.buck.core.util.graph.MutableDirectedGraph
-
- getNodesWithNoIncomingEdges() - Method in interface com.facebook.buck.core.util.graph.TraversableGraph
-
- getNodesWithNoOutgoingEdges() - Method in class com.facebook.buck.core.util.graph.DirectedAcyclicGraph
-
- getNodesWithNoOutgoingEdges() - Method in class com.facebook.buck.core.util.graph.MutableDirectedGraph
-
- getNodesWithNoOutgoingEdges() - Method in interface com.facebook.buck.core.util.graph.TraversableGraph
-
- getNoDx() - Method in class com.facebook.buck.android.AndroidAppModularityDescriptionArg
-
- getNoDx() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getNoDx() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getNoDx() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getNoDxClasspathEntries() - Method in interface com.facebook.buck.android.packageable.AndroidPackageableCollection
-
Java classes that were used during compilation, but don't got into the package.
- getNoJdk() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
Don't include Java runtime into classpath.
- getNoJdk() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
Don't include Java runtime into classpath.
- getNoJdk() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
Don't include Java runtime into classpath.
- getNoJdk() - Method in interface com.facebook.buck.jvm.kotlin.KotlinLibraryDescription.CoreArg
-
Don't include Java runtime into classpath.
- getNoJdk() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
Don't include Java runtime into classpath.
- getNoJdk() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
Don't include Java runtime into classpath.
- getNoMatchError() - Method in class com.facebook.buck.parser.syntax.SelectorValue
-
Provide an error message to show if select choices are not matched
- getNoMatchMessage() - Method in class com.facebook.buck.core.select.Selector
-
Returns a custom message that needs to be shown to a user when no condition matches.
- getNonIncludePathFlags(SourcePathResolverAdapter, Optional<Pair<PrecompiledHeaderData, PathShortener>>, Preprocessor) - Method in class com.facebook.buck.cxx.PreprocessorFlags
-
- getNonProvidedClasspathDeps(TargetConfiguration, Consumer<BuildTarget>) - Method in class com.facebook.buck.jvm.java.ConfiguredCompilerFactory
-
- getNonProvidedClasspathDeps(TargetConfiguration, Consumer<BuildTarget>) - Method in class com.facebook.buck.jvm.scala.ScalaConfiguredCompilerFactory
-
- getNonSourceBuildTargets() - Method in class com.facebook.buck.features.project.intellij.model.IjModule
-
- getNonSourceBuildTargets() - Method in class com.facebook.buck.features.project.intellij.ModuleBuildContext
-
- getNonSwiftSources() - Method in class com.facebook.buck.apple.AppleLibrarySwiftMetadata
-
- getNoReflect() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
Don't include kotlin-reflect.jar into classpath.
- getNoReflect() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
Don't include kotlin-reflect.jar into classpath.
- getNoReflect() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
Don't include kotlin-reflect.jar into classpath.
- getNoReflect() - Method in interface com.facebook.buck.jvm.kotlin.KotlinLibraryDescription.CoreArg
-
Don't include kotlin-reflect.jar into classpath.
- getNoReflect() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
Don't include kotlin-reflect.jar into classpath.
- getNoReflect() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
Don't include kotlin-reflect.jar into classpath.
- getNormals() - Method in class com.facebook.buck.event.ScubaData
-
- getNormalSymbols(ProcessExecutor, Tool, SourcePathResolverAdapter, Path) - Static method in class com.facebook.buck.android.relinker.Symbols
-
- getNoStdlib() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
Don't include kotlin-stdlib.jar or kotlin-reflect.jar into classpath.
- getNoStdlib() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
Don't include kotlin-stdlib.jar or kotlin-reflect.jar into classpath.
- getNoStdlib() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
Don't include kotlin-stdlib.jar or kotlin-reflect.jar into classpath.
- getNoStdlib() - Method in interface com.facebook.buck.jvm.kotlin.KotlinLibraryDescription.CoreArg
-
Don't include kotlin-stdlib.jar or kotlin-reflect.jar into classpath.
- getNoStdlib() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
Don't include kotlin-stdlib.jar or kotlin-reflect.jar into classpath.
- getNoStdlib() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
Don't include kotlin-stdlib.jar or kotlin-reflect.jar into classpath.
- getNotices() - Method in class com.facebook.buck.apple.AppleAssetCatalogsCompilationOptions
-
- getNotificationPayloadFile() - Method in class com.facebook.buck.apple.xcode.XCScheme.LaunchAction
-
- getNotificationPayloadFile() - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg
-
- getNullConditions() - Method in class com.facebook.buck.core.select.Selector
-
- getNullDevicePath() - Method in enum com.facebook.buck.util.environment.Platform
-
Return a path to a special file which accepts reads (always returning EOF) and writes (accepts
and immediately discards written data).
- getNullsafeArgs() - Method in class com.facebook.buck.infer.InferConfig
-
- getNullsafeThirdPartySignatures(TargetConfiguration) - Method in class com.facebook.buck.infer.InferConfig
-
Directory with third party signatures for nullsafe.
- getNumActiveConnections() - Method in class com.facebook.buck.httpserver.StreamingWebSocketServlet
-
- getNumActiveConnections() - Method in class com.facebook.buck.httpserver.WebServer
-
- getNumber() - Method in class com.facebook.buck.event.listener.util.ProgressEstimation
-
- getNumberEntries() - Method in class com.facebook.buck.util.cache.CacheStats
-
- getNumberNodesGenerated() - Method in class com.facebook.buck.event.ActionGraphPerfStatEvent
-
- getNumberOfPayloads() - Method in class com.facebook.buck.slb.HybridThriftRequestHandler
-
Total number of payloads.
- getNumberOfSections() - Method in class com.facebook.buck.cxx.toolchain.elf.Elf
-
- getNumberOfSlowRulesToShow() - Method in class com.facebook.buck.event.listener.SuperConsoleConfig
-
- getNumberOfSymbolTableEntries() - Method in class com.facebook.buck.cxx.toolchain.objectfile.MachoSymTabCommand
-
- getNumBuckets() - Method in class com.facebook.buck.apple.clang.HeaderMap
-
- getNumDepFiles() - Method in interface com.facebook.buck.core.build.engine.manifest.ManifestStats
-
- getNumEntries() - Method in class com.facebook.buck.apple.clang.HeaderMap
-
- getNumHashes() - Method in interface com.facebook.buck.core.build.engine.manifest.ManifestStats
-
- getNumInputs() - Method in interface com.facebook.buck.core.build.engine.manifest.ManifestStats
-
- getNumNoopNodesGenerated() - Method in class com.facebook.buck.event.ActionGraphPerfStatEvent
-
- getNumParsingThreads() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getNumRules() - Method in class com.facebook.buck.core.build.event.BuildEvent.RuleCountCalculated
-
- getNumRules() - Method in class com.facebook.buck.core.build.event.BuildEvent.UnskippedRuleCountUpdated
-
- getNumRules() - Method in class com.facebook.buck.parser.events.ParseBuckFileEvent.Finished
-
- getNumRulesToBuild(Iterable<BuildRule>) - Method in interface com.facebook.buck.core.build.engine.BuildEngine
-
Calculate the total number of transitive build rules processed from the given roots.
- getNumRulesToBuild(Iterable<BuildRule>) - Method in class com.facebook.buck.core.build.engine.impl.CachingBuildEngine
-
- getNumTestManagedThreads(ResourcesConfig) - Method in class com.facebook.buck.cli.TestCommand
-
- getNumTestThreads(BuckConfig) - Method in class com.facebook.buck.cli.TestCommand
-
- getNumTestThreads() - Method in class com.facebook.buck.test.config.TestBuckConfig
-
- getNumThreads() - Method in class com.facebook.buck.command.config.BuildBuckConfig
-
- getNumThreads(int) - Method in class com.facebook.buck.command.config.BuildBuckConfig
-
- getNumThreadsForSchedulerPool() - Method in class com.facebook.buck.command.config.BuildBuckConfig
-
- getObjCGeneratedHeader(BuildTarget, ActionGraphBuilder, CxxPlatform, HeaderVisibility) - Static method in class com.facebook.buck.apple.AppleLibraryDescriptionSwiftEnhancer
-
- getObjCGeneratedHeaderFileName() - Method in class com.facebook.buck.swift.SwiftCompile
-
- getObjCGeneratedHeaderPath() - Method in class com.facebook.buck.swift.SwiftCompile
-
- getObjcopy() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getObjcopy() - Method in class com.facebook.buck.cxx.toolchain.ElfSharedLibraryInterfaceParams
-
- getObjcopyForSharedLibraryInterface() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
Objcopy binary to use for creating shared library interfaces.
- getObjdump() - Method in class com.facebook.buck.android.NdkToolchainDescriptionArg
-
Objdump binary.
- getObjdump() - Method in interface com.facebook.buck.android.toolchain.ndk.NdkCxxPlatform
-
- getObject() - Method in interface com.facebook.buck.core.rules.actions.lib.args.CommandLineArgs.ArgAndFormatString
-
The original raw argument
- getObjectFileExtension() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getObjectFileExtension() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
Extension for object files.
- getObjectFileExtension() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getObjectFilePaths() - Method in interface com.facebook.buck.cxx.CxxLibraryDescriptionDelegate.ConfiguredDelegate
-
Defines the paths to object files (i.e., .o files) that will be combined into the final
product of
CxxLibraryDescription
.
- getObjectNameForSourceName(String) - Static method in class com.facebook.buck.features.d.DCompileStep
-
- getObjectPaths() - Method in class com.facebook.buck.swift.SwiftCompile
-
- getObjects() - Method in class com.facebook.buck.features.haskell.HaskellCompileRule
-
- getObjectsDir() - Method in class com.facebook.buck.features.haskell.HaskellCompileRule
-
- getOcamlContext() - Method in class com.facebook.buck.features.ocaml.OcamlBuild
-
- getOcamldepFlags() - Method in class com.facebook.buck.features.ocaml.OcamlBinaryDescriptionArg
-
- getOcamldepFlags() - Method in class com.facebook.buck.features.ocaml.OcamlLibraryDescriptionArg
-
- getOcamlLibraryDeps(BuildRuleResolver, OcamlPlatform) - Method in class com.facebook.buck.features.ocaml.OcamlLibrary
-
- getOfflineLogDir() - Method in class com.facebook.buck.io.filesystem.BuckPaths
-
- getOffset() - Method in interface com.facebook.buck.json.BuildFileSyntaxError
-
- getOmnibusPassthroughDeps(CxxPlatform, ActionGraphBuilder) - Method in interface com.facebook.buck.features.haskell.HaskellOmnibusLinkable
-
- getOmnibusSpec(BuildTarget, ActionGraphBuilder, ImmutableList<? extends NativeLinkable>, ImmutableList<? extends NativeLinkable>) - Static method in class com.facebook.buck.features.haskell.HaskellGhciDescription
-
- getOnDuplicateEntry() - Method in class com.facebook.buck.features.zip.rules.ZipFileDescriptionArg
-
- getOneLineSummary(Locale, boolean, Ansi) - Method in class com.facebook.buck.test.TestCaseSummary
-
- getOngoingCount() - Method in class com.facebook.buck.event.listener.stats.cache.RemoteCacheUploadStats
-
- getOnlyMatchingValue(String, ImmutableMap<BuildTarget, Version>) - Method in class com.facebook.buck.rules.coercer.VersionMatchedCollection
-
- getOnUnusedDependencies() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getOnUnusedDependencies() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getOnUnusedDependencies() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getOnUnusedDependencies() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getOnUnusedDependencies() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getOnUnusedDependencies() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getOnUnusedDependencies() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getOnUnusedDependencies() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getOnUnusedDependencies() - Method in interface com.facebook.buck.jvm.java.JvmLibraryArg
-
- getOnUnusedDependencies() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getOnUnusedDependencies() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getOnUnusedDependencies() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getOnUnusedDependencies() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getOpCode(boolean) - Method in enum com.facebook.buck.features.go.GoPackStep.Operation
-
- getOperation() - Method in class com.facebook.buck.artifact_cache.ArtifactCacheEvent
-
- getOperation() - Method in class com.facebook.buck.event.ArtifactCompressionEvent
-
- getOperation() - Method in class com.facebook.buck.jvm.java.AnnotationProcessingEvent
-
- getOptimization() - Method in class com.facebook.buck.apple.AppleAssetCatalogsCompilationOptions
-
- getOptimizationPasses() - Method in class com.facebook.buck.android.AndroidBinary
-
- getOptimizationPasses() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getOptimizationPasses() - Method in class com.facebook.buck.android.AndroidBundle
-
- getOptimizationPasses() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getOptimizationPasses() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getOptimize() - Method in class com.facebook.buck.features.gwt.GwtBinaryDescriptionArg
-
This will be passed to the GWT Compiler's -optimize
flag.
- getOptimizedProguardConfig() - Method in class com.facebook.buck.android.toolchain.AndroidPlatformTarget
-
- getOptional(BuildTarget) - Method in class com.facebook.buck.core.model.targetgraph.TargetGraph
-
- getOptionalBuildLineSuffix() - Method in class com.facebook.buck.event.listener.AbstractConsoleEventBusListener
-
- getOptionalExecutable(Path, ImmutableMap<String, String>) - Method in class com.facebook.buck.io.ExecutableFinder
-
- getOptionalExecutable(Path, Path) - Method in class com.facebook.buck.io.ExecutableFinder
-
- getOptionalExecutable(Path, ImmutableCollection<Path>, ImmutableCollection<String>) - Method in class com.facebook.buck.io.ExecutableFinder
-
- getOptionalFile(Set<String>, Iterable<Path>, Predicate<Path>) - Static method in class com.facebook.buck.io.file.FileFinder
-
Tries to find a file with one of a number of possible names in a search path.
- getOptionalListWithoutComments(String, String) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getOptionalListWithoutComments(String, String, char) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getOptionalListWithoutComments(String, String) - Method in class com.facebook.buck.util.config.Config
-
ini4j leaves things that look like comments in the values of entries in the file.
- getOptionalListWithoutComments(String, String, char) - Method in class com.facebook.buck.util.config.Config
-
- getOptionalPathList(String, String, boolean) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getOptionalToolPath(String, ImmutableList<Path>) - Method in class com.facebook.buck.io.ExecutableFinder
-
- getOptions(JavacOptions, ProjectFilesystem, SourcePathResolverAdapter, Path, Path, ExecutionContext, ImmutableSortedSet<Path>) - Static method in class com.facebook.buck.jvm.java.JavacPipelineState
-
- getOptionValue() - Method in class com.facebook.buck.features.apple.project.XCodeProjectSubCommand
-
- getOptionValue() - Method in class com.facebook.buck.features.go.GoProjectSubCommand
-
- getOptionValue() - Method in class com.facebook.buck.features.project.intellij.IjProjectSubCommand
-
- getOptionValue() - Method in interface com.facebook.buck.support.cli.args.PluginBasedSubCommand
-
The value of the option that identifies a subcommand from a particular plugin.
- getOrCreateAndroidFacetBuilder() - Method in class com.facebook.buck.features.project.intellij.ModuleBuildContext
-
- getOrCreateChildGroupByName(String) - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXGroup
-
- getOrCreateChildVariantGroupByName(String) - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXGroup
-
- getOrCreateChildVersionGroupsBySourceTreePath(SourceTreePath) - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXGroup
-
- getOrCreateDescendantGroupByPath(ImmutableList<String>) - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXGroup
-
- getOrCreateFileReferenceBySourceTreePath(SourceTreePath) - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXGroup
-
- getOrCreateFileReferenceBySourceTreePath(SourceTreePath) - Method in class com.facebook.buck.apple.xcode.xcodeproj.XCVersionGroup
-
- getOrCreateNodeCache(DaemonicParserState.CacheType<K, T>) - Method in class com.facebook.buck.parser.DaemonicParserState
-
Retrieve the cache view for caching a particular type.
- getOrCreateVariantFileReferenceByNameAndSourceTreePath(String, SourceTreePath) - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXVariantGroup
-
- getOrderIndependentHashCode() - Method in class com.facebook.buck.util.config.Config
-
gets an order-independent
HashCode
of this
Config
's raw data.
- getOrdinal() - Method in enum com.facebook.buck.util.unit.SizeUnit
-
- getOrFail() - Method in class com.facebook.buck.parser.ParserPythonInterpreterProvider
-
Returns the path to python interpreter.
- getOrigin() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.Finished
-
- getOrigin() - Method in class com.facebook.buck.log.ErrorLogRecord
-
- getOriginal() - Method in class com.facebook.buck.jvm.java.plugin.api.TaskEventMirror
-
- getOriginKey() - Method in class com.facebook.buck.core.graph.transformation.model.ComposedKey
-
- getOrThrow(String, String, Optional<T>) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getOs() - Method in class com.facebook.buck.util.environment.BuildEnvironmentDescription
-
- getOs_version() - Method in interface com.facebook.buck.apple.simulator.AppleDevice
-
String that represents the iOS version running on the device (i.e., "iOS 12.4", etc)
- getOtherFlags() - Method in class com.facebook.buck.cxx.PreprocessorFlags
-
Other flags included as is.
- getOut() - Method in class com.facebook.buck.android.ApkGenruleDescriptionArg
-
- getOut() - Method in class com.facebook.buck.cxx.CxxGenruleDescriptionArg
-
- getOut() - Method in class com.facebook.buck.features.zip.rules.ZipFileDescriptionArg
-
- getOut() - Method in class com.facebook.buck.file.HttpArchiveDescriptionArg
-
- getOut() - Method in class com.facebook.buck.file.HttpFileDescriptionArg
-
- getOut() - Method in class com.facebook.buck.file.RemoteFileDescriptionArg
-
- getOut() - Method in class com.facebook.buck.shell.ExportFileDescriptionArg
-
- getOut() - Method in class com.facebook.buck.shell.GenruleDescriptionArg
-
- getOuterClass(ExecutableElement) - Static method in class com.facebook.buck.jvm.java.lang.model.MoreElements
-
- getOutgoingEdges() - Method in class com.facebook.buck.core.util.graph.DirectedAcyclicGraph
-
- getOutgoingNodesFor(T) - Method in class com.facebook.buck.core.util.graph.DirectedAcyclicGraph
-
- getOutgoingNodesFor(T) - Method in class com.facebook.buck.core.util.graph.MutableDirectedGraph
-
- getOutgoingNodesFor(T) - Method in interface com.facebook.buck.core.util.graph.TraversableGraph
-
- getOutput() - Method in class com.facebook.buck.artifact_cache.AbstractAsynchronousCache.FetchRequest
-
- getOutput() - Method in interface com.facebook.buck.doctor.ExtraInfoCollector.ExtraInfoResult
-
- getOutput() - Method in class com.facebook.buck.features.go.CGoLibrary
-
returns compiled linkable file source path
- getOutput() - Method in class com.facebook.buck.features.ocaml.OcamlDebugLauncherStep.Args
-
- getOutputChannel(Path, boolean) - Method in interface com.facebook.buck.remoteexecution.ContentAddressedStorageClient.FileMaterializer
-
Get a writable channel to the file at the provided path, marking it executable if
appropriate.
- getOutputChannel(Path, boolean) - Method in class com.facebook.buck.remoteexecution.util.OutputsMaterializer.FilesystemFileMaterializer
-
- getOutputClass() - Method in class com.facebook.buck.rules.coercer.AbsoluteOutputMacroTypeCoercer
-
- getOutputClass() - Method in class com.facebook.buck.rules.coercer.BuildTargetMacroTypeCoercer
-
- getOutputClass() - Method in class com.facebook.buck.rules.coercer.CxxGenruleFilterAndTargetsMacroTypeCoercer
-
- getOutputClass() - Method in class com.facebook.buck.rules.coercer.EnvMacroTypeCoercer
-
- getOutputClass() - Method in class com.facebook.buck.rules.coercer.OutputMacroTypeCoercer
-
- getOutputClass() - Method in class com.facebook.buck.rules.coercer.ZeroArgMacroTypeCoercer
-
- getOutputClasspathJars(JavaLibrary, Optional<SourcePath>) - Static method in class com.facebook.buck.jvm.java.JavaLibraryClasspathProvider
-
- getOutputClasspaths() - Method in class com.facebook.buck.android.AndroidAar
-
- getOutputClasspaths() - Method in class com.facebook.buck.android.AndroidBinary
-
- getOutputClasspaths() - Method in class com.facebook.buck.android.AndroidBundle
-
- getOutputClasspaths() - Method in class com.facebook.buck.android.ApkGenrule
-
- getOutputClasspaths() - Method in interface com.facebook.buck.jvm.core.HasClasspathEntries
-
- getOutputClasspaths() - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getOutputClasspaths() - Method in class com.facebook.buck.jvm.java.JarFattener
-
- getOutputClasspaths() - Method in class com.facebook.buck.jvm.java.JavaBinary
-
- getOutputClasspaths() - Method in class com.facebook.buck.jvm.java.JavaTest
-
- getOutputClasspaths() - Method in class com.facebook.buck.jvm.java.PrebuiltJar
-
- getOutputDexFile() - Method in class com.facebook.buck.android.DxStep
-
- getOutputDir() - Method in class com.facebook.buck.apple.AppleAssetCatalog
-
- getOutputDir(BuildTarget, ProjectFilesystem) - Static method in class com.facebook.buck.features.rust.RustCompileRule
-
- getOutputDirectories() - Method in interface com.facebook.buck.remoteexecution.interfaces.Protocol.Command
-
- getOutputDirectories() - Method in interface com.facebook.buck.remoteexecution.RemoteExecutionServiceClient.ExecutionResult
-
- getOutputFileListPaths() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXShellScriptBuildPhase
-
Returns the list (possibly empty) of .xcfilelist files that contain inputs for the script
- getOutputFileLists() - Method in class com.facebook.buck.apple.XcodeScriptDescriptionArg
-
- getOutputFileNameFormatForLibrary(boolean) - Static method in class com.facebook.buck.apple.AppleBuildRules
-
- getOutputFiles() - Method in interface com.facebook.buck.remoteexecution.interfaces.Protocol.Command
-
- getOutputFiles() - Method in interface com.facebook.buck.remoteexecution.RemoteExecutionServiceClient.ExecutionResult
-
- getOutputFormat() - Method in class com.facebook.buck.apple.AppleAssetCatalogsCompilationOptions
-
- getOutputHash(FileHashLoader) - Method in class com.facebook.buck.core.build.engine.buildinfo.BuildInfoRecorder
-
- getOutputHash() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.Finished
-
- getOutputJarDirPath() - Method in class com.facebook.buck.jvm.java.CompilerOutputPaths
-
- getOutputJarDirPath(BuildTarget, ProjectFilesystem) - Static method in class com.facebook.buck.jvm.java.CompilerOutputPaths
-
- getOutputJarPath(BuildTarget, ProjectFilesystem) - Static method in class com.facebook.buck.android.DummyRDotJava
-
- getOutputJarPath() - Method in class com.facebook.buck.jvm.java.CompilerOutputPaths
-
- getOutputJarPath(BuildTarget, ProjectFilesystem) - Static method in class com.facebook.buck.jvm.java.CompilerOutputPaths
-
- getOutputJars() - Method in class com.facebook.buck.android.SplitUberRDotJavaJar
-
- getOutputLabel() - Method in class com.facebook.buck.core.model.BuildTargetWithOutputs
-
Returns the output label associated with the build target, if any.
- getOutputLabel() - Method in class com.facebook.buck.core.model.UnconfiguredBuildTargetWithOutputs
-
Returns the output label associated with the build target, if any.
- getOutputLabel() - Method in class com.facebook.buck.core.parser.buildtargetparser.BuildTargetOutputLabelParser.TargetWithOutputLabel
-
- getOutputLabels() - Method in interface com.facebook.buck.core.rules.attr.HasMultipleOutputs
-
returns a set of
OutputLabel
instances associated with this build rule.
- getOutputLabels() - Method in class com.facebook.buck.core.rules.impl.RuleAnalysisLegacyBuildRuleView
-
- getOutputLabels() - Method in class com.facebook.buck.shell.BaseGenrule
-
- getOutputLabels() - Method in class com.facebook.buck.shell.GenruleBuildable
-
Returns a set of output labels associated with this buildable.
- getOutputMaterializationThreads() - Method in interface com.facebook.buck.remoteexecution.config.RemoteExecutionStrategyConfig
-
- getOutputMode() - Method in class com.facebook.buck.features.apple.project.XCodeProjectSubCommand
-
- getOutputName(OutputLabel) - Method in class com.facebook.buck.apple.PrebuiltAppleFramework
-
- getOutputName(OutputLabel) - Method in interface com.facebook.buck.core.model.HasOutputName
-
Returns an output name for the build target associated with the given output label.
- getOutputName(OutputLabel) - Method in class com.facebook.buck.cxx.CxxGenrule
-
- getOutputName(OutputLabel) - Method in class com.facebook.buck.features.filegroup.Filegroup
-
- getOutputName(OutputLabel) - Method in class com.facebook.buck.features.zip.rules.Zip
-
- getOutputName() - Method in class com.facebook.buck.rules.macros.AbsoluteOutputMacro
-
- getOutputName() - Method in class com.facebook.buck.rules.macros.OutputMacro
-
- getOutputName(OutputLabel) - Method in class com.facebook.buck.shell.BaseGenrule
-
Get the output name of the generated file, as listed in the BUCK file.
- getOutputName(OutputLabel) - Method in class com.facebook.buck.shell.ExportFile
-
- getOutputName(OutputLabel) - Method in class com.facebook.buck.shell.GenruleBuildable
-
Returns a String representation of the output path relative to the root output directory.
- getOutputNormalizedString(int) - Method in class com.facebook.buck.android.resources.StringPool
-
- getOutputPath() - Method in interface com.facebook.buck.core.artifact.BuildArtifact
-
- getOutputPath() - Method in class com.facebook.buck.features.apple.projectV2.XcodeProductMetadata
-
- getOutputPath() - Method in class com.facebook.buck.step.fs.ZstdStep
-
- getOutputPath() - Method in class com.facebook.buck.swift.SwiftCompile
-
- getOutputPathFromJavaTargetNode(TargetNode<?>, BuildTarget, ProjectFilesystem) - Static method in class com.facebook.buck.features.project.intellij.IjProjectSourcePathResolver
-
- getOutputPathResolver() - Method in class com.facebook.buck.rules.modern.ModernBuildRule
-
This field could be used unsafely, most ModernBuildRule should never need this directly and it
should only be used within the getBuildSteps() call.
- getOutputPaths() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXShellScriptBuildPhase
-
Returns the list (possibly empty) of files created as output of the shell script.
- getOutputPaths() - Method in class com.facebook.buck.core.build.engine.buildinfo.DefaultOnDiskBuildInfo
-
- getOutputPaths() - Method in interface com.facebook.buck.core.build.engine.buildinfo.OnDiskBuildInfo
-
- getOutputPaths() - Method in class com.facebook.buck.jvm.java.CompilerParameters
-
- getOutputPlist() - Method in class com.facebook.buck.apple.AppleAssetCatalog
-
- getOutputRelativePath() - Method in class com.facebook.buck.features.apple.project.XCodeProjectCommandHelper.Result
-
- getOutputRelativePath() - Method in class com.facebook.buck.features.apple.projectV2.XCodeProjectCommandHelper.Result
-
- getOutputs() - Method in class com.facebook.buck.apple.XcodeScriptDescriptionArg
-
- getOutputs() - Method in class com.facebook.buck.core.rules.actions.AbstractAction
-
- getOutputs() - Method in interface com.facebook.buck.core.rules.actions.Action
-
- getOutputs() - Method in class com.facebook.buck.rules.modern.builders.RemoteExecutionActionInfo
-
- getOutputs(OutputLabel) - Method in class com.facebook.buck.shell.GenruleBuildable
-
- getOutputSize() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.Finished
-
- getOutputStream(Artifact, FileAttribute<?>...) - Method in class com.facebook.buck.core.artifact.ArtifactFilesystem
-
- getOutputStream() - Method in class com.facebook.buck.io.unixsocket.UnixDomainSocket
-
- getOutputStream() - Method in interface com.facebook.buck.io.watchman.Transport
-
Returns an input stream for writing messages.
- getOutputStream() - Method in class com.facebook.buck.io.windowspipe.WindowsNamedPipe
-
- getOutputToInputsMapSupplier(Path, Path) - Method in class com.facebook.buck.android.SplitZipStep
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.BuildConfigFieldsTypeCoercer
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.BuildTargetTypeCoercer
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.BuildTargetWithOutputsTypeCoercer
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.CxxLinkGroupMappingCoercer
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.CxxLinkGroupMappingTargetCoercer
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.CxxLinkGroupMappingTargetTraversalCoercer
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.EitherTypeCoercer
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.FrameworkPathTypeCoercer
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.ImmutableTypeCoercer
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.LeafUnconfiguredOnlyCoercer
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.ListTypeCoercer
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.ManifestEntriesTypeCoercer
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.MapTypeCoercer
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.NeededCoverageSpecTypeCoercer
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.OptionalTypeCoercer
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.PairTypeCoercer
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.PatternMatchedCollectionTypeCoercer
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.QueryCoercer
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.SetTypeCoercer
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.SortedMapTypeCoercer
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.SortedSetTypeCoercer
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.SourcePathTypeCoercer
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.SourceSetTypeCoercer
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.SourceSortedSetTypeCoercer
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.SourceWithFlagsListTypeCoercer
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.SourceWithFlagsTypeCoercer
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.StringWithMacrosTypeCoercer
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.TestRunnerSpecCoercer
-
- getOutputType() - Method in interface com.facebook.buck.rules.coercer.TypeCoercer
-
- getOutputType() - Method in class com.facebook.buck.rules.coercer.VersionMatchedCollectionTypeCoercer
-
- getOutputUrl() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getOuts() - Method in class com.facebook.buck.shell.GenruleDescriptionArg
-
- GetOverlappedResult(WinNT.HANDLE, Pointer, IntByReference, boolean) - Method in interface com.facebook.buck.io.windowspipe.WindowsNamedPipeLibrary
-
- getOverridesByPath(ImmutableMap<CellName, AbsPath>) - Method in class com.facebook.buck.core.cell.CellConfig
-
Translates the 'cell name'->override map into a 'Path'->override map.
- getOverrideSymbolsPath() - Method in interface com.facebook.buck.android.FilteredResourcesProvider
-
- getOverrideSymbolsPath() - Method in class com.facebook.buck.android.IdentityResourcesProvider
-
- getOverrideSymbolsPath() - Method in class com.facebook.buck.android.ResourcesFilter
-
- getOwner() - Method in class com.facebook.buck.core.rules.actions.AbstractAction
-
- getOwner() - Method in interface com.facebook.buck.core.rules.actions.Action
-
- getOwner() - Method in interface com.facebook.buck.core.rules.actions.ActionRegistry
-
- getOwner() - Method in class com.facebook.buck.core.rules.actions.DefaultActionRegistry
-
- getOwner() - Method in interface com.facebook.buck.core.starlark.rule.artifact.SkylarkArtifactApi
-
- getOwnerTyped() - Method in class com.facebook.buck.core.artifact.SourceArtifactImpl
-
- getOwningTarget(Elements, Element) - Method in interface com.facebook.buck.jvm.java.abi.source.api.SourceOnlyAbiRuleInfoFactory.SourceOnlyAbiRuleInfo
-
- getOwningTarget(Element) - Method in class com.facebook.buck.jvm.java.abi.source.FileManagerSimulator
-
- getPackage() - Method in class com.facebook.buck.android.AndroidBuildConfigDescriptionArg
-
For R.java
- getPackage() - Method in interface com.facebook.buck.android.AndroidManifestReader
-
- getPackage() - Method in class com.facebook.buck.android.AndroidResourceDescriptionArg
-
- getPackage() - Method in class com.facebook.buck.android.DefaultAndroidManifestReader
-
- getPackage() - Method in class com.facebook.buck.android.resources.ResourceTable
-
- getPackage() - Method in class com.facebook.buck.features.haskell.HaskellPackageRule
-
- getPackage() - Method in class com.facebook.buck.parser.api.PackageFileManifest
-
Contains the package defined in the build file.
- getPackage() - Method in class com.facebook.buck.skylark.parser.context.ParseContext
-
- getPackage() - Method in class com.facebook.buck.skylark.parser.ParseResult
-
Contains the package defined in a package file.
- getPackageableRules(Iterable<BuildRule>) - Static method in class com.facebook.buck.android.packageable.AndroidPackageableCollector
-
- getPackageBoundaryEnforcementPolicy(Path) - Method in class com.facebook.buck.parser.config.ParserConfig
-
Whether the cell is enforcing buck package boundaries for the package at the passed path.
- getPackageConfigForPlatform(ApplePlatform) - Method in class com.facebook.buck.apple.AppleConfig
-
Returns the custom packager command specified in the config, if defined.
- getPackageContext() - Method in class com.facebook.buck.skylark.parser.context.ParseContext
-
Returns a context of the package currently being parsed.
- getPackagedDependencies() - Method in class com.facebook.buck.jvm.java.Javadoc
-
- getPackagedDependencies() - Method in interface com.facebook.buck.jvm.java.MavenPublishable
-
When published, these will be included in the artifact.
- getPackagedDependencies() - Method in class com.facebook.buck.jvm.java.MavenUberJar
-
- getPackagedDependencies() - Method in class com.facebook.buck.jvm.java.MavenUberJar.SourceJar
-
- getPackagedRules() - Method in class com.facebook.buck.jvm.java.JarShape.Summary
-
- getPackageElement(Element) - Static method in class com.facebook.buck.jvm.java.lang.model.MoreElements
-
- getPackageElementEvenIfEmpty(Elements, CharSequence) - Static method in class com.facebook.buck.jvm.java.lang.model.MoreElements
-
Get a package by name, even if it has no members.
- getPackageFileCache() - Method in class com.facebook.buck.parser.DaemonicParserState
-
- getPackageIdentifier() - Method in class com.facebook.buck.skylark.packages.PackageContext
-
Returns a package identifier of the build file that is being parsed.
- getPackageImplicitIncludes() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getPackageImplicitIncludes() - Method in class com.facebook.buck.parser.options.ProjectBuildFileParserOptions
-
- getPackageInfo(String) - Method in interface com.facebook.buck.android.exopackage.AndroidDevice
-
- getPackageInfo(String) - Method in class com.facebook.buck.android.exopackage.RealAndroidDevice
-
- getPackageName() - Method in interface com.facebook.buck.event.external.events.InstallFinishedEventExternalInterface
-
- getPackageName() - Method in class com.facebook.buck.event.InstallEvent.Finished
-
- getPackageName() - Method in class com.facebook.buck.event.UninstallEvent
-
- getPackageName() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getPackageName() - Method in class com.facebook.buck.features.go.GoLibraryDescriptionArg
-
- getPackageName() - Method in class com.facebook.buck.features.go.GoTestDescriptionArg
-
- getPackageName() - Method in class com.facebook.buck.features.go.PrebuiltGoLibraryDescriptionArg
-
- getPackageName() - Method in class com.facebook.buck.features.project.intellij.model.IjModuleAndroidFacet
-
- getPackageNameFromSource(String) - Method in class com.facebook.buck.jvm.java.JavaFileParser
-
- getPackageNamePrefix(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getPackagePath() - Method in class com.facebook.buck.core.model.targetgraph.raw.UnconfiguredTargetNodeWithDepsPackage
-
Package path, relative to parse root, usually cell root
- getPackagePath() - Method in class com.facebook.buck.parser.targetnode.BuildTargetToUnconfiguredTargetNodeKey
-
- getPackagePath() - Method in class com.facebook.buck.parser.targetnode.UnconfiguredTargetNodeToUnconfiguredTargetNodeWithDepsKey
-
- getPackagePathFromSource(Path) - Method in class com.facebook.buck.features.project.intellij.lang.java.ParsingJavaPackageFinder.PackagePathResolver
-
Tries to return the package path from a Java source file.
- getPackagePrefix() - Method in class com.facebook.buck.features.project.intellij.model.folders.IjSourceFolder
-
- getPackager(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getPackager() - Method in class com.facebook.buck.features.lua.LuaPlatform
-
- getPackageRoots() - Method in class com.facebook.buck.core.parser.BuildPackagePaths
-
Relative paths to folders that are roots for build packages, i.e.
- getPackagerSource(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getPackageStyle() - Method in class com.facebook.buck.features.lua.LuaBinaryDescriptionArg
-
- getPackageStyle() - Method in class com.facebook.buck.features.lua.LuaPlatform
-
- getPackageStyle() - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg
-
- getPackageStyle() - Method in class com.facebook.buck.features.python.PythonBuckConfig
-
- getPackageStyle() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getPackageType() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getPackageType() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getPackageType() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getPaddedDir(String, int, char) - Static method in class com.facebook.buck.cxx.toolchain.DebugPathSanitizer
-
- getParallelizeBuild() - Method in class com.facebook.buck.apple.xcode.XCScheme.BuildAction
-
- getParallelizer() - Method in interface com.facebook.buck.core.rules.ActionGraphBuilder
-
Returns a parallelizer object that parallelizes if the current BuildRuleResolver supports
parallelism.
- getParallelizer() - Method in class com.facebook.buck.core.rules.resolver.impl.MultiThreadedActionGraphBuilder
-
- getParallelizer() - Method in class com.facebook.buck.core.rules.resolver.impl.RuleAnalysisCompatibleDelegatingActionGraphBuilder
-
- getParameters() - Method in class com.facebook.buck.jvm.java.JavacPluginParams
-
- getParamInfos() - Method in class com.facebook.buck.rules.coercer.DataTransferObjectDescriptor
-
The param infos needed to populate this object
- getParams() - Method in class com.facebook.buck.util.perf.ProcessTracker.ProcessResourceConsumptionEvent
-
- getParent() - Method in interface com.facebook.buck.core.filesystems.AbsPath
-
- getParent() - Method in class com.facebook.buck.core.filesystems.BuckUnixPath
-
- getParent() - Method in interface com.facebook.buck.core.filesystems.RelPath
-
- getParentOrEmpty(Path) - Static method in class com.facebook.buck.io.file.MorePaths
-
- getParentOrEmpty(RelPath) - Static method in class com.facebook.buck.io.file.MorePaths
-
- getParseContext(Environment, FuncallExpression) - Static method in class com.facebook.buck.skylark.parser.context.ParseContext
-
- getParseDeps() - Method in class com.facebook.buck.core.model.targetgraph.impl.TargetNodeImpl
-
- getParseDeps() - Method in interface com.facebook.buck.core.model.targetgraph.TargetNode
-
- getParser() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getParser() - Method in interface com.facebook.buck.cli.MainRunner.ParserAndCaches
-
- getParser() - Method in class com.facebook.buck.cli.ProjectGeneratorParameters
-
- getParserClass() - Method in class com.facebook.buck.parser.events.ParseBuckFileEvent
-
- getParserKind() - Method in class com.facebook.buck.parser.events.ParseBuckFileEvent.Finished
-
- getParserKind() - Method in class com.facebook.buck.parser.events.ParseBuckFileEvent.Started
-
- getParserPythonInterpreterPath() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getParserState() - Method in class com.facebook.buck.cli.BuckQueryEnvironment
-
- getParserTargetThreshold() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getParseTimeDeps(TargetConfiguration) - Method in class com.facebook.buck.android.toolchain.ndk.impl.ProviderBackedUnresolvedNdkCxxPlatform
-
- getParseTimeDeps(TargetConfiguration) - Method in class com.facebook.buck.android.toolchain.ndk.impl.StaticUnresolvedNdkCxxPlatform
-
- getParseTimeDeps(TargetConfiguration) - Method in interface com.facebook.buck.android.toolchain.ndk.UnresolvedNdkCxxPlatform
-
Returns the parse time deps of this platform.
- getParseTimeDeps(TargetConfiguration) - Method in class com.facebook.buck.apple.toolchain.impl.ProviderBackedUnresolvedAppleCxxPlatform
-
- getParseTimeDeps(TargetConfiguration) - Method in class com.facebook.buck.apple.toolchain.impl.StaticUnresolvedAppleCxxPlatform
-
- getParseTimeDeps(TargetConfiguration) - Method in interface com.facebook.buck.apple.toolchain.UnresolvedAppleCxxPlatform
-
Returns the parse time deps of this platform.
- getParseTimeDeps(TargetConfiguration) - Method in class com.facebook.buck.core.toolchain.toolprovider.impl.BinaryBuildRuleToolProvider
-
- getParseTimeDeps(TargetConfiguration) - Method in class com.facebook.buck.core.toolchain.toolprovider.impl.ConstantToolProvider
-
- getParseTimeDeps(TargetConfiguration) - Method in class com.facebook.buck.core.toolchain.toolprovider.impl.ErrorToolProvider
-
- getParseTimeDeps(TargetConfiguration) - Method in class com.facebook.buck.core.toolchain.toolprovider.impl.SystemToolProvider
-
- getParseTimeDeps(TargetConfiguration) - Method in interface com.facebook.buck.core.toolchain.toolprovider.ToolProvider
-
- getParseTimeDeps(TargetConfiguration) - Method in interface com.facebook.buck.cxx.toolchain.ArchiverProvider
-
- getParseTimeDeps(TargetConfiguration) - Method in class com.facebook.buck.cxx.toolchain.CxxToolProvider
-
- getParseTimeDeps(TargetConfiguration) - Method in class com.facebook.buck.cxx.toolchain.ElfSharedLibraryInterfaceParams
-
- getParseTimeDeps(TargetConfiguration, CxxPlatform) - Static method in class com.facebook.buck.cxx.toolchain.impl.CxxPlatforms
-
- getParseTimeDeps(TargetConfiguration) - Method in class com.facebook.buck.cxx.toolchain.impl.StaticUnresolvedCxxPlatform
-
- getParseTimeDeps(TargetConfiguration) - Method in class com.facebook.buck.cxx.toolchain.linker.impl.DefaultLinkerProvider
-
- getParseTimeDeps(TargetConfiguration) - Method in interface com.facebook.buck.cxx.toolchain.linker.LinkerProvider
-
- getParseTimeDeps(TargetConfiguration) - Method in class com.facebook.buck.cxx.toolchain.MachoDylibStubParams
-
- getParseTimeDeps(TargetConfiguration) - Method in class com.facebook.buck.cxx.toolchain.PosixNmSymbolNameTool
-
- getParseTimeDeps(TargetConfiguration) - Method in class com.facebook.buck.cxx.toolchain.ProviderBasedUnresolvedCxxPlatform
-
- getParseTimeDeps(TargetConfiguration) - Method in interface com.facebook.buck.cxx.toolchain.SharedLibraryInterfaceParams
-
- getParseTimeDeps(TargetConfiguration) - Method in interface com.facebook.buck.cxx.toolchain.SymbolNameTool
-
- getParseTimeDeps(TargetConfiguration) - Method in interface com.facebook.buck.cxx.toolchain.UnresolvedCxxPlatform
-
Returns the parse-time deps required for this platform.
- getParseTimeDeps(TargetConfiguration, Iterable<HaskellPlatform>, ImmutableCollection.Builder<BuildTarget>) - Static method in class com.facebook.buck.features.haskell.HaskellDescriptionUtils
-
Accumulate parse-time deps needed by Haskell descriptions in depsBuilder.
- getParseTimeDeps(TargetConfiguration) - Method in class com.facebook.buck.features.rust.ConfigBasedUnresolvedRustPlatform
-
- getParseTimeDeps(TargetConfiguration) - Method in interface com.facebook.buck.features.rust.UnresolvedRustPlatform
-
Returns the parse-time deps required for this platform.
- getParseTimeDeps(TargetConfiguration) - Method in class com.facebook.buck.infer.InferDistFromTargetProvider
-
- getParseTimeDeps(TargetConfiguration) - Method in interface com.facebook.buck.infer.UnresolvedInferPlatform
-
- getParseTimeDeps(TargetConfiguration) - Method in class com.facebook.buck.swift.toolchain.impl.StaticUnresolvedSwiftPlatform
-
- getParseTimeDeps(TargetConfiguration) - Method in interface com.facebook.buck.swift.toolchain.UnresolvedSwiftPlatform
-
Returns the parse time deps of this platform.
- getParseTimeMs() - Method in class com.facebook.buck.log.PerfTimesStats
-
- getParts() - Method in class com.facebook.buck.rules.macros.StringWithMacros
-
The components of the macro string.
- getPassed() - Method in interface com.facebook.buck.apple.AbstractIdbTestResult
-
Boolean that shows if the test passed or not
- getPassedCount() - Method in class com.facebook.buck.test.TestCaseSummary
-
- getPath() - Method in interface com.facebook.buck.android.exopackage.ExopackagePathAndHash
-
- getPath(AppleBundleDestinations) - Method in enum com.facebook.buck.apple.AppleBundleDestination
-
- getPath() - Method in class com.facebook.buck.apple.AppleWrapperResourceArg
-
- getPath() - Method in interface com.facebook.buck.apple.toolchain.AppleToolchain
-
The path to the toolchain.
- getPath() - Method in interface com.facebook.buck.apple.xcode.xcodeproj.CopyFilePhaseDestinationSpec
-
- getPath() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXReference
-
- getPath() - Method in class com.facebook.buck.apple.xcode.xcodeproj.SourceTreePath
-
- getPath() - Method in class com.facebook.buck.cli.ProjectGeneratorParameters
-
- getPath(String, String) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getPath(String, String, boolean) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getPath() - Method in class com.facebook.buck.core.files.DirectoryListKey
-
Path of the directory to list
- getPath() - Method in class com.facebook.buck.core.files.FileTree
-
Relative path to this instance from some root, usually cell root
- getPath() - Method in class com.facebook.buck.core.files.FileTreeKey
-
Path of the directory to generate a file tree for
- getPath(String, String...) - Method in class com.facebook.buck.core.filesystems.BuckFileSystem
-
- getPath(URI) - Method in class com.facebook.buck.core.filesystems.BuckFileSystemProvider
-
- getPath() - Method in class com.facebook.buck.core.filesystems.BuckUnixPath
-
- getPath() - Method in interface com.facebook.buck.core.filesystems.PathWrapper
-
- getPath() - Method in class com.facebook.buck.core.model.BaseName
-
- getPath() - Method in class com.facebook.buck.core.model.CellRelativePath
-
- getPath() - Method in class com.facebook.buck.core.toolchain.tool.impl.VersionedTool
-
The path to the tool.
- getPath(String) - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getPath() - Method in class com.facebook.buck.cxx.CxxSource
-
- getPath() - Method in interface com.facebook.buck.cxx.Omnibus.OmnibusLibrary
-
- getPath() - Method in interface com.facebook.buck.cxx.Omnibus.OmnibusRoot
-
- getPath() - Method in class com.facebook.buck.event.ParsingEvent.SymlinkInvalidation
-
- getPath() - Method in class com.facebook.buck.features.apple.projectV2.CoreDataResource
-
- getPath() - Method in class com.facebook.buck.features.apple.projectV2.XcconfigBaseConfiguration
-
- getPath() - Method in class com.facebook.buck.features.project.intellij.model.folders.IjFolder
-
- getPath() - Method in class com.facebook.buck.features.project.intellij.model.folders.IjSourceFolder
-
- getPath(SourcePath) - Method in interface com.facebook.buck.features.project.intellij.model.IjLibraryFactoryResolver
-
Does it get an absolute path? Does it get a relative path? Who knows!
- getPath() - Method in class com.facebook.buck.features.rust.RustLibraryArg
-
- getPath() - Method in class com.facebook.buck.io.file.BorrowablePath
-
- getPath(String, String...) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
Converts a path string (or sequence of strings) to a Path with the same VFS as this instance.
- getPath(String, String...) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
Converts a path string (or sequence of strings) to a Path with the same VFS as this instance.
- getPath() - Method in class com.facebook.buck.io.filesystem.RecursiveFileMatcher
-
- getPath() - Method in class com.facebook.buck.io.watchman.WatchmanMultiplePathEvent.Change
-
Path to a changed file or directory, relative to monitored root (cell root)
- getPath() - Method in class com.facebook.buck.io.watchman.WatchmanPathEvent
-
Relative path of the actual file the event is about.
- getPath() - Method in class com.facebook.buck.maven.Pom
-
- getPath() - Method in class com.facebook.buck.parser.manifest.BuildPackagePathToBuildFileManifestKey
-
Path of the root of the package to parse, relative to some root (usually cell root).
- getPath() - Method in class com.facebook.buck.parser.targetnode.BuildPackagePathToUnconfiguredTargetNodePackageKey
-
A path to a package root directory, i.e.
- getPath() - Method in class com.facebook.buck.query.QueryFileTarget
-
- getPath() - Method in class com.facebook.buck.remoteexecution.grpc.GrpcProtocol.GrpcOutputDirectory
-
- getPath() - Method in class com.facebook.buck.remoteexecution.grpc.GrpcProtocol.GrpcOutputFile
-
- getPath() - Method in interface com.facebook.buck.remoteexecution.interfaces.Protocol.OutputDirectory
-
- getPath() - Method in interface com.facebook.buck.remoteexecution.interfaces.Protocol.OutputFile
-
- getPath() - Method in class com.facebook.buck.rules.args.FileListableLinkerInputArg
-
- getPath() - Method in interface com.facebook.buck.rules.args.HasSourcePath
-
- getPath() - Method in class com.facebook.buck.rules.args.SourcePathArg
-
- getPath(OutputPath) - Method in class com.facebook.buck.rules.modern.OutputPath.Internals
-
- getPath() - Method in class com.facebook.buck.step.fs.MkdirStep
-
- getPath() - Method in class com.facebook.buck.step.fs.RmStep
-
- getPath() - Method in class com.facebook.buck.support.fix.BuckRunSpec
-
The path to the binary to invoke
- getPath() - Method in class com.facebook.buck.util.DirectoryCleaner.PathStats
-
- getPath() - Method in class com.facebook.buck.util.NamedTemporaryDirectory
-
- getPathElements() - Method in class com.facebook.buck.jvm.java.DefaultJavaPackageFinder
-
- getPathForRelativeExistingPath(Path) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- getPathForRelativeExistingPath(Path) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
- getPathForRelativePath(Path) - Method in class com.facebook.buck.edenfs.EdenProjectFilesystemDelegate
-
- getPathForRelativePath(Path) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- getPathForRelativePath(String) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- getPathForRelativePath(Path) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystemDelegate
-
- getPathForRelativePath(Path) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
- getPathForRelativePath(String) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
- getPathForRelativePath(Path) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystemDelegate
-
- getPathFromSegmentsUnsafe(String[]) - Method in class com.facebook.buck.core.filesystems.BuckFileSystem
-
Construct a path object from given segments without and validation or postprocessing.
- getPathIfJavaLibrary(TargetNode<?>) - Method in interface com.facebook.buck.features.project.intellij.model.IjLibraryFactoryResolver
-
- getPathMapping() - Method in class com.facebook.buck.core.cell.impl.DefaultCellPathResolver
-
- getPathMatcher(String) - Method in class com.facebook.buck.core.filesystems.BuckFileSystem
-
- getPathName() - Method in class com.facebook.buck.rules.coercer.NeededCoverageSpec
-
- getPathOrGlob() - Method in class com.facebook.buck.io.filesystem.ExactPathMatcher
-
- getPathOrGlob() - Method in class com.facebook.buck.io.filesystem.FileExtensionMatcher
-
- getPathOrGlob() - Method in class com.facebook.buck.io.filesystem.GlobPatternMatcher
-
- getPathOrGlob() - Method in interface com.facebook.buck.io.filesystem.PathMatcher
-
Returns a path or glob pattern identifying paths that should be matched by this matcher.
- getPathOrGlob() - Method in class com.facebook.buck.io.filesystem.RecursiveFileMatcher
-
- getPathRelativeToBuildCellRoot() - Method in class com.facebook.buck.io.BuildCellRelativePath
-
- getPathRelativeToProjectRoot(Path) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- getPathRelativeToProjectRoot(Path) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
- getPathResolver() - Method in class com.facebook.buck.cxx.CxxSourceRuleFactory
-
- getPaths() - Method in class com.facebook.buck.core.rules.common.RecordArtifactVerifier
-
- getPaths() - Method in class com.facebook.buck.rules.coercer.SourceSet
-
- getPaths() - Method in class com.facebook.buck.rules.coercer.SourceSortedSet
-
- getPaths() - Method in class com.facebook.buck.rules.modern.impl.InputsMapBuilder.Data
-
- getPathsChangedInWorkingDirectory() - Method in interface com.facebook.buck.util.versioncontrol.CommonSlowVersionControlStats
-
- getPathSelector() - Method in class com.facebook.buck.util.DirectoryCleanerArgs
-
- getPathsForArtifact() - Method in class com.facebook.buck.core.build.engine.buildinfo.DefaultOnDiskBuildInfo
-
- getPathsForArtifact() - Method in interface com.facebook.buck.core.build.engine.buildinfo.OnDiskBuildInfo
-
Returns the recorded output paths of the rule for creating a cache artifact.
- getPathsFromRoot() - Method in class com.facebook.buck.jvm.java.DefaultJavaPackageFinder
-
- getPathSourcePath(Path) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getPathSourcePath(Path, String) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getPathsToThirdPartyJars() - Method in interface com.facebook.buck.android.packageable.AndroidPackageableCollection
-
Prebuilt/third-party jars to be included in the package.
- getPathToArtifactMetadataDirectory(BuildTarget, ProjectFilesystem) - Static method in class com.facebook.buck.core.build.engine.buildinfo.BuildInfo
-
- getPathToArtifactMetadataFile(BuildTarget, ProjectFilesystem) - Static method in class com.facebook.buck.core.build.engine.buildinfo.BuildInfo
-
- getPathToBuildPrehookScript() - Method in class com.facebook.buck.command.config.BuildBuckConfig
-
- getPathToBuildReport(BuckConfig) - Method in class com.facebook.buck.cli.BuildCommand
-
- getPathToDex() - Method in class com.facebook.buck.android.DexProducedFromJavaLibrary
-
- getPathToExoResources() - Method in class com.facebook.buck.android.SplitResources
-
- getPathToFile(SourcePathResolverAdapter, SourcePath) - Static method in class com.facebook.buck.rules.keys.DependencyFileEntry
-
Gets the path to the file.
- getPathToJavaAgent() - Method in class com.facebook.buck.test.TestRunningOptions
-
- getPathToMergedAssets() - Method in class com.facebook.buck.android.MergeAssets
-
- getPathToMetadataDirectory(BuildTarget, ProjectFilesystem) - Static method in class com.facebook.buck.core.build.engine.buildinfo.BuildInfo
-
Returns the path to a directory where metadata files for a build rule with the specified target
should be stored.
- getPathToOtherMetadataDirectory(BuildTarget, ProjectFilesystem) - Static method in class com.facebook.buck.core.build.engine.buildinfo.BuildInfo
-
- getPathToOutputDir(BuildTarget, ProjectFilesystem) - Static method in class com.facebook.buck.android.DummyRDotJava
-
- getPathToOutputFile() - Method in class com.facebook.buck.android.AndroidResourceIndex
-
- getPathToPrimaryResources() - Method in class com.facebook.buck.android.SplitResources
-
- getPathToPropertiesFile() - Method in class com.facebook.buck.jvm.java.Keystore
-
- getPathToRDotJava(String) - Method in class com.facebook.buck.android.MergeAndroidResourcesStep
-
- getPathToRDotJavaPackageFile() - Method in class com.facebook.buck.android.AndroidPrebuiltAar
-
- getPathToRDotJavaPackageFile() - Method in class com.facebook.buck.android.AndroidResource
-
- getPathToRDotJavaPackageFile() - Method in interface com.facebook.buck.android.HasAndroidResourceDeps
-
- getPathToRDotJavaPackageFile() - Method in class com.facebook.buck.android.UnzipAar
-
- getPathToRDotTxt() - Method in class com.facebook.buck.android.SplitResources
-
- getPathToSourcesList() - Method in class com.facebook.buck.jvm.java.CompilerOutputPaths
-
- getPathToStore() - Method in class com.facebook.buck.jvm.java.Keystore
-
- getPathToTestExitCode() - Method in class com.facebook.buck.cxx.CxxTest
-
- getPathToTestExitCode() - Method in class com.facebook.buck.features.d.DTest
-
- getPathToTestExitCode() - Method in class com.facebook.buck.features.go.GoTest
-
- getPathToTestOutput() - Method in class com.facebook.buck.cxx.CxxTest
-
- getPathToTestOutput() - Method in class com.facebook.buck.features.d.DTest
-
- getPathToTestOutputDirectory() - Method in class com.facebook.buck.android.AndroidInstrumentationTest
-
- getPathToTestOutputDirectory() - Method in class com.facebook.buck.apple.AppleTest
-
- getPathToTestOutputDirectory() - Method in class com.facebook.buck.apple.AppleTestX
-
- getPathToTestOutputDirectory() - Method in class com.facebook.buck.core.rules.tool.RuleAnalysisLegacyTestBuildRuleView
-
- getPathToTestOutputDirectory() - Method in interface com.facebook.buck.core.test.rule.TestRule
-
- getPathToTestOutputDirectory() - Method in class com.facebook.buck.cxx.CxxTest
-
- getPathToTestOutputDirectory() - Method in class com.facebook.buck.features.d.DTest
-
- getPathToTestOutputDirectory() - Method in class com.facebook.buck.features.go.GoTest
-
- getPathToTestOutputDirectory() - Method in class com.facebook.buck.features.go.GoTestX
-
- getPathToTestOutputDirectory() - Method in class com.facebook.buck.features.python.PythonTest
-
- getPathToTestOutputDirectory() - Method in class com.facebook.buck.features.python.PythonTestX
-
- getPathToTestOutputDirectory() - Method in class com.facebook.buck.features.rust.RustTest
-
- getPathToTestOutputDirectory() - Method in class com.facebook.buck.jvm.java.JavaTest
-
- getPathToTestOutputDirectory() - Method in class com.facebook.buck.jvm.java.JavaTestX
-
- getPathToTestOutputDirectory() - Method in class com.facebook.buck.shell.ShTest
-
- getPathToTestResults() - Method in class com.facebook.buck.cxx.CxxTest
-
- getPathToTestResults() - Method in class com.facebook.buck.features.go.GoTest
-
- getPathToTestWorkingDirectory() - Method in class com.facebook.buck.features.go.GoTest
-
- getPathToTextSymbolsFile() - Method in class com.facebook.buck.android.AndroidPrebuiltAar
-
- getPathToTextSymbolsFile() - Method in class com.facebook.buck.android.AndroidResource
-
- getPathToTextSymbolsFile() - Method in interface com.facebook.buck.android.HasAndroidResourceDeps
-
- getPathToXmlTestOutput() - Method in class com.facebook.buck.test.TestRunningOptions
-
- getPattern() - Method in class com.facebook.buck.core.parser.BuildTargetPatternToBuildPackagePathKey
-
Pattern for which to discover paths to appropriate packages.
- getPattern(ImmutableList<QueryEnvironment.Argument<NODE_TYPE>>) - Method in class com.facebook.buck.query.FilterFunction
-
- getPattern(ImmutableList<QueryEnvironment.Argument<T>>) - Method in class com.facebook.buck.query.KindFunction
-
- getPattern() - Method in class com.facebook.buck.query.TargetLiteral
-
- getPattern() - Method in class com.facebook.buck.util.PatternAndMessage
-
- getPatternsAndValues() - Method in class com.facebook.buck.rules.coercer.PatternMatchedCollection
-
- getPayloadSizeBytes(int) - Method in class com.facebook.buck.slb.HybridThriftResponseHandler
-
Size bytes of the nth payload.
- getPayloadStream(int) - Method in class com.facebook.buck.slb.HybridThriftRequestHandler
-
Fetches the data for one specific payload.
- getPdcFlags() - Method in interface com.facebook.buck.cxx.toolchain.Compiler
-
- getPdcFlags() - Method in class com.facebook.buck.cxx.toolchain.DefaultCompiler
-
- getPdcFlags() - Method in class com.facebook.buck.cxx.toolchain.WindowsCompiler
-
- getPdcFlags() - Method in class com.facebook.buck.cxx.toolchain.WindowsMl64Compiler
-
- getPeak(ProcessResourceConsumption, ProcessResourceConsumption) - Static method in class com.facebook.buck.util.ProcessResourceConsumption
-
- getPendingLogLines() - Method in class com.facebook.buck.event.listener.RenderingConsole
-
- getPerBuildStateFactory() - Method in interface com.facebook.buck.parser.Parser
-
- getPerFeatureProviders() - Method in class com.facebook.buck.core.rules.knowntypes.KnownNativeRuleTypes
-
- getPerFeatureProviders() - Method in class com.facebook.buck.parser.options.ProjectBuildFileParserOptions
-
- getPermState() - Method in interface com.facebook.buck.parser.Parser
-
- getPerServerData() - Method in interface com.facebook.buck.slb.LoadBalancerPingEvent.LoadBalancerPingEventData
-
- getPerServerData() - Method in class com.facebook.buck.slb.ServerHealthManagerEvent.ServerHealthManagerEventData
-
- getPersistent() - Method in class com.facebook.buck.shell.WorkerToolDescriptionArg
-
- getPersistentWorkerKey() - Method in class com.facebook.buck.rules.macros.WorkerMacroArg
-
- getPersistentWorkerKey() - Method in interface com.facebook.buck.worker.WorkerProcessIdentity
-
If the current invocation allows to have persisted worker pools (buck is running as daemon), it
will be used to obtain the instance of the persisted worker process pool.
- getPersistentWorkerPools() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getPersistentWorkerPools() - Method in class com.facebook.buck.core.build.execution.context.ExecutionContext
-
Worker process pools that are persisted across buck invocations inside buck daemon.
- getPersistentWorkerPools() - Method in class com.facebook.buck.support.state.BuckGlobalState
-
- getPexExecutor(BuildRuleResolver, TargetConfiguration) - Method in class com.facebook.buck.features.python.PythonBuckConfig
-
- getPexExecutorTarget(TargetConfiguration) - Method in class com.facebook.buck.features.python.PythonBuckConfig
-
- getPexExtension() - Method in class com.facebook.buck.features.python.PythonBuckConfig
-
- getPexFlags() - Method in class com.facebook.buck.features.python.PythonBuckConfig
-
- getPexTarget(TargetConfiguration) - Method in class com.facebook.buck.features.python.PythonBuckConfig
-
- getPexTool(BuildRuleResolver, TargetConfiguration) - Method in class com.facebook.buck.features.python.toolchain.impl.DefaultPexToolProvider
-
- getPexTool(BuildRuleResolver, TargetConfiguration) - Method in interface com.facebook.buck.features.python.toolchain.PexToolProvider
-
- getPhase() - Method in class com.facebook.buck.event.chrome_trace.ChromeTraceEvent
-
- getPhase() - Method in class com.facebook.buck.jvm.java.tracing.JavacPhaseEvent
-
- getPhysicalDevices() - Method in class com.facebook.buck.apple.simulator.AppleDeviceController
-
- getPicFlags() - Method in interface com.facebook.buck.cxx.toolchain.Compiler
-
- getPicFlags() - Method in class com.facebook.buck.cxx.toolchain.DefaultCompiler
-
- getPicFlags() - Method in class com.facebook.buck.cxx.toolchain.WindowsCompiler
-
- getPicFlags() - Method in class com.facebook.buck.cxx.toolchain.WindowsMl64Compiler
-
- getPicType() - Method in class com.facebook.buck.cxx.CxxSourceRuleFactory
-
- getPicTypeForSharedLinking() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
nix platforms use PIC object files for shared libraries, while windows doesn't.
- getPid() - Method in class com.facebook.buck.event.CommandEvent
-
- getPid() - Method in class com.facebook.buck.event.InstallEvent.Finished
-
- getpid() - Method in interface com.facebook.buck.util.Libc
-
- getPid() - Method in class com.facebook.buck.util.ProcessHelper
-
Gets the native process identifier for the current process.
- getPid(Object) - Method in class com.facebook.buck.util.ProcessHelper
-
Gets the native process identifier for the given process instance.
- getPingLatencyMillis(long, int) - Method in class com.facebook.buck.slb.ServerHealthState
-
- getPingLatencySampleCount() - Method in class com.facebook.buck.slb.ServerHealthState
-
- getPingRequestCount() - Method in class com.facebook.buck.event.listener.LoadBalancerEventsListener.ServerCounters
-
- getPingRequestErrorCount() - Method in class com.facebook.buck.event.listener.LoadBalancerEventsListener.ServerCounters
-
- getPingRequestLatencyMillis() - Method in class com.facebook.buck.event.listener.LoadBalancerEventsListener.ServerCounters
-
- getPingRequestLatencyMillis() - Method in interface com.facebook.buck.slb.LoadBalancerPingEvent.PerServerPingData
-
- getPingRequestTimeoutCount() - Method in class com.facebook.buck.event.listener.LoadBalancerEventsListener.ServerCounters
-
- getPipelinedBuildSteps(BuildContext, BuildableContext, T) - Method in interface com.facebook.buck.core.rules.pipeline.SupportsPipelining
-
Deprecated.
- getPipelinedBuildSteps(BuildContext, ProjectFilesystem, JavacPipelineState, OutputPathResolver, BuildCellRelativePathFactory) - Method in class com.facebook.buck.jvm.java.CalculateSourceAbi.SourceAbiBuildable
-
- getPipelinedBuildSteps(BuildContext, ProjectFilesystem, State, OutputPathResolver, BuildCellRelativePathFactory) - Method in interface com.facebook.buck.rules.modern.PipelinedBuildable
-
- getPipelinedBuildSteps(BuildContext, BuildableContext, State) - Method in class com.facebook.buck.rules.modern.PipelinedModernBuildRule
-
- getPipelinedBuildStepsForAbiJar(BuildTarget, BuildContext, ProjectFilesystem, RecordArtifactVerifier, JavacPipelineState) - Method in class com.facebook.buck.jvm.java.JarBuildStepsFactory
-
- getPipelinedBuildStepsForLibraryJar(BuildContext, ProjectFilesystem, RecordArtifactVerifier, JavacPipelineState, Path) - Method in class com.facebook.buck.jvm.java.JarBuildStepsFactory
-
- getPipelineStateFactory() - Method in interface com.facebook.buck.core.rules.pipeline.SupportsPipelining
-
Deprecated.
- getPipelineStateFactory() - Method in class com.facebook.buck.jvm.java.CalculateSourceAbi
-
- getPipelineStateFactory() - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getPlaceholders() - Method in class com.facebook.buck.rules.coercer.ManifestEntries
-
- getPlatform() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getPlatform() - Method in class com.facebook.buck.command.BuildExecutorArgs
-
- getPlatform() - Method in class com.facebook.buck.core.build.execution.context.ExecutionContext
-
- getPlatform() - Method in class com.facebook.buck.core.config.BuckConfig
-
- getPlatform(BuildTarget, DependencyStack) - Method in interface com.facebook.buck.core.model.platform.PlatformResolver
-
- getPlatform(BuildTarget, DependencyStack) - Method in class com.facebook.buck.core.rules.platform.CachingPlatformResolver
-
- getPlatform(BuildTarget, DependencyStack) - Method in class com.facebook.buck.core.rules.platform.CombinedPlatformResolver
-
- getPlatform(BuildTarget, DependencyStack) - Method in class com.facebook.buck.core.rules.platform.RuleBasedMultiPlatformResolver
-
- getPlatform(BuildTarget, DependencyStack) - Method in class com.facebook.buck.core.rules.platform.RuleBasedPlatformResolver
-
- getPlatform() - Method in class com.facebook.buck.features.go.GoBinaryDescriptionArg
-
- getPlatform() - Method in class com.facebook.buck.features.go.GoTestDescriptionArg
-
- getPlatform() - Method in interface com.facebook.buck.features.go.HasGoLinkable
-
- getPlatform() - Method in class com.facebook.buck.features.haskell.HaskellBinaryDescriptionArg
-
- getPlatform() - Method in class com.facebook.buck.features.haskell.HaskellGhciDescriptionArg
-
- getPlatform() - Method in class com.facebook.buck.features.haskell.HaskellHaddockDescriptionArg
-
- getPlatform() - Method in class com.facebook.buck.features.haskell.HaskellHaddockLibRule
-
- getPlatform() - Method in class com.facebook.buck.features.haskell.HaskellLibraryDescriptionArg
-
- getPlatform() - Method in class com.facebook.buck.features.lua.LuaBinaryDescriptionArg
-
- getPlatform(TargetConfiguration, CxxPlatform) - Method in class com.facebook.buck.features.lua.LuaBuckConfig
-
- getPlatform() - Method in class com.facebook.buck.features.ocaml.OcamlBinaryDescriptionArg
-
- getPlatform() - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg
-
- getPlatform() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getPlatform(String, UnresolvedCxxPlatform, ProcessExecutor) - Method in class com.facebook.buck.features.rust.RustPlatformFactory
-
- getPlatform() - Method in class com.facebook.buck.util.environment.DefaultExecutionEnvironment
-
- getPlatform() - Method in interface com.facebook.buck.util.environment.ExecutionEnvironment
-
- getPlatformBinary() - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg
-
- getPlatformCompilerFlags() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getPlatformCompilerFlags() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getPlatformCompilerFlags() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getPlatformCompilerFlags() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getPlatformCompilerFlags() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
- getPlatformCompilerFlags() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getPlatformCompilerFlags(CxxPlatform, CxxSource.Type) - Static method in class com.facebook.buck.cxx.CxxSourceTypes
-
- getPlatformCompilerFlags() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getPlatformCompilerFlags() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getPlatformCompilerFlags() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getPlatformCompilerFlags() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getPlatformCompilerFlags() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getPlatformDeps() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getPlatformDeps() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getPlatformDeps() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getPlatformDeps() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getPlatformDeps() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
- getPlatformDeps() - Method in class com.facebook.buck.cxx.CxxDeps
-
- getPlatformDeps() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getPlatformDeps() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getPlatformDeps() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getPlatformDeps() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getPlatformDeps() - Method in class com.facebook.buck.features.haskell.HaskellBinaryDescriptionArg
-
- getPlatformDeps() - Method in class com.facebook.buck.features.haskell.HaskellGhciDescriptionArg
-
- getPlatformDeps() - Method in class com.facebook.buck.features.haskell.HaskellLibraryDescriptionArg
-
- getPlatformDeps() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getPlatformDeps() - Method in class com.facebook.buck.features.lua.LuaBinaryDescriptionArg
-
- getPlatformDeps() - Method in class com.facebook.buck.features.lua.LuaLibraryDescriptionArg
-
- getPlatformDeps() - Method in class com.facebook.buck.features.ocaml.OcamlBinaryDescriptionArg
-
- getPlatformDeps() - Method in class com.facebook.buck.features.ocaml.OcamlLibraryDescriptionArg
-
- getPlatformDeps() - Method in class com.facebook.buck.features.ocaml.PrebuiltOcamlLibraryDescriptionArg
-
- getPlatformDeps() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getPlatformDeps() - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg
-
- getPlatformDeps() - Method in class com.facebook.buck.features.python.PythonLibraryDescriptionArg
-
- getPlatformDeps() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getPlatformDeps() - Method in class com.facebook.buck.features.rust.PrebuiltRustLibraryDescriptionArg
-
- getPlatformDeps() - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg
-
- getPlatformDeps() - Method in interface com.facebook.buck.features.rust.RustCommonArgs
-
- getPlatformDeps() - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg
-
- getPlatformDeps() - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg
-
- getPlatformExe() - Method in class com.facebook.buck.shell.CommandAliasDescriptionArg
-
- getPlatformFlags() - Method in class com.facebook.buck.cxx.CxxToolFlags
-
Flags that precede flags from #getRuleFlags()
.
- getPlatformFlags() - Method in class com.facebook.buck.cxx.ExplicitCxxToolFlags
-
- getPlatformFlavorDomain() - Method in class com.facebook.buck.features.go.GoToolchain
-
- getPlatformHeaderDirs() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getPlatformHeaders() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getPlatformHeaders() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getPlatformHeaders() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getPlatformHeaders() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getPlatformHeaders() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
- getPlatformHeaders() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getPlatformHeaders() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getPlatformHeaders() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getPlatformHeaders() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getPlatformHeaders() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getPlatformHeaders() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getPlatformImportLib() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getPlatformLinkerFlags() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getPlatformLinkerFlags() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getPlatformLinkerFlags() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getPlatformLinkerFlags() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getPlatformLinkerFlags() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
- getPlatformLinkerFlags() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getPlatformLinkerFlags() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getPlatformLinkerFlags() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getPlatformLinkerFlags() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getPlatformLinkerFlags() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getPlatformLinkerFlags() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getPlatformName() - Method in class com.facebook.buck.android.toolchain.AndroidPlatformTarget
-
This is likely something like "Google Inc.:Google APIs:21"
.
- getPlatformName() - Method in class com.facebook.buck.apple.AppleBundle
-
- getPlatformName() - Method in class com.facebook.buck.apple.toolchain.ApplePlatform
-
- getPlatformName() - Method in class com.facebook.buck.swift.toolchain.SwiftTargetTriple
-
- getPlatformParseTimeDeps(TargetConfiguration) - Method in class com.facebook.buck.cxx.CxxLibraryFactory
-
- getPlatformParseTimeDeps(RustToolchain, BuildTarget, HasDefaultPlatform) - Static method in class com.facebook.buck.features.rust.RustCompileUtils
-
- getPlatformPath() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
Path to Apple platform
- getPlatformPath() - Method in class com.facebook.buck.apple.toolchain.AppleSdkPaths
-
Absolute path to tools and files which depend on a particular platform.
- getPlatformPreloadDeps() - Method in class com.facebook.buck.features.haskell.HaskellGhciDescriptionArg
-
- getPlatformPreprocessFlags(CxxPlatform, CxxSource.Type) - Static method in class com.facebook.buck.cxx.CxxSourceTypes
-
- getPlatformPreprocessorFlags() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getPlatformPreprocessorFlags() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getPlatformPreprocessorFlags() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getPlatformPreprocessorFlags() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getPlatformPreprocessorFlags() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
- getPlatformPreprocessorFlags() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getPlatformPreprocessorFlags() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getPlatformPreprocessorFlags() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getPlatformPreprocessorFlags() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getPlatformPreprocessorFlags() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getPlatformPreprocessorFlags() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getPlatformProvider() - Method in interface com.facebook.buck.core.rules.configsetting.ConfigSettingSelectableConfigurationContext
-
- getPlatformProvider() - Method in class com.facebook.buck.parser.DefaultSelectableConfigurationContext
-
- getPlatformResources() - Method in class com.facebook.buck.features.python.PythonLibraryDescriptionArg
-
- getPlatformResources() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getPlatforms(CxxBuckConfig, AndroidBuckConfig, ProjectFilesystem, TargetConfiguration, Platform, ToolchainProvider, String) - Static method in class com.facebook.buck.android.toolchain.ndk.impl.NdkCxxPlatforms
-
- getPlatforms(CxxBuckConfig, AndroidBuckConfig, ProjectFilesystem, Path, NdkCxxPlatformCompiler, NdkCxxRuntime, NdkCxxRuntimeType, Set<NdkTargetArchAbi>, Platform) - Static method in class com.facebook.buck.android.toolchain.ndk.impl.NdkCxxPlatforms
-
- getPlatforms(CxxBuckConfig, AndroidBuckConfig, ProjectFilesystem, Path, NdkCxxPlatformCompiler, NdkCxxRuntime, NdkCxxRuntimeType, Set<NdkTargetArchAbi>, Platform, ExecutableFinder, boolean) - Static method in class com.facebook.buck.android.toolchain.ndk.impl.NdkCxxPlatforms
-
- getPlatforms() - Method in class com.facebook.buck.apple.toolchain.ProvisioningProfileMetadata
-
The set of platforms the profile is valid for.
- getPlatforms(FlavorDomain<UnresolvedCxxPlatform>) - Method in class com.facebook.buck.features.haskell.HaskellPlatformsFactory
-
Maps the cxxPlatforms to corresponding HaskellPlatform.
- getPlatformSharedLib() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getPlatformSrcs() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getPlatformSrcs() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getPlatformSrcs() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getPlatformSrcs() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getPlatformSrcs() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
- getPlatformSrcs() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getPlatformSrcs() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getPlatformSrcs() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getPlatformSrcs() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getPlatformSrcs() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getPlatformSrcs() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getPlatformSrcs() - Method in class com.facebook.buck.features.python.PythonLibraryDescriptionArg
-
- getPlatformSrcs() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getPlatformStaticLib() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getPlatformStaticPicLib() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getPlatformWhitelist() - Method in class com.facebook.buck.cxx.toolchain.HeaderVerification
-
- getPlatformWithFlavor(Flavor) - Method in interface com.facebook.buck.cxx.toolchain.ProvidesCxxPlatform
-
- getPluginClassLoader(JavaCompiler.CompilationTask) - Method in interface com.facebook.buck.jvm.java.plugin.api.PluginClassLoaderFactory
-
- getPluginClassLoader(ClassLoaderCache, JavaCompiler.CompilationTask) - Static method in class com.facebook.buck.jvm.java.plugin.PluginLoader
-
Returns a class loader that can be used to load classes from the compiler plugin jar.
- getPluginManager() - Method in class com.facebook.buck.cli.AdditionalOptionsCmdLineParser
-
- getPluginManager() - Method in interface com.facebook.buck.cli.Command
-
- getPluginManager() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getPluginManager() - Method in class com.facebook.buck.cli.CommandWithPluginManager
-
- getPluginManager() - Method in interface com.facebook.buck.core.description.DescriptionCreationContext
-
- getPluginName() - Method in class com.facebook.buck.event.CompilerPluginDurationEvent
-
- getPluginName() - Method in class com.facebook.buck.jvm.java.JavaPluginDescriptionArg
-
- getPluginProperties() - Method in class com.facebook.buck.jvm.java.JavacPluginParams
-
- getPlugins() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getPlugins() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getPlugins() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getPlugins() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getPlugins() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getPlugins() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getPlugins() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getPlugins() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getPlugins() - Method in interface com.facebook.buck.jvm.java.JvmLibraryArg
-
- getPlugins() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getPlugins() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getPlugins() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getPlugins() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getPluginsOf(BuildRuleResolver, JavacPluginProperties.Type) - Method in interface com.facebook.buck.jvm.java.JvmLibraryArg
-
- getPomTemplate() - Method in class com.facebook.buck.jvm.java.Javadoc
-
- getPomTemplate() - Method in interface com.facebook.buck.jvm.java.MavenPublishable
-
- getPomTemplate() - Method in class com.facebook.buck.jvm.java.MavenUberJar
-
- getPomTemplate() - Method in class com.facebook.buck.jvm.java.MavenUberJar.SourceJar
-
- getPoolHash() - Method in interface com.facebook.buck.worker.WorkerProcessPool
-
- getPoolHash() - Method in class com.facebook.buck.worker.WorkerProcessPoolAsync
-
- getPoolHash() - Method in class com.facebook.buck.worker.WorkerProcessPoolSync
-
- getPort() - Method in interface com.facebook.buck.apple.simulator.AppleDevice
-
String that represents the port of the device
- getPort() - Method in class com.facebook.buck.httpserver.WebServer
-
- getPosixFileMode(Path) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- getPosixFileMode(Path) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
getPosixFileMode returns a number corresponding to stat()'s ST_MODE, for use when constructing
tar archives.
- getPosixFilePermissions(Path) - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
Returns the set of POSIX file permissions, or the empty set if the underlying file system does
not support POSIX file attributes.
- getPosixFilePermissions(Path) - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
Returns the set of POSIX file permissions, or the empty set if the underlying file system does
not support POSIX file attributes.
- getPostActions() - Method in class com.facebook.buck.apple.xcode.XCScheme.SchemeAction
-
- getPostBuildSteps(BuildContext) - Method in class com.facebook.buck.apple.AppleDsym
-
- getPostBuildSteps(BuildContext) - Method in interface com.facebook.buck.core.rules.attr.HasPostBuildSteps
-
- getPostBuildSteps(BuildContext) - Method in class com.facebook.buck.jvm.java.JavaTest
-
- getPostCoercionTransform() - Method in class com.facebook.buck.core.starlark.rule.attr.Attribute
-
- getPostCoercionTransform() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.DepAttribute
-
- getPostCoercionTransform() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.DepListAttribute
-
- getPostCoercionTransform() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.OutputAttribute
-
- getPostCoercionTransform() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.OutputListAttribute
-
- getPostCoercionTransform() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.SourceAttribute
-
- getPostCoercionTransform() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.SourceListAttribute
-
- getPostCoercionTransform() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.SourceSortedSetAttribute
-
- getPostCoercionTransform() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.UnconfiguredDepListAttribute
-
- getPostCoercionTransform() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.UnconfiguredOptionalDepAttribute
-
- getPostCoercionValue(String) - Method in interface com.facebook.buck.core.starlark.coercer.SkylarkDescriptionArgBuilder
-
- getPostCoercionValue(String) - Method in class com.facebook.buck.core.starlark.rule.SkylarkDescriptionArg
-
- getPostFilterResourcesCmd() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getPostFilterResourcesCmd() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getPostFilterResourcesCmd() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getPostLinkerFlags() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getPostLinkerFlags() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getPostLinkerFlags() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getPostLinkerFlags() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getPostLinkerFlags() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
- getPostLinkerFlags() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getPostLinkerFlags() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getPostLinkerFlags() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getPostLinkerFlags() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getPostLinkerFlags() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getPostLinkerFlags() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getPostPlatformLinkerFlags() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getPostPlatformLinkerFlags() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getPostPlatformLinkerFlags() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getPostPlatformLinkerFlags() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getPostPlatformLinkerFlags() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
- getPostPlatformLinkerFlags() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getPostPlatformLinkerFlags() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getPostPlatformLinkerFlags() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getPostPlatformLinkerFlags() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getPostPlatformLinkerFlags() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getPostPlatformLinkerFlags() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getPostprocessClassesCommands() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getPostprocessClassesCommands() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getPostprocessClassesCommands() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getPostprocessClassesCommands() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getPostprocessClassesCommands() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getPostprocessClassesCommands() - Method in interface com.facebook.buck.jvm.java.JavaLibraryDescription.CoreArg
-
- getPostprocessClassesCommands() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getPostprocessClassesCommands() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getPostprocessClassesCommands() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getPostprocessClassesCommands() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getPostprocessClassesCommands() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getPostprocessClassesCommands() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getPostprocessClassesCommands() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getPostStringificationFormatString() - Method in interface com.facebook.buck.core.rules.actions.lib.args.CommandLineArgs.ArgAndFormatString
-
- getPreActions() - Method in class com.facebook.buck.apple.xcode.XCScheme.SchemeAction
-
- getPreArgfileArgs() - Method in class com.facebook.buck.cxx.toolchain.ClangWindowsCompiler
-
- getPreArgfileArgs() - Method in interface com.facebook.buck.cxx.toolchain.Compiler
-
- getPreArgfileArgs() - Method in class com.facebook.buck.cxx.toolchain.DefaultCompiler
-
- getPrebuiltJar() - Method in class com.facebook.buck.android.AndroidPrebuiltAar
-
- getPrebuiltTool(String, String, Function<String, Path>) - Method in class com.facebook.buck.rules.tool.config.ToolConfig
-
- getPreCoercionDefaultValue() - Method in class com.facebook.buck.core.starlark.rule.attr.Attribute
-
The default value to use if no value is provided.
- getPreCoercionDefaultValue() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.BoolAttribute
-
- getPreCoercionDefaultValue() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.DepAttribute
-
- getPreCoercionDefaultValue() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.DepListAttribute
-
- getPreCoercionDefaultValue() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.IntAttribute
-
- getPreCoercionDefaultValue() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.IntListAttribute
-
- getPreCoercionDefaultValue() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.OutputAttribute
-
- getPreCoercionDefaultValue() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.OutputListAttribute
-
- getPreCoercionDefaultValue() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.SourceAttribute
-
- getPreCoercionDefaultValue() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.SourceListAttribute
-
- getPreCoercionDefaultValue() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.SourceSortedSetAttribute
-
- getPreCoercionDefaultValue() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.StringAttribute
-
- getPreCoercionDefaultValue() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.StringListAttribute
-
- getPreCoercionDefaultValue() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.StringSortedSetAttribute
-
- getPreCoercionDefaultValue() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.UnconfiguredDepListAttribute
-
- getPreCoercionDefaultValue() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.UnconfiguredOptionalDepAttribute
-
- getPrecompiledHeader() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getPrecompiledHeader() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getPrecompiledHeader() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getPrecompiledHeader() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getPrecompiledHeader() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
- getPrecompiledHeader() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getPrecompiledHeader(boolean, PreprocessorDelegate, DependencyAggregation, CxxToolFlags, Function<CxxToolFlags, String>, Function<CxxToolFlags, String>, CxxPlatform, CxxSource.Type, ImmutableList<String>, ActionGraphBuilder, SourcePathResolverAdapter) - Method in class com.facebook.buck.cxx.CxxPrecompiledHeaderTemplate
-
Build a PCH rule, given a cxx_precompiled_header
rule.
- getPrecompiledHeader(boolean, PreprocessorDelegate, DependencyAggregation, CxxToolFlags, Function<CxxToolFlags, String>, Function<CxxToolFlags, String>, CxxPlatform, CxxSource.Type, ImmutableList<String>, ActionGraphBuilder, SourcePathResolverAdapter) - Method in class com.facebook.buck.cxx.CxxPrefixHeader
-
- getPrecompiledHeader() - Method in class com.facebook.buck.cxx.CxxSourceRuleFactory
-
NOTE: precompiled_header
is incompatible with prefix_header
.
- getPrecompiledHeader() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getPrecompiledHeader(boolean, PreprocessorDelegate, DependencyAggregation, CxxToolFlags, Function<CxxToolFlags, String>, Function<CxxToolFlags, String>, CxxPlatform, CxxSource.Type, ImmutableList<String>, ActionGraphBuilder, SourcePathResolverAdapter) - Method in class com.facebook.buck.cxx.PreInclude
-
- getPrecompiledHeader() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getPrecompiledHeader() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getPrecompiledHeader() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getPrecompiledHeader() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getPrecompiledHeaderLanguage() - Method in enum com.facebook.buck.cxx.CxxSource.Type
-
"Language" type to pass to the compiler in order to generate a precompiled header.
- getPrecomputedHash() - Method in interface com.facebook.buck.core.sourcepath.BuildTargetSourcePath
-
In rare cases, a BuildTargetSourcePath may know a hash of its content on disk before it even
creates its output.
- getPrecomputedHash() - Method in class com.facebook.buck.core.sourcepath.DefaultBuildTargetSourcePath
-
- getPrecomputedHash() - Method in class com.facebook.buck.core.sourcepath.ExplicitBuildTargetSourcePath
-
- getPrecomputedHash() - Method in class com.facebook.buck.core.sourcepath.ForwardingBuildTargetSourcePath
-
- getPrecomputedWorkCache() - Method in class com.facebook.buck.rules.macros.StringWithMacrosConverter
-
- getPreferredLinkage() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getPreferredLinkage() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getPreferredLinkage() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getPreferredLinkage(CxxPlatform) - Method in class com.facebook.buck.apple.PrebuiltAppleFramework
-
- getPreferredLinkage() - Method in class com.facebook.buck.apple.PrebuiltAppleFrameworkDescriptionArg
-
- getPreferredLinkage() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
- getPreferredLinkage() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getPreferredLinkage(CxxPlatform) - Method in class com.facebook.buck.cxx.CxxLibraryGroup
-
- getPreferredLinkage() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getPreferredLinkage(CxxPlatform) - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescription.CustomPrebuiltCxxLibrary
-
- getPreferredLinkage(CxxPlatform) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.LegacyNativeLinkableGroup
-
Deprecated.
- getPreferredLinkage() - Method in interface com.facebook.buck.cxx.toolchain.nativelink.NativeLinkable
-
- getPreferredLinkage() - Method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableInfo
-
- getPreferredLinkage() - Method in class com.facebook.buck.cxx.toolchain.nativelink.PlatformLockedNativeLinkableGroup
-
- getPreferredLinkage() - Method in class com.facebook.buck.features.haskell.HaskellLibraryDescriptionArg
-
- getPreferredLinkage() - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg
-
- getPreferredLinkage() - Method in class com.facebook.buck.swift.SwiftLibraryDescriptionArg
-
- getPrefixHeader() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getPrefixHeader() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getPrefixHeader() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getPrefixHeader() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getPrefixHeader() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
- getPrefixHeader() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getPrefixHeader() - Method in class com.facebook.buck.cxx.CxxSourceRuleFactory
-
NOTE: prefix_header
is incompatible with precompiled_header
.
- getPrefixHeader() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getPrefixHeader() - Method in class com.facebook.buck.cxx.PreprocessorFlags
-
File set via -include
.
- getPrefixHeader() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getPrefixHeader() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getPrefixHeader() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getPrefixHeader() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getPregeneratedVersionControlStats() - Method in class com.facebook.buck.util.versioncontrol.VersionControlBuckConfig
-
- getPreInclude() - Method in class com.facebook.buck.cxx.CxxSourceRuleFactory
-
Get (possibly creating) the
PreInclude
instance corresponding to this rule's
prefix_header
or
precompiled_header
, whichever is applicable, or empty if neither is
used.
- getPreloadDeps() - Method in class com.facebook.buck.features.haskell.HaskellGhciDescriptionArg
-
- getPreloadDeps() - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg
-
- getPreloadDeps() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getPreloadLibraries() - Method in class com.facebook.buck.features.python.PythonBinary
-
- getPreprocessedLanguage() - Method in enum com.facebook.buck.cxx.CxxSource.Type
-
- getPreprocessJavaClassesBash() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getPreprocessJavaClassesBash() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getPreprocessJavaClassesBash() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getPreprocessJavaClassesDeps() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getPreprocessJavaClassesDeps() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getPreprocessor(CxxPlatform, CxxSource.Type) - Static method in class com.facebook.buck.cxx.CxxSourceTypes
-
- getPreprocessorFlags() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getPreprocessorFlags() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getPreprocessorFlags() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getPreprocessorFlags() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getPreprocessorFlags() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
- getPreprocessorFlags() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getPreprocessorFlags() - Method in class com.facebook.buck.cxx.CxxPreprocessorInput
-
- getPreprocessorFlags() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getPreprocessorFlags() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getPreprocessorFlags() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getPreprocessorFlags() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getPreprocessorFlags() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getPreprocessorInput() - Method in interface com.facebook.buck.cxx.CxxLibraryDescriptionDelegate.ConfiguredDelegate
-
Defines an additional preprocessor input for the public interface exposed by a target.
- getPreprocessorInputForSwift(BuildTarget, ActionGraphBuilder, CxxPlatform, CxxLibraryDescription.CommonArg) - Method in interface com.facebook.buck.apple.AppleLibrarySwiftDelegate
-
- getPreprocessorInputForSwift(BuildTarget, ActionGraphBuilder, CxxPlatform, CxxLibraryDescription.CommonArg) - Method in class com.facebook.buck.apple.AppleTestDescription
-
- getPreprocessorInputsForAppleLibrary(BuildTarget, ActionGraphBuilder, CxxPlatform, AppleNativeTargetDescriptionArg) - Static method in class com.facebook.buck.apple.AppleLibraryDescriptionSwiftEnhancer
-
Returns transitive preprocessor inputs excluding those from the swift delegate of the given
CxxLibrary.
- getPreprocessorOutputType(CxxSource.Type) - Static method in class com.facebook.buck.cxx.CxxSourceTypes
-
- getPrereq() - Method in class com.facebook.buck.core.graph.transformation.executor.DepsAwareTask.DepsSupplier
-
- getPrettyPrint() - Method in class com.facebook.buck.infer.InferConfig
-
- getPreviousRuleInPipeline() - Method in interface com.facebook.buck.core.rules.pipeline.SupportsPipelining
-
Deprecated.
- getPreviousRuleInPipeline() - Method in class com.facebook.buck.jvm.java.CalculateSourceAbi
-
- getPreviousRuleInPipeline() - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getPrevValue() - Method in interface com.facebook.buck.command.config.ConfigDifference.ConfigChange
-
- getPrimaryCert() - Method in class com.facebook.buck.artifact_cache.ClientCertificateHandler.CertificateInfo
-
- getPrimaryDexClassesFile() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getPrimaryDexClassesFile() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getPrimaryDexInputHashesPath() - Method in class com.facebook.buck.android.PreDexSplitDexGroup
-
- getPrimaryDexInputMetadata() - Method in class com.facebook.buck.android.PreDexSplitDexGroup
-
- getPrimaryDexPatterns() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getPrimaryDexPatterns() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getPrimaryDexRoot() - Method in class com.facebook.buck.android.PreDexSplitDexGroup
-
- getPrimaryDexScenarioFile() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getPrimaryDexScenarioFile() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getPrintableName() - Method in enum com.facebook.buck.util.environment.Platform
-
- getPrivateCxxDeps() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getPrivateCxxDeps() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getPrivateCxxDeps() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getPrivateCxxDeps() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getPrivateCxxDeps() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
- getPrivateCxxDeps() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getPrivateCxxDeps() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getPrivateCxxDeps() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getPrivateCxxDeps() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getPrivateCxxDeps() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getPrivateCxxDeps() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getPrivateCxxDeps() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getPrivateCxxPreprocessorInput(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.apple.AppleBundle
-
- getPrivateCxxPreprocessorInput(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.cxx.CxxBinary
-
- getPrivateCxxPreprocessorInput(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.cxx.CxxLibraryGroup
-
- getPrivateCxxPreprocessorInput(CxxPlatform, ActionGraphBuilder) - Method in interface com.facebook.buck.cxx.NativeTestable
-
- getPrivateHeadersSymlinksEnabled() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getPrivateHeadersSymlinksEnabled() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
When building or creating a project, create symlinks for the public headers if it's true.
- getPrivateHeadersSymlinksEnabled() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
When building or creating a project, create symlinks for the public headers if it's true.
- getPrivateHeadersSymlinksSetting() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getPrivateHeaderSymlinkTree() - Method in interface com.facebook.buck.cxx.CxxLibraryDescriptionDelegate.ConfiguredDelegate
-
Defines an additional private
HeaderSymlinkTree
that will be used when compiling the
the library.
- getPrivatePreprocessorInput() - Method in interface com.facebook.buck.cxx.CxxLibraryDescriptionDelegate.ConfiguredDelegate
-
Defines an additional preprocessor input for the private interface exposed by a target.
- getProbability() - Method in enum com.facebook.buck.android.AndroidInstallConfig.ConcurrentInstall
-
- getProbability() - Method in enum com.facebook.buck.core.graph.transformation.executor.factory.DepsAwareExecutorType
-
- getProbability() - Method in enum com.facebook.buck.util.randomizedtrial.CommonGroups
-
- getProbability() - Method in interface com.facebook.buck.util.randomizedtrial.WithProbability
-
- getProcessedBytes() - Method in class com.facebook.buck.parser.events.ParseBuckFileEvent.Finished
-
- getProcessedBytes() - Method in class com.facebook.buck.parser.ParseEvent.Finished
-
- getProcessExecutor() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getProcessExecutor() - Method in class com.facebook.buck.core.build.execution.context.ExecutionContext
-
- getProcessExecutor() - Method in class com.facebook.buck.core.rules.actions.ActionExecutionContext
-
- getProcessExecutor() - Method in interface com.facebook.buck.core.toolchain.ToolchainCreationContext
-
- getProcessExecutor() - Method in interface com.facebook.buck.jvm.java.JavacExecutionContext
-
- getProcessId() - Method in class com.facebook.buck.event.chrome_trace.ChromeTraceEvent
-
- getProcessingTimeMs() - Method in class com.facebook.buck.log.PerfTimesStats
-
- getProcessManager() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getProcessOnly() - Method in class com.facebook.buck.jvm.java.JavacPluginParams
-
- getProcessorClass() - Method in class com.facebook.buck.jvm.java.JavaAnnotationProcessorDescriptionArg
-
- getProcessorClasses() - Method in class com.facebook.buck.jvm.java.JavaAnnotationProcessorDescriptionArg
-
- getProcessorNames() - Method in class com.facebook.buck.jvm.java.JavacPluginJsr199Fields
-
- getProcessorNames() - Method in class com.facebook.buck.jvm.java.ResolvedJavacPluginProperties
-
- getProcessResourceConsumption(long) - Method in class com.facebook.buck.util.ProcessHelper
-
Gets resource consumption of the process with the given pid.
- getProcMacro() - Method in class com.facebook.buck.features.rust.PrebuiltRustLibraryDescriptionArg
-
- getProcMacro() - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg
-
- getProductName() - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg
-
- getProductName() - Method in interface com.facebook.buck.apple.HasAppleBundleFields
-
- getProductName() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXTarget
-
- getProductReference() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXTarget
-
- getProductType() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXTarget
-
- getProfile() - Method in interface com.facebook.buck.json.BuildFilePythonResult
-
- getProfile() - Method in class com.facebook.buck.parser.events.ParseBuckFileEvent.Finished
-
- getProfileAction() - Method in class com.facebook.buck.apple.xcode.XCScheme
-
- getProfiledStaticLibs() - Method in class com.facebook.buck.features.haskell.HaskellPrebuiltLibraryDescriptionArg
-
- getProfilePath() - Method in class com.facebook.buck.apple.toolchain.ProvisioningProfileMetadata
-
- getProgress() - Method in class com.facebook.buck.event.listener.util.ProgressEstimation
-
- getProgressValue() - Method in interface com.facebook.buck.event.external.events.ProgressEventInterface
-
- getProgressValue() - Method in class com.facebook.buck.event.ProgressEvent
-
- getProguardAgentPath() - Method in class com.facebook.buck.android.ProGuardConfig
-
- getProguardConfig() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getProguardConfig() - Method in class com.facebook.buck.android.AndroidBinary
-
- getProguardConfig() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getProguardConfig() - Method in class com.facebook.buck.android.AndroidBundle
-
- getProguardConfig() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getProguardConfig() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getProguardConfig() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getProguardConfig() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getProguardConfig() - Method in class com.facebook.buck.android.toolchain.AndroidPlatformTarget
-
- getProguardConfig() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getProguardConfig() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getProguardConfig() - Method in interface com.facebook.buck.jvm.java.JavaLibraryDescription.CoreArg
-
- getProguardConfig() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getProguardConfig() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getProguardConfig() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getProguardConfig() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getProguardConfig() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getProguardConfig() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getProguardConfig() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getProguardConfigPath() - Method in class com.facebook.buck.features.project.intellij.model.IjModuleAndroidFacet
-
- getProguardConfigPath(TargetNode<AndroidBinaryDescriptionArg>) - Method in interface com.facebook.buck.features.project.intellij.model.IjModuleFactoryResolver
-
- getProguardConfigs() - Method in interface com.facebook.buck.android.packageable.AndroidPackageableCollection
-
Proguard configurations to include when running release builds.
- getProguardJar() - Method in class com.facebook.buck.android.toolchain.AndroidPlatformTarget
-
- getProguardJarOverride(TargetConfiguration) - Method in class com.facebook.buck.android.ProGuardConfig
-
- getProguardJvmArgs() - Method in class com.facebook.buck.android.AndroidBinary
-
- getProguardJvmArgs() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getProguardJvmArgs() - Method in class com.facebook.buck.android.AndroidBundle
-
- getProguardJvmArgs() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getProguardJvmArgs() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getProguardMaxHeapSize() - Method in class com.facebook.buck.android.ProGuardConfig
-
- getProguardTarget(TargetConfiguration) - Method in class com.facebook.buck.android.ProGuardConfig
-
- getProject() - Method in class com.facebook.buck.features.apple.projectV2.XCodeProjectCommandHelper.Result
-
- getProjectAddASTPaths() - Method in class com.facebook.buck.swift.SwiftBuckConfig
-
If enabled, AST paths to the .swiftmodules will be added as part of the linker invocation.
- getProjectAssets() - Method in class com.facebook.buck.android.AndroidResourceDescriptionArg
-
- getProjectEmbedRuntime() - Method in class com.facebook.buck.swift.SwiftBuckConfig
-
If enabled, automatically emebds the Swift runtime if a relevant target depends on any
libraries that use Swift.
- getProjectFilesystem() - Method in interface com.facebook.buck.android.HasInstallableApk
-
- getProjectFilesystem() - Method in class com.facebook.buck.artifact_cache.AbstractAsynchronousCache
-
- getProjectFilesystem() - Method in interface com.facebook.buck.core.rules.BuildRule
-
- getProjectFilesystem() - Method in interface com.facebook.buck.core.rules.BuildRuleCreationContext
-
- getProjectFilesystem() - Method in interface com.facebook.buck.core.rules.BuildRuleCreationContextWithTargetGraph
-
- getProjectFilesystem() - Method in class com.facebook.buck.core.rules.impl.AbstractBuildRule
-
- getProjectFilesystem() - Method in interface com.facebook.buck.core.rules.ProviderCreationContext
-
- getProjectFilesystem() - Method in class com.facebook.buck.cxx.CxxSourceRuleFactory
-
- getProjectFilesystem() - Method in interface com.facebook.buck.jvm.java.JavacExecutionContext
-
- getProjectFilesystem() - Method in class com.facebook.buck.jvm.java.UnusedDependenciesFinder
-
- getProjectFilesystemFactory() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getProjectFilesystemFactory() - Method in class com.facebook.buck.command.BuildExecutorArgs
-
- getProjectFilesystemFactory() - Method in class com.facebook.buck.core.build.execution.context.ExecutionContext
-
- getProjectFilesystemFactory() - Method in interface com.facebook.buck.jvm.java.JavacExecutionContext
-
- getProjectJdkName() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getProjectJdkType() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getProjectLanguageLevel() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getProjectPath() - Method in class com.facebook.buck.features.apple.project.ProjectGenerator
-
- getProjectPaths() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getProjectPrefix() - Method in interface com.facebook.buck.io.watchman.ProjectWatch
-
- getProjectQualifiedPath(Path) - Method in class com.facebook.buck.features.project.intellij.IjProjectPaths
-
- getProjectRelativePath(Path) - Method in class com.facebook.buck.features.project.intellij.IjProjectPaths
-
- getProjectRes() - Method in class com.facebook.buck.android.AndroidResourceDescriptionArg
-
- getProjectRoot() - Method in class com.facebook.buck.edenfs.EdenMount
-
- getProjectRoot() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getProjectRoot() - Method in class com.facebook.buck.parser.options.ProjectBuildFileParserOptions
-
- getProjectRootDir() - Method in class com.facebook.buck.io.filesystem.BuckPaths
-
- getProjectTimeMs() - Method in class com.facebook.buck.log.PerfTimesStats
-
- getProjectWatches() - Method in class com.facebook.buck.io.watchman.Watchman
-
- getProjectWMO() - Method in class com.facebook.buck.swift.SwiftBuckConfig
-
If enabled, turns on Whole Module Optimization for any targets that contain Swift.
- getProperties() - Method in class com.facebook.buck.jvm.java.KeystoreDescriptionArg
-
- getProperty(String) - Method in interface com.facebook.buck.android.exopackage.AndroidDevice
-
- getProperty(String) - Method in class com.facebook.buck.android.exopackage.RealAndroidDevice
-
- getPropertyName() - Method in class com.facebook.buck.event.ExperimentEvent
-
- getPropertyValueFromPlistStream(Path, InputStream, String) - Static method in class com.facebook.buck.apple.AppleInfoPlistParsing
-
Extracts a property value from an Info.plist, returning it if present.
- getProtocol() - Method in class com.facebook.buck.remoteexecution.grpc.GrpcRemoteExecutionClients
-
- getProtocol() - Method in interface com.facebook.buck.remoteexecution.RemoteExecutionClients
-
- getProtocol() - Method in class com.facebook.buck.remoteexecution.util.OutOfProcessIsolatedExecutionClients
-
- getProtocolFactory(ThriftProtocol) - Static method in class com.facebook.buck.slb.ThriftUtil
-
- getProtocolVersion() - Method in class com.facebook.buck.doctor.config.DoctorConfig
-
- getProvided() - Method in class com.facebook.buck.jvm.java.PrebuiltJarDescriptionArg
-
- getProvidedDeps() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getProvidedDeps() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getProvidedDeps() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getProvidedDeps() - Method in interface com.facebook.buck.core.description.arg.HasProvidedDeps
-
- getProvidedDeps() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getProvidedDeps() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getProvidedDeps() - Method in class com.facebook.buck.jvm.java.JavaLibraryDeps
-
- getProvidedDeps() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getProvidedDeps() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getProvidedDeps() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getProvidedDeps() - Method in class com.facebook.buck.jvm.java.UnusedDependenciesFinder
-
- getProvidedDeps() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getProvidedDeps() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getProvidedDeps() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getProvidedDeps() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getProvidedDepsQuery() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getProvidedDepsQuery() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getProvidedDepsQuery() - Method in interface com.facebook.buck.core.description.arg.HasProvidedDepsQuery
-
- getProvidedSharedLibs() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescriptionArg
-
- getProvider() - Method in class com.facebook.buck.core.rules.providers.impl.BuiltInProviderInfo
-
- getProvider() - Method in class com.facebook.buck.core.rules.providers.impl.UserDefinedProviderInfo
-
- getProvider() - Method in interface com.facebook.buck.core.rules.providers.ProviderInfo
-
- getProviderBasedPlatform(BuckConfig, Flavor) - Static method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
If the config specifies a value for "toolchain_target", returns a
UnresolvedCxxPlatform
backed by the specified target.
- getProviderForSpec(JavacSpec) - Static method in class com.facebook.buck.jvm.java.ExternalJavacProvider
-
Creates a JavacProvider based on a spec.
- getProviderInfo() - Method in class com.facebook.buck.core.rules.providers.impl.BuiltInProviderInfo
-
- getProviderInfo() - Method in class com.facebook.buck.core.rules.providers.impl.UserDefinedProviderInfo
-
- getProviderInfo() - Method in interface com.facebook.buck.core.rules.providers.SkylarkProviderInfo
-
- getProviderInfoCollection() - Method in interface com.facebook.buck.core.rules.BuildRuleCreationContextWithTargetGraph
-
- getProviderInfos() - Method in class com.facebook.buck.core.rules.analysis.impl.LegacyProviderRuleAnalysisResult
-
- getProviderInfos() - Method in interface com.facebook.buck.core.rules.analysis.RuleAnalysisResult
-
- getProviderInfos() - Method in class com.facebook.buck.core.rules.impl.RuleAnalysisLegacyBuildRuleView
-
- getProviderInfos() - Method in class com.facebook.buck.core.starlark.rule.data.SkylarkDependency
-
- getProviders() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.DepAttribute
-
- getProviders() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.DepListAttribute
-
- getProviders(DependencyOnlyRuleAnalysisContext, TargetConfiguration) - Method in interface com.facebook.buck.core.toolchain.RuleAnalysisLegacyToolchain
-
- getProvisioningProfileByUUID(String) - Method in class com.facebook.buck.apple.toolchain.ProvisioningProfileStore
-
- getProvisioningProfileName() - Method in class com.facebook.buck.apple.toolchain.ApplePlatform
-
The platform name used to match provisioning profiles.
- getProvisioningProfileReadCommand() - Method in class com.facebook.buck.apple.AppleConfig
-
- getProvisioningProfiles() - Method in class com.facebook.buck.apple.toolchain.ProvisioningProfileStore
-
- getProvisioningProfileSearchPath() - Method in class com.facebook.buck.apple.AppleConfig
-
- getProvisioningProfilesSupplier() - Method in class com.facebook.buck.apple.toolchain.ProvisioningProfileStore
-
- getProxy() - Method in class com.facebook.buck.file.downloader.impl.DownloadConfig
-
- getProxyType() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXContainerItemProxy
-
- getPublicCxxPreprocessorInputExcludingDelegate(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.cxx.CxxLibraryGroup
-
- getPublicHeadersSymlinksEnabled() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getPublicHeadersSymlinksEnabled() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
When building or creating a project, create symlinks for the public headers if it's true.
- getPublicHeadersSymlinksEnabled() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
When building or creating a project, create symlinks for the public headers if it's true.
- getPublicHeadersSymlinksSetting() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getPublicIncludeDirectories() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
A list of include directories to be added to the compile command for compiling this cxx
target and every target that depends on it.
- getPublicIncludeDirectories() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
A list of include directories to be added to the compile command for compiling this cxx
target and every target that depends on it.
- getPublicIncludeDirectories() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
A list of include directories to be added to the compile command for compiling this cxx
target and every target that depends on it.
- getPublicIncludeDirectories() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
A list of include directories to be added to the compile command for compiling this cxx
target and every target that depends on it.
- getPublicIncludeDirectories() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
A list of include directories to be added to the compile command for compiling this cxx
target and every target that depends on it.
- getPublicSystemIncludeDirectories() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
A list of include directories to be added to the compile command for compiling this cxx
target and every target that depends on it.
- getPublicSystemIncludeDirectories() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
A list of include directories to be added to the compile command for compiling this cxx
target and every target that depends on it.
- getPublicSystemIncludeDirectories() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
A list of include directories to be added to the compile command for compiling this cxx
target and every target that depends on it.
- getPublicSystemIncludeDirectories() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
A list of include directories to be added to the compile command for compiling this cxx
target and every target that depends on it.
- getPublicSystemIncludeDirectories() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
A list of include directories to be added to the compile command for compiling this cxx
target and every target that depends on it.
- getPythonBytecode(PythonPlatform, CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.features.python.PrebuiltPythonLibrary
-
- getPythonBytecode(PythonPlatform, CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.features.python.PythonLibrary
-
- getPythonBytecode(PythonPlatform, CxxPlatform, ActionGraphBuilder) - Method in interface com.facebook.buck.features.python.PythonPackagable
-
Compiled Python bytecode (e.g.
- getPythonInterpreter() - Method in class com.facebook.buck.parser.options.ProjectBuildFileParserOptions
-
- getPythonInterpreterPath(String) - Method in class com.facebook.buck.features.python.toolchain.impl.PythonInterpreterFromConfig
-
- getPythonInterpreterPath() - Method in class com.facebook.buck.features.python.toolchain.impl.PythonInterpreterFromConfig
-
- getPythonInterpreterPath(String) - Method in interface com.facebook.buck.features.python.toolchain.PythonInterpreter
-
- getPythonInterpreterPath() - Method in interface com.facebook.buck.features.python.toolchain.PythonInterpreter
-
- getPythonModules(PythonPlatform, CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.features.python.CxxPythonExtension
-
- getPythonModules(PythonPlatform, CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.features.python.PrebuiltPythonLibrary
-
- getPythonModules(PythonPlatform, CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.features.python.PythonLibrary
-
- getPythonModules(PythonPlatform, CxxPlatform, ActionGraphBuilder) - Method in interface com.facebook.buck.features.python.PythonPackagable
-
Python modules (i.e.
- getPythonModuleSdkName() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getPythonModuleSdkType() - Method in class com.facebook.buck.features.project.intellij.model.IjProjectConfig
-
- getPythonModuleSearchPath() - Method in class com.facebook.buck.parser.config.ParserConfig
-
Returns the module search path PYTHONPATH to set for the parser, as specified by the
'python_path' key of the 'parser' section.
- getPythonModuleSearchPath() - Method in class com.facebook.buck.parser.options.ProjectBuildFileParserOptions
-
- getPythonName() - Method in class com.facebook.buck.rules.coercer.AbstractParamInfo
-
- getPythonName() - Method in interface com.facebook.buck.rules.coercer.ParamInfo
-
- getPythonPackageDeps(PythonPlatform, CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.features.python.PrebuiltPythonLibrary
-
- getPythonPackageDeps(PythonPlatform, CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.features.python.PythonLibrary
-
- getPythonPackageDeps(PythonPlatform, CxxPlatform, ActionGraphBuilder) - Method in interface com.facebook.buck.features.python.PythonPackagable
-
- getPythonPath() - Method in class com.facebook.buck.features.python.toolchain.PythonEnvironment
-
- getPythonPlatform() - Method in class com.facebook.buck.features.lua.LuaBinaryDescriptionArg
-
- getPythonPlatform() - Method in class com.facebook.buck.features.python.PythonBinary
-
- getPythonPlatforms(ToolchainProvider, PythonBuckConfig, ProcessExecutor, TargetConfiguration) - Method in class com.facebook.buck.features.python.toolchain.impl.PythonPlatformsProviderFactory
-
Constructs set of Python platform flavors given in a .buckconfig file, as is specified by
section names of the form python#{flavor name}.
- getPythonPlatforms() - Method in interface com.facebook.buck.features.python.toolchain.PythonPlatformsProvider
-
- getPythonPlatformSections() - Method in class com.facebook.buck.features.python.PythonBuckConfig
-
- getPythonResources(PythonPlatform, CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.features.python.PrebuiltPythonLibrary
-
- getPythonResources(PythonPlatform, CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.features.python.PythonLibrary
-
- getPythonResources(PythonPlatform, CxxPlatform, ActionGraphBuilder) - Method in interface com.facebook.buck.features.python.PythonPackagable
-
Resources (e.g.
- getPythonTimeMs() - Method in class com.facebook.buck.log.PerfTimesStats
-
- getPythonVersion() - Method in class com.facebook.buck.features.python.toolchain.PythonEnvironment
-
- getQuery() - Method in class com.facebook.buck.rules.macros.QueryMacro
-
- getQuery() - Method in class com.facebook.buck.rules.macros.QueryTargetsAndOutputsMacro
-
- getQuery() - Method in class com.facebook.buck.rules.query.Query
-
- getQueueLength() - Method in class com.facebook.buck.util.concurrent.ListeningMultiSemaphore
-
- getRageUrl() - Method in interface com.facebook.buck.doctor.config.DoctorJsonResponse
-
- getRanlib() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getRanlib() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
Ranlib binary.
- getRanlib() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getRanlibflags() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getRanlibFlags() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
Ranlib flags.
- getRanlibflags() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getRawConfig() - Method in class com.facebook.buck.parser.options.ProjectBuildFileParserOptions
-
- getRawConfig() - Method in class com.facebook.buck.skylark.packages.PackageContext
-
Returns a raw map of configuration options defined in .buckconfig
file and passed
through a --config
command line option.
- getRawConfig() - Method in class com.facebook.buck.util.config.Config
-
- getRawConfigForParser() - Method in class com.facebook.buck.command.config.ConfigIgnoredByDaemon
-
- getRawHeaders() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
Raw headers are headers which are used as they are (via compilation flags).
- getRawHeaders() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
Raw headers are headers which are used as they are (via compilation flags).
- getRawHeaders() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
Raw headers are headers which are used as they are (via compilation flags).
- getRawHeaders() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
Raw headers are headers which are used as they are (via compilation flags).
- getRawHeaders() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
Raw headers are headers which are used as they are (via compilation flags).
- getRawHeaders() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
Raw headers are headers which are used as they are (via compilation flags).
- getRawHeaders() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
Raw headers are headers which are used as they are (via compilation flags).
- getRawHeaders() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getRawHeaders() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getRawHeaders() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getRawHeaders() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getRawKeys() - Method in class com.facebook.buck.artifact_cache.HttpArtifactCacheBinaryProtocol.StoreResponseReadResult
-
- getRawNodeCache() - Method in class com.facebook.buck.parser.DaemonicParserState
-
- getRawOutput() - Method in class com.facebook.buck.features.go.GoListStep
-
- getRawPexTool(BuildRuleResolver, TargetConfiguration) - Method in class com.facebook.buck.features.python.PythonBuckConfig
-
- getRawResult() - Method in class com.facebook.buck.util.concurrent.WorkThreadTrackingTask
-
- getRawRules() - Method in class com.facebook.buck.skylark.parser.ParseResult
-
Returns rules organized in a map where a key is a rule name and the value is a map with keys
representing rule parameters and values representing rule arguments.
- getRawSelector() - Method in class com.facebook.buck.test.selectors.PatternTestSelector
-
- getRawSelector() - Method in class com.facebook.buck.test.selectors.SimpleTestSelector
-
- getRawSelector() - Method in interface com.facebook.buck.test.selectors.TestSelector
-
- getRawSelectors() - Method in class com.facebook.buck.test.selectors.TestSelectorList
-
- getRawStream() - Method in class com.facebook.buck.util.DirtyPrintStreamDecorator
-
- getRawValue(String, String) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getRDotJavaBinFolder(BuildTarget, ProjectFilesystem) - Static method in class com.facebook.buck.android.DummyRDotJava
-
- getRDotJavaBinFolder() - Method in class com.facebook.buck.android.DummyRDotJava
-
- getRDotJavaFiles() - Method in class com.facebook.buck.android.MergeAndroidResourcesStep
-
- getRDotJavaPackage() - Method in class com.facebook.buck.android.AndroidPrebuiltAar
-
- getRDotJavaPackage() - Method in class com.facebook.buck.android.AndroidResource
-
- getRDotJavaPackage() - Method in interface com.facebook.buck.android.HasAndroidResourceDeps
-
- getRDotJavaSrcFolder(BuildTarget, ProjectFilesystem) - Static method in class com.facebook.buck.android.DummyRDotJava
-
- getReadConfigurationOptions() - Method in class com.facebook.buck.skylark.parser.ParseResult
-
Returns all configuration options accessed during parsing of the build or package file.
- getReadHeaders() - Method in class com.facebook.buck.artifact_cache.config.HttpCacheEntry
-
- getReadOnlyPaths() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getReadTimeoutSeconds() - Method in class com.facebook.buck.artifact_cache.config.HttpCacheEntry
-
- getReason() - Method in class com.facebook.buck.event.WatchmanStatusEvent.Overflow
-
- getReason() - Method in class com.facebook.buck.io.watchman.WatchmanOverflowEvent
-
Human-readable message why overflow event is sent
- getRebaseInfoOffset() - Method in class com.facebook.buck.cxx.toolchain.objectfile.MachoDyldInfoCommand
-
- getRebaseInfoSize() - Method in class com.facebook.buck.cxx.toolchain.objectfile.MachoDyldInfoCommand
-
- getRecord() - Method in class com.facebook.buck.log.ErrorLogRecord
-
- getRecordedPaths() - Method in class com.facebook.buck.core.build.engine.buildinfo.BuildInfoRecorder
-
- getRecordedRules() - Method in class com.facebook.buck.skylark.parser.context.ParseContext
-
- getRecursiveTargetNodeDependenciesOfTypes(XCodeDescriptions, TargetGraph, Optional<AppleDependenciesCache>, AppleBuildRules.RecursiveDependenciesMode, TargetNode<?>, Optional<ImmutableSet<Class<? extends BaseDescription<?>>>>) - Static method in class com.facebook.buck.apple.AppleBuildRules
-
- getRecursiveTargetNodeDependenciesOfTypes(XCodeDescriptions, TargetGraph, Optional<AppleDependenciesCache>, AppleBuildRules.RecursiveDependenciesMode, TargetNode<?>, Predicate<TargetNode<?>>, Optional<AppleCxxPlatform>) - Static method in class com.facebook.buck.apple.AppleBuildRules
-
- getRecursiveTargetNodeDependenciesOfTypes(XCodeDescriptions, TargetGraph, Optional<AppleDependenciesCache>, AppleBuildRules.RecursiveDependenciesMode, TargetNode<?>, ImmutableSet<Class<? extends BaseDescription<?>>>) - Static method in class com.facebook.buck.apple.AppleBuildRules
-
- getRedex() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getRedex() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getRedex() - Method in class com.facebook.buck.android.redex.RedexOptions
-
- getRedexConfig() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getRedexConfig() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getRedexConfig() - Method in class com.facebook.buck.android.redex.RedexOptions
-
- getRedexExtraArgs() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getRedexExtraArgs() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getRedexExtraArgs() - Method in class com.facebook.buck.android.redex.RedexOptions
-
- getRedexTarget(TargetConfiguration) - Method in class com.facebook.buck.android.AndroidBuckConfig
-
- getRedexTool(BuildRuleResolver, TargetConfiguration) - Method in class com.facebook.buck.android.AndroidBuckConfig
-
- getRedirectError() - Method in class com.facebook.buck.util.ProcessExecutorParams
-
If present, redirects stderr for the process to this location.
- getRedirectErrorStream() - Method in class com.facebook.buck.util.ProcessExecutorParams
-
- getRedirectInput() - Method in class com.facebook.buck.util.ProcessExecutorParams
-
If present, redirects stdout for the process to this location.
- getRedirectOutput() - Method in class com.facebook.buck.util.ProcessExecutorParams
-
If present, redirects stdin for the process to this location.
- getReferencedFiles(AbsPath) - Method in class com.facebook.buck.cli.TargetsCommand
-
- getReferencedResources() - Method in class com.facebook.buck.android.DexProducedFromJavaLibrary
-
- getReferencedResources() - Method in class com.facebook.buck.android.PreDexSplitDexGroup
-
- getReferencedResourcesPath() - Method in class com.facebook.buck.android.PreDexSplitDexGroup
-
- getRefName(int) - Method in class com.facebook.buck.android.resources.ResTablePackage
-
- getRegisteredActionData() - Method in class com.facebook.buck.core.rules.analysis.impl.RuleAnalysisContextImpl
-
- getRegisteredActions() - Method in interface com.facebook.buck.core.rules.analysis.action.ActionAnalysisDataLookUp
-
- getRegisteredActions() - Method in class com.facebook.buck.core.rules.analysis.impl.LegacyProviderRuleAnalysisResult
-
- getRelativeHeaderPath(ProjectFilesystem) - Method in class com.facebook.buck.cxx.PreInclude
-
- getRelativeOutputPath() - Method in class com.facebook.buck.features.project.intellij.model.folders.IjSourceFolder
-
- getRelativeOutputPath() - Method in class com.facebook.buck.features.project.intellij.model.folders.ResourceFolder
-
- getRelativePath() - Method in class com.facebook.buck.core.sourcepath.PathSourcePath
-
- getRelativePath(SourcePath) - Method in class com.facebook.buck.core.sourcepath.resolver.impl.AbstractSourcePathResolver
-
- getRelativePath(ProjectFilesystem, SourcePath) - Method in class com.facebook.buck.core.sourcepath.resolver.impl.AbstractSourcePathResolver
-
- getRelativePath(SourcePath) - Method in interface com.facebook.buck.core.sourcepath.resolver.SourcePathResolver
-
- getRelativePath(ProjectFilesystem, SourcePath) - Method in interface com.facebook.buck.core.sourcepath.resolver.SourcePathResolver
-
- getRelativePath(SourcePath) - Method in class com.facebook.buck.core.sourcepath.resolver.SourcePathResolverAdapter
-
- getRelativePath(ProjectFilesystem, SourcePath) - Method in class com.facebook.buck.core.sourcepath.resolver.SourcePathResolverAdapter
-
- getRelativePath() - Method in interface com.facebook.buck.doctor.config.BuildLogEntry
-
- getRelativePath(Path, Path) - Static method in class com.facebook.buck.io.file.MorePaths
-
Get the path of a file relative to a base directory.
- getRelativePath() - Method in interface com.facebook.buck.jvm.java.classes.FileLike
-
Returns the relative path for the entry.
- getRelativeResDirectories(ProjectFilesystem, SourcePathResolverAdapter) - Method in interface com.facebook.buck.android.FilteredResourcesProvider
-
- getRelativizeTargetsToWorkingDirectory() - Method in class com.facebook.buck.support.cli.config.CliConfig
-
- getRelinkedLibs() - Method in class com.facebook.buck.android.relinker.NativeRelinker
-
- getRelinkedLibsAssets() - Method in class com.facebook.buck.android.relinker.NativeRelinker
-
- getRelinkerWhitelist() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getRelinkerWhitelist() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getRelinkerWhitelist() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getRemote() - Method in class com.facebook.buck.android.ApkGenruleDescriptionArg
-
If present and true, requests that Buck run this genrule remotely if possible.
- getRemote() - Method in class com.facebook.buck.cxx.CxxGenruleDescriptionArg
-
If present and true, requests that Buck run this genrule remotely if possible.
- getRemote() - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg
-
- getRemote() - Method in class com.facebook.buck.jvm.java.JarGenruleDescriptionArg
-
If present and true, requests that Buck run this genrule remotely if possible.
- getRemote() - Method in interface com.facebook.buck.shell.AbstractGenruleDescription.CommonArg
-
If present and true, requests that Buck run this genrule remotely if possible.
- getRemote() - Method in class com.facebook.buck.shell.GenruleDescriptionArg
-
If present and true, requests that Buck run this genrule remotely if possible.
- getRemoteArtifactUploadStats() - Method in class com.facebook.buck.event.listener.stats.cache.NetworkStatsTracker
-
Get the current upload stats.
- getRemoteCpuTimeMs() - Method in class com.facebook.buck.remoteexecution.event.listener.RemoteExecutionEventListener
-
- getRemoteCpuTimeMs() - Method in interface com.facebook.buck.remoteexecution.event.RemoteExecutionStatsProvider
-
Metadata for total time spent executing actions remotely in millis.
- getRemoteDownloadStats() - Method in class com.facebook.buck.event.listener.stats.cache.NetworkStatsTracker
-
Get the current download stats.
- getRemoteDurationMillis() - Method in class com.facebook.buck.remoteexecution.event.LocalFallbackEvent.Finished
-
- getRemoteErrorMessage() - Method in class com.facebook.buck.remoteexecution.event.LocalFallbackEvent.Finished
-
- getRemoteExecutionMetadata() - Method in class com.facebook.buck.remoteexecution.event.LocalFallbackEvent.Finished
-
- getRemoteExecutionMetadata() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.Terminal
-
- getRemoteExecutionMetadata() - Method in interface com.facebook.buck.remoteexecution.RemoteExecutionServiceClient.ExecutionResult
-
- getRemoteExecutionMetadata() - Method in exception com.facebook.buck.step.StepFailedException
-
- getRemoteExecutionService() - Method in class com.facebook.buck.remoteexecution.grpc.GrpcRemoteExecutionClients
-
- getRemoteExecutionService() - Method in interface com.facebook.buck.remoteexecution.RemoteExecutionClients
-
- getRemoteExecutionService() - Method in class com.facebook.buck.remoteexecution.util.OutOfProcessIsolatedExecutionClients
-
- getRemoteGlobalIDString() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXContainerItemProxy
-
- getRemoteGrpcStatus() - Method in class com.facebook.buck.remoteexecution.event.LocalFallbackEvent.Finished
-
- getRemoteHost() - Method in class com.facebook.buck.remoteexecution.config.RemoteExecutionConfig
-
- getRemotePort() - Method in class com.facebook.buck.remoteexecution.config.RemoteExecutionConfig
-
- getRemoteQueueTimeMs() - Method in class com.facebook.buck.remoteexecution.event.listener.RemoteExecutionEventListener
-
- getRemoteQueueTimeMs() - Method in interface com.facebook.buck.remoteexecution.event.RemoteExecutionStatsProvider
-
Metadata for total time spent queued for executing actions in millis.
- getRemoteResult() - Method in class com.facebook.buck.remoteexecution.event.LocalFallbackEvent.Finished
-
- getRemoteRunnablePath() - Method in class com.facebook.buck.apple.xcode.XCScheme.LaunchAction
-
- getRemoteSandboxDir() - Method in class com.facebook.buck.io.filesystem.BuckPaths
-
- getRemoveClasses() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getRemoveClasses() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getRemoveClasses() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getRemoveClasses() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getRemoveClasses() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getRemoveClasses() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getRemoveClasses() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getRemoveClasses() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getRemoveClasses() - Method in interface com.facebook.buck.jvm.java.JvmLibraryArg
-
- getRemoveClasses() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getRemoveClasses() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getRemoveClasses() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getRemoveClasses() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getRemoveEntryPredicate() - Method in class com.facebook.buck.jvm.java.JarParameters
-
- getRemoveOutput() - Method in class com.facebook.buck.support.build.report.BuildReportConfig
-
- getRepoConfigurationFiles(Path) - Static method in class com.facebook.buck.util.config.Configs
-
Gets the repository defined configuration files (excluding configuration directories) that
should be used for parsing the project configuration.
- getRepoCredentials(String) - Method in class com.facebook.buck.file.downloader.impl.DownloadConfig
-
- getReport() - Method in class com.facebook.buck.parser.events.ParseBuckProfilerReportEvent
-
- getReportId() - Method in interface com.facebook.buck.doctor.config.DoctorJsonResponse
-
- getReportId() - Method in interface com.facebook.buck.doctor.DefectReporter.DefectSubmitResult
-
- getReportMaxSizeBytes() - Method in class com.facebook.buck.doctor.config.DoctorConfig
-
- getReportMaxUploadRetries() - Method in class com.facebook.buck.doctor.config.DoctorConfig
-
- getReportSubmitErrorMessage() - Method in interface com.facebook.buck.doctor.DefectReporter.DefectSubmitResult
-
- getReportSubmitLocation() - Method in interface com.facebook.buck.doctor.DefectReporter.DefectSubmitResult
-
- getReportSubmitMessage() - Method in interface com.facebook.buck.doctor.DefectReporter.DefectSubmitResult
-
- getReportTimeoutMs() - Method in class com.facebook.buck.doctor.config.DoctorConfig
-
- getReportUploadPath() - Method in class com.facebook.buck.doctor.config.DoctorConfig
-
- getReportUrl() - Method in interface com.facebook.buck.doctor.config.DoctorEndpointRequest
-
- getRepository() - Method in class com.facebook.buck.artifact_cache.AbstractNetworkCache
-
- getRepository() - Method in class com.facebook.buck.artifact_cache.ArtifactInfo
-
- getRepository() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getRepository() - Method in class com.facebook.buck.log.GlobalStateManager
-
- getRepository() - Method in class com.facebook.buck.log.InvocationInfo
-
- getRepository() - Method in class com.facebook.buck.util.network.RemoteLogBuckConfig
-
- getRepresentation() - Method in interface com.facebook.buck.rules.visibility.VisibilityPattern
-
User readable value for this pattern.
- getRequest() - Method in class com.facebook.buck.slb.HybridThriftRequestHandler
-
Get thrift request.
- getRequestCount() - Method in class com.facebook.buck.event.listener.LoadBalancerEventsListener.ServerCounters
-
- getRequestCount() - Method in class com.facebook.buck.util.cache.CacheStats
-
- getRequestDurationMillis() - Method in class com.facebook.buck.artifact_cache.HttpArtifactCacheEvent.Finished
-
- getRequestedRuleKey() - Method in interface com.facebook.buck.artifact_cache.HttpArtifactCacheEvent.HttpArtifactCacheEventFetchData
-
- getRequestErrorCount() - Method in class com.facebook.buck.event.listener.LoadBalancerEventsListener.ServerCounters
-
- getRequestLengthBytes() - Method in class com.facebook.buck.artifact_cache.ThriftArtifactCacheProtocol.Request
-
- getRequestProtocol() - Method in interface com.facebook.buck.doctor.DefectReporter.DefectSubmitResult
-
- getRequestSampleCount() - Method in class com.facebook.buck.slb.ServerHealthState
-
- getRequestSizeBytes() - Method in interface com.facebook.buck.artifact_cache.HttpArtifactCacheEvent.HttpArtifactCacheEventStoreData
-
- getRequestSizeBytes() - Method in class com.facebook.buck.event.listener.LoadBalancerEventsListener.ServerCounters
-
- getRequestSizeBytes() - Method in interface com.facebook.buck.slb.LoadBalancedServiceEvent.LoadBalancedServiceEventData
-
- getRequestSuccessful() - Method in interface com.facebook.buck.doctor.config.DoctorJsonResponse
-
- getRequestTimeoutCount() - Method in class com.facebook.buck.event.listener.LoadBalancerEventsListener.ServerCounters
-
- getRequiredBufferCapacity() - Method in class com.facebook.buck.apple.clang.HeaderMap
-
- getRequiredBuildTarget(String, String, TargetConfiguration) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getRequiredBuildTargets() - Method in class com.facebook.buck.features.apple.project.ProjectGenerator
-
- getRequiredBuildTargets() - Method in class com.facebook.buck.features.apple.project.WorkspaceAndProjectGenerator
-
- getRequiredBuildTargets() - Method in class com.facebook.buck.features.apple.projectV2.WorkspaceAndProjectGenerator
-
- getRequiredData() - Method in class com.facebook.buck.rules.modern.builders.RemoteExecutionActionInfo
-
- getRequiredForSourceOnlyAbi() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getRequiredForSourceOnlyAbi() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getRequiredForSourceOnlyAbi() - Method in class com.facebook.buck.android.AndroidPrebuiltAarDescriptionArg
-
- getRequiredForSourceOnlyAbi() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getRequiredForSourceOnlyAbi() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getRequiredForSourceOnlyAbi() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getRequiredForSourceOnlyAbi() - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getRequiredForSourceOnlyAbi() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getRequiredForSourceOnlyAbi() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getRequiredForSourceOnlyAbi() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getRequiredForSourceOnlyAbi() - Method in interface com.facebook.buck.jvm.java.MaybeRequiredForSourceOnlyAbi
-
- getRequiredForSourceOnlyAbi() - Method in interface com.facebook.buck.jvm.java.MaybeRequiredForSourceOnlyAbiArg
-
- getRequiredForSourceOnlyAbi() - Method in class com.facebook.buck.jvm.java.PrebuiltJar
-
- getRequiredForSourceOnlyAbi() - Method in class com.facebook.buck.jvm.java.PrebuiltJarDescriptionArg
-
- getRequiredForSourceOnlyAbi() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getRequiredForSourceOnlyAbi() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getRequiredForSourceOnlyAbi() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getRequiredForSourceOnlyAbi() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getRequiredPackageables(BuildRuleResolver) - Method in class com.facebook.buck.android.AndroidResource
-
- getRequiredPackageables(BuildRuleResolver) - Method in class com.facebook.buck.android.NdkLibrary
-
- getRequiredPackageables(BuildRuleResolver) - Method in interface com.facebook.buck.android.packageable.AndroidPackageable
-
Get the set of packagables that need to be included in any package that includes this object.
- getRequiredPackageables(BuildRuleResolver) - Method in class com.facebook.buck.android.PrebuiltNativeLibrary
-
- getRequiredPackageables(BuildRuleResolver) - Method in class com.facebook.buck.cxx.CxxLibraryGroup
-
- getRequiredPackageables(BuildRuleResolver) - Method in class com.facebook.buck.cxx.CxxPrecompiledHeaderTemplate
-
- getRequiredPackageables(BuildRuleResolver) - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescription.CustomPrebuiltCxxLibrary
-
- getRequiredPackageables(BuildRuleResolver) - Method in class com.facebook.buck.features.js.JsBundleAndroid
-
- getRequiredPackageables(BuildRuleResolver) - Method in class com.facebook.buck.features.js.JsBundleGenrule
-
- getRequiredPackageables(BuildRuleResolver) - Method in class com.facebook.buck.features.lua.SystemLuaCxxLibrary
-
- getRequiredPackageables(BuildRuleResolver) - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getRequiredPackageables(BuildRuleResolver) - Method in class com.facebook.buck.jvm.java.PrebuiltJar
-
- getRequiredPath(String, String) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getRequiredPaths(HasInstallableApk, Optional<Path>, Optional<Path>) - Static method in class com.facebook.buck.android.AndroidInstrumentationTest
-
- getRequiredPaths() - Method in class com.facebook.buck.android.exopackage.ExopackageInfo
-
- getRequiredPaths() - Method in class com.facebook.buck.core.test.rule.ExternalTestRunnerTestSpec
-
- getRequiredTool(String, String, BuildRuleResolver, TargetConfiguration) - Method in class com.facebook.buck.rules.tool.config.ToolConfig
-
- getRequiredValue(BuildTarget) - Method in class com.facebook.buck.core.model.FlavorDomain
-
- getRequireTargetPlatform() - Method in class com.facebook.buck.parser.config.ParserConfig
-
When set, requested target node will fail to configure if platform is not specified either
per-target with default_target_platform
or globally with --target-platforms=
command line flag.
- getRes() - Method in class com.facebook.buck.android.AndroidPrebuiltAar
-
- getRes() - Method in class com.facebook.buck.android.AndroidResource
-
- getRes() - Method in class com.facebook.buck.android.AndroidResourceDescriptionArg
-
- getRes() - Method in interface com.facebook.buck.android.HasAndroidResourceDeps
-
- getResDir() - Method in class com.facebook.buck.io.filesystem.BuckPaths
-
- getResDirectories() - Method in interface com.facebook.buck.android.FilteredResourcesProvider
-
- getResDirectories() - Method in class com.facebook.buck.android.IdentityResourcesProvider
-
- getResDirectories() - Method in class com.facebook.buck.android.ResourcesFilter
-
- getReSessionId() - Method in interface com.facebook.buck.remoteexecution.event.listener.model.ReSessionData
-
- getReSessionLabel() - Method in class com.facebook.buck.remoteexecution.config.RemoteExecutionConfig
-
- getReSessionLabel() - Method in interface com.facebook.buck.remoteexecution.event.listener.model.ReSessionData
-
- getResolvedIncludeRoot(SourcePathResolverAdapter) - Method in class com.facebook.buck.cxx.CxxHeaders
-
- getResolvedIncludeRoot(SourcePathResolverAdapter) - Method in class com.facebook.buck.cxx.CxxRawHeaders
-
- getResolvedIncludeRoot(SourcePathResolverAdapter) - Method in class com.facebook.buck.cxx.CxxSymlinkTreeHeaders
-
- getResolvedNdkCxxPlatforms(BuildRuleResolver) - Method in class com.facebook.buck.android.toolchain.ndk.NdkCxxPlatformsProvider
-
- getResolvedPath() - Method in class com.facebook.buck.core.sourcepath.ExplicitBuildTargetSourcePath
-
- getResolvedQuery() - Method in class com.facebook.buck.rules.query.Query
-
- getResolvedSymlinks(SourcePathResolverAdapter) - Method in class com.facebook.buck.core.rules.impl.SymlinkTree
-
- getResolver() - Method in class com.facebook.buck.core.sourcepath.resolver.SourcePathResolverAdapter
-
- getResourceAllocationFairness() - Method in class com.facebook.buck.core.resources.ResourcesConfig
-
- getResourceAmountsForRule(BuildRule) - Method in class com.facebook.buck.core.build.engine.config.ResourceAwareSchedulingInfo
-
- getResourceAmountsPerRuleType() - Method in class com.facebook.buck.core.resources.ResourcesConfig
-
- getResourceApk() - Method in class com.facebook.buck.android.ModuleInfo
-
- getResourceAwareSchedulingInfo() - Method in class com.facebook.buck.core.build.engine.config.CachingBuildEngineBuckConfig
-
- getResourceCompression() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getResourceCompression() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getResourceCompression() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getResourceCompressionMode() - Method in class com.facebook.buck.android.AndroidBinary
-
- getResourceConsumption() - Method in class com.facebook.buck.util.perf.ProcessTracker.ProcessResourceConsumptionEvent
-
- getResourceDeps() - Method in class com.facebook.buck.android.UnsortedAndroidResourceDeps
-
- getResourceDetails() - Method in interface com.facebook.buck.android.packageable.AndroidPackageableCollection
-
- getResourceDirectories() - Method in class com.facebook.buck.android.packageable.AndroidPackageableCollection.ResourceDetails
-
A list of "res" directories that should be passed to the aapt command to build the APK,
sorted topologically.
- getResourceDirs() - Method in class com.facebook.buck.apple.AppleBundleResources
-
Directories that should be copied into the bundle as directories of files with the same name.
- getResourceDirsForDestination(AppleBundleDestination) - Method in class com.facebook.buck.apple.AppleBundleResources
-
- getResourceFactory() - Method in class com.facebook.buck.features.project.intellij.model.folders.JavaResourceFolder
-
- getResourceFactory() - Method in class com.facebook.buck.features.project.intellij.model.folders.JavaTestResourceFolder
-
- getResourceFactory() - Method in class com.facebook.buck.features.project.intellij.model.folders.ResourceFolder
-
- getResourceFiles() - Method in class com.facebook.buck.apple.AppleBundleResources
-
Files that are copied to the root of the resources subdirectory.
- getResourceFilesByHash(SourcePathResolverAdapter, ProjectFilesystem, Stream<ExopackagePathAndHash>) - Static method in class com.facebook.buck.android.exopackage.ResourcesExoHelper
-
Returns a map of hash to path for resource files.
- getResourceFilesForDestination(AppleBundleDestination) - Method in class com.facebook.buck.apple.AppleBundleResources
-
- getResourceFilter() - Method in class com.facebook.buck.android.AndroidBinary
-
- getResourceFilter() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getResourceFilter() - Method in class com.facebook.buck.android.AndroidBundle
-
- getResourceFilter() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getResourceFilterRule() - Method in interface com.facebook.buck.android.FilteredResourcesProvider
-
- getResourceFilterRule() - Method in class com.facebook.buck.android.IdentityResourcesProvider
-
- getResourceFilterRule() - Method in class com.facebook.buck.android.ResourcesFilter
-
- getResourceFolderFactory() - Method in enum com.facebook.buck.features.project.intellij.FolderTypeWithPackageInfo
-
- getResourceFolderType() - Method in class com.facebook.buck.features.project.intellij.model.folders.JavaResourceFolder
-
- getResourceFolderType() - Method in class com.facebook.buck.features.project.intellij.model.folders.JavaTestResourceFolder
-
- getResourceFolderType() - Method in class com.facebook.buck.features.project.intellij.model.folders.ResourceFolder
-
- getResourceGroup() - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg
-
- getResourceGroupMap() - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg
-
- getResourceIdentifier() - Method in class com.facebook.buck.android.PackagedResource
-
Use this as unique ID for resource when hashing is not enabled
- getResourceName(String, Protocol.Digest) - Static method in class com.facebook.buck.remoteexecution.grpc.GrpcRemoteExecutionClients
-
- getResourcePaths(Collection<SourcePath>) - Method in class com.facebook.buck.features.project.intellij.BaseIjModuleRule
-
- getResourcePaths(Collection<SourcePath>, Path) - Method in class com.facebook.buck.features.project.intellij.BaseIjModuleRule
-
- getResourcePaths() - Method in class com.facebook.buck.features.project.intellij.model.IjModuleAndroidFacet
-
- getResourceRef(int) - Method in class com.facebook.buck.android.resources.ResTableType
-
- getResources() - Method in class com.facebook.buck.android.aapt.RDotTxtResourceCollector
-
- getResources() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getResources() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getResources() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getResources() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getResources() - Method in class com.facebook.buck.features.dotnet.CsharpLibraryDescriptionArg
-
- getResources() - Method in class com.facebook.buck.features.go.GoBinaryDescriptionArg
-
- getResources() - Method in class com.facebook.buck.features.go.GoTestDescriptionArg
-
- getResources() - Method in interface com.facebook.buck.features.go.HasGoLinkable
-
- getResources() - Method in class com.facebook.buck.features.python.PythonLibraryDescriptionArg
-
- getResources() - Method in class com.facebook.buck.features.python.PythonPackageComponents
-
- getResources() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getResources() - Method in interface com.facebook.buck.jvm.core.JavaLibrary
-
- getResources() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getResources() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getResources() - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getResources() - Method in class com.facebook.buck.jvm.java.JarBuildStepsFactory
-
- getResources() - Method in interface com.facebook.buck.jvm.java.JavaLibraryDescription.CoreArg
-
- getResources() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getResources() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getResources() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getResources() - Method in class com.facebook.buck.jvm.java.PrebuiltJar
-
- getResources() - Method in class com.facebook.buck.jvm.java.ResourcesParameters
-
- getResources() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getResources() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getResources() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getResources() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getResources() - Method in class com.facebook.buck.shell.ShBinaryDescriptionArg
-
- getResources() - Method in class com.facebook.buck.shell.ShTestDescriptionArg
-
- getResourcesFromDeps() - Method in class com.facebook.buck.apple.AppleResourceDescriptionArg
-
- getResourcesGraphEnhancer() - Method in class com.facebook.buck.android.AndroidBinaryGraphEnhancer
-
- getResourcesInfo() - Method in class com.facebook.buck.android.exopackage.ExopackageInfo
-
- getResourcesParameters() - Method in class com.facebook.buck.jvm.java.JarBuildStepsFactory
-
- getResourcesPaths() - Method in interface com.facebook.buck.android.exopackage.ExopackageInfo.ResourcesInfo
-
- getResourcesRoot() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getResourcesRoot() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getResourcesRoot() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getResourcesRoot() - Method in class com.facebook.buck.features.project.intellij.model.folders.ResourceFolder
-
- getResourcesRoot() - Method in interface com.facebook.buck.jvm.core.JavaLibrary
-
- getResourcesRoot() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getResourcesRoot() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getResourcesRoot() - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getResourcesRoot() - Method in class com.facebook.buck.jvm.java.JarBuildStepsFactory
-
- getResourcesRoot() - Method in interface com.facebook.buck.jvm.java.JavaLibraryDescription.CoreArg
-
- getResourcesRoot() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getResourcesRoot() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getResourcesRoot() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getResourcesRoot() - Method in class com.facebook.buck.jvm.java.PrebuiltJar
-
- getResourcesRoot() - Method in class com.facebook.buck.jvm.java.ResourcesParameters
-
- getResourcesRoot() - Method in class com.facebook.buck.jvm.java.ResourcesRootPackageFinder
-
- getResourcesRoot() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getResourcesRoot() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getResourcesRoot() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getResourcesRoot() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getResourcesRootFromFolder(IjFolder) - Method in enum com.facebook.buck.features.project.intellij.model.folders.IjResourceFolderType
-
- getResourcesRootsToResources(JavaPackageFinder, ImmutableSet<Path>) - Method in class com.facebook.buck.features.project.intellij.BaseIjModuleRule
-
- getResourcesWithEmptyResButNonEmptyAssetsDir() - Method in class com.facebook.buck.android.packageable.AndroidPackageableCollection.ResourceDetails
-
- getResourcesWithNonEmptyResDir() - Method in class com.facebook.buck.android.packageable.AndroidPackageableCollection.ResourceDetails
-
A list of build targets belonging to
AndroidResource
s with
non-empty "res" directory, sorted topologically.
- getResourceType() - Method in class com.facebook.buck.android.resources.ResTableTypeSpec
-
- getResourceTypeName(ResTablePackage) - Method in class com.facebook.buck.android.resources.ResTableTypeSpec
-
- getResourceUnion() - Method in class com.facebook.buck.android.AndroidResourceDescriptionArg
-
- getResourceUnionPackage() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getResourceUnionPackage() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getResourceUnionPackage() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getResourceUnionPackage() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getResourceUnionPackage() - Method in interface com.facebook.buck.android.AndroidLibraryDescription.CoreArg
-
- getResourceUnionPackage() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getResourceUnionPackage() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getResourceVariantFiles() - Method in class com.facebook.buck.apple.AppleBundleResources
-
Resource files with localization variants.
- getResponse() - Method in class com.facebook.buck.slb.HybridThriftResponseHandler
-
The thrift response.
- getResponse() - Method in class com.facebook.buck.slb.OkHttpResponseWrapper
-
- getResponseBody() - Method in class com.facebook.buck.util.network.HttpResponse
-
- getResponseSizeBytes() - Method in class com.facebook.buck.artifact_cache.HttpArtifactCacheBinaryProtocol.MetadataAndPayloadReadResult
-
- getResponseSizeBytes() - Method in interface com.facebook.buck.artifact_cache.HttpArtifactCacheEvent.HttpArtifactCacheEventFetchData
-
- getResponseSizeBytes() - Method in class com.facebook.buck.event.listener.LoadBalancerEventsListener.ServerCounters
-
- getResponseSizeBytes() - Method in interface com.facebook.buck.slb.LoadBalancedServiceEvent.LoadBalancedServiceEventData
-
- getRestartAdbOnFailure() - Method in class com.facebook.buck.android.exopackage.AdbConfig
-
- getRestartAllStreamingCalls() - Method in class com.facebook.buck.remoteexecution.grpc.retry.RetryPolicy
-
- getResult() - Method in class com.facebook.buck.core.build.engine.BuildEngine.BuildEngineResult
-
- getResult() - Method in interface com.facebook.buck.remoteexecution.RemoteExecutionServiceClient.ExecutionHandle
-
- getResultClass() - Method in class com.facebook.buck.rules.coercer.AbstractParamInfo
-
- getResultClass() - Method in interface com.facebook.buck.rules.coercer.ParamInfo
-
- getResultFile(File) - Method in class com.facebook.buck.testrunner.BuckXmlTestRunListener
-
Creates a
File
where the report will be created.
- getResultForMatcher(ChromeTraceParser.ChromeTraceEventMatcher<T>, Map<ChromeTraceParser.ChromeTraceEventMatcher<?>, Object>) - Static method in class com.facebook.buck.util.trace.ChromeTraceParser
-
- getResultFuture() - Method in class com.facebook.buck.core.graph.transformation.executor.DepsAwareTask
-
- getResults() - Method in class com.facebook.buck.core.test.event.IndividualTestEvent.Finished
-
- getResults() - Method in class com.facebook.buck.core.test.event.TestRunEvent.Finished
-
- getResults() - Method in interface com.facebook.buck.event.external.events.IndividualTestEventFinishedExternalInterface
-
- getResults() - Method in interface com.facebook.buck.event.external.events.TestRunFinishedEventInterface
-
- getResultString() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.Finished
-
- getResultSummaryVerbosity() - Method in class com.facebook.buck.test.config.TestBuckConfig
-
- getResultTypeClass() - Method in class com.facebook.buck.core.graph.transformation.model.ClassBasedComputationIdentifier
-
- getResultTypeClass() - Method in class com.facebook.buck.core.graph.transformation.model.ComposedComputationIdentifier
-
- getResultTypeClass() - Method in interface com.facebook.buck.core.graph.transformation.model.ComputationIdentifier
-
- getRetrievalTime() - Method in class com.facebook.buck.util.cache.CacheStats
-
- getReusedNodeCount() - Method in class com.facebook.buck.event.ActionGraphEvent.IncrementalLoad
-
- getReverseDeps(Iterable<QueryBuildTarget>) - Method in class com.facebook.buck.cli.BuckQueryEnvironment
-
- getReverseDeps(Iterable<NODE_TYPE>) - Method in interface com.facebook.buck.query.QueryEnvironment
-
Returns the direct reverse dependencies of the specified targets.
- getReverseDeps(Iterable<NODE_TYPE>) - Method in class com.facebook.buck.query.TargetVariablesQueryEnvironment
-
- getReverseDeps(Iterable<QueryBuildTarget>) - Method in class com.facebook.buck.rules.query.GraphEnhancementQueryEnvironment
-
- getRevisionIdOffTracked() - Method in interface com.facebook.buck.doctor.config.SourceControlInfo
-
- getRevisionTimestampOffTracked() - Method in interface com.facebook.buck.doctor.config.SourceControlInfo
-
- getRewriteDepsFile() - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg
-
- getRewriteMisc() - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg
-
- getRewriteSourcemap() - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg
-
- getRight() - Method in class com.facebook.buck.util.types.Either
-
Returns the right value.
- getRightOption() - Method in class com.facebook.buck.util.types.Either
-
Right value or empty otherwise.
- getRlib() - Method in class com.facebook.buck.features.rust.PrebuiltRustLibraryDescriptionArg
-
- getRobolectricManifest() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getRobolectricRuntimeDependency() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getRoot() - Method in interface com.facebook.buck.core.cell.Cell
-
- getRoot() - Method in class com.facebook.buck.core.cell.impl.DefaultCellPathResolver
-
- getRoot() - Method in interface com.facebook.buck.core.filesystems.AbsPath
-
Get the filesystem root of the current path.
- getRoot() - Method in class com.facebook.buck.core.filesystems.BuckUnixPath
-
- getRoot() - Method in class com.facebook.buck.core.rules.impl.SymlinkTree
-
- getRoot() - Method in class com.facebook.buck.cxx.CxxHeaders
-
- getRoot() - Method in class com.facebook.buck.cxx.CxxHeadersDir
-
- getRoot() - Method in class com.facebook.buck.cxx.CxxRawHeaders
-
- getRoot() - Method in class com.facebook.buck.cxx.CxxSymlinkTreeHeaders
-
- getRoot() - Method in interface com.facebook.buck.remoteexecution.interfaces.Protocol.Tree
-
- getRootAPKModule() - Method in class com.facebook.buck.android.apkmodule.APKModuleGraph
-
Get the APKModule representing the core application that is always included in the apk
- getRootCause(Throwable) - Static method in interface com.facebook.buck.core.exceptions.WrapsException
-
Unwraps exception to the root cause.
- getRootCause() - Method in class com.facebook.buck.util.ErrorLogger.DeconstructedException
-
- getRootCell() - Method in class com.facebook.buck.core.cell.CellProvider
-
- getRootCell() - Method in class com.facebook.buck.core.cell.Cells
-
- getRootDirectories() - Method in class com.facebook.buck.core.filesystems.BuckFileSystem
-
- getRootPath() - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- getRootPath() - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystemView
-
- getRootPath() - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystem
-
- getRootPath() - Method in interface com.facebook.buck.io.filesystem.ProjectFilesystemView
-
- getRootPath() - Method in class com.facebook.buck.rules.modern.DefaultOutputPathResolver
-
- getRootPath() - Method in interface com.facebook.buck.rules.modern.OutputPathResolver
-
Returns a relative path to the root directory for build outputs.
- getRoots() - Method in class com.facebook.buck.cxx.Omnibus.OmnibusLibraries
-
- getRootSourcePath() - Method in class com.facebook.buck.core.rules.impl.SymlinkTree
-
- getRotateLog() - Method in class com.facebook.buck.log.LogConfigSetup
-
- getRound() - Method in class com.facebook.buck.jvm.java.AnnotationProcessingEvent
-
- getRule() - Method in class com.facebook.buck.core.build.engine.BuildResult
-
- getRule() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.WillBuildLocally
-
- getRule(BuildTarget) - Method in interface com.facebook.buck.core.rules.BuildRuleResolver
-
Returns the BuildRule
associated with the buildTarget
.
- getRule(BuildTarget, Class<R>, DependencyStack) - Method in interface com.facebook.buck.core.rules.config.ConfigurationRuleResolver
-
- getRule(BuildTarget, Class<R>, DependencyStack) - Method in class com.facebook.buck.core.rules.config.impl.SameThreadConfigurationRuleResolver
-
- getRule(BuildTarget) - Method in class com.facebook.buck.core.rules.impl.AbstractBuildRuleResolver
-
- getRule(SourcePath) - Method in class com.facebook.buck.core.rules.impl.AbstractBuildRuleResolver
-
- getRule(BuildTargetSourcePath) - Method in class com.facebook.buck.core.rules.impl.AbstractBuildRuleResolver
-
- getRule(SourcePath) - Method in class com.facebook.buck.core.rules.impl.DefaultSourcePathRuleFinder
-
- getRule(BuildTargetSourcePath) - Method in class com.facebook.buck.core.rules.impl.DefaultSourcePathRuleFinder
-
- getRule(SourcePath) - Method in interface com.facebook.buck.core.rules.SourcePathRuleFinder
-
- getRule(BuildTargetSourcePath) - Method in interface com.facebook.buck.core.rules.SourcePathRuleFinder
-
- getRule(String) - Method in class com.facebook.buck.core.starlark.knowntypes.KnownUserDefinedRuleTypes
-
Get a rule based on its name
- getRule() - Method in class com.facebook.buck.core.starlark.rule.SkylarkDescriptionArg
-
Get the
SkylarkDescriptionArg
that has information about parameters and the user's
implementation function
- getRuleCacheResult() - Method in class com.facebook.buck.core.build.engine.manifest.ManifestFetchResult
-
- getRuleClass() - Method in class com.facebook.buck.android.toolchain.platform.AndroidPlatformDescription
-
- getRuleClass() - Method in interface com.facebook.buck.core.rules.config.ConfigurationRuleDescription
-
Reified type parameter
- getRuleClass() - Method in class com.facebook.buck.core.rules.configsetting.ConfigSettingDescription
-
- getRuleClass() - Method in class com.facebook.buck.core.rules.platform.ConstraintSettingDescription
-
- getRuleClass() - Method in class com.facebook.buck.core.rules.platform.ConstraintValueDescription
-
- getRuleClass() - Method in class com.facebook.buck.core.rules.platform.PlatformDescription
-
- getRuleContext() - Method in interface com.facebook.buck.rules.modern.builders.RemoteExecutionStrategy.RemoteExecutionStrategyBuildResult
-
- getRuleCount() - Method in class com.facebook.buck.event.listener.stats.cache.CacheRateStatsKeeper
-
- getRuleDepsCache() - Method in class com.facebook.buck.core.rulekey.calculator.ParallelRuleKeyCalculator
-
- getRuleFinder() - Method in interface com.facebook.buck.rules.modern.InputRuleResolver.UnsafeInternals
-
- getRuleFlags() - Method in class com.facebook.buck.cxx.CxxToolFlags
-
Flags that succeed flags from #getPlatformFlags()
.
- getRuleFlags() - Method in class com.facebook.buck.cxx.ExplicitCxxToolFlags
-
- getRuleKey() - Method in class com.facebook.buck.artifact_cache.AbstractAsynchronousCache.FetchRequest
-
- getRuleKey(String) - Method in class com.facebook.buck.core.build.engine.buildinfo.DefaultOnDiskBuildInfo
-
- getRuleKey(String) - Method in interface com.facebook.buck.core.build.engine.buildinfo.OnDiskBuildInfo
-
Returns the
RuleKey
for the rule whose output is currently stored on disk.
- getRuleKey() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.Resumed
-
- getRuleKey() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.Suspended
-
- getRuleKey() - Method in interface com.facebook.buck.core.rulekey.BuildRuleKeys
-
- getRuleKey() - Method in interface com.facebook.buck.rules.keys.DependencyFileRuleKeyFactory.RuleKeyAndInputs
-
- getRuleKey() - Method in class com.facebook.buck.rules.keys.InputBasedRuleKeyFactory.Result
-
- getRuleKeyCacheCheckTimestamps() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.Finished
-
- getRuleKeyCacheResult() - Method in class com.facebook.buck.artifact_cache.RuleKeyCacheResultEvent
-
- getRuleKeyCaching() - Method in class com.facebook.buck.command.config.BuildBuckConfig
-
- getRuleKeyCalculator() - Method in class com.facebook.buck.core.build.engine.impl.CachingBuildEngine
-
- getRuleKeyConfiguration() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getRuleKeyConfiguration() - Method in class com.facebook.buck.command.BuildExecutorArgs
-
- getRuleKeyConfiguration() - Method in interface com.facebook.buck.core.toolchain.ToolchainCreationContext
-
- getRuleKeyDiagGraphFile() - Method in interface com.facebook.buck.doctor.config.BuildLogEntry
-
- getRuleKeyDiagKeysFile() - Method in interface com.facebook.buck.doctor.config.BuildLogEntry
-
- getRuleKeyDiagnosticsMode() - Method in class com.facebook.buck.core.build.execution.context.ExecutionContext
-
- getRuleKeyDiagnosticsMode() - Method in class com.facebook.buck.core.rulekey.config.RuleKeyConfig
-
- getRuleKeyLoggerLogFile() - Method in interface com.facebook.buck.doctor.config.BuildLogEntry
-
- getRuleKeys() - Method in class com.facebook.buck.artifact_cache.ArtifactCacheEvent
-
- getRuleKeys() - Method in class com.facebook.buck.artifact_cache.ArtifactInfo
-
- getRuleKeys() - Method in class com.facebook.buck.artifact_cache.HttpArtifactCacheBinaryProtocol.MetadataAndPayloadReadResult
-
- getRuleKeys() - Method in interface com.facebook.buck.artifact_cache.HttpArtifactCacheEvent.HttpArtifactCacheEventStoreData
-
- getRuleKeys() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.Finished
-
- getRuleKeys() - Method in class com.facebook.buck.event.ArtifactCompressionEvent
-
- getRulekeyTimeMs() - Method in class com.facebook.buck.log.PerfTimesStats
-
- getRuleName(T) - Method in interface com.facebook.buck.core.description.RuleDescriptionWithInstanceName
-
- getRuleName(SkylarkDescriptionArg) - Method in class com.facebook.buck.core.starlark.rule.SkylarkDescription
-
- getRuleName() - Method in interface com.facebook.buck.jvm.java.abi.source.api.SourceOnlyAbiRuleInfoFactory.SourceOnlyAbiRuleInfo
-
- getRuleOptional(BuildTarget) - Method in interface com.facebook.buck.core.rules.BuildRuleResolver
-
Returns the BuildRule
associated with the given BuildTarget
if it is already
present.
- getRuleOptional(BuildTarget) - Method in class com.facebook.buck.core.rules.resolver.impl.MultiThreadedActionGraphBuilder
-
- getRuleOptional(BuildTarget) - Method in class com.facebook.buck.core.rules.resolver.impl.RuleAnalysisCompatibleDelegatingActionGraphBuilder
-
- getRuleOptionalWithType(BuildTarget, Class<T>) - Method in interface com.facebook.buck.core.rules.BuildRuleResolver
-
Returns the BuildRule
associated with the given BuildTarget
if it is already
present, casting it to an expected type.
- getRuleOptionalWithType(BuildTarget, Class<T>) - Method in class com.facebook.buck.core.rules.impl.AbstractBuildRuleResolver
-
- getRules() - Method in class com.facebook.buck.android.relinker.NativeRelinker
-
- getRules() - Method in class com.facebook.buck.cxx.CxxPreprocessorInput
-
- getRuleScheduleInfo() - Method in interface com.facebook.buck.core.rules.schedule.OverrideScheduleRule
-
- getRuleScheduleInfo() - Method in class com.facebook.buck.cxx.CxxLink
-
- getRuleScheduleInfo() - Method in class com.facebook.buck.cxx.CxxThinLTOIndex
-
- getRulesInGraph(ActionGraphBuilder, Iterable<BuildTarget>) - Static method in class com.facebook.buck.cli.AbstractPerfCommand
-
Gets a list of the rules in the graph reachable from the provided targets.
- getRulesToBuild(Iterable<? extends BuildTarget>) - Method in class com.facebook.buck.command.Build
-
* Converts given BuildTargetPaths into BuildRules
- getRulesToExcludeFromDex() - Method in class com.facebook.buck.android.AndroidBinary
-
- getRuleType() - Method in interface com.facebook.buck.cli.ActionGraphSerializer.ActionGraphData
-
- getRuleType(Class<? extends BaseDescription<?>>) - Static method in class com.facebook.buck.core.description.impl.DescriptionCache
-
- getRuleType(BaseDescription<?>) - Static method in class com.facebook.buck.core.description.impl.DescriptionCache
-
- getRuleType() - Method in class com.facebook.buck.core.model.targetgraph.impl.ImmutableUnconfiguredTargetNode
-
- getRuleType() - Method in class com.facebook.buck.core.model.targetgraph.impl.TargetNodeImpl
-
- getRuleType() - Method in class com.facebook.buck.core.model.targetgraph.MergedTargetNode
-
- getRuleType() - Method in interface com.facebook.buck.core.model.targetgraph.raw.UnconfiguredTargetNode
-
The type of a rule.
- getRuleType() - Method in interface com.facebook.buck.core.model.targetgraph.TargetNode
-
- getRuleType() - Method in class com.facebook.buck.core.rules.knowntypes.RuleDescriptor
-
- getRuleType() - Method in interface com.facebook.buck.cxx.toolchain.nativelink.LegacyNativeLinkableGroup
-
Deprecated.
- getRuleType() - Method in interface com.facebook.buck.cxx.toolchain.nativelink.NativeLinkable
-
- getRuleType() - Method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableInfo
-
- getRuleType() - Method in class com.facebook.buck.cxx.toolchain.nativelink.PlatformLockedNativeLinkableGroup
-
- getRuleWithType(BuildTarget, Class<T>) - Method in interface com.facebook.buck.core.rules.BuildRuleResolver
-
Returns the BuildRule
associated with the buildTarget
, casting it to an
expected type.
- getRuleWithType(BuildTarget, Class<T>) - Method in class com.facebook.buck.core.rules.impl.AbstractBuildRuleResolver
-
- getRunInfo() - Method in class com.facebook.buck.core.rules.tool.RunInfoLegacyTool
-
- getRunInfo(DependencyOnlyRuleAnalysisContext, TargetConfiguration) - Method in class com.facebook.buck.core.toolchain.toolprovider.impl.BinaryBuildRuleToolProvider
-
- getRunInfo(DependencyOnlyRuleAnalysisContext, TargetConfiguration) - Method in class com.facebook.buck.core.toolchain.toolprovider.impl.SystemToolProvider
-
- getRunInfo(DependencyOnlyRuleAnalysisContext, TargetConfiguration) - Method in interface com.facebook.buck.core.toolchain.toolprovider.RuleAnalysisLegacyToolProvider
-
- getRunnablePath() - Method in class com.facebook.buck.apple.xcode.XCScheme.LaunchAction
-
- getRunner() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getRunner() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getRunner() - Method in interface com.facebook.buck.core.test.rule.HasTestRunner
-
- getRunner() - Method in class com.facebook.buck.features.go.GoTestDescriptionArg
-
- getRunner() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getRunner() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getRunTestSeparately() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getRunTestSeparately() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getRunTestSeparately() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getRunTestSeparately() - Method in class com.facebook.buck.features.go.GoTestDescriptionArg
-
- getRunTestSeparately() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getRunTestSeparately() - Method in interface com.facebook.buck.jvm.java.JavaTestDescription.CoreArg
-
- getRunTestSeparately() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getRunTestSeparately() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getRunTestSeparately() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getRunTestSeparately() - Method in class com.facebook.buck.shell.ShTestDescriptionArg
-
- getRuntimeClasspath(BuildContext) - Method in class com.facebook.buck.jvm.java.JavaTest
-
- getRuntimeClasspath(BuildContext) - Method in class com.facebook.buck.jvm.java.JavaTestX
-
- getRuntimeDeps() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.android.AndroidBinary
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.android.AndroidBinaryNonExoInstaller
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.android.AndroidBundle
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.android.AndroidInstrumentationApk
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.android.AndroidInstrumentationTest
-
- getRuntimeDeps() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.android.AndroidPrebuiltAar
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.android.ApkGenrule
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.android.RobolectricTest
-
- getRuntimeDeps() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.android.RobolectricTestX
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.android.UnstrippedNativeLibraries
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.apple.AppleBundle
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.apple.AppleDebuggableBinary
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.apple.AppleTest
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.apple.AppleTestX
-
- getRuntimeDeps() - Method in interface com.facebook.buck.cli.ActionGraphSerializer.ActionGraphData
-
- getRuntimeDeps(BuildRule) - Method in class com.facebook.buck.core.build.engine.impl.DefaultRuleDepsCache
-
- getRuntimeDeps(BuildEngineAction) - Method in class com.facebook.buck.core.build.engine.impl.DefaultRuleDepsCache
-
- getRuntimeDeps(BuildRule) - Method in interface com.facebook.buck.core.build.engine.RuleDepsCache
-
- getRuntimeDeps(BuildEngineAction) - Method in interface com.facebook.buck.core.build.engine.RuleDepsCache
-
- getRuntimeDeps(BuildRuleResolver) - Method in interface com.facebook.buck.core.rules.attr.HasRuntimeDeps
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.core.rules.impl.DependencyAggregation
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.core.rules.impl.SymlinkTree
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.core.rules.tool.BinaryWrapperRule
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.cxx.CxxBinary
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.cxx.CxxCompilationDatabase
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.cxx.CxxLibraryGroup
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.cxx.CxxTest
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.features.d.DBinary
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.features.d.DTest
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.features.go.GoBinary
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.features.go.GoTest
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.features.go.GoTestX
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.features.js.JsBundleGenrule
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.features.lua.LuaBinary
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.features.ocaml.OcamlBinary
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.features.python.PythonBinary
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.features.python.PythonInPlaceBinary
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.features.python.PythonLibrary
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.features.python.PythonPackagedBinary
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.features.python.PythonTest
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.features.python.PythonTestX
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.features.rust.RustTest
-
- getRuntimeDeps() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getRuntimeDeps() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.jvm.java.JavaBinary
-
- getRuntimeDeps() - Method in class com.facebook.buck.jvm.java.JavaLibraryDeps
-
- getRuntimeDeps() - Method in interface com.facebook.buck.jvm.java.JavaLibraryDescription.CoreArg
-
- getRuntimeDeps() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.jvm.java.JavaTest
-
- getRuntimeDeps() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getRuntimeDeps() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.jvm.java.JavaTestX
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.jvm.java.PrebuiltJar
-
- getRuntimeDeps() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getRuntimeDeps() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getRuntimeDeps() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getRuntimeDeps() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.shell.CommandAlias
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.shell.DefaultWorkerToolRule
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.shell.ExportFile
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.shell.ShBinary
-
- getRuntimeDeps(BuildRuleResolver) - Method in class com.facebook.buck.shell.ShTest
-
- getRuntimeLdflags() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getRuntimePathsForBundling() - Method in class com.facebook.buck.swift.SwiftToolchainDescriptionArg
-
Runtime paths for bundling.
- getRuntimePathsForLinking() - Method in class com.facebook.buck.swift.SwiftToolchainDescriptionArg
-
Runtime paths for linking.
- getRuntimeRunPaths() - Method in class com.facebook.buck.swift.SwiftToolchainDescriptionArg
-
Runtime run paths.
- getRustcBinaryFlags(String) - Method in class com.facebook.buck.features.rust.RustBuckConfig
-
Get rustc flags for rust_binary() rules.
- getRustcCheckFlags(String) - Method in class com.facebook.buck.features.rust.RustBuckConfig
-
Get rustc flags for #check flavored builds.
- getRustcFlags() - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg
-
- getRustcFlags() - Method in interface com.facebook.buck.features.rust.RustCommonArgs
-
- getRustcFlags() - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg
-
- getRustcFlags() - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg
-
- getRustcLibraryFlags(String) - Method in class com.facebook.buck.features.rust.RustBuckConfig
-
Get rustc flags for rust_library() rules.
- getRustCompiler(String) - Method in class com.facebook.buck.features.rust.RustBuckConfig
-
- getRustcTestFlags(String) - Method in class com.facebook.buck.features.rust.RustBuckConfig
-
Get rustc flags for rust_test() rules.
- getRustLinker(String) - Method in class com.facebook.buck.features.rust.RustBuckConfig
-
- getRustPlatform(RustToolchain, BuildTarget, HasDefaultPlatform) - Static method in class com.facebook.buck.features.rust.RustCompileUtils
-
- getRustPlatforms() - Method in interface com.facebook.buck.features.rust.RustToolchain
-
- getSandboxExecutionStrategy() - Method in interface com.facebook.buck.core.description.DescriptionCreationContext
-
- getSanitizedIncludePathFlags(DebugPathSanitizer, SourcePathResolverAdapter, PathShortener, Function<FrameworkPath, Path>, Preprocessor) - Method in class com.facebook.buck.cxx.PreprocessorFlags
-
- getSanitizeFunction() - Method in class com.facebook.buck.cxx.CxxSourceRuleFactory
-
- getSanitizer() - Method in class com.facebook.buck.rules.macros.StringWithMacrosConverter
-
- getScalac(BuildRuleResolver, TargetConfiguration) - Method in class com.facebook.buck.jvm.scala.ScalaBuckConfig
-
- getScalacTarget(TargetConfiguration) - Method in class com.facebook.buck.jvm.scala.ScalaBuckConfig
-
- getScalaLibraryTarget(TargetConfiguration) - Method in class com.facebook.buck.jvm.scala.ScalaBuckConfig
-
- getScaleStep() - Method in class com.facebook.buck.android.FilterResourcesSteps
-
- getScheduled() - Method in interface com.facebook.buck.event.listener.stats.cache.NetworkStatsTracker.RemoteArtifactUploadStats
-
- getScheduledCount() - Method in class com.facebook.buck.event.listener.stats.cache.RemoteCacheUploadStats
-
- getScheduledExecutor() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getScheduledTasks() - Method in class com.facebook.buck.support.bgtasks.AsyncBackgroundTaskManager
-
Return list of currently scheduled (not yet submitted) tasks.
- getScheduleType() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getScheme() - Method in class com.facebook.buck.core.filesystems.BuckFileSystemProvider
-
- getSchemeBuildableTargetNodes(XCodeDescriptions, TargetGraph, Optional<AppleDependenciesCache>, TargetNode<?>) - Static method in class com.facebook.buck.apple.AppleBuildRules
-
- getScratchDir(ProjectFilesystem, BuildTarget) - Static method in class com.facebook.buck.core.model.impl.BuildPaths
-
Return a path to a file in the buck-out/bin/ directory, formatted with the target short name.
- getScratchDir() - Method in class com.facebook.buck.io.filesystem.BuckPaths
-
- getScratchDirectory() - Method in class com.facebook.buck.android.SplitResources
-
- getScratchPath(ProjectFilesystem, BuildTarget, String) - Static method in class com.facebook.buck.core.model.impl.BuildTargetPaths
-
Deprecated.
Return a path to a file in the buck-out/bin/ directory.
- getScriptFileContents(ExecutionContext) - Method in class com.facebook.buck.shell.AbstractGenruleStep
-
- getScriptFilePath(ExecutionContext) - Method in class com.facebook.buck.shell.AbstractGenruleStep
-
- getScrubbers() - Method in interface com.facebook.buck.cxx.toolchain.Archiver
-
- getScrubbers() - Method in class com.facebook.buck.cxx.toolchain.BsdArchiver
-
- getScrubbers() - Method in class com.facebook.buck.cxx.toolchain.ClangWindowsArchiver
-
- getScrubbers() - Method in class com.facebook.buck.cxx.toolchain.GnuArchiver
-
- getScrubbers(ImmutableMap<Path, Path>) - Method in class com.facebook.buck.cxx.toolchain.linker.impl.DarwinLinker
-
- getScrubbers(ImmutableMap<Path, Path>) - Method in class com.facebook.buck.cxx.toolchain.linker.impl.GnuLinker
-
- getScrubbers(ImmutableMap<Path, Path>) - Method in class com.facebook.buck.cxx.toolchain.linker.impl.WindowsLinker
-
- getScrubbers(ImmutableMap<Path, Path>) - Method in interface com.facebook.buck.cxx.toolchain.linker.Linker
-
- getScrubbers() - Method in class com.facebook.buck.cxx.toolchain.WindowsArchiver
-
- getSdkName() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
Name of SDK which should be used.
- getSdkName(IjProjectConfig) - Method in enum com.facebook.buck.features.project.intellij.model.IjModuleType
-
- getSdkOrThrow() - Method in class com.facebook.buck.android.toolchain.impl.AndroidSdkDirectoryResolver
-
- getSdkPath() - Method in class com.facebook.buck.android.AndroidBuckConfig
-
- getSdkPath() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
Path to Apple SDK.
- getSdkPath() - Method in class com.facebook.buck.apple.toolchain.AppleSdkPaths
-
Absolute path to tools and files which depend on a particular SDK on a particular platform.
- getSdkPathConfigOptionFromSearchOrderEntry(String) - Method in class com.facebook.buck.android.AndroidBuckConfig
-
Given the entry to from the order of search of the Android SDK location returns the name of the
configuration option that contains SDK path if the entry instructs to get that value from
.buckconfig
(i.e.
- getSdkPathSearchOrder() - Method in class com.facebook.buck.android.AndroidBuckConfig
-
Defines the order of search of the path to Android SDK.
- getSdkRootPath() - Method in interface com.facebook.buck.android.toolchain.AndroidSdkLocation
-
- getSdkType(IjProjectConfig) - Method in enum com.facebook.buck.features.project.intellij.model.IjModuleType
-
- getSecond() - Method in class com.facebook.buck.util.types.Pair
-
- getSecondaryDexHeadClassesFile() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getSecondaryDexHeadClassesFile() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getSecondaryDexTailClassesFile() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getSecondaryDexTailClassesFile() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getSection(String) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getSection() - Method in interface com.facebook.buck.cxx.toolchain.elf.Elf.ElfSectionLookupResult
-
- getSection(String) - Method in class com.facebook.buck.util.config.RawConfig
-
Retrieve a section by name.
- getSectionByIndex(int) - Method in class com.facebook.buck.cxx.toolchain.elf.Elf
-
- getSectionByName(String) - Method in class com.facebook.buck.cxx.toolchain.elf.Elf
-
- getSectionForPlatform(UnresolvedCxxPlatform) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getSectionName(ElfSectionHeader) - Method in class com.facebook.buck.cxx.toolchain.elf.Elf
-
- getSections() - Method in class com.facebook.buck.core.config.BuckConfig
-
- getSectionToEntries() - Method in class com.facebook.buck.util.config.Config
-
- getSeed() - Method in class com.facebook.buck.rules.keys.config.RuleKeyConfiguration
-
The seed of all rule keys.
- getSeedConfigMap() - Method in class com.facebook.buck.android.apkmodule.APKModuleGraph
-
- getSegmentsUnsafe() - Method in class com.facebook.buck.core.filesystems.BuckUnixPath
-
Access path segments.
- getSelectable(BuildTarget, DependencyStack) - Method in class com.facebook.buck.core.rules.config.impl.ConfigurationRuleSelectableResolver
-
- getSelectable() - Method in class com.facebook.buck.core.rules.configsetting.ConfigSettingRule
-
- getSelectable() - Method in interface com.facebook.buck.core.select.ProvidesSelectable
-
Returns a
Selectable
that can be used during evaluation of conditions in a
select
statement.
- getSelectable(BuildTarget, DependencyStack) - Method in interface com.facebook.buck.core.select.SelectableResolver
-
- getSelectedVersions() - Method in class com.facebook.buck.core.model.targetgraph.impl.TargetNodeImpl
-
- getSelectedVersions() - Method in interface com.facebook.buck.core.model.targetgraph.TargetNode
-
- getSelectedVersions(BuildTarget) - Method in class com.facebook.buck.versions.TargetNodeTranslator
-
- getSelectors() - Method in class com.facebook.buck.core.select.SelectorList
-
- getSeparator() - Method in class com.facebook.buck.core.filesystems.BuckFileSystem
-
- getSequenceNumber() - Method in class com.facebook.buck.test.TestResults
-
- getSerialNumber() - Method in class com.facebook.buck.android.device.TargetDeviceOptions
-
- getSerialNumber() - Method in interface com.facebook.buck.android.exopackage.AndroidDevice
-
- getSerialNumber() - Method in class com.facebook.buck.android.exopackage.RealAndroidDevice
-
- getSerialNumber() - Method in class com.facebook.buck.cli.TargetDeviceCommandLineOptions
-
- getServedLocalCache() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getServer() - Method in interface com.facebook.buck.slb.LoadBalancedServiceEvent.LoadBalancedServiceEventData
-
- getServer() - Method in interface com.facebook.buck.slb.LoadBalancerPingEvent.PerServerPingData
-
- getServer() - Method in class com.facebook.buck.slb.ServerHealthManagerEvent.PerServerData
-
- getServer() - Method in class com.facebook.buck.slb.ServerHealthState
-
- getServerNotHealthyCount() - Method in class com.facebook.buck.event.listener.LoadBalancerEventsListener.ServerCounters
-
- getServerPoolName() - Method in class com.facebook.buck.slb.ServerHealthManagerEvent.ServerHealthManagerEventData
-
- getService() - Method in class com.facebook.buck.slb.HybridThriftOverHttpServiceImplArgs
-
- getService() - Method in class com.facebook.buck.slb.ThriftOverHttpServiceConfig
-
- getServices() - Method in class com.facebook.buck.remoteexecution.grpc.GrpcRemoteExecutionServiceServer
-
- getSet() - Method in class com.facebook.buck.core.model.FlavorSet
-
- getSetter() - Method in class com.facebook.buck.rules.coercer.ReflectionParamInfo
-
- getSettings() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXBuildFile
-
- getSetupStepsForBuildable(BuildContext, ProjectFilesystem, Iterable<Path>, ImmutableList.Builder<Step>, OutputPathResolver) - Static method in class com.facebook.buck.rules.modern.ModernBuildRule
-
Gets the steps for preparing the output directories of the build rule.
- getSHA1(String, List<String>) - Method in interface com.facebook.buck.edenfs.EdenClient
-
- getSha1(Path) - Method in class com.facebook.buck.edenfs.EdenMount
-
- getSha1() - Method in class com.facebook.buck.file.RemoteFileDescriptionArg
-
- getSha256() - Method in class com.facebook.buck.file.HttpArchiveDescriptionArg
-
- getSha256() - Method in class com.facebook.buck.file.HttpFileDescriptionArg
-
- getSharedDepRuntimeLdFlags() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
Flags for linking the c/c++ runtime for shared libraries.
- getSharedLib() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getSharedLibFlag() - Method in class com.facebook.buck.cxx.toolchain.linker.impl.DarwinLinker
-
- getSharedLibFlag() - Method in class com.facebook.buck.cxx.toolchain.linker.impl.GnuLinker
-
- getSharedLibFlag() - Method in class com.facebook.buck.cxx.toolchain.linker.impl.WindowsLinker
-
- getSharedLibFlag() - Method in interface com.facebook.buck.cxx.toolchain.linker.Linker
-
- getSharedLibraries(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.apple.PrebuiltAppleFramework
-
- getSharedLibraries(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.cxx.CxxLibraryGroup
-
- getSharedLibraries(BuildTarget, ProjectFilesystem, BuildRuleParams, CellPathResolver, ActionGraphBuilder, CxxBuckConfig, CxxPlatform, ImmutableList<? extends Arg>, Iterable<? extends NativeLinkTarget>, Iterable<? extends NativeLinkable>) - Static method in class com.facebook.buck.cxx.Omnibus
-
An alternate link strategy for languages which need to package native deps up as shared
libraries, which only links native nodes which have an explicit edge from non-native code as
separate, and statically linking all other native nodes into a single giant shared library.
- getSharedLibraries(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescription.CustomPrebuiltCxxLibrary
-
- getSharedLibraries(CxxPlatform, ActionGraphBuilder) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.LegacyNativeLinkableGroup
-
Deprecated.
- getSharedLibraries(ActionGraphBuilder) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.NativeLinkable
-
- getSharedLibraries(ActionGraphBuilder) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableInfo.Delegate
-
- getSharedLibraries(ActionGraphBuilder) - Method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableInfo
-
- getSharedLibraries(ActionGraphBuilder) - Method in class com.facebook.buck.cxx.toolchain.nativelink.PlatformLockedNativeLinkableGroup
-
- getSharedLibraryExtension() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getSharedLibraryExtension() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
Extension of shared library files.
- getSharedLibraryExtension() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getSharedLibraryInterfaceParams() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getSharedLibraryInterfaces() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getSharedLibraryInterfaceType() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
Type of shared library interfaces to create.
- getSharedLibraryLoadingType() - Method in class com.facebook.buck.cxx.toolchain.linker.impl.DarwinLinker
-
- getSharedLibraryLoadingType() - Method in class com.facebook.buck.cxx.toolchain.linker.impl.GnuLinker
-
- getSharedLibraryLoadingType() - Method in class com.facebook.buck.cxx.toolchain.linker.impl.WindowsLinker
-
- getSharedLibraryLoadingType() - Method in interface com.facebook.buck.cxx.toolchain.linker.Linker
-
- getSharedLibraryPath(ProjectFilesystem, BuildTarget, String) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- getSharedLibrarySoname(Optional<String>, BuildTarget, CxxPlatform, ProjectFilesystem) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- getSharedLibrarySymlinkTreePath(ProjectFilesystem, BuildTarget, Flavor) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- getSharedLibraryVersionedExtensionFormat() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
Extension format for versioned shared libraries.
- getSharedLibraryVersionedExtensionFormat() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getSharedLibs() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescriptionArg
-
Libraries references in the shared link args above.
- getSharedLibs() - Method in class com.facebook.buck.features.haskell.HaskellPrebuiltLibraryDescriptionArg
-
- getSharedLink() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescriptionArg
-
The link arguments to use when linking using the shared link style.
- getSharedRuntimePath() - Method in class com.facebook.buck.android.NdkToolchainDescriptionArg
-
Path for the c++ shared runtime to package in the apk.
- getShellCommand(SourcePathResolverAdapter, Path) - Method in class com.facebook.buck.cxx.CxxTest
-
- getShellCommand(ExecutionContext) - Method in class com.facebook.buck.shell.ShellStep
-
This method is idempotent.
- getShellCommandArgsForDescription(ExecutionContext) - Method in class com.facebook.buck.shell.AbstractGenruleStep
-
- getShellCommandArgsForDescription(ExecutionContext) - Method in class com.facebook.buck.shell.ShellStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.android.AaptStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.android.AidlStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.android.DxStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.android.InstrumentationStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.android.NdkBuildStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.android.ProGuardObfuscateStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.android.redex.ReDexStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.android.StripStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.android.ZipalignStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.apple.LibtoolStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.cxx.MachoScrubContentSectionsStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.features.d.DCompileStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.features.dotnet.CsharpLibraryCompile
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.features.go.CGoCompileStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.features.go.CGoGenerateImportStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.features.go.GoAssembleStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.features.go.GoCompileStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.features.go.GoLinkStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.features.go.GoListStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.features.go.GoPackStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.features.go.GoTestCoverStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.features.go.GoTestMainStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.features.halide.HalideCompilerStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.features.ocaml.OcamlCCompileStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.features.ocaml.OcamlDepToolStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.features.ocaml.OcamlLexStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.features.ocaml.OcamlLinkStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.features.ocaml.OcamlMLCompileStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.features.ocaml.OcamlNativePluginStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.features.ocaml.OcamlYaccStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.features.python.PexStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.jvm.java.GenerateCodeCoverageReportStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.jvm.java.JUnitStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.jvm.scala.ScalacStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.shell.AbstractGenruleStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.shell.BashStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.shell.DefaultShellStep
-
- getShellCommandInternal(ExecutionContext) - Method in class com.facebook.buck.shell.ShellStep
-
Implementations of this method should not have any observable side-effects.
- getShellPath() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXShellScriptBuildPhase
-
Returns the path to the shell under which the script is to be executed.
- getShellScript() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXShellScriptBuildPhase
-
- getShortDescription() - Method in class com.facebook.buck.cli.AuditActionGraphCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.AuditAliasCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.AuditBuildInfoCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.AuditCellCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.AuditClasspathCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.AuditCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.AuditConfigCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.AuditDependenciesCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.AuditFlavorsCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.AuditIncludesCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.AuditInputCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.AuditMbrCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.AuditMbrIsolationCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.AuditModulesCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.AuditOwnerCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.AuditRulesCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.AuditRuleTypeCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.AuditRuleTypesCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.AuditTestsCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.BuckCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.BuildCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.CacheCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.CacheDeleteCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.CleanCommand
-
- getShortDescription() - Method in interface com.facebook.buck.cli.Command
-
- getShortDescription() - Method in class com.facebook.buck.cli.DoctorCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.FetchCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.FixCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.HelpCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.InstallCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.KillAllCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.KillCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.PerfActionGraphCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.PerfCasCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.PerfCasDownloadCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.PerfCasUploadCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.PerfCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.PerfManifestCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.PerfMbrCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.PerfMbrPrepareRemoteExecutionCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.PerfMbrSerializationCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.PerfRuleKeyCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.PerfStatCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.ProjectCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.PublishCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.QueryCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.RootCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.RunCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.ServerCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.ServerStatusCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.TargetsCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.TestCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.UnconfiguredQueryCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.UninstallCommand
-
- getShortDescription() - Method in class com.facebook.buck.cli.VerifyCachesCommand
-
- getShortDescription() - Method in enum com.facebook.buck.core.build.engine.BuildRuleSuccessType
-
- getShortDescription() - Method in class com.facebook.buck.features.apple.project.XCodeProjectSubCommand
-
- getShortDescription() - Method in class com.facebook.buck.features.go.GoProjectSubCommand
-
- getShortDescription() - Method in class com.facebook.buck.features.project.intellij.IjProjectSubCommand
-
- getShortDescription() - Method in interface com.facebook.buck.support.cli.args.PluginBasedCommand
-
- getShortDescription() - Method in interface com.facebook.buck.support.cli.args.PluginBasedSubCommand
-
- getShortName() - Method in class com.facebook.buck.android.AabBuilderStep
-
- getShortName() - Method in class com.facebook.buck.android.aapt.MiniAapt
-
- getShortName() - Method in class com.facebook.buck.android.AaptStep
-
- getShortName() - Method in class com.facebook.buck.android.AidlStep
-
- getShortName() - Method in class com.facebook.buck.android.AndroidModuleConsistencyStep
-
- getShortName() - Method in class com.facebook.buck.android.ApkBuilderStep
-
- getShortName() - Method in class com.facebook.buck.android.ApkInstallStep
-
- getShortName() - Method in class com.facebook.buck.android.CompileStringsStep
-
- getShortName() - Method in class com.facebook.buck.android.ConcatStep
-
- getShortName() - Method in class com.facebook.buck.android.dalvik.EstimateDexWeightStep
-
- getShortName() - Method in class com.facebook.buck.android.DxStep
-
- getShortName() - Method in class com.facebook.buck.android.GenerateBuildConfigStep
-
- getShortName() - Method in class com.facebook.buck.android.GenerateManifestStep
-
- getShortName() - Method in class com.facebook.buck.android.GetStringsFilesStep
-
- getShortName() - Method in class com.facebook.buck.android.InstrumentationStep
-
- getShortName() - Method in class com.facebook.buck.android.IntraDexReorderStep
-
- getShortName() - Method in class com.facebook.buck.android.MergeAndroidResourcesStep
-
- getShortName() - Method in class com.facebook.buck.android.NdkBuildStep
-
- getShortName() - Method in class com.facebook.buck.android.ProGuardObfuscateStep
-
- getShortName() - Method in class com.facebook.buck.android.redex.ReDexStep
-
- getShortName() - Method in class com.facebook.buck.android.ReplaceManifestPlaceholdersStep
-
- getShortName() - Method in class com.facebook.buck.android.SmartDexingStep
-
- getShortName() - Method in class com.facebook.buck.android.SplitZipStep
-
- getShortName() - Method in class com.facebook.buck.android.StripStep
-
- getShortName() - Method in class com.facebook.buck.android.WriteAppModuleMetadataStep
-
- getShortName() - Method in class com.facebook.buck.android.ZipalignStep
-
- getShortName() - Method in class com.facebook.buck.apple.IdbRunTestsStep
-
- getShortName() - Method in class com.facebook.buck.apple.LibtoolStep
-
- getShortName() - Method in class com.facebook.buck.core.model.BuildTarget
-
- getShortName() - Method in class com.facebook.buck.core.rules.actions.AbstractAction
-
- getShortName() - Method in interface com.facebook.buck.core.rules.actions.Action
-
- getShortName() - Method in class com.facebook.buck.cxx.MachoDylibStubScrubContentsStep
-
- getShortName() - Method in class com.facebook.buck.cxx.MachoScrubContentSectionsStep
-
- getShortName() - Method in class com.facebook.buck.features.d.DCompileStep
-
- getShortName() - Method in class com.facebook.buck.features.dotnet.CsharpLibraryCompile
-
- getShortName() - Method in class com.facebook.buck.features.go.CGoCompileStep
-
- getShortName() - Method in class com.facebook.buck.features.go.CGoGenerateImportStep
-
- getShortName() - Method in class com.facebook.buck.features.go.GoAssembleStep
-
- getShortName() - Method in class com.facebook.buck.features.go.GoCompileStep
-
- getShortName() - Method in class com.facebook.buck.features.go.GoLinkStep
-
- getShortName() - Method in class com.facebook.buck.features.go.GoListStep
-
- getShortName() - Method in class com.facebook.buck.features.go.GoPackStep
-
- getShortName() - Method in class com.facebook.buck.features.go.GoTestCoverStep
-
- getShortName() - Method in class com.facebook.buck.features.go.GoTestMainStep
-
- getShortName() - Method in class com.facebook.buck.features.halide.HalideCompilerStep
-
- getShortName() - Method in class com.facebook.buck.features.ocaml.OcamlBuildStep
-
- getShortName() - Method in class com.facebook.buck.features.ocaml.OcamlCCompileStep
-
- getShortName() - Method in class com.facebook.buck.features.ocaml.OcamlDebugLauncherStep
-
- getShortName() - Method in class com.facebook.buck.features.ocaml.OcamlDepToolStep
-
- getShortName() - Method in class com.facebook.buck.features.ocaml.OcamlLexStep
-
- getShortName() - Method in class com.facebook.buck.features.ocaml.OcamlLinkStep
-
- getShortName() - Method in class com.facebook.buck.features.ocaml.OcamlMLCompileStep
-
- getShortName() - Method in class com.facebook.buck.features.ocaml.OcamlNativePluginStep
-
- getShortName() - Method in class com.facebook.buck.features.ocaml.OcamlYaccStep
-
- getShortName() - Method in class com.facebook.buck.features.python.MovePythonWhlDataStep
-
- getShortName() - Method in class com.facebook.buck.features.python.PexStep
-
- getShortName() - Method in class com.facebook.buck.features.python.PythonRunTestsStep
-
- getShortName() - Method in class com.facebook.buck.features.zip.rules.CopyToZipStep
-
- getShortName() - Method in class com.facebook.buck.file.DownloadStep
-
- getShortName() - Method in class com.facebook.buck.json.JsonConcatenateStep
-
- getShortName() - Method in class com.facebook.buck.jvm.java.AccumulateClassNamesStep
-
- getShortName() - Method in class com.facebook.buck.jvm.java.CalculateClassAbiStep
-
- getShortName() - Method in class com.facebook.buck.jvm.java.CopyResourcesStep
-
- getShortName() - Method in class com.facebook.buck.jvm.java.DiffAbisStep
-
- getShortName() - Method in class com.facebook.buck.jvm.java.ExternalJavac
-
- getShortName() - Method in class com.facebook.buck.jvm.java.GenerateCodeCoverageReportStep
-
- getShortName() - Method in class com.facebook.buck.jvm.java.JarDirectoryStep
-
- getShortName() - Method in interface com.facebook.buck.jvm.java.Javac
-
- getShortName() - Method in class com.facebook.buck.jvm.java.JavacStep
-
- getShortName() - Method in class com.facebook.buck.jvm.java.Jsr199Javac
-
- getShortName() - Method in class com.facebook.buck.jvm.java.JUnitStep
-
- getShortName() - Method in class com.facebook.buck.jvm.java.UnusedDependenciesFinder
-
- getShortName() - Method in class com.facebook.buck.jvm.kotlin.ExternalKotlinc
-
- getShortName() - Method in class com.facebook.buck.jvm.kotlin.JarBackedReflectedKotlinc
-
- getShortName() - Method in interface com.facebook.buck.jvm.kotlin.Kotlinc
-
- getShortName() - Method in class com.facebook.buck.jvm.kotlin.KotlincStep
-
- getShortName() - Method in class com.facebook.buck.jvm.scala.ScalacStep
-
- getShortName() - Method in class com.facebook.buck.shell.AbstractGenruleStep
-
- getShortName() - Method in class com.facebook.buck.shell.BashStep
-
- getShortName() - Method in class com.facebook.buck.shell.DefaultShellStep
-
- getShortName() - Method in class com.facebook.buck.shell.RunTestAndRecordResultStep
-
- getShortName() - Method in class com.facebook.buck.shell.WorkerShellStep
-
- getShortName() - Method in class com.facebook.buck.step.AbstractExecutionStep
-
- getShortName() - Method in class com.facebook.buck.step.AbstractTestStep
-
- getShortName() - Method in class com.facebook.buck.step.ConditionalStep
-
- getShortName() - Method in class com.facebook.buck.step.fs.CopyStep
-
- getShortName() - Method in class com.facebook.buck.step.fs.FileScrubberStep
-
- getShortName() - Method in class com.facebook.buck.step.fs.FindAndReplaceStep
-
- getShortName() - Method in class com.facebook.buck.step.fs.MakeExecutableStep
-
- getShortName() - Method in class com.facebook.buck.step.fs.MkdirStep
-
- getShortName() - Method in class com.facebook.buck.step.fs.MoveStep
-
- getShortName() - Method in class com.facebook.buck.step.fs.RmStep
-
- getShortName() - Method in class com.facebook.buck.step.fs.StringTemplateStep
-
- getShortName() - Method in class com.facebook.buck.step.fs.SymCopyStep
-
- getShortName() - Method in class com.facebook.buck.step.fs.SymlinkFileStep
-
- getShortName() - Method in class com.facebook.buck.step.fs.SymlinkTreeMergeStep
-
- getShortName() - Method in class com.facebook.buck.step.fs.SymlinkTreeStep
-
- getShortName() - Method in class com.facebook.buck.step.fs.TouchStep
-
- getShortName() - Method in class com.facebook.buck.step.fs.WriteFileStep
-
- getShortName() - Method in class com.facebook.buck.step.fs.XzStep
-
- getShortName() - Method in class com.facebook.buck.step.fs.ZstdStep
-
- getShortName() - Method in class com.facebook.buck.step.impl.ActionExecutionStep
-
- getShortName() - Method in interface com.facebook.buck.step.Step
-
- getShortName() - Method in class com.facebook.buck.unarchive.UntarStep
-
- getShortName() - Method in class com.facebook.buck.unarchive.UnzipStep
-
- getShortName() - Method in enum com.facebook.buck.util.unarchive.ArchiveFormat
-
Get the short name for the archive type
- getShortName() - Method in class com.facebook.buck.zip.RepackZipEntriesStep
-
- getShortName() - Method in class com.facebook.buck.zip.ZipScrubberStep
-
- getShortName() - Method in class com.facebook.buck.zip.ZipStep
-
- getShortNameAndFlavorPostfix() - Method in class com.facebook.buck.core.model.BuildTarget
-
If this build target were cell//third_party/java/guava:guava-latest, then this would return
"guava-latest".
- getShortNameAndFlavorPostfix() - Method in class com.facebook.buck.core.model.UnconfiguredBuildTarget
-
- getShortNames() - Static method in enum com.facebook.buck.util.unarchive.ArchiveFormat
-
Get all available short names
- getShortPath() - Method in class com.facebook.buck.core.artifact.SourceArtifactImpl
-
- getShortPath() - Method in interface com.facebook.buck.core.starlark.rule.artifact.SkylarkArtifactApi
-
- getShortStepName() - Method in interface com.facebook.buck.event.external.events.StepEventExternalInterface
-
- getShortStepName() - Method in class com.facebook.buck.step.StepEvent
-
- getShouldCacheLinks(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getShouldDeleteTemporaries() - Method in class com.facebook.buck.command.config.BuildBuckConfig
-
Whether to delete temporary files generated to run a build rule immediately after the rule is
run.
- getShouldDeleteTemporaries() - Method in class com.facebook.buck.core.build.context.BuildContext
-
- getShouldIncludeClasses() - Method in class com.facebook.buck.android.AndroidAppModularityDescriptionArg
-
- getShouldIncludeLibraries() - Method in class com.facebook.buck.android.AndroidAppModularityDescriptionArg
-
- getShouldProduceLibraryArtifact() - Method in interface com.facebook.buck.cxx.CxxLibraryDescriptionDelegate.ConfiguredDelegate
-
Specifies whether a library artifact (e.g., libName.a) should be produced.
- getShouldRemapHostPlatform() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getShouldUseArgsfile(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getShouldUsedOldBinaryOutputLocation(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getShutdownFullyCompleteFuture() - Method in class com.facebook.buck.util.concurrent.ResourcePool
-
- getSignature(String) - Method in interface com.facebook.buck.android.exopackage.AndroidDevice
-
- getSignature(String) - Method in class com.facebook.buck.android.exopackage.RealAndroidDevice
-
- getSimpleConsoleOutputFilePath() - Method in class com.facebook.buck.log.InvocationInfo
-
- getSimulatorName() - Method in class com.facebook.buck.cli.TargetDeviceCommandLineOptions
-
- getSimulators() - Method in class com.facebook.buck.apple.simulator.AppleDeviceController
-
- getSimulatorState() - Method in interface com.facebook.buck.apple.simulator.AppleSimulator
-
- getSimulatorUdidForTest() - Method in class com.facebook.buck.apple.simulator.AppleDeviceController
-
Picks the simulator to be used for testing
- getSize() - Method in class com.facebook.buck.core.model.actiongraph.ActionGraph
-
- getSize() - Method in class com.facebook.buck.core.model.targetgraph.TargetGraph
-
- getSize() - Method in interface com.facebook.buck.doctor.config.BuildLogEntry
-
- getSize() - Method in interface com.facebook.buck.jvm.java.classes.FileLike
-
Returns the size of the entry in bytes.
- getSize() - Method in class com.facebook.buck.remoteexecution.grpc.GrpcProtocol.GrpcDigest
-
- getSize() - Method in interface com.facebook.buck.remoteexecution.interfaces.Protocol.Digest
-
- getSize(Path) - Method in class com.facebook.buck.util.cache.DelegatingFileHashCacheEngine
-
- getSize(Path) - Method in interface com.facebook.buck.util.cache.FileHashCacheEngine
-
- getSize(Path) - Method in class com.facebook.buck.util.cache.impl.DefaultFileHashCache
-
- getSize(Path) - Method in class com.facebook.buck.util.cache.impl.StackedFileHashCache
-
- getSize(ProjectFilesystem, Path) - Method in class com.facebook.buck.util.cache.impl.StackedFileHashCache
-
- getSize(Path) - Method in interface com.facebook.buck.util.hashing.FileHashLoader
-
- getSize(ProjectFilesystem, Path) - Method in interface com.facebook.buck.util.hashing.FileHashLoader
-
- getSize(Path) - Method in class com.facebook.buck.util.hashing.FilePathHashLoader
-
- getSize(Path) - Method in interface com.facebook.buck.util.hashing.ProjectFileHashLoader
-
- getSizeBytes() - Method in class com.facebook.buck.remoteexecution.event.CasBlobDownloadEvent.Started
-
- getSizeBytes() - Method in class com.facebook.buck.remoteexecution.event.CasBlobUploadEvent.Started
-
- getSizeIfPresent(Path) - Method in class com.facebook.buck.util.cache.DelegatingFileHashCacheEngine
-
- getSizeIfPresent(Path) - Method in interface com.facebook.buck.util.cache.FileHashCacheEngine
-
- getSkeleton() - Method in class com.facebook.buck.android.AndroidManifestDescriptionArg
-
- getSkipCrunchPngsDefault() - Method in class com.facebook.buck.android.AndroidBuckConfig
-
Whether to skip crunching pngs by default in aapt2 compile.
- getSkippedCount() - Method in interface com.facebook.buck.event.external.elements.TestCaseSummaryExternalInterface
-
- getSkippedCount() - Method in class com.facebook.buck.test.TestCaseSummary
-
- getSkipProguard() - Method in class com.facebook.buck.android.AndroidBinary
-
- getSkipProguard() - Method in class com.facebook.buck.android.AndroidBundle
-
- getSkipResources() - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg
-
- getSkylarkGlobHandler() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getSlbConfig() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getSnapshotImagesDiffPath() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getSnapshotReferenceImagesPath() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getSnapshots() - Method in class com.facebook.buck.counters.CountersSnapshotEvent
-
- getSoLibsRelDir(BuildTarget) - Static method in class com.facebook.buck.features.haskell.HaskellGhciDescription
-
Give the relative path from the omnibus to its shared library directory.
- getSoloAsync() - Method in class com.facebook.buck.shell.WorkerToolDescriptionArg
-
- getSoName() - Method in interface com.facebook.buck.android.AndroidLinkableMetadata
-
- getSoname() - Method in enum com.facebook.buck.android.toolchain.ndk.NdkCxxRuntime
-
- getSoname() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getSoname() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getSoname() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getSoname() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
- getSoname() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getSoname() - Method in interface com.facebook.buck.cxx.Omnibus.OmnibusLibrary
-
- getSoname(BuildTarget, CxxPlatform, Optional<String>) - Static method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescription
-
- getSoname() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getSoname() - Method in class com.facebook.buck.swift.SwiftLibraryDescriptionArg
-
- getSortedIds(boolean) - Method in class com.facebook.buck.event.listener.BuildThreadStateRenderer
-
- getSortedIds(boolean) - Method in interface com.facebook.buck.event.listener.MultiStateRenderer
-
- getSortedIds(boolean) - Method in class com.facebook.buck.event.listener.RemoteExecutionStateRenderer
-
- getSortedIds(boolean) - Method in class com.facebook.buck.event.listener.TestThreadStateRenderer
-
- getSortedThreadIds(boolean) - Method in class com.facebook.buck.event.listener.CommonThreadStateRenderer
-
- getSortOrder() - Method in class com.facebook.buck.features.project.intellij.IjDependencyListBuilder.DependencyEntry
-
- getSource() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getSource() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getSource() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getSource() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getSource() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getSource() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getSource() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getSource() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getSource() - Method in interface com.facebook.buck.jvm.java.JvmLibraryArg
-
- getSource() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getSource() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getSource() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getSource() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getSourceAbiJar(BuildTarget) - Static method in class com.facebook.buck.jvm.core.JavaAbis
-
- getSourceAbiPath() - Method in class com.facebook.buck.jvm.java.DiffAbisStep
-
- getSourceAbiVerificationMode() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getSourceAbiVerificationMode() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getSourceAbiVerificationMode() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getSourceAbiVerificationMode() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getSourceAbiVerificationMode() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getSourceAbiVerificationMode() - Method in class com.facebook.buck.jvm.java.JavaBuckConfig
-
Controls a special verification mode that generates ABIs both from source and from class files
and diffs them.
- getSourceAbiVerificationMode() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getSourceAbiVerificationMode() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getSourceAbiVerificationMode() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getSourceAbiVerificationMode() - Method in interface com.facebook.buck.jvm.java.JvmLibraryArg
-
- getSourceAbiVerificationMode() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getSourceAbiVerificationMode() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getSourceAbiVerificationMode() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getSourceAbiVerificationMode() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getSourceBuildTarget() - Method in interface com.facebook.buck.android.DexWithClasses
-
- getSourceControlInfo() - Method in class com.facebook.buck.doctor.AbstractReport
-
- getSourceControlInfo() - Method in interface com.facebook.buck.doctor.DefectReporter.DefectReport
-
- getSourceDirs() - Method in class com.facebook.buck.features.project.intellij.model.IjLibrary
-
- getSourceFile() - Method in class com.facebook.buck.jvm.java.plugin.api.TaskEventMirror
-
- getSourceFilePath() - Method in interface com.facebook.buck.util.zip.collect.FileZipEntrySource
-
- getSourceFilePath() - Method in interface com.facebook.buck.util.zip.collect.ZipEntrySource
-
Location of a file where source is located.
- getSourceFilePath() - Method in interface com.facebook.buck.util.zip.collect.ZipEntrySourceFromZip
-
Path to the source zip file.
- getSourceFilePaths() - Method in class com.facebook.buck.jvm.java.CompilerParameters
-
- getSourceFiles() - Method in class com.facebook.buck.features.go.GoListStep
-
- getSourceFolders() - Method in class com.facebook.buck.features.project.intellij.ModuleBuildContext
-
- getSourceFoldersToInputsIndex(ImmutableCollection<Path>) - Static method in class com.facebook.buck.features.project.intellij.BaseIjModuleRule
-
Calculate the set of directories containing inputs to the target.
- getSourceGroup() - Method in class com.facebook.buck.apple.GroupedSource
-
- getSourceGroupName() - Method in class com.facebook.buck.apple.GroupedSource
-
- getSourceGroupPathRelativeToTarget() - Method in class com.facebook.buck.apple.GroupedSource
-
- getSourceInputPath(SourcePathResolverAdapter) - Method in class com.facebook.buck.cxx.CxxPreprocessAndCompile
-
Returns the original path of the source file relative to its own project root
- getSourceJar() - Method in class com.facebook.buck.android.AndroidPrebuiltAarDescriptionArg
-
- getSourceJar() - Method in class com.facebook.buck.jvm.java.PrebuiltJar
-
- getSourceJar() - Method in class com.facebook.buck.jvm.java.PrebuiltJarDescriptionArg
-
- getSourceJars() - Method in class com.facebook.buck.features.project.intellij.model.IjLibrary
-
- getSourceLevel() - Method in class com.facebook.buck.jvm.java.JavacLanguageLevelOptions
-
- getSourceLevelBootclasspath() - Method in class com.facebook.buck.jvm.java.JavacOptions
-
- getSourcemapPath(JsBundleOutputs) - Static method in class com.facebook.buck.features.js.JsUtil
-
- getSourcemapPath(String) - Static method in class com.facebook.buck.features.js.JsUtil
-
- getSourceOnlyAbiDeps() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getSourceOnlyAbiDeps() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getSourceOnlyAbiDeps() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getSourceOnlyAbiDeps() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getSourceOnlyAbiDeps() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getSourceOnlyAbiDeps() - Method in class com.facebook.buck.jvm.java.JavaLibraryDeps
-
- getSourceOnlyAbiDeps() - Method in interface com.facebook.buck.jvm.java.JavaLibraryDescription.CoreArg
-
- getSourceOnlyAbiDeps() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getSourceOnlyAbiDeps() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getSourceOnlyAbiDeps() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getSourceOnlyAbiDeps() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getSourceOnlyAbiDeps() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getSourceOnlyAbiDeps() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getSourceOnlyAbiDeps() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getSourceOnlyAbiJar() - Method in interface com.facebook.buck.jvm.core.HasJavaAbi
-
- getSourceOnlyAbiJar(BuildTarget) - Static method in class com.facebook.buck.jvm.core.JavaAbis
-
- getSourceOnlyAbiJar() - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getSourceOnlyAbiRuleInfoFactory() - Method in class com.facebook.buck.jvm.java.CompilerParameters
-
- getSourceOnlyAbiRules(ActionGraphBuilder, Iterable<BuildRule>) - Static method in class com.facebook.buck.jvm.java.JavaLibraryRules
-
- getSourcePath() - Method in class com.facebook.buck.android.CopyNativeLibraries.StrippedObjectDescription
-
- getSourcePath() - Method in class com.facebook.buck.apple.GroupedSource
-
- getSourcePath() - Method in class com.facebook.buck.apple.SourcePathWithAppleBundleDestination
-
- getSourcePath() - Method in interface com.facebook.buck.core.artifact.BoundArtifact
-
- getSourcePath() - Method in interface com.facebook.buck.core.artifact.BuildArtifact
-
- getSourcePath() - Method in interface com.facebook.buck.core.artifact.SourceArtifact
-
- getSourcePath() - Method in class com.facebook.buck.core.artifact.SourceArtifactImpl
-
- getSourcePath(String, String, TargetConfiguration) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getSourcePath() - Method in class com.facebook.buck.core.sourcepath.NonHashableSourcePathContainer
-
- getSourcePath() - Method in class com.facebook.buck.core.sourcepath.SourceWithFlags
-
- getSourcePath(Path) - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getSourcePath(String, TargetConfiguration) - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getSourcePath() - Method in class com.facebook.buck.features.apple.common.CopyInXcode
-
- getSourcePath(Path) - Method in class com.facebook.buck.features.python.PythonBuckConfig
-
- getSourcePath() - Method in class com.facebook.buck.rules.coercer.FrameworkPath
-
- getSourcePath(OutputPath) - Method in class com.facebook.buck.rules.modern.ModernBuildRule
-
This should only be exposed to implementations of the ModernBuildRule, not of the Buildable.
- getSourcePathName(BuildTarget, SourcePath) - Method in class com.facebook.buck.core.sourcepath.resolver.impl.AbstractSourcePathResolver
-
- getSourcePathName(BuildTarget, SourcePath) - Method in class com.facebook.buck.core.sourcepath.resolver.impl.DefaultSourcePathResolver
-
- getSourcePathName(BuildTarget, SourcePath) - Method in interface com.facebook.buck.core.sourcepath.resolver.SourcePathResolver
-
- getSourcePathName(BuildTarget, SourcePath) - Method in class com.facebook.buck.core.sourcepath.resolver.SourcePathResolverAdapter
-
- getSourcePathName(BuildTarget, SourcePath) - Method in class com.facebook.buck.features.project.intellij.IjProjectSourcePathResolver
-
Source path names are only used when constructing the ActionGraph, so we don't need to support
them here.
- getSourcePathNames(BuildTarget, String, Iterable<SourcePath>) - Method in class com.facebook.buck.core.sourcepath.resolver.impl.AbstractSourcePathResolver
-
Resolved the logical names for a group of SourcePath objects into a map, throwing an error on
duplicates.
- getSourcePathNames(BuildTarget, String, Iterable<T>, Predicate<T>, Function<T, SourcePath>) - Method in class com.facebook.buck.core.sourcepath.resolver.impl.AbstractSourcePathResolver
-
Resolves the logical names for a group of objects that have a SourcePath into a map, throwing
an error on duplicates.
- getSourcePathNames(BuildTarget, String, Iterable<SourcePath>) - Method in interface com.facebook.buck.core.sourcepath.resolver.SourcePathResolver
-
- getSourcePathNames(BuildTarget, String, Iterable<T>, Predicate<T>, Function<T, SourcePath>) - Method in interface com.facebook.buck.core.sourcepath.resolver.SourcePathResolver
-
- getSourcePathNames(BuildTarget, String, Iterable<SourcePath>) - Method in class com.facebook.buck.core.sourcepath.resolver.SourcePathResolverAdapter
-
Resolves the logical names for a group of
SourcePath
objects into a map, throwing an
error on duplicates.
- getSourcePathNames(BuildTarget, String, Iterable<T>, Predicate<T>, Function<T, SourcePath>) - Method in class com.facebook.buck.core.sourcepath.resolver.SourcePathResolverAdapter
-
Resolves the logical names for a group of
SourcePath
objects into a map, throwing an
error on duplicates.
- getSourcePathOutputs() - Method in interface com.facebook.buck.core.build.action.BuildEngineAction
-
- getSourcePathOutputs() - Method in class com.facebook.buck.core.rules.actions.AbstractAction
-
- getSourcePathOutputs() - Method in interface com.facebook.buck.core.rules.actions.Action
-
- getSourcePathOutputs() - Method in class com.facebook.buck.core.rules.impl.AbstractBuildRule
-
- getSourcePathResolver() - Method in class com.facebook.buck.core.build.context.BuildContext
-
- getSourcePathResolver() - Method in class com.facebook.buck.core.rules.impl.AbstractBuildRuleResolver
-
- getSourcePathResolver() - Method in class com.facebook.buck.core.rules.impl.DefaultSourcePathRuleFinder
-
- getSourcePathResolver() - Method in interface com.facebook.buck.core.rules.SourcePathRuleFinder
-
- getSourcePathResolver() - Method in class com.facebook.buck.core.test.rule.ExternalRunnerTestProtocol
-
- getSourcePathResolver() - Method in class com.facebook.buck.jvm.java.UnusedDependenciesFinder
-
- getSourcePaths() - Method in class com.facebook.buck.cxx.FrameworkDependencies
-
- getSourcePaths(Collection<OutputPath>) - Method in class com.facebook.buck.rules.modern.ModernBuildRule
-
- getSourcePathToDepsFile() - Method in class com.facebook.buck.features.js.JsBundleGenrule
-
- getSourcePathToDepsFile() - Method in interface com.facebook.buck.features.js.JsDependenciesOutputs
-
- getSourcePathToDexFile() - Method in interface com.facebook.buck.android.DexWithClasses
-
- getSourcePathToGeneratedAnnotationPath(BuildTarget, ProjectFilesystem) - Method in class com.facebook.buck.jvm.java.JarBuildStepsFactory
-
- getSourcePathToGeneratedRDotJavaSrcFiles() - Method in class com.facebook.buck.android.GenerateRDotJava
-
- getSourcePathToMisc() - Method in class com.facebook.buck.features.js.JsBundleGenrule
-
- getSourcePathToMisc() - Method in interface com.facebook.buck.features.js.JsBundleOutputs
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.aapt.MergeAndroidResourceSources
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.Aapt2Compile
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.Aapt2Link
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.AaptPackageResources
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.AndroidAar
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.AndroidAppModularity
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.AndroidAppModularityVerification
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.AndroidBinary
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.AndroidBinaryExopackageSymlinkTree
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.AndroidBinaryNonExoInstaller
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.AndroidBuildConfig
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.AndroidBundle
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.AndroidInstrumentationTest
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.AndroidManifest
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.AndroidResource
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.AndroidResourceIndex
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.AssembleDirectories
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.CopyNativeLibraries
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.DexProducedFromJavaLibrary
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.DummyRDotJava
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.ExopackageDeviceDirectoryLister
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.ExopackageFilesInstaller
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.ExopackageInstallFinisher
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.ExopackageResourcesInstaller
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.GenAidl
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.GenerateRDotJava
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.GenerateStringResources
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.MergeAssets
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.MergeThirdPartyJarResources
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.NativeLibraryProguardGenerator
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.NdkLibrary
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.PackageStringAssets
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.PrebuiltNativeLibrary
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.PreDexMerge
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.PreDexSplitDexGroup
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.ResourcesFilter
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.SplitResources
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.StripLinkable
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.UnitTestOptions
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.UnstrippedNativeLibraries
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.UnzipAar
-
- getSourcePathToOutput() - Method in class com.facebook.buck.android.WriteFileHashCode
-
- getSourcePathToOutput() - Method in class com.facebook.buck.apple.AppleAssetCatalog
-
- getSourcePathToOutput() - Method in class com.facebook.buck.apple.AppleBundle
-
- getSourcePathToOutput() - Method in class com.facebook.buck.apple.AppleDebuggableBinary
-
- getSourcePathToOutput() - Method in class com.facebook.buck.apple.AppleDsym
-
- getSourcePathToOutput() - Method in class com.facebook.buck.apple.AppleTest
-
- getSourcePathToOutput() - Method in class com.facebook.buck.apple.AppleTestAggregatedDependencies
-
- getSourcePathToOutput() - Method in class com.facebook.buck.apple.AppleTestX
-
- getSourcePathToOutput() - Method in class com.facebook.buck.apple.BuiltinApplePackage
-
- getSourcePathToOutput() - Method in class com.facebook.buck.apple.CoreDataModel
-
- getSourcePathToOutput() - Method in class com.facebook.buck.apple.MultiarchFile
-
- getSourcePathToOutput() - Method in class com.facebook.buck.apple.PrebuiltAppleFramework
-
- getSourcePathToOutput() - Method in class com.facebook.buck.apple.SceneKitAssets
-
- getSourcePathToOutput(OutputLabel) - Method in interface com.facebook.buck.core.rules.attr.HasMultipleOutputs
-
Returns
SourcePath
instances to the outputs associated with the given output label, or
null
if the output label does not exist.
- getSourcePathToOutput() - Method in interface com.facebook.buck.core.rules.attr.HasMultipleOutputs
-
- getSourcePathToOutput() - Method in interface com.facebook.buck.core.rules.BuildRule
-
- getSourcePathToOutput() - Method in class com.facebook.buck.core.rules.impl.DependencyAggregation
-
- getSourcePathToOutput() - Method in class com.facebook.buck.core.rules.impl.NoopBuildRule
-
- getSourcePathToOutput() - Method in class com.facebook.buck.core.rules.impl.NoopBuildRuleWithDeclaredAndExtraDeps
-
- getSourcePathToOutput() - Method in class com.facebook.buck.core.rules.impl.RuleAnalysisLegacyBuildRuleView
-
- getSourcePathToOutput(OutputLabel) - Method in class com.facebook.buck.core.rules.impl.RuleAnalysisLegacyBuildRuleView
-
- getSourcePathToOutput() - Method in class com.facebook.buck.core.rules.impl.SymlinkTree
-
- getSourcePathToOutput() - Method in class com.facebook.buck.core.rules.impl.WriteStringTemplateRule
-
- getSourcePathToOutput() - Method in class com.facebook.buck.cxx.Archive
-
- getSourcePathToOutput() - Method in class com.facebook.buck.cxx.CxxBinary
-
- getSourcePathToOutput() - Method in class com.facebook.buck.cxx.CxxCompilationDatabase
-
- getSourcePathToOutput() - Method in class com.facebook.buck.cxx.CxxLink
-
- getSourcePathToOutput() - Method in class com.facebook.buck.cxx.CxxPreprocessAndCompile
-
- getSourcePathToOutput() - Method in class com.facebook.buck.cxx.CxxStrip
-
- getSourcePathToOutput() - Method in class com.facebook.buck.cxx.CxxTest
-
- getSourcePathToOutput() - Method in class com.facebook.buck.cxx.CxxThinLTOIndex
-
- getSourcePathToOutput() - Method in class com.facebook.buck.cxx.CxxThinLTOOpt
-
- getSourcePathToOutput() - Method in class com.facebook.buck.cxx.HeaderSymlinkTreeWithHeaderMap
-
- getSourcePathToOutput() - Method in class com.facebook.buck.cxx.MachoDylibStubRule
-
- getSourcePathToOutput() - Method in class com.facebook.buck.cxx.toolchain.HeaderSymlinkTreeWithModuleMap
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.d.DBinary
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.d.DCompileBuildRule
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.d.DTest
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.dotnet.CsharpLibrary
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.dotnet.PrebuiltDotnetLibrary
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.filegroup.Filegroup
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.go.CGoGenImport
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.go.CGoGenSource
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.go.GoBinary
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.go.GoCompile
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.go.GoTest
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.go.GoTestCoverSource
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.go.GoTestMain
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.go.GoTestX
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.gwt.GwtBinary
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.gwt.GwtModule
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.halide.HalideCompile
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.haskell.HaskellBinary
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.haskell.HaskellCompileRule
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.haskell.HaskellGhciRule
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.haskell.HaskellHaddockLibRule
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.haskell.HaskellHaddockRule
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.haskell.HaskellLinkRule
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.haskell.HaskellPackageRule
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.js.JsBundleGenrule
-
- getSourcePathToOutput() - Method in interface com.facebook.buck.features.js.JsBundleOutputs
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.js.JsDependenciesFile
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.js.JsFile
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.js.JsLibrary
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.lua.LuaBinary
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.lua.LuaStandaloneBinary
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.ocaml.OcamlBinary
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.ocaml.OcamlBuild
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.ocaml.OcamlCCompile
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.ocaml.OcamlClean
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.ocaml.OcamlDebugLauncher
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.ocaml.OcamlLink
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.ocaml.OcamlMLCompile
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.python.PrebuiltPythonLibrary
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.python.PythonBinary
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.python.PythonCompileRule
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.python.PythonTest
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.python.PythonTestX
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.rust.RustCompileRule
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.rust.RustTest
-
- getSourcePathToOutput() - Method in class com.facebook.buck.features.zip.rules.Zip
-
- getSourcePathToOutput() - Method in class com.facebook.buck.file.HttpArchive
-
- getSourcePathToOutput() - Method in class com.facebook.buck.file.HttpFile
-
- getSourcePathToOutput() - Method in class com.facebook.buck.file.RemoteFile
-
- getSourcePathToOutput() - Method in class com.facebook.buck.file.WriteFile
-
- getSourcePathToOutput() - Method in class com.facebook.buck.infer.InferNullsafe
-
- getSourcePathToOutput() - Method in class com.facebook.buck.json.JsonConcatenate
-
- getSourcePathToOutput() - Method in class com.facebook.buck.jvm.java.CalculateClassAbi
-
- getSourcePathToOutput() - Method in class com.facebook.buck.jvm.java.CalculateSourceAbi
-
- getSourcePathToOutput() - Method in class com.facebook.buck.jvm.java.CalculateSourceAbiFromLibraryTarget
-
- getSourcePathToOutput() - Method in class com.facebook.buck.jvm.java.CompareAbis
-
- getSourcePathToOutput() - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getSourcePathToOutput(BuildTarget, ProjectFilesystem) - Method in class com.facebook.buck.jvm.java.JarBuildStepsFactory
-
- getSourcePathToOutput() - Method in class com.facebook.buck.jvm.java.JarFattener
-
- getSourcePathToOutput() - Method in class com.facebook.buck.jvm.java.JavaBinary
-
- getSourcePathToOutput() - Method in class com.facebook.buck.jvm.java.Javadoc
-
- getSourcePathToOutput() - Method in class com.facebook.buck.jvm.java.JavaSourceJar
-
- getSourcePathToOutput() - Method in class com.facebook.buck.jvm.java.JavaTest
-
- getSourcePathToOutput() - Method in class com.facebook.buck.jvm.java.JavaTestX
-
- getSourcePathToOutput() - Method in class com.facebook.buck.jvm.java.Keystore
-
- getSourcePathToOutput() - Method in class com.facebook.buck.jvm.java.MavenUberJar
-
- getSourcePathToOutput() - Method in class com.facebook.buck.jvm.java.PrebuiltJar
-
- getSourcePathToOutput() - Method in class com.facebook.buck.rules.modern.ModernBuildRule
-
- getSourcePathToOutput() - Method in class com.facebook.buck.shell.BaseGenrule
-
Returns the output defined in 'out'.
- getSourcePathToOutput(OutputLabel) - Method in class com.facebook.buck.shell.BaseGenrule
-
- getSourcePathToOutput() - Method in class com.facebook.buck.shell.ExportFile
-
- getSourcePathToOutput() - Method in class com.facebook.buck.shell.ShBinary
-
- getSourcePathToOutput() - Method in class com.facebook.buck.swift.SwiftCompile
-
- getSourcePathToPrimaryDex() - Method in class com.facebook.buck.android.PreDexMerge
-
- getSourcePathToResources() - Method in class com.facebook.buck.features.js.JsBundleGenrule
-
- getSourcePathToResources() - Method in interface com.facebook.buck.features.js.JsBundleOutputs
-
- getSourcePathToRZip() - Method in class com.facebook.buck.android.GenerateRDotJava
-
- getSourcePathToSourceMap() - Method in class com.facebook.buck.features.js.JsBundleGenrule
-
- getSourcePathToSourceMap() - Method in interface com.facebook.buck.features.js.JsBundleOutputs
-
- getSourcePathToStringAssetsZip() - Method in class com.facebook.buck.android.PackageStringAssets
-
- getSourcePathToSupplementaryOutput(String) - Method in class com.facebook.buck.apple.AppleTestX
-
- getSourcePathToSupplementaryOutput(String) - Method in interface com.facebook.buck.core.rules.attr.HasSupplementaryOutputs
-
Returns a SourcePath to a named supplementary output, or null if it does not exist.
- getSourcePathToSupplementaryOutput(String) - Method in interface com.facebook.buck.core.test.rule.TestXRule
-
- getSourcePathToSupplementaryOutput(String) - Method in class com.facebook.buck.cxx.CxxBinary
-
- getSourcePathToSupplementaryOutput(String) - Method in class com.facebook.buck.cxx.CxxLink
-
- getSourcePathToSupplementaryOutput(String) - Method in class com.facebook.buck.jvm.java.JavaTestX
-
- getSourceRootFromSource(Path) - Method in class com.facebook.buck.features.project.intellij.lang.java.ParsingJavaPackageFinder.PackagePathResolver
-
Given a file at `a/b/c/D.java`, and full name of the class is `b.c.D`, the source root for
that file is `a`.
- getSources() - Method in interface com.facebook.buck.jvm.core.HasSources
-
- getSources() - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getSources() - Method in class com.facebook.buck.jvm.java.JarBuildStepsFactory
-
- getSources() - Method in class com.facebook.buck.jvm.java.JavaSourceJar
-
- getSources() - Method in class com.facebook.buck.jvm.java.PrebuiltJar
-
- getSources() - Method in interface com.facebook.buck.util.zip.collect.ZipEntrySourceCollection
-
- getSourceToBootclasspath() - Method in class com.facebook.buck.jvm.java.JavacOptions
-
- getSourceTree() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXReference
-
- getSourceTree() - Method in class com.facebook.buck.apple.xcode.xcodeproj.SourceTreePath
-
- getSourceTreePath() - Method in class com.facebook.buck.features.apple.projectV2.ProjectFileWriter.Result
-
- getSourceTreePath() - Method in class com.facebook.buck.rules.coercer.FrameworkPath
-
- getSourceType() - Method in class com.facebook.buck.features.apple.common.CopyInXcode
-
- getSourceVersionFromTarget(String) - Static method in class com.facebook.buck.jvm.java.abi.SourceVersionUtils
-
Gets the source version corresponding to the given target string.
- getSourceWithFlags() - Method in class com.facebook.buck.apple.GroupedSource
-
- getSpecs() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getSpecs() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getSpecs() - Method in class com.facebook.buck.apple.AppleTestX
-
- getSpecs() - Method in class com.facebook.buck.core.test.rule.ExternalRunnerTestProtocol
-
- getSpecs() - Method in interface com.facebook.buck.core.test.rule.HasTestRunner
-
- getSpecs() - Method in interface com.facebook.buck.core.test.rule.TestXRule
-
- getSpecs() - Method in class com.facebook.buck.features.go.GoTestDescriptionArg
-
- getSpecs() - Method in class com.facebook.buck.features.go.GoTestX
-
- getSpecs() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getSpecs() - Method in class com.facebook.buck.features.python.PythonTestX
-
- getSpecs() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getSpecs() - Method in class com.facebook.buck.jvm.java.JavaTestX
-
- getSpeculativeParsing() - Method in class com.facebook.buck.parser.ParsingContext
-
Whether speculative parsing is enabled.
- getSpellingSuggestions(String, Collection<String>, int) - Static method in class com.facebook.buck.util.string.MoreStrings
-
- getSpoolMode() - Method in class com.facebook.buck.jvm.java.JavacOptions
-
- getSQLiteCacheEntries() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheEntries
-
- getSrc() - Method in class com.facebook.buck.cxx.CxxPrecompiledHeaderDescriptionArg
-
- getSrc() - Method in class com.facebook.buck.features.python.PythonTestRunner
-
- getSrc() - Method in class com.facebook.buck.features.python.PythonTestRunnerDescriptionArg
-
- getSrc() - Method in class com.facebook.buck.shell.ExportFileDescriptionArg
-
- getSrcRoots() - Method in class com.facebook.buck.jvm.java.JavaBuckConfig
-
- getSrcs() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.android.ApkGenruleDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.android.NdkLibraryDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.apple.XcodeScriptDescriptionArg
-
- getSrcs() - Method in interface com.facebook.buck.core.description.arg.HasSrcs
-
- getSrcs() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getSrcs() - Method in interface com.facebook.buck.cxx.CxxConstructorArg
-
- getSrcs() - Method in class com.facebook.buck.cxx.CxxGenruleDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.features.d.DBinaryDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.features.d.DLibraryDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.features.d.DTestDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.features.dotnet.CsharpLibraryDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.features.filegroup.FileGroupDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.features.go.GoBinaryDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.features.go.GoLibrary
-
- getSrcs() - Method in class com.facebook.buck.features.go.GoLibraryDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.features.go.GoTestDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.features.haskell.HaskellBinaryDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.features.haskell.HaskellGhciDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.features.haskell.HaskellLibraryDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.features.js.JsLibraryDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.features.lua.LuaLibraryDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.features.ocaml.OcamlBinaryDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.features.ocaml.OcamlLibraryDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.features.python.PythonLibraryDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.features.zip.rules.ZipFileDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.jvm.java.JarGenruleDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getSrcs() - Method in interface com.facebook.buck.shell.AbstractGenruleDescription.CommonArg
-
- getSrcs() - Method in class com.facebook.buck.shell.GenruleBuildable
-
- getSrcs() - Method in class com.facebook.buck.shell.GenruleDescriptionArg
-
- getSrcs() - Method in class com.facebook.buck.swift.SwiftLibraryDescriptionArg
-
- getSrcTarget() - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg
-
- getStack() - Method in class com.facebook.buck.log.ErrorLogRecord
-
- getStacktrace() - Method in interface com.facebook.buck.event.external.elements.TestResultSummaryExternalInterface
-
- getStackTrace() - Method in interface com.facebook.buck.json.BuildFileParseExceptionData
-
- getStackTrace() - Method in class com.facebook.buck.parser.exceptions.ParsingError
-
- getStacktrace() - Method in class com.facebook.buck.test.TestResultSummary
-
- getStandardDeviation() - Method in class com.facebook.buck.util.Statistics
-
Get the standard deviation.
- getStandardJavacPluginParams() - Method in class com.facebook.buck.jvm.java.JavacOptions
-
- getStart() - Method in class com.facebook.buck.event.listener.util.EventInterval
-
- getStarted() - Method in interface com.facebook.buck.event.listener.stats.cache.NetworkStatsTracker.RemoteArtifactUploadStats
-
- getStartedEvent() - Method in class com.facebook.buck.artifact_cache.HttpArtifactCacheEvent.Finished
-
- getStartedEvent() - Method in class com.facebook.buck.remoteexecution.event.CasBlobDownloadEvent.Finished
-
- getStartedEvent() - Method in class com.facebook.buck.remoteexecution.event.CasBlobUploadEvent.Finished
-
- getStartedEvent() - Method in class com.facebook.buck.remoteexecution.event.LocalFallbackEvent.Finished
-
- getStartedEvent() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.Finished
-
- getStartedEvent() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionSessionEvent.Finished
-
- getStartedTimeStamp() - Method in class com.facebook.buck.event.ArtifactCompressionEvent.Finished
-
Returns the timestamp of corresponding started event
- getStarterType() - Method in class com.facebook.buck.features.lua.LuaPlatform
-
- getStartEvent() - Method in class com.facebook.buck.event.listener.TimeCostEntry
-
- getStartIndex() - Method in interface com.facebook.buck.core.macros.MacroMatchResult
-
- getStartTime() - Method in class com.facebook.buck.event.listener.util.EventInterval
-
- getStartupCommand() - Method in class com.facebook.buck.rules.macros.WorkerMacroArg
-
- getStartupCommand() - Method in interface com.facebook.buck.worker.WorkerProcessParams
-
Command that is used to start the worker job, e.g.
- getStartupEnvironment() - Method in interface com.facebook.buck.worker.WorkerProcessParams
-
Environment that will be used to start the worker tool.
- getState() - Method in interface com.facebook.buck.apple.simulator.AppleDevice
-
String that represents the state of the device (i.e., "Booted", "Shutdown", etc)
- getState() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.Started
-
- getState() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.Terminal
-
- getStateCount(RemoteExecutionActionEvent.State) - Method in class com.facebook.buck.remoteexecution.event.listener.RemoteExecutionEventListener
-
- getStateMetadata() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.Terminal
-
- getStateWaitingMetadata() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.Terminal
-
- getStaticallyResolvedInstance() - Method in class com.facebook.buck.android.toolchain.ndk.impl.StaticUnresolvedNdkCxxPlatform
-
- getStaticallyResolvedInstance() - Method in class com.facebook.buck.apple.toolchain.impl.StaticUnresolvedAppleCxxPlatform
-
- getStaticallyResolvedInstance() - Method in class com.facebook.buck.swift.toolchain.impl.StaticUnresolvedSwiftPlatform
-
- getStaticDepRuntimeLdFlags() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
Flags for linking the c/c++ runtime for static libraries.
- getStaticLib() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getStaticLibraryBasename() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getStaticLibraryBasename() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getStaticLibraryBasename() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getStaticLibraryBasename(BuildTarget, String, boolean) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- getStaticLibraryBasename() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
- getStaticLibraryBasename() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getStaticLibraryExtension() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getStaticLibraryExtension() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
Extension for static library files.
- getStaticLibraryExtension() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getStaticLibraryName(BuildTarget, Optional<String>, String, boolean) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- getStaticLibraryName(BuildTarget, Optional<String>, String, String, boolean) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
Returns static library name
- getStaticLibs() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescriptionArg
-
Libraries references in the static link args above.
- getStaticLibs() - Method in class com.facebook.buck.features.haskell.HaskellPrebuiltLibraryDescriptionArg
-
- getStaticLink() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescriptionArg
-
The link arguments to use when linking using the static link style.
- getStaticPicDepRuntimeLdFlags() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
Flags for linking the c/c++ runtime for static-pic libraries.
- getStaticPicLib() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getStaticPicLibs() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescriptionArg
-
Libraries references in the static-pic link args above.
- getStaticPicLink() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescriptionArg
-
The link arguments to use when linking using the static-pic link style.
- getStaticRuntimePaths() - Method in class com.facebook.buck.swift.SwiftToolchainDescriptionArg
-
Static runtime paths.
- getStats() - Method in class com.facebook.buck.core.build.engine.manifest.Manifest
-
- getStats() - Method in class com.facebook.buck.event.CacheStatsEvent
-
- getStats() - Method in class com.facebook.buck.event.listener.stats.cache.CacheRateStatsKeeper
-
- getStats() - Method in class com.facebook.buck.rules.keys.TrackedRuleKeyCache
-
- getStatsEvents() - Method in class com.facebook.buck.util.cache.DelegatingFileHashCacheEngine
-
- getStatsEvents() - Method in interface com.facebook.buck.util.cache.FileHashCacheEngine
-
- getStatsEvents() - Method in class com.facebook.buck.util.cache.impl.DefaultFileHashCache
-
- getStatsEvents() - Method in class com.facebook.buck.util.cache.impl.StatsTrackingFileHashCacheEngine
-
- getStatus() - Method in class com.facebook.buck.core.build.engine.BuildResult
-
- getStatus() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.Finished
-
- getStatus() - Method in interface com.facebook.buck.doctor.config.DoctorSuggestion
-
- getStdErr() - Method in class com.facebook.buck.cli.ProjectGeneratorParameters
-
- getStdErr() - Method in class com.facebook.buck.core.build.execution.context.ExecutionContext
-
- getStdErr() - Method in interface com.facebook.buck.core.rules.actions.ActionExecutionResult.ActionExecutionFailure
-
- getStdErr() - Method in interface com.facebook.buck.core.rules.actions.ActionExecutionResult.ActionExecutionSuccess
-
- getStdErr() - Method in interface com.facebook.buck.core.rules.actions.ActionExecutionResult
-
- getStderr(ProcessExecutor.Result) - Method in class com.facebook.buck.cxx.toolchain.ClangClCompiler
-
- getStderr(ProcessExecutor.Result) - Method in interface com.facebook.buck.cxx.toolchain.Compiler
-
- getStderr(ProcessExecutor.Result) - Method in class com.facebook.buck.cxx.toolchain.DefaultCompiler
-
- getStderr(ProcessExecutor.Result) - Method in class com.facebook.buck.cxx.toolchain.WindowsCompiler
-
- getStderr(ProcessExecutor.Result) - Method in class com.facebook.buck.cxx.toolchain.WindowsMl64Compiler
-
- getStdErr() - Method in interface com.facebook.buck.event.external.elements.TestResultSummaryExternalInterface
-
- getStdErr() - Method in interface com.facebook.buck.jvm.java.JavacExecutionContext
-
- getStderr() - Method in interface com.facebook.buck.remoteexecution.RemoteExecutionServiceClient.ExecutionResult
-
- getStderr() - Method in class com.facebook.buck.shell.ShellStep
-
- getStderr() - Method in interface com.facebook.buck.step.StepExecutionResult
-
- getStdErr() - Method in class com.facebook.buck.test.TestResultSummary
-
- getStdErr() - Method in class com.facebook.buck.util.Console
-
- getStderr() - Method in interface com.facebook.buck.util.ProcessExecutor.LaunchedProcess
-
Input stream that maps into stderr of the process.
- getStderr() - Method in class com.facebook.buck.util.ProcessExecutor.LaunchedProcessImpl
-
- getStderr() - Method in class com.facebook.buck.util.ProcessExecutor.Result
-
- getStderr() - Method in interface com.facebook.buck.worker.WorkerJobResult
-
- getStderrContents() - Method in class com.facebook.buck.jvm.java.JavacPipelineState
-
- getStdErrLogLevel() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getStdErrLogLevel() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getStdErrLogLevel() - Method in interface com.facebook.buck.jvm.java.JavaTestDescription.CoreArg
-
- getStdErrLogLevel() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getStdErrLogLevel() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getStdErrLogLevel() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getStdIn() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getStdin(ExecutionContext) - Method in class com.facebook.buck.features.python.PexStep
-
Return the manifest as a JSON blob to write to the pex processes stdin.
- getStdin(ExecutionContext) - Method in class com.facebook.buck.shell.ShellStep
-
- getStdin() - Method in interface com.facebook.buck.util.ProcessExecutor.LaunchedProcess
-
Output stream that maps into stdin of the process.
- getStdin() - Method in class com.facebook.buck.util.ProcessExecutor.LaunchedProcessImpl
-
- getStdlibPath(SourcePathResolverAdapter) - Method in class com.facebook.buck.jvm.kotlin.ExternalKotlinc
-
- getStdlibPath(SourcePathResolverAdapter) - Method in class com.facebook.buck.jvm.kotlin.JarBackedReflectedKotlinc
-
- getStdlibPath(SourcePathResolverAdapter) - Method in interface com.facebook.buck.jvm.kotlin.Kotlinc
-
- getStdOut() - Method in class com.facebook.buck.cli.ProjectGeneratorParameters
-
- getStdOut() - Method in class com.facebook.buck.core.build.execution.context.ExecutionContext
-
- getStdOut() - Method in interface com.facebook.buck.core.rules.actions.ActionExecutionResult.ActionExecutionFailure
-
- getStdOut() - Method in interface com.facebook.buck.core.rules.actions.ActionExecutionResult.ActionExecutionSuccess
-
- getStdOut() - Method in interface com.facebook.buck.core.rules.actions.ActionExecutionResult
-
- getStdOut() - Method in interface com.facebook.buck.event.external.elements.TestResultSummaryExternalInterface
-
- getStdout() - Method in interface com.facebook.buck.remoteexecution.RemoteExecutionServiceClient.ExecutionResult
-
- getStdout() - Method in class com.facebook.buck.shell.ShellStep
-
- getStdOut() - Method in class com.facebook.buck.test.TestResultSummary
-
- getStdOut() - Method in class com.facebook.buck.util.Console
-
- getStdout() - Method in interface com.facebook.buck.util.ProcessExecutor.LaunchedProcess
-
Input stream that maps into stdout of the process.
- getStdout() - Method in class com.facebook.buck.util.ProcessExecutor.LaunchedProcessImpl
-
- getStdout() - Method in class com.facebook.buck.util.ProcessExecutor.Result
-
- getStdout() - Method in interface com.facebook.buck.worker.WorkerJobResult
-
- getStdoutContents() - Method in class com.facebook.buck.jvm.java.JavacPipelineState
-
- getStdOutLogLevel() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getStdOutLogLevel() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getStdOutLogLevel() - Method in interface com.facebook.buck.jvm.java.JavaTestDescription.CoreArg
-
- getStdOutLogLevel() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getStdOutLogLevel() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getStdOutLogLevel() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getStep() - Method in exception com.facebook.buck.step.StepFailedException
-
- getSteps(BuildContext, Path, Path) - Method in interface com.facebook.buck.cxx.LinkOutputPostprocessor
-
- getStore() - Method in class com.facebook.buck.jvm.java.KeystoreDescriptionArg
-
- getStoreBuilder() - Method in class com.facebook.buck.artifact_cache.HttpArtifactCacheEvent.Finished.Builder
-
- getStoreData() - Method in class com.facebook.buck.artifact_cache.HttpArtifactCacheEvent.Finished
-
- getStoreFuture() - Method in interface com.facebook.buck.core.build.engine.manifest.ManifestStoreResult
-
- getStorepass() - Method in class com.facebook.buck.android.KeystoreProperties
-
- getStoreRetryIntervalMillis() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getStoreType() - Method in class com.facebook.buck.artifact_cache.ArtifactCacheEvent
-
- getStoreType() - Method in interface com.facebook.buck.artifact_cache.HttpArtifactCacheEvent.HttpArtifactCacheEventStoreData
-
- getStrategy() - Method in interface com.facebook.buck.remoteexecution.event.listener.model.ReSessionData
-
- getStrategyConfig() - Method in class com.facebook.buck.remoteexecution.config.RemoteExecutionConfig
-
- getStrategyResult() - Method in class com.facebook.buck.core.build.engine.BuildResult
-
- getStrategyResult() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.Finished
-
- getStreamForPayload(int) - Method in class com.facebook.buck.slb.HybridThriftResponseHandler
-
Where to write the nth payload bytes to.
- getStrict() - Method in class com.facebook.buck.features.gwt.GwtBinaryDescriptionArg
-
If true
, the GWT Compiler's -strict
flag will be set.
- getString(int) - Method in class com.facebook.buck.android.resources.StringPool
-
- getStringCount() - Method in class com.facebook.buck.android.resources.StringPool
-
- getStringFiles() - Method in interface com.facebook.buck.android.FilteredResourcesProvider
-
- getStringFiles() - Method in class com.facebook.buck.android.IdentityResourcesProvider
-
- getStringFiles() - Method in class com.facebook.buck.android.ResourcesFilter
-
- getStringOrEnvironmentVariable(BuckConfig, String, String) - Static method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getStrings() - Method in class com.facebook.buck.android.resources.ResourcesXml
-
- getStrings() - Method in class com.facebook.buck.android.resources.ResourceTable
-
- GetStringsFilesStep - Class in com.facebook.buck.android
-
Generates a list of strings.xml files
- getStringTableOffset() - Method in class com.facebook.buck.cxx.toolchain.objectfile.MachoSymTabCommand
-
- getStringTableSize() - Method in class com.facebook.buck.cxx.toolchain.objectfile.MachoSymTabCommand
-
- getStringToFilter(QueryEnvironment<NODE_TYPE>, ImmutableList<QueryEnvironment.Argument<NODE_TYPE>>, QueryTarget) - Method in class com.facebook.buck.query.FilterFunction
-
- getStringToFilter(QueryEnvironment<T>, ImmutableList<QueryEnvironment.Argument<T>>, T) - Method in class com.facebook.buck.query.KindFunction
-
- getStringWithMacrosArgsConverter(BuildTarget, CellPathResolver, ActionGraphBuilder, CxxPlatform) - Static method in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- getStrip() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getStrip() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
Strip binary.
- getStrip() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getStrip() - Method in class com.facebook.buck.cxx.toolchain.MachoDylibStubParams
-
- getStripFlags() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
Strip flags.
- getStripFlags() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getStrippedObjectName() - Method in class com.facebook.buck.android.CopyNativeLibraries.StrippedObjectDescription
-
- getStripPrefix() - Method in class com.facebook.buck.file.HttpArchiveDescriptionArg
-
- getStripStyle() - Method in class com.facebook.buck.cxx.CxxStrip
-
- getStripToolArgs() - Method in enum com.facebook.buck.cxx.toolchain.StripStyle
-
- getStub() - Method in interface com.facebook.buck.remoteexecution.grpc.GrpcHeaderHandler.StubAndResponseMetadata
-
- getStubBinary() - Method in class com.facebook.buck.apple.toolchain.AppleCxxPlatform
-
- getStubBinaryPath() - Method in class com.facebook.buck.apple.toolchain.ApplePlatform
-
- getStubsDir() - Method in class com.facebook.buck.features.haskell.HaskellCompileRule
-
- getStyle() - Method in class com.facebook.buck.features.gwt.GwtBinaryDescriptionArg
-
This will be passed to the GWT Compiler's -style
flag.
- getSubcommand() - Method in class com.facebook.buck.cli.AbstractContainerCommand
-
- getSubcommand() - Method in class com.facebook.buck.cli.AuditCommand
-
- getSubcommand() - Method in class com.facebook.buck.cli.AuditMbrCommand
-
- getSubcommand() - Method in class com.facebook.buck.cli.BuckCommand
-
- getSubcommand() - Method in class com.facebook.buck.cli.PerfCasCommand
-
- getSubcommand() - Method in class com.facebook.buck.cli.PerfCommand
-
- getSubcommand() - Method in class com.facebook.buck.cli.PerfMbrCommand
-
- getSubcommand() - Method in class com.facebook.buck.cli.ServerCommand
-
- getSubCommand() - Method in class com.facebook.buck.log.InvocationInfo
-
- getSubCommandNameForLogging() - Method in class com.facebook.buck.cli.BuckCommand
-
- getSubCommands() - Method in class com.facebook.buck.cli.ProjectCommand
-
- getSubCommands() - Method in interface com.facebook.buck.support.cli.args.PluginBasedCommand
-
- getSubcommandsFieldName() - Method in class com.facebook.buck.cli.AbstractContainerCommand
-
- getSubgraph(Iterable<? extends TargetNode<? extends T>>) - Method in class com.facebook.buck.core.model.targetgraph.TargetGraph
-
Get the subgraph of the the current graph containing the passed in roots and all of their
transitive dependencies as nodes.
- getSubjectCommonName() - Method in class com.facebook.buck.apple.toolchain.CodeSignIdentity
-
Returns the full name of the identity.
- getSuccess() - Method in class com.facebook.buck.core.build.engine.BuildResult
-
- getSuccessCount() - Method in class com.facebook.buck.event.listener.stats.cache.RemoteCacheUploadStats
-
- getSuccessfullyConstructedBuildRules() - Method in interface com.facebook.buck.core.rules.ActionGraphBuilder
-
- getSuccessfullyConstructedBuildRules() - Method in class com.facebook.buck.core.rules.resolver.impl.MultiThreadedActionGraphBuilder
-
- getSuccessfullyConstructedBuildRules() - Method in class com.facebook.buck.core.rules.resolver.impl.RuleAnalysisCompatibleDelegatingActionGraphBuilder
-
- getSuccessOptional() - Method in class com.facebook.buck.core.build.engine.BuildResult
-
- getSuccessType() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.Finished
-
- getSuccessTypeName() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.Finished
-
- getSuccessUploadCount() - Method in class com.facebook.buck.artifact_cache.CacheCountersSummary
-
- getSuggestion() - Method in interface com.facebook.buck.doctor.config.DoctorSuggestion
-
- getSuggestions() - Method in interface com.facebook.buck.doctor.config.DoctorEndpointResponse
-
- getSuggestions() - Method in class com.facebook.buck.event.CompilerErrorEvent
-
- getSuggestions() - Method in interface com.facebook.buck.event.external.events.CompilerErrorEventExternalInterface
-
- getSummary() - Method in class com.facebook.buck.artifact_cache.CacheCountersSummaryEvent
-
- getSuperclass(TypeElement) - Static method in class com.facebook.buck.jvm.java.lang.model.MoreElements
-
- getSuperConsoleEnabled() - Method in class com.facebook.buck.log.InvocationInfo
-
- getSuperInfo() - Method in interface com.facebook.buck.rules.modern.ClassInfo
-
- getSuperInfo() - Method in class com.facebook.buck.rules.modern.impl.DefaultClassInfo
-
- getSuperRootPath() - Method in class com.facebook.buck.core.cell.Cells
-
- getSupertypes(Class<?>) - Static method in class com.facebook.buck.util.Types
-
Returns a Set of classes and interfaces inherited or implemented by clazz.
- getSupportAbiGenerationFromSource() - Method in class com.facebook.buck.jvm.java.ResolvedJavacPluginProperties
-
- getSupportedFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.swift.SwiftLibraryDescription
-
- getSupportedPlatformsRegex() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getSupportedPlatformsRegex() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getSupportedPlatformsRegex() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getSupportedPlatformsRegex() - Method in class com.facebook.buck.apple.PrebuiltAppleFrameworkDescriptionArg
-
- getSupportedPlatformsRegex() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
- getSupportedPlatformsRegex() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getSupportedPlatformsRegex() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getSupportedPlatformsRegex() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescriptionArg
-
- getSupportedPlatformsRegex() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getSupportedPlatformsRegex() - Method in class com.facebook.buck.swift.SwiftLibraryDescriptionArg
-
- getSupportedSourceVersion() - Method in class com.facebook.buck.core.module.annotationprocessor.BuckModuleAnnotationProcessor
-
- getSupportExposePackage(String) - Method in class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- getSupportsMergedLinking() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getSupportsMergedLinking() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getSupportsMergedLinking() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getSupportsMergedLinking() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
- getSupportsMergedLinking() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getSupportsMergedLinking() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getSuppressWarnings() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
Generate no warnings.
- getSuppressWarnings() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
Generate no warnings.
- getSuppressWarnings() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
Generate no warnings.
- getSuppressWarnings() - Method in interface com.facebook.buck.jvm.kotlin.KotlinLibraryDescription.CoreArg
-
Generate no warnings.
- getSuppressWarnings() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
Generate no warnings.
- getSuppressWarnings() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
Generate no warnings.
- getSwiftc() - Method in class com.facebook.buck.swift.SwiftToolchainDescriptionArg
-
Swift compiler binary.
- getSwiftc() - Method in interface com.facebook.buck.swift.toolchain.SwiftPlatform
-
- getSwiftcFlags() - Method in class com.facebook.buck.swift.SwiftToolchainDescriptionArg
-
Flags for Swift compiler.
- getSwiftCompilerFlags() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getSwiftCompilerFlags() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getSwiftCompilerFlags() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getSwiftCompilerFlags() - Method in interface com.facebook.buck.swift.SwiftCommonArg
-
- getSwiftModuleOutputPath() - Method in class com.facebook.buck.swift.SwiftCompile
-
- getSwiftName() - Method in class com.facebook.buck.apple.toolchain.ApplePlatform
-
The Swift name for the platform.
- getSwiftObjCGeneratedHeaderName(TargetNode<?>, Optional<String>) - Static method in class com.facebook.buck.features.apple.projectV2.SwiftAttributeParser
-
Get the generated header name with the provided optModuleName
or getting the module
name from the node
.
- getSwiftPlatform() - Method in class com.facebook.buck.apple.toolchain.AppleCxxPlatform
-
- getSwiftPlatform(SwiftTargetTriple) - Method in class com.facebook.buck.swift.SwiftToolchainBuildRule
-
Provides SwiftPlatform for given Swift target triple
- getSwiftRuntimePathsForBundling() - Method in interface com.facebook.buck.swift.toolchain.SwiftPlatform
-
- getSwiftRuntimePathsForLinking() - Method in interface com.facebook.buck.swift.toolchain.SwiftPlatform
-
- getSwiftSharedLibraryRunPaths() - Method in interface com.facebook.buck.swift.toolchain.SwiftPlatform
-
- getSwiftSources() - Method in class com.facebook.buck.apple.AppleLibrarySwiftMetadata
-
- getSwiftStaticRuntimePaths() - Method in interface com.facebook.buck.swift.toolchain.SwiftPlatform
-
- getSwiftStdlibTool() - Method in class com.facebook.buck.swift.SwiftToolchainDescriptionArg
-
Swift stdlib tool binary.
- getSwiftStdlibTool() - Method in interface com.facebook.buck.swift.toolchain.SwiftPlatform
-
- getSwiftStdlibToolFlags() - Method in class com.facebook.buck.swift.SwiftToolchainDescriptionArg
-
Flags for Swift stdlib tool.
- getSwiftTarget() - Method in interface com.facebook.buck.swift.toolchain.SwiftPlatform
-
- getSwiftToolchain() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
Target for the swift toolchain which should be used for this SDK.
- getSwiftVersion() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getSwiftVersion() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getSwiftVersion() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getSwiftVersion() - Method in interface com.facebook.buck.swift.SwiftCommonArg
-
- getSymbolNameTool() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getSymbols() - Method in class com.facebook.buck.parser.implicit.ImplicitInclude
-
- getSymbolTableOffset() - Method in class com.facebook.buck.cxx.toolchain.objectfile.MachoSymTabCommand
-
- getSymlinkPathForDir(Path) - Method in class com.facebook.buck.io.filesystem.BuckPaths
-
- getSymlinks() - Method in class com.facebook.buck.core.files.DirectoryList
-
- getSymlinksList() - Method in interface com.facebook.buck.remoteexecution.interfaces.Protocol.Directory
-
- getSymlinkTreeClass() - Method in class com.facebook.buck.cxx.CxxSymlinkTreeHeaders
-
- getSyntaxError() - Method in interface com.facebook.buck.json.BuildFileParseExceptionData
-
- getSystemEnv() - Static method in class com.facebook.buck.util.environment.EnvVariablesProvider
-
- getSystemJavaCompiler() - Static method in class com.facebook.buck.jvm.java.javax.SynchronizedToolProvider
-
- getSystemMemory() - Method in class com.facebook.buck.util.environment.BuildEnvironmentDescription
-
- getSystemToolClassLoader() - Static method in class com.facebook.buck.jvm.java.javax.SynchronizedToolProvider
-
- getTag() - Method in class com.facebook.buck.event.ExperimentEvent
-
- getTags() - Method in class com.facebook.buck.counters.Counter
-
- getTags() - Method in class com.facebook.buck.counters.CounterSnapshot
-
- getTags() - Method in class com.facebook.buck.event.ScubaData
-
- getTagSets() - Method in class com.facebook.buck.counters.CounterSnapshot
-
- getTagsForServer(URI) - Static method in class com.facebook.buck.event.listener.LoadBalancerEventsListener.ServerCounters
-
- getTarget() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getTarget() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getTarget() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getTarget(ImmutableMap<String, String>) - Method in class com.facebook.buck.artifact_cache.AbstractArtifactCacheEventFactory
-
- getTarget(Function<String, UnconfiguredBuildTarget>, TargetConfigurationSerializer, ImmutableMap<String, String>) - Static method in class com.facebook.buck.artifact_cache.AbstractArtifactCacheEventFactory
-
- getTarget(Function<String, UnconfiguredBuildTarget>, String, TargetConfiguration) - Static method in class com.facebook.buck.artifact_cache.AbstractArtifactCacheEventFactory
-
- getTarget() - Method in class com.facebook.buck.artifact_cache.ArtifactCacheEvent
-
- getTarget() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.FinishedRuleKeyCalc
-
- getTarget() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.StartedRuleKeyCalc
-
- getTarget() - Method in class com.facebook.buck.core.build.event.BuildRuleExecutionEvent.Event
-
- getTarget() - Method in interface com.facebook.buck.core.build.event.BuildRuleExecutionEvent
-
- getTarget() - Method in interface com.facebook.buck.core.sourcepath.BuildTargetSourcePath
-
- getTarget() - Method in class com.facebook.buck.core.test.rule.ExternalRunnerTestProtocol
-
- getTarget() - Method in class com.facebook.buck.core.test.rule.ExternalTestRunnerTestSpec
-
- getTarget() - Method in class com.facebook.buck.event.CompilerErrorEvent
-
- getTarget() - Method in interface com.facebook.buck.event.external.events.CompilerErrorEventExternalInterface
-
- getTarget() - Method in class com.facebook.buck.event.RuleKeyCalculationEvent.Event
-
- getTarget() - Method in interface com.facebook.buck.event.RuleKeyCalculationEvent
-
- getTarget() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getTarget() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getTarget() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getTarget() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getTarget() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getTarget() - Method in interface com.facebook.buck.jvm.java.JvmLibraryArg
-
- getTarget() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getTarget() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getTarget() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getTarget() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getTarget() - Method in interface com.facebook.buck.remoteexecution.interfaces.Protocol.SymlinkNode
-
- getTarget() - Method in class com.facebook.buck.rules.macros.BuildTargetMacro
-
- getTargetAppPlatform() - Method in class com.facebook.buck.android.toolchain.ndk.NdkCxxPlatformTargetConfiguration
-
- getTargetAppPlatformLevel() - Method in class com.facebook.buck.android.toolchain.ndk.NdkCxxPlatformTargetConfiguration
-
- getTargetArch() - Method in class com.facebook.buck.android.toolchain.ndk.NdkCxxPlatformTargetConfiguration
-
- getTargetArch() - Method in enum com.facebook.buck.android.toolchain.ndk.TargetCpuType
-
- getTargetArchAbi() - Method in class com.facebook.buck.android.toolchain.ndk.NdkCxxPlatformTargetConfiguration
-
- getTargetArchAbi() - Method in enum com.facebook.buck.android.toolchain.ndk.TargetCpuType
-
- getTargetConfiguration() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getTargetConfiguration() - Method in class com.facebook.buck.core.model.BuildTarget
-
- getTargetConfiguration() - Method in interface com.facebook.buck.core.rules.configsetting.ConfigSettingSelectableConfigurationContext
-
- getTargetConfiguration() - Method in class com.facebook.buck.parser.DefaultSelectableConfigurationContext
-
- getTargetConfiguration() - Method in class com.facebook.buck.rules.query.Query
-
- getTargetConfigurations() - Method in class com.facebook.buck.core.model.targetgraph.MergedTargetNode
-
- getTargetConfigurationSerializer() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getTargetCpuType() - Method in interface com.facebook.buck.android.AndroidLinkableMetadata
-
- getTargetCpuType() - Method in class com.facebook.buck.android.CopyNativeLibraries.StrippedObjectDescription
-
- getTargetCpuType() - Method in class com.facebook.buck.android.toolchain.ndk.NdkCxxPlatformTargetConfiguration
-
- getTargetCpuType() - Method in enum com.facebook.buck.android.toolchain.ndk.NdkTargetArchAbi
-
- getTargetDevice() - Method in class com.facebook.buck.core.build.execution.context.ExecutionContext
-
- getTargetDeviceOptional() - Method in class com.facebook.buck.cli.TargetDeviceCommandLineOptions
-
- getTargetDeviceOptional() - Method in class com.facebook.buck.cli.TestCommand
-
- getTargetDeviceOptions() - Method in class com.facebook.buck.cli.TargetDeviceCommandLineOptions
-
- getTargetDeviceOptions() - Method in class com.facebook.buck.cli.TestCommand
-
- getTargetEvaluator() - Method in class com.facebook.buck.cli.BuckQueryEnvironment
-
- getTargetEvaluator() - Method in interface com.facebook.buck.query.QueryEnvironment
-
Returns an evaluator for target patterns.
- getTargetEvaluator() - Method in class com.facebook.buck.query.TargetVariablesQueryEnvironment
-
- getTargetEvaluator() - Method in class com.facebook.buck.rules.query.GraphEnhancementQueryEnvironment
-
- getTargetForId(ProjectFilesystem, String, AndroidBuildToolsLocation, AndroidSdkLocation, Optional<Supplier<Tool>>, Optional<ToolProvider>, AdbToolchain) - Static method in class com.facebook.buck.android.toolchain.impl.AndroidPlatformTargetProducer
-
- getTargetForPlatform(CxxPlatform, boolean) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.LegacyNativeLinkTargetGroup
-
- getTargetForPlatform(CxxPlatform, boolean) - Method in interface com.facebook.buck.cxx.toolchain.nativelink.NativeLinkTargetGroup
-
- getTargetGraph(CommandRunnerParams, ImmutableSet<BuildTarget>) - Method in class com.facebook.buck.cli.AbstractPerfCommand
-
Most of our perf tests require a target graph, this helps them get it concisely.
- getTargetGraph() - Method in class com.facebook.buck.cli.BuckQueryEnvironment
-
- getTargetGraph(TargetGraphCreationResult, Optional<TargetGraphCreationResult>) - Static method in class com.facebook.buck.core.model.graph.ActionAndTargetGraphs
-
Helper method to choose versioned vs un-versioned
TargetGraph
.
- getTargetGraph() - Method in class com.facebook.buck.core.model.graph.ActionAndTargetGraphs
-
- getTargetGraph() - Method in class com.facebook.buck.core.model.targetgraph.TargetGraphCreationResult
-
- getTargetGraph() - Method in interface com.facebook.buck.core.rules.BuildRuleCreationContextWithTargetGraph
-
- getTargetGraphOnlyDeps() - Method in class com.facebook.buck.android.AndroidBinary
-
- getTargetGraphOnlyDeps() - Method in class com.facebook.buck.android.AndroidBundle
-
- getTargetGraphOnlyDeps() - Method in class com.facebook.buck.apple.AppleDebuggableBinary
-
- getTargetGraphOnlyDeps() - Method in class com.facebook.buck.core.model.targetgraph.impl.TargetNodeImpl
-
BuildTargetPaths which, when changed, may change the BuildRules produced by this TargetNode,
but whose steps don't need executing in order to build this TargetNode's BuildRules.
- getTargetGraphOnlyDeps() - Method in interface com.facebook.buck.core.model.targetgraph.TargetNode
-
BuildTargetPaths which, when changed, may change the BuildRules produced by this TargetNode,
but whose steps don't need executing in order to build this TargetNode's BuildRules.
- getTargetGraphOnlyDeps() - Method in interface com.facebook.buck.core.rules.attr.HasDeclaredAndExtraDeps
-
- getTargetGraphOnlyDeps() - Method in class com.facebook.buck.core.rules.BuildRuleParams
-
- getTargetGraphOnlyDeps() - Method in class com.facebook.buck.core.rules.impl.AbstractBuildRuleWithDeclaredAndExtraDeps
-
- getTargetHashModifiedPaths() - Method in class com.facebook.buck.cli.TargetsCommand
-
- getTargetId() - Method in interface com.facebook.buck.cli.ActionGraphSerializer.ActionGraphData
-
- getTargetId() - Method in interface com.facebook.buck.event.listener.FileSerializationOutputRuleDepsListener.RuleExecutionTimeData
-
- getTargetKind(QueryBuildTarget) - Method in class com.facebook.buck.cli.BuckQueryEnvironment
-
- getTargetKind(NODE_TYPE) - Method in interface com.facebook.buck.query.QueryEnvironment
-
- getTargetKind(NODE_TYPE) - Method in class com.facebook.buck.query.TargetVariablesQueryEnvironment
-
- getTargetKind(QueryBuildTarget) - Method in class com.facebook.buck.rules.query.GraphEnhancementQueryEnvironment
-
- getTargetLevel() - Method in class com.facebook.buck.jvm.java.JavacLanguageLevelOptions
-
- getTargetName() - Method in class com.facebook.buck.core.parser.buildtargetparser.BuildTargetOutputLabelParser.TargetWithOutputLabel
-
- getTargetNames() - Method in class com.facebook.buck.core.test.event.TestRunEvent.Started
-
- getTargetNames() - Method in class com.facebook.buck.test.external.ExternalTestRunEvent.Started
-
- getTargetNodeAssertCompatible(ParsingContext, BuildTarget, DependencyStack) - Method in interface com.facebook.buck.parser.Parser
-
- getTargetNodeAssertCompatible(PerBuildState, BuildTarget, DependencyStack) - Method in interface com.facebook.buck.parser.Parser
-
- getTargetNodeDescriptionName() - Method in class com.facebook.buck.event.ActionGraphPerfStatEvent
-
- getTargetNodeJobAssertCompatible(PerBuildState, BuildTarget, DependencyStack) - Method in interface com.facebook.buck.parser.Parser
-
- getTargetNodeOptional() - Method in class com.facebook.buck.core.model.targetgraph.TargetNodeMaybeIncompatible
-
- getTargetNodeRawAttributes(PerBuildState, Cell, TargetNode<?>, DependencyStack) - Method in interface com.facebook.buck.parser.Parser
-
- getTargetNodeRawAttributes(ParsingContext, TargetNode<?>, DependencyStack) - Method in interface com.facebook.buck.parser.Parser
-
- getTargetNodeRawAttributesJob(PerBuildState, Cell, TargetNode<?>, DependencyStack) - Method in interface com.facebook.buck.parser.Parser
-
- getTargetNodeTranslator(TargetNode<?>, ImmutableMap<BuildTarget, Version>) - Method in class com.facebook.buck.versions.AbstractVersionedTargetGraphBuilder
-
- getTargetPackage() - Method in interface com.facebook.buck.android.AndroidManifestReader
-
- getTargetPackage() - Method in class com.facebook.buck.android.DefaultAndroidManifestReader
-
- getTargetPlatform(TargetConfiguration, DependencyStack) - Method in class com.facebook.buck.core.model.platform.impl.ThrowingPlatformResolver
-
Unconditionally throw
- getTargetPlatform(TargetConfiguration, DependencyStack) - Method in interface com.facebook.buck.core.model.platform.TargetPlatformResolver
-
- getTargetPlatform() - Method in class com.facebook.buck.core.model.RuleBasedTargetConfiguration
-
- getTargetPlatform(TargetConfiguration, DependencyStack) - Method in class com.facebook.buck.core.rules.platform.DefaultTargetPlatformResolver
-
- getTargetPlatform(TargetConfiguration, DependencyStack) - Method in class com.facebook.buck.core.rules.platform.RuleBasedTargetPlatformResolver
-
- getTargetPlatformBinary(Optional<BuildTarget>, Optional<PatternMatchedCollection<BuildTarget>>, Flavor) - Static method in class com.facebook.buck.apple.AppleDescriptions
-
Returns a build target of the apple binary for the requested target platform.
- getTargetPlatformDetectorSpec() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getTargetPlatformResolver() - Method in interface com.facebook.buck.core.rules.config.registry.ConfigurationRuleRegistry
-
Resolves target configuration to a platform.
- getTargetPlatforms() - Method in class com.facebook.buck.cli.AbstractCommand
-
- getTargetPlatforms() - Method in class com.facebook.buck.cli.AbstractContainerCommand
-
- getTargetPlatforms() - Method in interface com.facebook.buck.cli.Command
-
- getTargetPlatforms() - Method in class com.facebook.buck.cli.UnconfiguredQueryCommand
-
- getTargetPlatforms() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getTargetProxy() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXTargetDependency
-
- getTargetResultClass() - Method in class com.facebook.buck.core.graph.transformation.model.ComposedComputationIdentifier
-
- getTargetResultClass() - Method in class com.facebook.buck.core.graph.transformation.model.ComposedKey
-
- getTargets() - Method in class com.facebook.buck.apple.xcode.xcodeproj.PBXProject
-
- getTargets() - Method in class com.facebook.buck.features.project.intellij.aggregation.AggregationModule
-
- getTargets() - Method in class com.facebook.buck.features.project.intellij.model.IjLibrary
-
- getTargets() - Method in class com.facebook.buck.features.project.intellij.model.IjModule
-
- getTargets() - Method in interface com.facebook.buck.features.project.intellij.model.IjProjectElement
-
- getTargets() - Method in class com.facebook.buck.parser.api.BuildFileManifest
-
- getTargets(QueryEnvironment<NODE_TYPE>) - Method in class com.facebook.buck.query.QueryExpression
-
Returns a set of all targets referenced from literals within this query expression.
- getTargets() - Method in class com.facebook.buck.rules.macros.CxxGenruleFilterAndTargetsMacro
-
- getTargetSdkVersion() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
The minimum OS version for which this target should be built.
- getTargetSdkVersion(ApplePlatform) - Method in class com.facebook.buck.apple.AppleConfig
-
- getTargetSdkVersion() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
The minimum OS version for which this target should be built.
- getTargetSdkVersion() - Method in interface com.facebook.buck.apple.AppleNativeTargetDescriptionArg
-
The minimum OS version for which this target should be built.
- getTargetSdkVersion() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
The minimum OS version for which this target should be built.
- getTargetSdkVersion() - Method in class com.facebook.buck.rules.coercer.ManifestEntries
-
- getTargetSdkVersion() - Method in class com.facebook.buck.swift.SwiftLibraryDescriptionArg
-
The minimum OS version for which this target should be built.
- getTargetSdkVersion() - Method in class com.facebook.buck.swift.toolchain.SwiftTargetTriple
-
- getTargetsFromBuildTargets(Iterable<BuildTarget>) - Method in class com.facebook.buck.cli.BuckQueryEnvironment
-
- getTargetsFromTargetNodes(Iterable<TargetNode<?>>) - Method in class com.facebook.buck.cli.BuckQueryEnvironment
-
- getTargetsInAttribute(QueryBuildTarget, String) - Method in class com.facebook.buck.cli.BuckQueryEnvironment
-
- getTargetsInAttribute(NODE_TYPE, String) - Method in interface com.facebook.buck.query.QueryEnvironment
-
Returns the existing targets in the value of `attribute` of the given `target`.
- getTargetsInAttribute(NODE_TYPE, String) - Method in class com.facebook.buck.query.TargetVariablesQueryEnvironment
-
- getTargetsInAttribute(QueryBuildTarget, String) - Method in class com.facebook.buck.rules.query.GraphEnhancementQueryEnvironment
-
- getTargetsInAttribute(TypeCoercerFactory, TargetNode<T>, String, CellNameResolver) - Static method in class com.facebook.buck.rules.query.QueryTargetAccessor
-
Get targets in attribute.
- getTargetsMatchingPattern(String) - Method in interface com.facebook.buck.query.QueryEnvironment
-
Returns the set of target nodes in the graph for the specified target pattern, in 'buck build'
syntax.
- getTargetsToGeneratedSourcesMap() - Method in class com.facebook.buck.features.project.intellij.model.IjModule
-
- getTargetsToGeneratedSourcesMap() - Method in class com.facebook.buck.features.project.intellij.ModuleBuildContext
-
- getTargetsVersions() - Method in class com.facebook.buck.command.config.BuildBuckConfig
-
- getTargetType() - Method in class com.facebook.buck.parser.spec.BuildTargetSpec
-
- getTargetType() - Method in class com.facebook.buck.parser.spec.TargetNodePredicateSpec
-
- getTargetType() - Method in interface com.facebook.buck.parser.spec.TargetNodeSpec
-
- getTargetWithOutputs() - Method in interface com.facebook.buck.core.sourcepath.BuildTargetSourcePath
-
- getTargetWithOutputs() - Method in class com.facebook.buck.core.sourcepath.DefaultBuildTargetSourcePath
-
- getTargetWithOutputs() - Method in class com.facebook.buck.core.sourcepath.ExplicitBuildTargetSourcePath
-
- getTargetWithOutputs() - Method in class com.facebook.buck.core.sourcepath.ForwardingBuildTargetSourcePath
-
- getTargetWithOutputs() - Method in class com.facebook.buck.rules.macros.BuildTargetMacro
-
- getTargetWithOutputs() - Method in class com.facebook.buck.rules.macros.LocationPlatformMacro
-
- getTask(PluginClassLoaderFactory, JavaCompiler, Writer, JavaFileManager, DiagnosticListener<? super JavaFileObject>, Iterable<String>, Iterable<String>, Iterable<? extends JavaFileObject>) - Static method in interface com.facebook.buck.jvm.java.abi.source.api.FrontendOnlyJavacTaskProxy
-
- getTask(PluginClassLoaderFactory, JavaCompiler, Writer, JavaFileManager, DiagnosticListener<? super JavaFileObject>, Iterable<String>, Iterable<String>, Iterable<? extends JavaFileObject>) - Static method in interface com.facebook.buck.jvm.java.plugin.api.BuckJavacTaskProxy
-
- getTempDir() - Method in class com.facebook.buck.rules.macros.WorkerMacroArg
-
- getTempDir(ProjectFilesystem) - Method in interface com.facebook.buck.shell.WorkerTool
-
Returns temp dir for this WorkerTool and provided filesystem
- getTempDir() - Method in interface com.facebook.buck.worker.WorkerProcessParams
-
Temp folder location.
- getTemplateForRequest(Request) - Method in interface com.facebook.buck.httpserver.TemplateHandlerDelegate
-
- getTemplateForRequest(Request) - Method in class com.facebook.buck.httpserver.TraceHandlerDelegate
-
- getTemplateForRequest(Request) - Method in class com.facebook.buck.httpserver.TracesHandlerDelegate
-
- getTemplateGroup() - Method in interface com.facebook.buck.httpserver.TemplateHandlerDelegate
-
- getTemplateGroup() - Method in class com.facebook.buck.httpserver.TraceHandlerDelegate
-
- getTemplateGroup() - Method in class com.facebook.buck.httpserver.TracesHandlerDelegate
-
- getTempPath() - Method in class com.facebook.buck.rules.modern.DefaultOutputPathResolver
-
- getTempPath() - Method in interface com.facebook.buck.rules.modern.OutputPathResolver
-
Returns a relative path to the root directory for intermediate build outputs.
- getTempPath(String) - Method in interface com.facebook.buck.rules.modern.OutputPathResolver
-
- getTenantId() - Method in class com.facebook.buck.remoteexecution.config.RemoteExecutionConfig
-
- getTest() - Method in class com.facebook.buck.shell.ShTestDescriptionArg
-
- getTestables() - Method in class com.facebook.buck.apple.xcode.XCScheme.TestAction
-
- getTestAction() - Method in class com.facebook.buck.apple.xcode.XCScheme
-
- getTestCaseName() - Method in class com.facebook.buck.core.test.event.TestSummaryEvent
-
- getTestCaseName() - Method in interface com.facebook.buck.event.external.elements.TestCaseSummaryExternalInterface
-
- getTestCaseName() - Method in interface com.facebook.buck.event.external.elements.TestResultSummaryExternalInterface
-
- getTestCaseName() - Method in class com.facebook.buck.test.TestCaseSummary
-
- getTestCaseName() - Method in class com.facebook.buck.test.TestResultSummary
-
- getTestCases() - Method in interface com.facebook.buck.event.external.elements.TestResultsExternalInterface
-
- getTestCases() - Method in class com.facebook.buck.test.TestResults
-
- getTestCaseSummaries() - Method in class com.facebook.buck.apple.TestCaseSummariesBuildingIdb
-
- getTestCaseTimeoutMs() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getTestCaseTimeoutMs() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getTestCaseTimeoutMs() - Method in interface com.facebook.buck.jvm.java.JavaTestDescription.CoreArg
-
- getTestCaseTimeoutMs() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getTestCaseTimeoutMs() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getTestCaseTimeoutMs() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getTestCommand(ExecutionContext, TestRunningOptions, BuildContext, TestRule.TestReportingCallback) - Method in class com.facebook.buck.apple.AppleTest
-
- getTestEventsByThread() - Method in class com.facebook.buck.event.listener.BuildRuleThreadTracker
-
- getTestHostApp() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getTestLogDirectoryEnvironmentVariable() - Method in class com.facebook.buck.apple.AppleConfig
-
- getTestLogLevel() - Method in class com.facebook.buck.apple.AppleConfig
-
- getTestLogLevelEnvironmentVariable() - Method in class com.facebook.buck.apple.AppleConfig
-
- getTestLogPaths() - Method in class com.facebook.buck.test.TestResults
-
- getTestMainPath(SourcePathResolverAdapter, Optional<PythonTestRunner>) - Static method in class com.facebook.buck.features.python.PythonTestDescription
-
- getTestModulesListName() - Static method in class com.facebook.buck.features.python.PythonTestDescription
-
- getTestModulesListPath(BuildTarget, ProjectFilesystem) - Static method in class com.facebook.buck.features.python.PythonTestDescription
-
- getTestName() - Method in class com.facebook.buck.core.test.event.TestSummaryEvent
-
- getTestName() - Method in interface com.facebook.buck.event.external.elements.TestResultSummaryExternalInterface
-
- getTestName() - Method in class com.facebook.buck.test.TestResultSummary
-
- getTestResults() - Method in interface com.facebook.buck.event.external.elements.TestCaseSummaryExternalInterface
-
- getTestResults() - Method in class com.facebook.buck.test.TestCaseSummary
-
- getTestResultSummary() - Method in class com.facebook.buck.core.test.event.TestSummaryEvent.Finished
-
- getTestRuleTimeoutMs() - Method in class com.facebook.buck.android.AndroidInstrumentationTestDescriptionArg
-
- getTestRuleTimeoutMs() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getTestRuleTimeoutMs() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getTestRuleTimeoutMs() - Method in interface com.facebook.buck.core.description.arg.HasTestTimeout
-
- getTestRuleTimeoutMs() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getTestRuleTimeoutMs() - Method in class com.facebook.buck.features.d.DTestDescriptionArg
-
- getTestRuleTimeoutMs() - Method in class com.facebook.buck.features.go.GoTestDescriptionArg
-
- getTestRuleTimeoutMs() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getTestRuleTimeoutMs() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getTestRuleTimeoutMs() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getTestRuleTimeoutMs() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getTestRuleTimeoutMs() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getTestRuleTimeoutMs() - Method in class com.facebook.buck.shell.ShTestDescriptionArg
-
- getTestRunnerGenerator() - Method in class com.facebook.buck.features.go.GoTestRunner
-
- getTestRunnerGenerator() - Method in class com.facebook.buck.features.go.GoTestRunnerDescriptionArg
-
- getTests() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getTests() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getTests() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getTests() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getTests() - Method in class com.facebook.buck.android.ApkGenruleDescriptionArg
-
- getTests() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getTests() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getTests() - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg
-
- getTests() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getTests() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getTests() - Method in interface com.facebook.buck.core.description.arg.HasTests
-
- getTests() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getTests() - Method in class com.facebook.buck.cxx.CxxGenruleDescriptionArg
-
- getTests() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getTests() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getTests() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getTests() - Method in class com.facebook.buck.features.go.GoLibraryDescriptionArg
-
- getTests() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getTests() - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg
-
- getTests() - Method in class com.facebook.buck.features.js.JsLibraryDescriptionArg
-
- getTests() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
- getTests() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
- getTests() - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg
-
- getTests() - Method in class com.facebook.buck.features.python.PythonLibraryDescriptionArg
-
- getTests() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getTests() - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg
-
- getTests() - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg
-
- getTests() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getTests() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getTests() - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getTests() - Method in class com.facebook.buck.jvm.java.JarGenruleDescriptionArg
-
- getTests() - Method in class com.facebook.buck.jvm.java.JavaBinaryDescriptionArg
-
- getTests() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getTests() - Method in interface com.facebook.buck.jvm.java.JavaLibraryWithTests
-
- getTests() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getTests() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getTests() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getTests() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getTests() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getTests() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getTests() - Method in class com.facebook.buck.shell.GenruleDescriptionArg
-
- getTests() - Method in class com.facebook.buck.shell.ShBinaryDescriptionArg
-
- getTests() - Method in class com.facebook.buck.shell.TestSuiteDescriptionArg
-
Test or TestSuite targets that should be invoked when this rule run through buck test
- getTestSelectorList() - Method in class com.facebook.buck.cli.TestSelectorOptions
-
- getTestSelectorList() - Method in class com.facebook.buck.core.test.event.TestRunEvent.Started
-
- getTestSelectorList() - Method in class com.facebook.buck.test.external.ExternalTestRunEvent.Started
-
- getTestSelectorList() - Method in class com.facebook.buck.test.TestRunningOptions
-
- getTestsForTarget(QueryBuildTarget) - Method in class com.facebook.buck.cli.BuckQueryEnvironment
-
- getTestsForTarget(NODE_TYPE) - Method in interface com.facebook.buck.query.QueryEnvironment
-
Returns the tests associated with the given target.
- getTestsForTarget(NODE_TYPE) - Method in class com.facebook.buck.query.TargetVariablesQueryEnvironment
-
- getTestsForTarget(QueryBuildTarget) - Method in class com.facebook.buck.rules.query.GraphEnhancementQueryEnvironment
-
- getTestSources() - Method in class com.facebook.buck.features.go.GoTestCoverSource
-
- getTestStatusMessage() - Method in class com.facebook.buck.core.test.event.TestStatusMessageEvent
-
- getTestSummary(ExecutionContext) - Method in class com.facebook.buck.shell.RunShTestAndRecordResultStep
-
- getTestSummary(ExecutionContext) - Method in class com.facebook.buck.shell.RunTestAndRecordResultStep
-
Run whatever binaries are necessary, and return a
TestResultSummary
explaining the
outcome
- getTestTargetsForNode(TargetNode<?>) - Static method in class com.facebook.buck.core.model.targetgraph.impl.TargetNodes
-
If node
refers to a node which contains references to its tests, returns the tests
associated with that node.
- getTestTargetsForNodes(Iterator<TargetNode<?>>) - Static method in class com.facebook.buck.core.model.targetgraph.impl.TargetNodes
-
- getTestType() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getTestType() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getTestType() - Method in interface com.facebook.buck.jvm.java.JavaTestDescription.CoreArg
-
- getTestType() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getTestType() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getTestType() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getText() - Method in enum com.facebook.buck.doctor.config.DoctorSuggestion.StepStatus
-
- getText() - Method in interface com.facebook.buck.json.BuildFileParseExceptionStackTraceEntry
-
- getText() - Method in interface com.facebook.buck.json.BuildFileSyntaxError
-
- getThinLto() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getThinLto() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getThinLto() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getThinLto() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getThinLto() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getThinLto() - Method in class com.facebook.buck.cxx.CxxLinkOptions
-
- getThinLto() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getThinLto() - Method in interface com.facebook.buck.cxx.LinkableCxxConstructorArg
-
- getThinLto() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getThinLto() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getThreadCount() - Method in class com.facebook.buck.event.listener.CommonThreadStateRenderer
-
- getThreadId() - Method in class com.facebook.buck.event.AbstractBuckEvent
-
- getThreadId() - Method in interface com.facebook.buck.event.BuckEvent
-
- getThreadId() - Method in class com.facebook.buck.event.chrome_trace.ChromeTraceEvent
-
- getThreadIdToCommandIdMapper() - Method in class com.facebook.buck.log.GlobalStateManager
-
- getThreadLineLimit() - Method in class com.facebook.buck.event.listener.SuperConsoleConfig
-
- getThreadLineLimitOnError() - Method in class com.facebook.buck.event.listener.SuperConsoleConfig
-
- getThreadLineLimitOnWarning() - Method in class com.facebook.buck.event.listener.SuperConsoleConfig
-
- getThreadLineOutputMaxColumns() - Method in class com.facebook.buck.event.listener.SuperConsoleConfig
-
- getThreadPoolKeepAliveDurationMillis() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getThreadPoolSize() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getThreads() - Method in interface com.facebook.buck.remoteexecution.config.RemoteExecutionStrategyConfig
-
- getThreadToCommandRegister() - Method in class com.facebook.buck.log.GlobalStateManager
-
- getThreadUserNanoDuration() - Method in class com.facebook.buck.util.timing.ClockDuration
-
- getThreadUserNanoTime() - Method in class com.facebook.buck.event.AbstractBuckEvent
-
- getThreadUserNanoTime() - Method in interface com.facebook.buck.event.BuckEvent
-
- getThriftData() - Method in class com.facebook.buck.artifact_cache.ThriftArtifactCacheProtocol.Response
-
- getThriftPath() - Method in class com.facebook.buck.slb.ThriftOverHttpServiceConfig
-
- getThriftProtocol() - Method in class com.facebook.buck.slb.HybridThriftOverHttpServiceImplArgs
-
- getThriftProtocol() - Method in class com.facebook.buck.slb.ThriftOverHttpServiceConfig
-
- getThrowableOrigin(Throwable) - Static method in class com.facebook.buck.util.MoreThrowables
-
Returns string representing class, method, filename and line number that throwable was thrown
from
- getTime() - Method in interface com.facebook.buck.event.external.elements.TestResultSummaryExternalInterface
-
- getTime() - Method in class com.facebook.buck.log.ErrorLogRecord
-
- getTime() - Method in class com.facebook.buck.test.TestResultSummary
-
- getTimeout() - Method in class com.facebook.buck.android.InstrumentationStep
-
- getTimeout() - Method in class com.facebook.buck.jvm.java.JUnitStep
-
- getTimeout() - Method in class com.facebook.buck.shell.ShellStep
-
- getTimeoutHandler(ExecutionContext) - Method in class com.facebook.buck.jvm.java.JUnitStep
-
- getTimeoutHandler(ExecutionContext) - Method in class com.facebook.buck.shell.ShellStep
-
- getTimeSpentInGcMs() - Method in class com.facebook.buck.util.perf.PerfStatsTracking.MemoryPerfStatsEvent
-
- getTimestampMillis() - Method in class com.facebook.buck.core.test.event.TestStatusMessageEvent
-
- getTimestampMillis() - Method in class com.facebook.buck.event.AbstractBuckEvent
-
- getTimestampMillis() - Method in interface com.facebook.buck.event.external.events.BuckEventExternalInterface
-
- getTimestampMillis() - Method in class com.facebook.buck.log.InvocationInfo
-
- getTimestampMillis() - Method in interface com.facebook.buck.test.TestStatusMessage
-
- getTmpDir() - Method in class com.facebook.buck.io.filesystem.BuckPaths
-
- getTmpGenPathForSourceAbi(ProjectFilesystem, BuildTarget) - Static method in class com.facebook.buck.jvm.core.JavaAbis
-
- getTool() - Method in interface com.facebook.buck.rules.args.ToolArg
-
- getTool(BuildRule) - Method in class com.facebook.buck.rules.macros.WorkerMacroExpander
-
- getTool(String, String, BuildRuleResolver, TargetConfiguration) - Method in class com.facebook.buck.rules.tool.config.ToolConfig
-
- getTool() - Method in interface com.facebook.buck.shell.WorkerTool
-
- getToolchain() - Method in class com.facebook.buck.android.toolchain.ndk.NdkCxxPlatformTargetConfiguration
-
- getToolchain() - Method in enum com.facebook.buck.android.toolchain.ndk.TargetCpuType
-
- getToolchainClass() - Method in interface com.facebook.buck.core.toolchain.ToolchainDescriptor
-
- getToolchainDescriptor() - Method in class com.facebook.buck.android.toolchain.impl.AndroidSdkToolchainsSupplier
-
- getToolchainDescriptor() - Method in class com.facebook.buck.android.toolchain.ndk.impl.AndroidNdkToolchainsSupplier
-
- getToolchainDescriptor() - Method in class com.facebook.buck.apple.toolchain.impl.AppleToolchainsSupplier
-
- getToolchainDescriptor() - Method in interface com.facebook.buck.core.toolchain.ToolchainSupplier
-
- getToolchainDescriptor() - Method in class com.facebook.buck.cxx.toolchain.impl.CxxToolchainsSupplier
-
- getToolchainDescriptor() - Method in class com.facebook.buck.features.dotnet.DotnetToolchainSupplier
-
- getToolchainDescriptor() - Method in class com.facebook.buck.features.go.GoToolchainSupplier
-
- getToolchainDescriptor() - Method in class com.facebook.buck.features.haskell.HaskellToolchainSupplier
-
- getToolchainDescriptor() - Method in class com.facebook.buck.features.lua.LuaToolchainsSupplier
-
- getToolchainDescriptor() - Method in class com.facebook.buck.features.ocaml.OcamlToolchainsSupplier
-
- getToolchainDescriptor() - Method in class com.facebook.buck.features.python.toolchain.impl.PythonToolchainsSupplier
-
- getToolchainDescriptor() - Method in class com.facebook.buck.features.rust.RustToolchainSupplier
-
- getToolchainDescriptor() - Method in class com.facebook.buck.file.downloader.impl.DownloaderSupplier
-
- getToolchainDescriptor() - Method in class com.facebook.buck.infer.toolchain.InferToolchainSupplier
-
- getToolchainDescriptor() - Method in class com.facebook.buck.jvm.java.toolchain.impl.JavaToolchainsSupplier
-
- getToolchainDescriptor() - Method in class com.facebook.buck.swift.toolchain.impl.SwiftToolchainsSupplier
-
- getToolchainFactoryClass() - Method in interface com.facebook.buck.core.toolchain.ToolchainDescriptor
-
- getToolchainInstantiationException(String, TargetConfiguration) - Method in class com.facebook.buck.core.toolchain.impl.DefaultToolchainProvider
-
- getToolchainInstantiationException(String, TargetConfiguration) - Method in interface com.facebook.buck.core.toolchain.ToolchainProvider
-
- getToolchainName() - Method in class com.facebook.buck.core.toolchain.rule.LegacyToolchainDescriptionArg
-
The name of the legacy toolchain, from Toolchain#getName()
- getToolchainPaths() - Method in class com.facebook.buck.apple.toolchain.AppleSdkPaths
-
Absolute paths to tools and files independent of the platform.
- getToolchainProvider() - Method in interface com.facebook.buck.core.cell.Cell
-
- getToolchainProvider() - Method in interface com.facebook.buck.core.description.DescriptionCreationContext
-
- getToolchainProvider() - Method in interface com.facebook.buck.core.rules.BuildRuleCreationContext
-
- getToolchainProvider() - Method in interface com.facebook.buck.core.rules.BuildRuleCreationContextWithTargetGraph
-
- getToolchains() - Method in class com.facebook.buck.apple.toolchain.AppleSdk
-
The toolchains used by the SDK.
- getToolchainsOverrideForSDKName(String) - Method in class com.facebook.buck.apple.AppleConfig
-
- getToolchainsWithCapability(Class<T>) - Method in class com.facebook.buck.core.toolchain.impl.DefaultToolchainProvider
-
- getToolchainsWithCapability(Class<T>) - Method in interface com.facebook.buck.core.toolchain.ToolchainProvider
-
Provides access to all known toolchains that support the provided capability.
- getToolchainTarget() - Method in class com.facebook.buck.android.toolchain.ndk.NdkCxxPlatformTargetConfiguration
-
- getToolchainTarget() - Method in enum com.facebook.buck.android.toolchain.ndk.TargetCpuType
-
- getToolPath(ImmutableList<Path>, String) - Method in class com.facebook.buck.apple.toolchain.impl.XcodeToolFinder
-
- getToolProvider(SourcePath) - Static method in class com.facebook.buck.core.toolchain.toolprovider.impl.ToolProviders
-
- getToolProvider(String, String) - Method in class com.facebook.buck.rules.tool.config.ToolConfig
-
- getToolProvider(String, String, Function<String, Path>) - Method in class com.facebook.buck.rules.tool.config.ToolConfig
-
- getToolType() - Method in class com.facebook.buck.cxx.toolchain.CxxToolProvider
-
Return tool type of this provider instance
- getTopLevelTypeElement(Element) - Static method in class com.facebook.buck.jvm.java.lang.model.MoreElements
-
- getTopoSortedNativeLinkables(Iterable<? extends NativeLinkable>, TopologicalSort.Traversable<NativeLinkable>) - Static method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkables
-
- getTotal(ProcessResourceConsumption, ProcessResourceConsumption) - Static method in class com.facebook.buck.util.ProcessResourceConsumption
-
- getTotalBytes() - Method in interface com.facebook.buck.event.listener.stats.cache.NetworkStatsTracker.RemoteArtifactUploadStats
-
- getTotalCacheBytes() - Method in class com.facebook.buck.artifact_cache.CacheCountersSummary
-
- getTotalCacheErrors() - Method in class com.facebook.buck.artifact_cache.CacheCountersSummary
-
- getTotalCacheHits() - Method in class com.facebook.buck.artifact_cache.CacheCountersSummary
-
- getTotalCacheIgnores() - Method in class com.facebook.buck.artifact_cache.CacheCountersSummary
-
- getTotalCacheLocalKeyUnchangedHits() - Method in class com.facebook.buck.artifact_cache.CacheCountersSummary
-
- getTotalCacheMisses() - Method in class com.facebook.buck.artifact_cache.CacheCountersSummary
-
- getTotalCompletedTimeFromEventIntervals(Collection<EventInterval>) - Static method in class com.facebook.buck.event.listener.AbstractConsoleEventBusListener
-
Get the summed elapsed time from all matched event pairs.
- getTotalDeps() - Method in class com.facebook.buck.core.model.targetgraph.impl.TargetNodeImpl
-
- getTotalDeps() - Method in interface com.facebook.buck.core.model.targetgraph.TargetNode
-
Dependencies that include build targets as well as configuration targets that this node depends
on.
- getTotalEvictionCount() - Method in interface com.facebook.buck.util.cache.CacheStatsTracker
-
- getTotalEvictionCount() - Method in class com.facebook.buck.util.cache.InstrumentingCacheStatsTracker
-
- getTotalEvictionCount() - Method in class com.facebook.buck.util.cache.NoOpCacheStatsTracker
-
- getTotalExecutedRules() - Method in interface com.facebook.buck.remoteexecution.event.LocalFallbackStats
-
The total number of actions executed both remote and local.
- getTotalHitCount() - Method in interface com.facebook.buck.util.cache.CacheStatsTracker
-
- getTotalHitCount() - Method in class com.facebook.buck.util.cache.InstrumentingCacheStatsTracker
-
- getTotalHitCount() - Method in class com.facebook.buck.util.cache.NoOpCacheStatsTracker
-
- getTotalInputSize() - Method in class com.facebook.buck.rules.modern.builders.RemoteExecutionActionInfo
-
- getTotalInvalidationCount() - Method in interface com.facebook.buck.util.cache.CacheStatsTracker
-
- getTotalInvalidationCount() - Method in class com.facebook.buck.util.cache.InstrumentingCacheStatsTracker
-
- getTotalInvalidationCount() - Method in class com.facebook.buck.util.cache.NoOpCacheStatsTracker
-
- getTotalLoadExceptionCount() - Method in interface com.facebook.buck.util.cache.CacheStatsTracker
-
- getTotalLoadExceptionCount() - Method in class com.facebook.buck.util.cache.InstrumentingCacheStatsTracker
-
- getTotalLoadExceptionCount() - Method in class com.facebook.buck.util.cache.NoOpCacheStatsTracker
-
- getTotalLoadSuccessCount() - Method in interface com.facebook.buck.util.cache.CacheStatsTracker
-
- getTotalLoadSuccessCount() - Method in class com.facebook.buck.util.cache.InstrumentingCacheStatsTracker
-
- getTotalLoadSuccessCount() - Method in class com.facebook.buck.util.cache.NoOpCacheStatsTracker
-
- getTotalLoadTime() - Method in class com.facebook.buck.util.cache.CacheStats
-
- getTotalLoadTime() - Method in interface com.facebook.buck.util.cache.CacheStatsTracker
-
- getTotalLoadTime() - Method in class com.facebook.buck.util.cache.InstrumentingCacheStatsTracker
-
- getTotalLoadTime() - Method in class com.facebook.buck.util.cache.NoOpCacheStatsTracker
-
- getTotalMemory() - Method in class com.facebook.buck.util.environment.DefaultExecutionEnvironment
-
- getTotalMemory() - Method in interface com.facebook.buck.util.environment.ExecutionEnvironment
-
- getTotalMemoryBytes() - Method in class com.facebook.buck.util.perf.PerfStatsTracking.MemoryPerfStatsEvent
-
- getTotalMissCount() - Method in interface com.facebook.buck.util.cache.CacheStatsTracker
-
- getTotalMissCount() - Method in class com.facebook.buck.util.cache.InstrumentingCacheStatsTracker
-
- getTotalMissCount() - Method in class com.facebook.buck.util.cache.NoOpCacheStatsTracker
-
- getTotalMissMatchCount() - Method in interface com.facebook.buck.util.cache.CacheStatsTracker
-
- getTotalMissMatchCount() - Method in class com.facebook.buck.util.cache.InstrumentingCacheStatsTracker
-
- getTotalMissMatchCount() - Method in class com.facebook.buck.util.cache.NoOpCacheStatsTracker
-
- getTotalMissTime() - Method in class com.facebook.buck.util.cache.CacheStats
-
- getTotalMissTime() - Method in interface com.facebook.buck.util.cache.CacheStatsTracker
-
- getTotalMissTime() - Method in class com.facebook.buck.util.cache.InstrumentingCacheStatsTracker
-
- getTotalMissTime() - Method in class com.facebook.buck.util.cache.NoOpCacheStatsTracker
-
- getTotalNanoTime() - Method in class com.facebook.buck.event.FileHashCacheEvent
-
- getTotalNanoTime() - Method in class com.facebook.buck.event.listener.TimeCostEntry
-
- getTotalNumberOfTests() - Method in interface com.facebook.buck.event.external.elements.TestResultsExternalInterface
-
- getTotalNumberOfTests() - Method in class com.facebook.buck.test.TestResults
-
- getTotalPayloads() - Method in class com.facebook.buck.slb.HybridThriftResponseHandler
-
Total number of payloads expected for the current thrift response.
- getTotalPayloadsSizeBytes() - Method in class com.facebook.buck.slb.HybridThriftRequestHandler
-
The sum bytes of all out-of-band payloads.
- getTotalRemoteTimeMs() - Method in class com.facebook.buck.remoteexecution.event.listener.RemoteExecutionEventListener
-
- getTotalRemoteTimeMs() - Method in interface com.facebook.buck.remoteexecution.event.RemoteExecutionStatsProvider
-
Metadata for total time spent running actions remotely.
- getTotalResourceConsumption(long) - Method in class com.facebook.buck.util.ProcessHelper
-
Gets resource consumption of the process subtree rooted at the process with the given pid.
- getTotalRetrievalTime() - Method in interface com.facebook.buck.util.cache.CacheStatsTracker
-
- getTotalRetrievalTime() - Method in class com.facebook.buck.util.cache.InstrumentingCacheStatsTracker
-
- getTotalRetrievalTime() - Method in class com.facebook.buck.util.cache.NoOpCacheStatsTracker
-
- getTotalRulekeyTimeMs() - Method in class com.facebook.buck.log.PerfTimesStats
-
- getTotalRulesBuilt() - Method in class com.facebook.buck.remoteexecution.event.listener.RemoteExecutionEventListener
-
- getTotalRulesBuilt() - Method in interface com.facebook.buck.remoteexecution.event.RemoteExecutionStatsProvider
-
Get the total number of BuildRules that are finished.
- getTotalRulesCount() - Method in class com.facebook.buck.event.listener.stats.cache.CacheRateStatsKeeper.CacheRateStatsUpdateEvent
-
- getTotalSize() - Method in class com.facebook.buck.android.resources.ResChunk
-
For most chunk's totalSize == chunkSize.
- getTotalSize() - Method in class com.facebook.buck.android.resources.ResTableTypeSpec
-
- getTotalSize() - Method in class com.facebook.buck.remoteexecution.util.MerkleTreeNodeCache.NodeData
-
- getTotalSizeBytes() - Method in class com.facebook.buck.util.DirectoryCleaner.PathStats
-
- getTotalThreadUserNanoTime() - Method in class com.facebook.buck.event.listener.TimeCostEntry
-
- getTotalTime() - Method in interface com.facebook.buck.event.external.elements.TestCaseSummaryExternalInterface
-
- getTotalTime() - Method in class com.facebook.buck.test.TestCaseSummary
-
- getTraceAttributesFor(String) - Method in class com.facebook.buck.util.trace.BuildTraces
-
- getTraceAttributesFor(Path) - Method in class com.facebook.buck.util.trace.BuildTraces
-
Parses a trace file and returns the command that the user executed to create the trace.
- getTraceDir() - Method in class com.facebook.buck.io.filesystem.BuckPaths
-
- getTraceFile() - Method in interface com.facebook.buck.doctor.config.BuildLogEntry
-
- getTraceId() - Method in interface com.facebook.buck.log.TraceInfoProvider
-
- getTraceUploadUri() - Method in class com.facebook.buck.event.chrome_trace.ChromeTraceBuckConfig
-
Get URL to upload trace.
- getTraceUploadUriIfEnabled() - Method in class com.facebook.buck.event.chrome_trace.ChromeTraceBuckConfig
-
Get URL to upload trace if the config is enabled.
- getTraits() - Method in class com.facebook.buck.log.ErrorLogRecord
-
- getTransformFunction() - Method in class com.facebook.buck.parser.api.BuildFileManifestPojoizer.PojoTransformer
-
Function that transforms a parser object to POJO object
- getTransitiveClasspathDeps() - Method in class com.facebook.buck.android.AndroidAar
-
- getTransitiveClasspathDeps() - Method in class com.facebook.buck.android.AndroidBinary
-
- getTransitiveClasspathDeps() - Method in class com.facebook.buck.android.AndroidBundle
-
- getTransitiveClasspathDeps() - Method in class com.facebook.buck.android.ApkGenrule
-
- getTransitiveClasspathDeps() - Method in interface com.facebook.buck.jvm.core.HasClasspathEntries
-
- getTransitiveClasspathDeps() - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getTransitiveClasspathDeps() - Method in class com.facebook.buck.jvm.java.JarFattener
-
- getTransitiveClasspathDeps() - Method in class com.facebook.buck.jvm.java.JavaBinary
-
- getTransitiveClasspathDeps(JavaLibrary) - Static method in class com.facebook.buck.jvm.java.JavaLibraryClasspathProvider
-
- getTransitiveClasspathDeps() - Method in class com.facebook.buck.jvm.java.JavaTest
-
- getTransitiveClasspathDeps() - Method in class com.facebook.buck.jvm.java.PrebuiltJar
-
- getTransitiveClasspaths() - Method in class com.facebook.buck.android.AndroidAar
-
- getTransitiveClasspaths() - Method in class com.facebook.buck.android.AndroidBinary
-
- getTransitiveClasspaths() - Method in class com.facebook.buck.android.AndroidBundle
-
- getTransitiveClasspaths() - Method in class com.facebook.buck.android.ApkGenrule
-
- getTransitiveClasspaths() - Method in interface com.facebook.buck.jvm.core.HasClasspathEntries
-
- getTransitiveClasspaths() - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- getTransitiveClasspaths() - Method in class com.facebook.buck.jvm.java.JarFattener
-
- getTransitiveClasspaths() - Method in class com.facebook.buck.jvm.java.JavaBinary
-
- getTransitiveClasspaths() - Method in class com.facebook.buck.jvm.java.JavaTest
-
- getTransitiveClasspaths() - Method in class com.facebook.buck.jvm.java.PrebuiltJar
-
- getTransitiveClosure(Set<QueryBuildTarget>) - Method in class com.facebook.buck.cli.BuckQueryEnvironment
-
- getTransitiveClosure(Set<NODE_TYPE>) - Method in interface com.facebook.buck.query.QueryEnvironment
-
Returns the forward transitive closure of all of the targets in "targets".
- getTransitiveClosure(Set<NODE_TYPE>) - Method in class com.facebook.buck.query.TargetVariablesQueryEnvironment
-
- getTransitiveClosure(Set<QueryBuildTarget>) - Method in class com.facebook.buck.rules.query.GraphEnhancementQueryEnvironment
-
- getTransitiveCxxPreprocessorInput(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.apple.PrebuiltAppleFramework
-
- getTransitiveCxxPreprocessorInput(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.cxx.CxxLibraryGroup
-
- getTransitiveCxxPreprocessorInput(CxxPlatform, ActionGraphBuilder, Iterable<? extends CxxPreprocessorDep>) - Static method in class com.facebook.buck.cxx.CxxPreprocessables
-
- getTransitiveCxxPreprocessorInput(CxxPlatform, ActionGraphBuilder) - Method in interface com.facebook.buck.cxx.CxxPreprocessorDep
-
Returns all transitive preprocessor inputs for this library.
- getTransitiveCxxPreprocessorInput(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescription.CustomPrebuiltCxxLibrary
-
- getTransitiveCxxPreprocessorInput(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.cxx.PreInclude
-
- getTransitiveCxxPreprocessorInput(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.features.halide.HalideLibrary
-
- getTransitiveCxxPreprocessorInput(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.features.lua.SystemLuaCxxLibrary
-
- getTransitiveCxxPreprocessorInputFromDeps(CxxPlatform, ActionGraphBuilder, Iterable<? extends BuildRule>) - Static method in class com.facebook.buck.cxx.CxxPreprocessables
-
- getTransitiveDepsClosure(BuildTarget) - Method in class com.facebook.buck.features.project.intellij.TransitiveDepsClosureResolver
-
- getTransitiveNativeLinkableInput(ActionGraphBuilder, TargetConfiguration, Iterable<? extends NativeLinkable>, Linker.LinkableDepType) - Static method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkables
-
- getTransitiveNativeLinkables(ActionGraphBuilder, Iterable<? extends NativeLinkable>) - Static method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkables
-
- getTransitiveRuntimeDeps(HasRuntimeDeps, BuildRuleResolver) - Static method in class com.facebook.buck.core.rules.common.BuildRules
-
- getTransitiveRustSharedLibraries(RustPlatform, Iterable<? extends BuildRule>, boolean) - Static method in class com.facebook.buck.features.rust.RustCompileUtils
-
Collect all the shared libraries generated by
RustLinkable
s found by transitively
traversing all unbroken dependency chains of
RustLinkable
objects found via the passed in
BuildRule
roots.
- getTransitiveSharedLibraries(ActionGraphBuilder, Iterable<? extends NativeLinkable>, boolean) - Static method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkables
-
- getTransitiveSuperclasses(TypeElement) - Static method in class com.facebook.buck.jvm.java.lang.model.MoreElements
-
- getTranslatableClass() - Method in class com.facebook.buck.versions.QueryTargetTranslator
-
- getTranslateBuildTarget(TargetNode<?>, ImmutableMap<BuildTarget, Version>) - Method in class com.facebook.buck.versions.AbstractVersionedTargetGraphBuilder
-
- getTransportPath() - Method in class com.facebook.buck.io.watchman.Watchman
-
- getTrashDir() - Method in class com.facebook.buck.io.filesystem.BuckPaths
-
- getTraversal() - Method in class com.facebook.buck.core.linkgroup.CxxLinkGroupMappingTarget
-
- getTree(Protocol.Digest) - Method in class com.facebook.buck.remoteexecution.util.LocalContentAddressedStorage
-
Returns a list of all sub directories.
- getTreeDigest() - Method in class com.facebook.buck.remoteexecution.grpc.GrpcProtocol.GrpcOutputDirectory
-
- getTreeDigest() - Method in interface com.facebook.buck.remoteexecution.interfaces.Protocol.OutputDirectory
-
- getTrees() - Method in class com.facebook.buck.jvm.java.abi.source.FrontendOnlyJavacTask
-
- getTrees() - Method in class com.facebook.buck.jvm.java.plugin.adapter.BuckJavacTask
-
- getTriggerPath(ProjectFilesystem) - Static method in class com.facebook.buck.core.rules.common.InstallTrigger
-
- getTriple() - Method in class com.facebook.buck.swift.toolchain.SwiftTargetTriple
-
- getTwoLevelCachingEnabled() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getTwoLevelCachingMaximumSize() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getTwoLevelCachingMinimumSize() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- getType() - Method in class com.facebook.buck.android.AndroidLibrary
-
- getType() - Method in class com.facebook.buck.android.resources.ResChunk
-
- getType() - Method in interface com.facebook.buck.android.toolchain.ndk.NdkCxxPlatformCompiler
-
- getType() - Method in class com.facebook.buck.apple.GroupedSource
-
- getType() - Method in interface com.facebook.buck.apple.simulator.AppleDevice
-
String that represents the type of the device ("simulator" or "device")
- getType() - Method in class com.facebook.buck.apple.toolchain.ApplePlatform
-
- getType() - Method in class com.facebook.buck.artifact_cache.CacheResult
-
- getType() - Method in class com.facebook.buck.artifact_cache.SecondLevelContentKey
-
- getType() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.FinishedRuleKeyCalc
-
- getType() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.StartedRuleKeyCalc
-
- getType() - Method in interface com.facebook.buck.core.rules.HasNameAndType
-
- getType() - Method in class com.facebook.buck.core.rules.impl.AbstractBuildRule
-
- getType() - Method in class com.facebook.buck.core.rules.impl.RuleAnalysisLegacyBuildRuleView
-
- getType() - Method in class com.facebook.buck.core.rules.impl.SymlinkTree
-
- getType() - Method in class com.facebook.buck.core.test.rule.ExternalTestRunnerTestSpec
-
- getType() - Method in class com.facebook.buck.cxx.CxxGenruleDescriptionArg
-
- getType() - Method in class com.facebook.buck.cxx.CxxPreprocessAndCompile
-
- getType() - Method in class com.facebook.buck.cxx.CxxSource
-
- getType() - Method in enum com.facebook.buck.cxx.toolchain.elf.ElfDynamicSection.DTag
-
- getType() - Method in class com.facebook.buck.cxx.toolchain.linker.impl.DefaultLinkerProvider
-
- getType() - Method in interface com.facebook.buck.cxx.toolchain.linker.LinkerProvider
-
- getType() - Method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableCacheKey
-
- getType() - Method in class com.facebook.buck.cxx.toolchain.nativelink.NativeLinkTargetMode
-
- getType() - Method in interface com.facebook.buck.event.external.elements.TestResultSummaryExternalInterface
-
- getType() - Method in interface com.facebook.buck.event.listener.CriticalPathReportableNode
-
- getType() - Method in class com.facebook.buck.event.RuleKeyCalculationEvent.Event
-
- getType() - Method in interface com.facebook.buck.event.RuleKeyCalculationEvent
-
- getType() - Method in class com.facebook.buck.features.apple.projectV2.XcodeProductMetadata
-
- getType() - Method in class com.facebook.buck.features.project.intellij.IjDependencyListBuilder.DependencyEntry
-
- getType() - Method in class com.facebook.buck.features.project.intellij.model.folders.IjSourceFolder
-
- getType() - Method in class com.facebook.buck.features.project.intellij.model.IjLibrary
-
- getType() - Method in class com.facebook.buck.file.HttpArchiveDescriptionArg
-
- getType() - Method in class com.facebook.buck.file.RemoteFileDescriptionArg
-
- getType() - Method in class com.facebook.buck.io.watchman.WatchmanMultiplePathEvent.Change
-
Type of the file that was changed, like a regular file or a directory
- getType() - Method in interface com.facebook.buck.json.BuildFileParseExceptionData
-
- getType() - Method in class com.facebook.buck.jvm.java.CalculateSourceAbi
-
- getType() - Method in class com.facebook.buck.jvm.java.JarGenruleDescriptionArg
-
- getType() - Method in class com.facebook.buck.parser.syntax.ListWithSelects
-
Type of the data in selector values
- getType() - Method in class com.facebook.buck.query.QueryEnvironment.Argument
-
- getType() - Method in interface com.facebook.buck.query.QueryEnvironment.TargetEvaluator
-
- getType() - Method in class com.facebook.buck.remoteexecution.config.RemoteExecutionConfig
-
- getType() - Method in class com.facebook.buck.rules.coercer.BuildConfigFields.Field
-
- getType() - Method in class com.facebook.buck.rules.coercer.FrameworkPath
-
- getType() - Method in class com.facebook.buck.rules.coercer.SourceSet
-
- getType() - Method in class com.facebook.buck.rules.coercer.SourceSortedSet
-
- getType() - Method in class com.facebook.buck.rules.coercer.SourceWithFlagsList
-
- getType() - Method in interface com.facebook.buck.rules.modern.ClassInfo
-
Returns a lower underscore name for this type.
- getType() - Method in class com.facebook.buck.rules.modern.impl.DefaultClassInfo
-
- getType() - Method in interface com.facebook.buck.shell.AbstractGenruleDescription.CommonArg
-
- getType() - Method in class com.facebook.buck.shell.BaseGenrule
-
- getType() - Method in class com.facebook.buck.shell.GenruleDescriptionArg
-
- getType() - Method in class com.facebook.buck.shell.ShTestDescriptionArg
-
- getType() - Method in class com.facebook.buck.test.TestResultSummary
-
- getType() - Method in class com.facebook.buck.util.cache.HashCodeAndFileType
-
- getType() - Method in enum com.facebook.buck.util.environment.Platform
-
- getTypeCoercer() - Method in class com.facebook.buck.core.starlark.rule.attr.Attribute
-
The type coercer to use to convert raw values from the parser into something usable internally.
- getTypeCoercer() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.BoolAttribute
-
- getTypeCoercer() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.DepAttribute
-
- getTypeCoercer() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.DepListAttribute
-
- getTypeCoercer() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.IntAttribute
-
- getTypeCoercer() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.IntListAttribute
-
- getTypeCoercer() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.OutputAttribute
-
- getTypeCoercer() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.OutputListAttribute
-
- getTypeCoercer() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.SourceAttribute
-
- getTypeCoercer() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.SourceListAttribute
-
- getTypeCoercer() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.SourceSortedSetAttribute
-
- getTypeCoercer() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.StringAttribute
-
- getTypeCoercer() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.StringListAttribute
-
- getTypeCoercer() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.StringSortedSetAttribute
-
- getTypeCoercer() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.UnconfiguredDepListAttribute
-
- getTypeCoercer() - Method in class com.facebook.buck.core.starlark.rule.attr.impl.UnconfiguredOptionalDepAttribute
-
- getTypeCoercer() - Method in class com.facebook.buck.rules.coercer.AbstractParamInfo
-
- getTypeCoercer() - Method in interface com.facebook.buck.rules.coercer.ParamInfo
-
- getTypeCoercerFactory() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getTypeCoercerFactory() - Method in interface com.facebook.buck.cli.MainRunner.ParserAndCaches
-
- getTypeCoercerFactory() - Method in class com.facebook.buck.support.state.BuckGlobalState
-
- getTypeElement(Element) - Static method in class com.facebook.buck.jvm.java.lang.model.MoreElements
-
- getTypeElement() - Method in class com.facebook.buck.jvm.java.plugin.api.TaskEventMirror
-
- getTypeFromPath(PathSourcePath) - Static method in class com.facebook.buck.cxx.toolchain.CxxToolTypeInferer
-
Invokes the tool with `--version` and parses the output to determine the type of the compiler.
- getTypeFromVersionOutput(Iterable<String>) - Static method in class com.facebook.buck.cxx.toolchain.CxxToolTypeInferer
-
Checks if the output looks like `clang --version`'s output.
- getTypeMirror(Iterable<? extends Tree>) - Method in class com.facebook.buck.jvm.java.abi.source.FrontendOnlyJavacTask
-
- getTypeOptionName() - Method in class com.facebook.buck.cli.ProjectCommand
-
- getTypeOptionName() - Method in interface com.facebook.buck.support.cli.args.PluginBasedCommand
-
- getTypes() - Method in class com.facebook.buck.android.resources.ResTablePackage
-
- getTypes() - Method in class com.facebook.buck.cli.AuditRulesCommand
-
- getTypes() - Method in class com.facebook.buck.cli.TargetsCommand
-
- getTypes() - Method in class com.facebook.buck.jvm.java.abi.source.FrontendOnlyJavacTask
-
- getTypes() - Method in class com.facebook.buck.jvm.java.plugin.adapter.BuckJavacTaskProxyImpl
-
- getTypes() - Method in interface com.facebook.buck.jvm.java.plugin.api.BuckJavacTaskProxy
-
- getTypeSpec(int) - Method in class com.facebook.buck.android.resources.ResTablePackage
-
- getTypeSpecs() - Method in class com.facebook.buck.android.resources.ResTablePackage
-
- getUdid() - Method in interface com.facebook.buck.apple.simulator.AppleDevice
-
String that represents the udid of the device (its identifier)
- getUdid() - Method in interface com.facebook.buck.apple.simulator.AppleSimulator
-
- getUdidFromDeviceName(String) - Method in class com.facebook.buck.apple.simulator.AppleDeviceController
-
- getuid() - Method in interface com.facebook.buck.util.Libc
-
- getUiTestTargetApp() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getUnarchiver() - Method in enum com.facebook.buck.util.unarchive.ArchiveFormat
-
Get the unarchiver used to extract archives of this type
- getUnbundledResourcesRoot() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
- getUnbundledResourcesRoot() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
- getUnbundledResourcesRoot() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getUnbundledResourcesRoot() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
- getUnbundledResourcesRoot() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getUnbundledResourcesRoot() - Method in interface com.facebook.buck.jvm.java.JavaLibraryDescription.CoreArg
-
- getUnbundledResourcesRoot() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
- getUnbundledResourcesRoot() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getUnbundledResourcesRoot() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
- getUnbundledResourcesRoot() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
- getUnbundledResourcesRoot() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getUnbundledResourcesRoot() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
- getUnbundledResourcesRoot() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getUnchecked(CxxPlatform, ActionGraphBuilder) - Method in class com.facebook.buck.cxx.TransitiveCxxPreprocessorInputCache
-
Get a value from the cache
- getUnchecked() - Method in class com.facebook.buck.io.file.LazyPath
-
Does not invoke the path supplier, assuming it was invoked previously.
- getUncheckedInterruptibly(Future<V>) - Static method in class com.facebook.buck.util.concurrent.MoreFutures
-
Waits for the given future to complete and returns the result.
- getUnconfiguredBuildTarget() - Method in class com.facebook.buck.core.model.BuildTarget
-
- getUnconfiguredBuildTarget() - Method in class com.facebook.buck.parser.spec.BuildTargetSpec
-
- getUnconfiguredBuildTargetFactory() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getUnconfiguredBuildTargetForFullyQualifiedTarget(String) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getUnconfiguredBuildTargetViewWithOutputs() - Method in class com.facebook.buck.parser.spec.BuildTargetSpec
-
- getUnconfiguredTargetNode() - Method in class com.facebook.buck.core.model.targetgraph.raw.UnconfiguredTargetNodeWithDeps
-
Raw target node, i.e.
- getUnconfiguredTargetNode() - Method in interface com.facebook.buck.core.model.targetgraph.raw.UnconfiguredTargetNodeWithDeps.UnconfiguredTargetNodeWithDepsUnwrappedMixin
-
- getUnconfiguredTargetNode() - Method in class com.facebook.buck.parser.targetnode.UnconfiguredTargetNodeToUnconfiguredTargetNodeWithDepsKey
-
- getUnconfiguredTargetNodesWithDeps() - Method in class com.facebook.buck.core.model.targetgraph.raw.UnconfiguredTargetNodeWithDepsPackage
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.BuildTargetTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.BuildTargetWithOutputsTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.ConstraintTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.CxxLinkGroupMappingCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.CxxLinkGroupMappingTargetCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.EitherTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.EnumTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.FlavorTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.FrameworkPathTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.IdentityTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.ImmutableTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.LeafTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.ListTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.LogLevelTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.MapTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.NeededCoverageSpecTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.NumberTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.OptionalTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.PairTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.PathTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.PatternMatchedCollectionTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.PatternTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.QueryCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.SetTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.SortedMapTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.SortedSetTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.SourcePathTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.SourceSetTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.SourceSortedSetTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.SourceWithFlagsListTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.SourceWithFlagsTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.StringWithMacrosTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.TestRunnerSpecCoercer
-
- getUnconfiguredType() - Method in interface com.facebook.buck.rules.coercer.TypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.UnconfiguredBuildTargetTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.UnconfiguredBuildTargetWithOutputsTypeCoercer
-
- getUnconfiguredType() - Method in class com.facebook.buck.rules.coercer.VersionMatchedCollectionTypeCoercer
-
- getUnexpandedCommandArgs() - Method in class com.facebook.buck.log.InvocationInfo
-
- getUnexpandedSearchPath(Function<SourcePath, Path>, Function<? super Path, Path>, FrameworkPath) - Static method in class com.facebook.buck.rules.coercer.FrameworkPath
-
- getUnflavoredBuildTarget() - Method in class com.facebook.buck.core.model.BuildTarget
-
- getUnflavoredBuildTarget() - Method in class com.facebook.buck.core.model.UnconfiguredBuildTarget
-
- getUnnamedSources() - Method in class com.facebook.buck.rules.coercer.SourceSet
-
- getUnnamedSources() - Method in class com.facebook.buck.rules.coercer.SourceSortedSet
-
- getUnnamedSources() - Method in class com.facebook.buck.rules.coercer.SourceWithFlagsList
-
- getUnresolvedAppleCxxPlatforms() - Method in class com.facebook.buck.apple.toolchain.AppleCxxPlatformsProvider
-
- getUnresolvedCxxPlatform() - Method in class com.facebook.buck.apple.toolchain.impl.ProviderBackedUnresolvedAppleCxxPlatform
-
- getUnresolvedCxxPlatform() - Method in class com.facebook.buck.apple.toolchain.impl.StaticUnresolvedAppleCxxPlatform
-
- getUnresolvedCxxPlatform() - Method in interface com.facebook.buck.apple.toolchain.UnresolvedAppleCxxPlatform
-
- getUnresolvedCxxPlatforms() - Method in class com.facebook.buck.android.toolchain.ndk.NdkCxxPlatformsProvider
-
- getUnresolvedCxxPlatforms() - Method in class com.facebook.buck.apple.toolchain.AppleCxxPlatformsProvider
-
- getUnresolvedCxxPlatforms() - Method in class com.facebook.buck.cxx.toolchain.CxxPlatformsProvider
-
- getUnresolvedCxxPlatforms() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatformsSupplier
-
- getUnresolvedSwiftPlatform() - Method in class com.facebook.buck.apple.toolchain.impl.ProviderBackedUnresolvedAppleCxxPlatform
-
- getUnresolvedSwiftPlatform() - Method in class com.facebook.buck.apple.toolchain.impl.StaticUnresolvedAppleCxxPlatform
-
- getUnresolvedSwiftPlatform() - Method in interface com.facebook.buck.apple.toolchain.UnresolvedAppleCxxPlatform
-
- getUnresolvedSwiftPlatforms() - Method in interface com.facebook.buck.swift.toolchain.SwiftPlatformsProvider
-
- getUnsortedExportedRules(Iterable<? extends BuildRule>) - Static method in class com.facebook.buck.core.rules.common.BuildRules
-
- getUnusedDependenciesAction() - Method in class com.facebook.buck.jvm.java.JavaBuckConfig
-
- getUnusedDependenciesAction() - Method in class com.facebook.buck.jvm.java.UnusedDependenciesFinder
-
- getUnusedDependenciesBuildozerString() - Method in class com.facebook.buck.jvm.java.JavaBuckConfig
-
- getUnversionedTargetGraph() - Method in class com.facebook.buck.core.model.graph.ActionAndTargetGraphs
-
- getUnzippedOutputFilePathToBinary() - Method in class com.facebook.buck.apple.AppleBundle
-
- getUpdatedRulesCount() - Method in interface com.facebook.buck.event.external.events.CacheRateStatsUpdateExternalEventInterface
-
- getUpdatedRulesCount() - Method in class com.facebook.buck.event.listener.stats.cache.CacheRateStatsKeeper.CacheRateStatsUpdateEvent
-
- getUploaded() - Method in interface com.facebook.buck.event.listener.stats.cache.NetworkStatsTracker.RemoteArtifactUploadStats
-
- getUploadToCacheResultType() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.Finished
-
- getUptime() - Method in class com.facebook.buck.support.state.BuckGlobalState
-
- getUrl() - Method in class com.facebook.buck.artifact_cache.config.HttpCacheEntry
-
- getUrl(String, String) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getUrl(String) - Static method in class com.facebook.buck.features.project.intellij.IjProjectPaths
-
- getUrl() - Method in class com.facebook.buck.features.project.intellij.model.ContentRoot
-
- getUrl() - Method in class com.facebook.buck.features.project.intellij.model.folders.IjSourceFolder
-
- getUrl() - Method in class com.facebook.buck.file.RemoteFileDescriptionArg
-
- getUrl() - Method in class com.facebook.buck.maven.aether.Repository
-
- getUrl(String, String) - Method in class com.facebook.buck.util.config.Config
-
- getUrls() - Method in class com.facebook.buck.file.HttpArchiveDescriptionArg
-
- getUrls() - Method in class com.facebook.buck.file.HttpFileDescriptionArg
-
- getUseArgFile() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getUseArgFile() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
Whether to use an argfile for long command lines.
- getUseArgFile() - Method in interface com.facebook.buck.cxx.toolchain.CxxPlatform
-
- getUseCxxLibraries() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getUseCxxLibraries() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getUseCxxLibraries() - Method in interface com.facebook.buck.jvm.java.JavaTestDescription.CoreArg
-
- getUseCxxLibraries() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getUseCxxLibraries() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getUseCxxLibraries() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getUseDefaultTestMain() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getUseDetailedUntrackedHeaderMessages() - Method in class com.facebook.buck.cxx.config.CxxBuckConfig
-
- getUseDynamicFeature() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getUseDynamicFeature() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getUseDynamicFeature() - Method in interface com.facebook.buck.android.AndroidGraphEnhancerArgs
-
- getUseFileList() - Method in class com.facebook.buck.swift.SwiftBuckConfig
-
- getUseHeaderMap() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
Whether to use header maps.
- getUseLipoThin() - Method in class com.facebook.buck.swift.SwiftBuckConfig
-
Uses `lipo -thin` instead of `lipo -extract` when copying the Swift standard libraries.
- getUseModulewrap() - Method in class com.facebook.buck.swift.SwiftBuckConfig
-
- getUser() - Method in class com.facebook.buck.util.environment.BuildEnvironmentDescription
-
- getUserArgs() - Method in class com.facebook.buck.support.fix.BuckFixSpec
-
The arguments that the user sent to buck.
- getUserDefinedRulesState() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getUserDefinedRulesState() - Method in class com.facebook.buck.parser.options.ProjectBuildFileParserOptions
-
- getUserDefinedRuleTypes(Cell) - Method in class com.facebook.buck.core.rules.knowntypes.provider.KnownRuleTypesProvider
-
Get details for rules defined by users in extension files
- getUseRemoteExecutionForGenruleIfRequestedField(String) - Static method in class com.facebook.buck.remoteexecution.config.RemoteExecutionConfig
-
- getUserFriendlyMessage(Throwable) - Static method in class com.facebook.buck.util.ErrorLogger
-
Prints the stacktrace as formatted by an ErrorLogger.
- getUserId() - Method in class com.facebook.buck.util.UnixUserIdFetcher
-
- getUserId() - Method in interface com.facebook.buck.util.UserIdFetcher
-
Returns the user ID for the current user.
- getUserLocalConfiguration() - Method in interface com.facebook.buck.doctor.DefectReporter.DefectReport
-
- getUsername() - Method in class com.facebook.buck.util.environment.DefaultExecutionEnvironment
-
- getUsername() - Method in interface com.facebook.buck.util.environment.ExecutionEnvironment
-
- getUserPrincipalLookupService() - Method in class com.facebook.buck.core.filesystems.BuckFileSystem
-
- getUserReport() - Method in class com.facebook.buck.doctor.AbstractReport
-
- getUserReport() - Method in interface com.facebook.buck.doctor.DefectReporter.DefectReport
-
- getUserReport() - Method in class com.facebook.buck.doctor.DoctorInteractiveReport
-
- getUseSplitDex() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getUseSplitDex() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getUsesWatchman() - Method in class com.facebook.buck.support.state.BuckGlobalState
-
- getUseUnixPathSeparator() - Method in class com.facebook.buck.cxx.toolchain.ClangPreprocessor
-
- getUseUnixPathSeparator() - Method in interface com.facebook.buck.cxx.toolchain.Compiler
-
- getUseUnixPathSeparator() - Method in class com.facebook.buck.cxx.toolchain.CxxToolProvider
-
- getUseUnixPathSeparator() - Method in class com.facebook.buck.cxx.toolchain.DefaultCompiler
-
- getUseUnixPathSeparator() - Method in class com.facebook.buck.cxx.toolchain.GccPreprocessor
-
- getUseUnixPathSeparator() - Method in class com.facebook.buck.cxx.toolchain.linker.impl.DarwinLinker
-
- getUseUnixPathSeparator() - Method in class com.facebook.buck.cxx.toolchain.linker.impl.GnuLinker
-
- getUseUnixPathSeparator() - Method in class com.facebook.buck.cxx.toolchain.linker.impl.WindowsLinker
-
- getUseUnixPathSeparator() - Method in interface com.facebook.buck.cxx.toolchain.linker.Linker
-
- getUseWatchmanGlob() - Method in class com.facebook.buck.parser.options.ProjectBuildFileParserOptions
-
- getUUID() - Method in class com.facebook.buck.apple.toolchain.ProvisioningProfileMetadata
-
- getUuid() - Method in class com.facebook.buck.step.StepEvent
-
- getValue() - Method in enum com.facebook.buck.apple.xcode.xcodeproj.PBXCopyFilesBuildPhase.Destination
-
- getValue(String) - Method in class com.facebook.buck.core.build.engine.buildinfo.DefaultOnDiskBuildInfo
-
- getValue(String) - Method in interface com.facebook.buck.core.build.engine.buildinfo.OnDiskBuildInfo
-
- getValue(String, String) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getValue(Set<Flavor>) - Method in class com.facebook.buck.core.model.FlavorDomain
-
- getValue(FlavorSet) - Method in class com.facebook.buck.core.model.FlavorDomain
-
- getValue(BuildTarget) - Method in class com.facebook.buck.core.model.FlavorDomain
-
- getValue(Flavor) - Method in class com.facebook.buck.core.model.FlavorDomain
-
- getValue(String) - Method in class com.facebook.buck.core.rules.providers.impl.UserDefinedProviderInfo
-
- getValue(String) - Method in class com.facebook.buck.core.starlark.compatible.BuckStarlarkStructObject
-
- getValue(CellNameResolver, ProjectFilesystem, ForwardRelativePath, TargetConfiguration, TargetConfiguration, Object) - Method in class com.facebook.buck.core.starlark.rule.attr.Attribute
-
Get the coerced value for this attribute.
- getValue(String) - Method in class com.facebook.buck.core.starlark.rule.SkylarkRuleContextAttr
-
- getValue() - Method in enum com.facebook.buck.cxx.toolchain.elf.ElfDynamicSection.DTag
-
- getValue() - Method in enum com.facebook.buck.cxx.toolchain.elf.ElfSectionHeader.SHType
-
- getValue() - Method in class com.facebook.buck.event.EventKey
-
- getValue() - Method in class com.facebook.buck.event.ExperimentEvent
-
- getValue() - Method in class com.facebook.buck.event.SimplePerfEvent.PerfEventId
-
- getValue() - Method in enum com.facebook.buck.event.SimplePerfEvent.Type
-
- getValue() - Method in interface com.facebook.buck.json.BuildFileParseExceptionData
-
- getValue() - Method in class com.facebook.buck.rules.coercer.BuildConfigFields.Field
-
- getValue(Object) - Method in class com.facebook.buck.rules.keys.FieldValueExtractor
-
- getValue(Object) - Method in interface com.facebook.buck.rules.keys.ValueExtractor
-
- getValue(Object) - Method in class com.facebook.buck.rules.keys.ValueMethodValueExtractor
-
- getValue() - Method in class com.facebook.buck.rules.modern.impl.StringifyingValueVisitor
-
- getValue(String, String) - Method in class com.facebook.buck.util.config.Config
-
- getValue(String, String) - Method in class com.facebook.buck.util.config.RawConfig
-
Retrieve a value from a named section.
- getValue() - Method in enum com.facebook.buck.util.zip.ZipCompressionLevel
-
- getValueForFlavor(ImmutableMap<UserFlavor, String>, Flavor) - Static method in class com.facebook.buck.features.js.JsUtil
-
- getValuePairs() - Method in class com.facebook.buck.rules.coercer.VersionMatchedCollection
-
- getValues() - Method in class com.facebook.buck.android.AndroidBuildConfigDescriptionArg
-
- getValues(String) - Method in class com.facebook.buck.core.build.engine.buildinfo.DefaultOnDiskBuildInfo
-
- getValues(String) - Method in interface com.facebook.buck.core.build.engine.buildinfo.OnDiskBuildInfo
-
- getValues() - Method in class com.facebook.buck.core.cell.CellConfig
-
- getValues() - Method in class com.facebook.buck.core.model.FlavorDomain
-
- getValues(BuildTarget) - Method in class com.facebook.buck.core.model.FlavorDomain
-
- getValues() - Method in class com.facebook.buck.core.rules.configsetting.ConfigSettingArg
-
- getValues() - Method in class com.facebook.buck.counters.CounterSnapshot
-
- getValues() - Method in interface com.facebook.buck.json.BuildFilePythonResult
-
- getValues() - Method in class com.facebook.buck.rules.coercer.PatternMatchedCollection
-
- getValues() - Method in class com.facebook.buck.rules.coercer.VersionMatchedCollection
-
- getValues() - Method in class com.facebook.buck.util.config.RawConfig
-
- getValuesFile() - Method in class com.facebook.buck.android.AndroidBuildConfigDescriptionArg
-
- getValuesOrThrow(String) - Method in class com.facebook.buck.core.build.engine.buildinfo.DefaultOnDiskBuildInfo
-
- getValuesOrThrow(String) - Method in interface com.facebook.buck.core.build.engine.buildinfo.OnDiskBuildInfo
-
Tries to read the "artifact" values and if it fails it logs the attributes of the file it tried
to read.
- getValueString() - Method in class com.facebook.buck.artifact_cache.ArtifactCacheConnectEvent
-
- getValueString() - Method in class com.facebook.buck.artifact_cache.ArtifactCacheEvent
-
- getValueString() - Method in class com.facebook.buck.artifact_cache.CacheCountersSummaryEvent
-
- getValueString() - Method in class com.facebook.buck.artifact_cache.HttpArtifactCacheEvent.Shutdown
-
- getValueString() - Method in class com.facebook.buck.artifact_cache.RuleKeyCacheResultEvent
-
- getValueString() - Method in class com.facebook.buck.core.build.event.BuildEvent.BuildReport
-
- getValueString() - Method in class com.facebook.buck.core.build.event.BuildEvent.Finished
-
- getValueString() - Method in class com.facebook.buck.core.build.event.BuildEvent.RuleCountCalculated
-
- getValueString() - Method in class com.facebook.buck.core.build.event.BuildEvent.Started
-
- getValueString() - Method in class com.facebook.buck.core.build.event.BuildEvent.UnskippedRuleCountUpdated
-
- getValueString() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent
-
- getValueString() - Method in class com.facebook.buck.core.build.event.BuildRuleEvent.WillBuildLocally
-
- getValueString() - Method in class com.facebook.buck.core.build.event.BuildRuleExecutionEvent.Event
-
- getValueString() - Method in class com.facebook.buck.core.build.event.FinalizingBuildRuleEvent
-
- getValueString() - Method in class com.facebook.buck.core.test.event.IndividualTestEvent.Finished
-
- getValueString() - Method in class com.facebook.buck.core.test.event.IndividualTestEvent.Started
-
- getValueString() - Method in class com.facebook.buck.core.test.event.TestRunEvent.Finished
-
- getValueString() - Method in class com.facebook.buck.core.test.event.TestRunEvent.Started
-
- getValueString() - Method in class com.facebook.buck.core.test.event.TestStatusMessageEvent.Finished
-
- getValueString() - Method in class com.facebook.buck.core.test.event.TestStatusMessageEvent.Started
-
- getValueString() - Method in class com.facebook.buck.core.test.event.TestSummaryEvent.Finished
-
- getValueString() - Method in class com.facebook.buck.core.test.event.TestSummaryEvent.Started
-
- getValueString() - Method in class com.facebook.buck.counters.CounterRegistry.AsyncCounterRegistrationEvent
-
- getValueString() - Method in class com.facebook.buck.counters.CountersSnapshotEvent
-
- getValueString() - Method in class com.facebook.buck.event.AbstractBuckEvent
-
- getValueString() - Method in class com.facebook.buck.event.ActionGraphEvent
-
- getValueString() - Method in class com.facebook.buck.event.ActionGraphPerfStatEvent
-
- getValueString() - Method in class com.facebook.buck.event.ArtifactCompressionEvent
-
- getValueString() - Method in class com.facebook.buck.event.BuckInitializationDurationEvent
-
- getValueString() - Method in class com.facebook.buck.event.CacheStatsEvent
-
- getValueString() - Method in class com.facebook.buck.event.CommandEvent
-
- getValueString() - Method in class com.facebook.buck.event.CompilerErrorEvent
-
- getValueString() - Method in class com.facebook.buck.event.CompilerPluginDurationEvent
-
- getValueString() - Method in class com.facebook.buck.event.ConsoleEvent
-
- getValueString() - Method in class com.facebook.buck.event.DaemonEvent
-
- getValueString() - Method in class com.facebook.buck.event.ExperimentEvent
-
- getValueString() - Method in class com.facebook.buck.event.FileHashCacheEvent
-
- getValueString() - Method in class com.facebook.buck.event.FlushConsoleEvent
-
- getValueString() - Method in class com.facebook.buck.event.InstallEvent
-
- getValueString() - Method in class com.facebook.buck.event.LeafEvents.SimpleLeafEvent.Finished
-
- getValueString() - Method in class com.facebook.buck.event.LeafEvents.SimpleLeafEvent.Started
-
- getValueString() - Method in class com.facebook.buck.event.listener.PerfTimesEventListener.PerfTimesEvent
-
- getValueString() - Method in class com.facebook.buck.event.listener.stats.cache.CacheRateStatsKeeper.CacheRateStatsUpdateEvent
-
- getValueString() - Method in class com.facebook.buck.event.NetworkEvent.BytesReceivedEvent
-
- getValueString() - Method in class com.facebook.buck.event.ParsingEvent
-
- getValueString() - Method in class com.facebook.buck.event.ProgressEvent
-
- getValueString() - Method in class com.facebook.buck.event.ProjectGenerationEvent
-
- getValueString() - Method in class com.facebook.buck.event.RuleKeyCalculationEvent.Event
-
- getValueString() - Method in class com.facebook.buck.event.StartActivityEvent
-
- getValueString() - Method in class com.facebook.buck.event.UninstallEvent
-
- getValueString() - Method in class com.facebook.buck.event.WatchmanStatusEvent
-
- getValueString() - Method in class com.facebook.buck.file.downloader.impl.DownloadEvent
-
- getValueString() - Method in class com.facebook.buck.file.downloader.impl.DownloadProgressEvent
-
- getValueString() - Method in class com.facebook.buck.io.watchman.WatchmanDiagnosticEvent
-
- getValueString() - Method in class com.facebook.buck.json.ProjectBuildFileParseEvents.Finished
-
- getValueString() - Method in class com.facebook.buck.json.ProjectBuildFileParseEvents.Started
-
- getValueString() - Method in class com.facebook.buck.jvm.java.AnnotationProcessingEvent
-
- getValueString() - Method in class com.facebook.buck.jvm.java.tracing.JavacPhaseEvent
-
- getValueString() - Method in class com.facebook.buck.parser.events.ParseBuckFileEvent
-
- getValueString() - Method in class com.facebook.buck.parser.events.ParseBuckProfilerReportEvent
-
- getValueString() - Method in class com.facebook.buck.parser.ParseEvent
-
- getValueString() - Method in class com.facebook.buck.remoteexecution.event.CasBlobDownloadEvent.Finished
-
- getValueString() - Method in class com.facebook.buck.remoteexecution.event.CasBlobDownloadEvent.Started
-
- getValueString() - Method in class com.facebook.buck.remoteexecution.event.CasBlobUploadEvent.Finished
-
- getValueString() - Method in class com.facebook.buck.remoteexecution.event.CasBlobUploadEvent.Started
-
- getValueString() - Method in class com.facebook.buck.remoteexecution.event.LocalFallbackEvent.Finished
-
- getValueString() - Method in class com.facebook.buck.remoteexecution.event.LocalFallbackEvent.Started
-
- getValueString() - Method in class com.facebook.buck.remoteexecution.event.RemoteBuildRuleExecutionEvent
-
- getValueString() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.Finished
-
- getValueString() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.InputsUploaded
-
- getValueString() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.Scheduled
-
- getValueString() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.Started
-
- getValueString() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.Terminal
-
- getValueString() - Method in class com.facebook.buck.remoteexecution.event.RemoteExecutionSessionEvent
-
- getValueString() - Method in class com.facebook.buck.rules.modern.builders.HybridLocalEvent.Stolen
-
- getValueString() - Method in class com.facebook.buck.slb.LoadBalancedServiceEvent
-
- getValueString() - Method in class com.facebook.buck.slb.LoadBalancerPingEvent
-
- getValueString() - Method in class com.facebook.buck.slb.ServerHealthManagerEvent
-
- getValueString() - Method in class com.facebook.buck.step.StepEvent
-
- getValueString() - Method in class com.facebook.buck.support.jvm.GCCollectionEvent
-
- getValueString() - Method in class com.facebook.buck.test.external.ExternalTestRunEvent.Finished
-
- getValueString() - Method in class com.facebook.buck.test.external.ExternalTestRunEvent.Started
-
- getValueString() - Method in class com.facebook.buck.test.external.ExternalTestSpecCalculationEvent
-
- getValueString() - Method in class com.facebook.buck.test.TestRuleEvent
-
- getValueString() - Method in class com.facebook.buck.util.environment.NetworkInfo.Event
-
- getValueString() - Method in class com.facebook.buck.util.perf.PerfStatsTracking.PerfStatsEvent
-
- getValueString() - Method in class com.facebook.buck.util.perf.ProcessTracker.ProcessResourceConsumptionEvent
-
- getValueString() - Method in class com.facebook.buck.util.versioncontrol.FastVersionControlStatsEvent
-
- getValueString() - Method in class com.facebook.buck.util.versioncontrol.VersionControlStatsEvent
-
- getValueString() - Method in class com.facebook.buck.versions.VersionedTargetGraphEvent
-
- getValueTypeInfo() - Method in class com.facebook.buck.rules.modern.FieldInfo
-
- getVar() - Method in interface com.facebook.buck.rules.macros.EnvMacro
-
- getVariableExpansionForPlatform(String, String, Map<String, String>) - Static method in class com.facebook.buck.apple.InfoPlistSubstitution
-
Returns a variable expansion for keys which may depend on platform name, trying from most to
least specific.
- getVariables() - Method in class com.facebook.buck.features.go.GoTestCoverSource
-
- getVariance() - Method in class com.facebook.buck.util.Statistics
-
Get the standard deviation.
- getVariant() - Method in class com.facebook.buck.event.ExperimentEvent
-
- getVariants() - Method in class com.facebook.buck.apple.AppleResourceDescriptionArg
-
- getVendor() - Method in class com.facebook.buck.swift.toolchain.SwiftTargetTriple
-
- getVerbose() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
Enable verbose logging output.
- getVerbose() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
Enable verbose logging output.
- getVerbose() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
Enable verbose logging output.
- getVerbose() - Method in interface com.facebook.buck.jvm.kotlin.KotlinLibraryDescription.CoreArg
-
Enable verbose logging output.
- getVerbose() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
Enable verbose logging output.
- getVerbose() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
Enable verbose logging output.
- getVerbosity() - Method in class com.facebook.buck.core.build.execution.context.ExecutionContext
-
- getVerbosity() - Method in class com.facebook.buck.event.listener.RenderingConsole
-
- getVerbosity() - Method in interface com.facebook.buck.jvm.java.JavacExecutionContext
-
- getVerbosity() - Method in class com.facebook.buck.util.Console
-
- getVerbosityForLevel(int) - Static method in class com.facebook.buck.cli.VerbosityParser
-
- getVerificationErrors() - Method in interface com.facebook.buck.util.cache.FileHashCache.FileHashCacheVerificationResult
-
- getVerificationMode() - Method in class com.facebook.buck.jvm.java.DiffAbisStep
-
- getVerifiedSourceAbiJar(BuildTarget) - Static method in class com.facebook.buck.jvm.core.JavaAbis
-
- getVerifyStep(SymlinkPaths) - Method in class com.facebook.buck.core.rules.impl.SymlinkTree
-
- getVersion() - Method in interface com.facebook.buck.android.toolchain.ndk.NdkCxxPlatformCompiler
-
- getVersion() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
Version of SDK.
- getVersion() - Method in class com.facebook.buck.apple.toolchain.AppleSdk
-
The version number of the SDK.
- getVersion() - Method in interface com.facebook.buck.apple.toolchain.AppleToolchain
-
The version number of the toolchain.
- getVersion() - Method in class com.facebook.buck.core.toolchain.tool.impl.VersionedTool
-
- getVersion() - Method in class com.facebook.buck.features.haskell.HaskellPrebuiltLibraryDescriptionArg
-
- getVersion() - Method in class com.facebook.buck.infer.InferConfig
-
- getVersion() - Method in class com.facebook.buck.io.watchman.Watchman
-
- getVersion() - Method in class com.facebook.buck.jvm.kotlin.ExternalKotlinc
-
- getVersion() - Method in class com.facebook.buck.jvm.kotlin.JarBackedReflectedKotlinc
-
- getVersion() - Method in interface com.facebook.buck.jvm.kotlin.Kotlinc
-
- getVersion() - Static method in class com.facebook.buck.rules.keys.config.impl.BuckVersion
-
- getVersion() - Method in class com.facebook.buck.swift.SwiftBuckConfig
-
- getVersion() - Method in class com.facebook.buck.swift.SwiftLibraryDescriptionArg
-
- getVersion() - Method in class com.facebook.buck.versions.ExactConstraint
-
- getVersionCode() - Method in interface com.facebook.buck.android.AndroidManifestReader
-
- getVersionCode() - Method in class com.facebook.buck.android.DefaultAndroidManifestReader
-
- getVersionCode() - Method in class com.facebook.buck.rules.coercer.ManifestEntries
-
- getVersionControlStats() - Method in class com.facebook.buck.util.versioncontrol.FastVersionControlStatsEvent
-
- getVersionControlStats() - Method in class com.facebook.buck.util.versioncontrol.VersionControlStatsEvent
-
- getVersionControlStatsGenerator() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getVersionedExportedLangPlatformPreprocessorFlags() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getVersionedExportedLangPreprocessorFlags() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getVersionedExportedPlatformPreprocessorFlags() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getVersionedExportedPreprocessorFlags() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getVersionedHeaderDirs() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getVersionedImportLib() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getVersionedResources() - Method in class com.facebook.buck.features.python.PythonLibraryDescriptionArg
-
- getVersionedResources() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getVersionedSharedLib() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getVersionedSrcs() - Method in class com.facebook.buck.features.python.PythonLibraryDescriptionArg
-
- getVersionedSrcs() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getVersionedStaticLib() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getVersionedStaticPicLib() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
- getVersionedTargetGraph() - Method in class com.facebook.buck.core.model.graph.ActionAndTargetGraphs
-
- getVersionedTargetGraph(DepsAwareExecutor<? super ComputeResult, ?>, TypeCoercerFactory, UnconfiguredBuildTargetViewFactory, TargetGraphCreationResult, ImmutableMap<String, VersionUniverse>, Cells) - Method in class com.facebook.buck.versions.InstrumentedVersionedTargetGraphCache
-
- getVersionedTargetGraph(DepsAwareExecutor<? super ComputeResult, ?>, BuckConfig, TypeCoercerFactory, UnconfiguredBuildTargetViewFactory, TargetGraphCreationResult, Optional<TargetConfiguration>, CacheStatsTracker, BuckEventBus, Cells) - Method in class com.facebook.buck.versions.VersionedTargetGraphCache
-
- getVersionedTargetGraphCache() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getVersionedTargetGraphCache() - Method in interface com.facebook.buck.cli.MainRunner.ParserAndCaches
-
- getVersionedTargetGraphCache() - Method in class com.facebook.buck.support.state.BuckGlobalState
-
- getVersionGroupType() - Method in class com.facebook.buck.apple.xcode.xcodeproj.XCVersionGroup
-
- getVersionInfo(TargetNode<?>) - Method in class com.facebook.buck.versions.AbstractVersionedTargetGraphBuilder
-
Get/cache the transitive version info for this node.
- getVersionInfo(TargetNode<?>) - Method in class com.facebook.buck.versions.AsyncVersionedTargetGraphBuilder
-
- getVersionName() - Method in class com.facebook.buck.rules.coercer.ManifestEntries
-
- getVersions() - Method in class com.facebook.buck.versions.VersionedAliasDescriptionArg
-
- getVersions() - Method in class com.facebook.buck.versions.VersionUniverse
-
- getVersionString() - Method in class com.facebook.buck.features.python.toolchain.PythonVersion
-
- getVersionTargetGraphTimeoutSeconds() - Method in class com.facebook.buck.versions.VersionBuckConfig
-
- getVersionUniverse() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
- getVersionUniverse() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
- getVersionUniverse() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
- getVersionUniverse() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
- getVersionUniverse() - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg
-
- getVersionUniverse() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getVersionUniverse() - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg
-
- getVersionUniverse() - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg
-
- getVersionUniverse() - Method in interface com.facebook.buck.versions.HasVersionUniverse
-
- getVersionUniverse(TargetNode<?>) - Method in class com.facebook.buck.versions.VersionUniverseVersionSelector
-
- getVersionUniverses(Optional<TargetConfiguration>) - Method in class com.facebook.buck.versions.VersionBuckConfig
-
- getView(Class<T>) - Method in class com.facebook.buck.core.config.BuckConfig
-
- getView(Class<V>) - Method in class com.facebook.buck.core.config.ConfigViewCache
-
- getVisibility() - Method in class com.facebook.buck.parser.api.PackageMetadata
-
- getVisibilityChecker() - Method in class com.facebook.buck.core.model.targetgraph.impl.TargetNodeImpl
-
- getVisibilityChecker() - Method in interface com.facebook.buck.rules.visibility.ObeysVisibility
-
- getVisibilityPatterns() - Method in class com.facebook.buck.core.model.targetgraph.impl.ImmutableUnconfiguredTargetNode
-
- getVisibilityPatterns() - Method in class com.facebook.buck.core.model.targetgraph.impl.Package
-
- getVisibilityPatterns() - Method in class com.facebook.buck.core.model.targetgraph.impl.TargetNodeImpl
-
- getVisibilityPatterns() - Method in interface com.facebook.buck.core.model.targetgraph.raw.UnconfiguredTargetNode
-
List of patterns from visibility
attribute.
- getVisibilityPatterns() - Method in interface com.facebook.buck.core.model.targetgraph.TargetNode
-
- getVmArgs() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
- getVmArgs() - Method in class com.facebook.buck.features.gwt.GwtBinaryDescriptionArg
-
In practice, these may be values such as -Xmx512m
.
- getVmArgs() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
- getVmArgs() - Method in interface com.facebook.buck.jvm.java.JavaTestDescription.CoreArg
-
- getVmArgs() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
- getVmArgs() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
- getVmArgs() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
- getWallMillisDuration() - Method in class com.facebook.buck.util.timing.ClockDuration
-
- getWantsPackagePrefix() - Method in class com.facebook.buck.features.project.intellij.model.folders.IjFolder
-
Used to make IntelliJ ignore the package name->folder structure convention and assume the
given package prefix.
- getWarnings() - Method in class com.facebook.buck.apple.AppleAssetCatalogsCompilationOptions
-
- getWarningsFlags() - Method in class com.facebook.buck.features.ocaml.OcamlBinaryDescriptionArg
-
- getWarningsFlags() - Method in class com.facebook.buck.features.ocaml.OcamlLibraryDescriptionArg
-
- getWarnOnConfigFileOverrides() - Method in class com.facebook.buck.support.cli.config.CliConfig
-
- getWarnOnConfigFileOverridesIgnoredFiles() - Method in class com.facebook.buck.support.cli.config.CliConfig
-
- getWasCreatedForAppExtension() - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg
-
Add value to scheme to indicate it will be used to work on an app extension.
- getWasCreatedForExtension() - Method in class com.facebook.buck.apple.xcode.XCScheme
-
- getWatchCells() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getWatchInterface() - Method in class com.facebook.buck.apple.xcode.XCScheme.LaunchAction
-
- getWatchInterface() - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg
-
- getWatchman() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getWatchman(WatchmanClient, Path, ImmutableSet<AbsPath>, Console, Clock, long) - Static method in class com.facebook.buck.io.watchman.WatchmanFactory
-
Query Watchman's capabilities and watch the given directories.
- getWatchman() - Method in class com.facebook.buck.parser.options.ProjectBuildFileParserOptions
-
- getWatchmanCursor() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getWatchmanCursor() - Method in class com.facebook.buck.support.state.BuckGlobalState
-
- getWatchmanDiagReport() - Method in interface com.facebook.buck.doctor.DefectReporter.FileChangesIgnoredReport
-
- getWatchmanErrorMessage() - Method in exception com.facebook.buck.io.watchman.WatchmanQueryFailedException
-
- getWatchmanGlobSanityCheck() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getWatchmanGlobStatResults() - Method in class com.facebook.buck.parser.options.ProjectBuildFileParserOptions
-
- getWatchmanQueryTimeoutMs() - Method in class com.facebook.buck.parser.config.ParserConfig
-
- getWatchmanQueryTimeoutMs() - Method in class com.facebook.buck.parser.options.ProjectBuildFileParserOptions
-
- getWatchmanRelativizedFinalPath(Path) - Method in class com.facebook.buck.skylark.io.impl.HybridGlobberFactory
-
Ask Watchman to get the final path for a file, following links (and ReparsePoints on Windows).
- getWatchmanUseGlobGenerator() - Method in class com.facebook.buck.parser.options.ProjectBuildFileParserOptions
-
- getWatchmanVersion() - Method in class com.facebook.buck.log.InvocationInfo
-
- getWatchRoot() - Method in interface com.facebook.buck.io.watchman.ProjectWatch
-
- getWeakBindInfoOffset() - Method in class com.facebook.buck.cxx.toolchain.objectfile.MachoDyldInfoCommand
-
- getWeakBindInfoSize() - Method in class com.facebook.buck.cxx.toolchain.objectfile.MachoDyldInfoCommand
-
- getWebServer() - Method in class com.facebook.buck.cli.CommandRunnerParams
-
- getWebServer() - Method in class com.facebook.buck.support.state.BuckGlobalState
-
- getWeightedListeningExecutorService() - Method in class com.facebook.buck.cli.CommandThreadManager
-
- getWeightEstimate() - Method in interface com.facebook.buck.android.DexWithClasses
-
- getWhitelist() - Method in class com.facebook.buck.cxx.toolchain.HeaderVerification
-
- getWhitelistedStringDirectories() - Method in class com.facebook.buck.android.packageable.AndroidPackageableCollection.ResourceDetails
-
A set of "res" directories that contain "whitelisted" strings, i.e.
- getWhitelistPatterns() - Method in class com.facebook.buck.cxx.toolchain.HeaderVerification
-
- getWifiSsid() - Method in class com.facebook.buck.util.environment.DefaultExecutionEnvironment
-
- getWifiSsid() - Method in interface com.facebook.buck.util.environment.ExecutionEnvironment
-
- getWifiSsid() - Static method in class com.facebook.buck.util.environment.NetworkInfo
-
- getWindowsFSInstance() - Static method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystemFactory
-
- getWindowsLongPathString(Path) - Static method in class com.facebook.buck.io.file.MorePaths
-
Converts a path to an absolute Windows 'long path' as a string.
- getWithinView() - Method in class com.facebook.buck.parser.api.PackageMetadata
-
- getWithinViewPatterns() - Method in class com.facebook.buck.core.model.targetgraph.impl.ImmutableUnconfiguredTargetNode
-
- getWithinViewPatterns() - Method in class com.facebook.buck.core.model.targetgraph.impl.Package
-
- getWithinViewPatterns() - Method in class com.facebook.buck.core.model.targetgraph.impl.TargetNodeImpl
-
- getWithinViewPatterns() - Method in interface com.facebook.buck.core.model.targetgraph.raw.UnconfiguredTargetNode
-
List of patterns from within_view
attribute.
- getWithinViewPatterns() - Method in interface com.facebook.buck.core.model.targetgraph.TargetNode
-
- getWord() - Method in class com.facebook.buck.query.QueryEnvironment.Argument
-
- getWorkAroundDsymutilLtoStackOverflowBug() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
If work around for dsymutil should be used.
- getWorker() - Method in class com.facebook.buck.features.js.JsBundleDescriptionArg
-
- getWorker() - Method in class com.facebook.buck.features.js.JsLibraryDescriptionArg
-
- getWorkerHash() - Method in class com.facebook.buck.rules.macros.WorkerMacroArg
-
- getWorkerHash() - Method in interface com.facebook.buck.worker.WorkerProcessIdentity
-
Hash to identify the specific worker pool and kind of a mechanism for invalidating existing
pools.
- getWorkerJobParamsToUse(Platform) - Method in class com.facebook.buck.shell.WorkerShellStep
-
- getWorkerProcessIdentity() - Method in interface com.facebook.buck.worker.WorkerProcessParams
-
Identifies the instance of the persisted worker process pool.
- getWorkerProcessParams() - Method in interface com.facebook.buck.worker.WorkerJobParams
-
- getWorkerProcessPool(ExecutionContext, WorkerProcessParams) - Method in class com.facebook.buck.worker.WorkerProcessPoolFactory
-
Returns an existing WorkerProcessPool for the given job params if one exists, otherwise creates
a new one.
- getWorkerProcessPools() - Method in class com.facebook.buck.core.build.execution.context.ExecutionContext
-
Worker process pools that you can populate as needed.
- getWorkerRequirementsFilename() - Method in interface com.facebook.buck.remoteexecution.config.RemoteExecutionStrategyConfig
-
- getWorkerTool() - Method in class com.facebook.buck.shell.DefaultWorkerToolRule
-
- getWorkerTool() - Method in interface com.facebook.buck.shell.ProvidesWorkerTool
-
- getWorkingDirectory() - Method in class com.facebook.buck.core.rules.actions.ActionExecutionContext
-
- getWorkingDirectory() - Method in class com.facebook.buck.jvm.java.CompilerOutputPaths
-
- getWorkingTimeFromLastStartUntilNow(Collection<EventInterval>, long) - Static method in class com.facebook.buck.event.listener.AbstractConsoleEventBusListener
-
Deprecated.
- getWorkspaceName() - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg
-
- getWorkspaceNameFromArg(XcodeWorkspaceConfigDescriptionArg) - Static method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescription
-
- getWorkspacePath() - Method in class com.facebook.buck.features.project.intellij.WorkspaceUpdater
-
- getWriteHeaders() - Method in class com.facebook.buck.artifact_cache.config.HttpCacheEntry
-
- getWriter(String) - Method in interface com.facebook.buck.log.ConsoleHandlerState
-
- getWriters(String) - Method in interface com.facebook.buck.log.LogFileHandlerState
-
- getWriteTimeoutSeconds() - Method in class com.facebook.buck.artifact_cache.config.HttpCacheEntry
-
- getXcconfigPaths() - Method in class com.facebook.buck.features.apple.project.ProjectGenerator
-
- getXcodeBuildVersion() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
XCode build version from from 'xcodebuild -version'
- getXcodeBuildVersion() - Method in class com.facebook.buck.apple.toolchain.AppleCxxPlatform
-
- getXcodeCompileScriptPath() - Method in class com.facebook.buck.features.halide.HalideBuckConfig
-
- getXCodeDescriptions() - Method in class com.facebook.buck.apple.AppleXCodeDescriptionClassSupplier
-
- getXCodeDescriptions() - Method in interface com.facebook.buck.apple.XCodeDescriptionClassSupplier
-
- getXCodeDescriptions() - Method in class com.facebook.buck.apple.XCodeDescriptions
-
- getXCodeDescriptions() - Method in class com.facebook.buck.features.halide.HalideXCodeDescriptionClassSupplier
-
- getXcodeDeveloperDirectoryForTests() - Method in class com.facebook.buck.apple.AppleConfig
-
- getXcodeDir() - Method in class com.facebook.buck.io.filesystem.BuckPaths
-
- getXcodeDisableParallelizeBuild() - Method in class com.facebook.buck.apple.AppleConfig
-
- getXcodePrivateHeadersSymlinks() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getXcodePrivateHeadersSymlinks() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getXcodePrivateHeadersSymlinks() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getXcodePrivateHeadersSymlinks() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
- getXcodePrivateHeadersSymlinks() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getXcodeProductType() - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg
-
- getXcodeProductType() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getXcodeProductType() - Method in interface com.facebook.buck.apple.HasAppleBundleFields
-
- getXcodePublicHeadersSymlinks() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
- getXcodePublicHeadersSymlinks() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
- getXcodePublicHeadersSymlinks() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
- getXcodePublicHeadersSymlinks() - Method in interface com.facebook.buck.cxx.CxxLibraryDescription.CommonArg
-
- getXcodePublicHeadersSymlinks() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
- getXcodeToolName(String) - Method in class com.facebook.buck.apple.AppleConfig
-
- getXcodeToolReplacement(String) - Method in class com.facebook.buck.apple.AppleConfig
-
- getXcodeToolVersion(String, String) - Method in class com.facebook.buck.apple.AppleConfig
-
- getXcodeVersion() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
XCode version which can be found in DTXcode in XCode plist
- getXcodeVersion() - Method in class com.facebook.buck.apple.toolchain.AppleCxxPlatform
-
- getXctest() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
xctest binary.
- getXctest() - Method in class com.facebook.buck.apple.toolchain.AppleCxxPlatform
-
- getXctestPlatformNames() - Method in class com.facebook.buck.apple.AppleConfig
-
- getXctoolDefaultDestinationSpecifier() - Method in class com.facebook.buck.apple.AppleConfig
-
- getXctoolPath() - Method in class com.facebook.buck.apple.AppleConfig
-
- getXctoolStutterTimeoutMs() - Method in class com.facebook.buck.apple.AppleConfig
-
- getXctoolZipTarget(TargetConfiguration) - Method in class com.facebook.buck.apple.AppleConfig
-
- getXzCompressionLevel() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
- getXzCompressionLevel() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
- getZipAbsolutePath() - Method in class com.facebook.buck.zip.ZipScrubberStep
-
- getZipalignExecutable() - Method in class com.facebook.buck.android.toolchain.AndroidPlatformTarget
-
- getZipCompressionLevel() - Method in class com.facebook.buck.apple.AppleConfig
-
- getZipFiles() - Method in class com.facebook.buck.android.ModuleInfo
-
- getZipMembers(Path) - Static method in class com.facebook.buck.util.unarchive.Unzip
-
Gets a set of files that are contained in an archive
- getZipSafe() - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg
-
- getZipSafe() - Method in class com.facebook.buck.features.python.PythonLibraryDescriptionArg
-
- getZipSafe() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
- getZipSrcs() - Method in class com.facebook.buck.features.zip.rules.ZipFileDescriptionArg
-
- GidGenerator - Class in com.facebook.buck.apple.xcode
-
Generator for Global ID (GID) which are present on every xcode project object.
- GidGenerator() - Constructor for class com.facebook.buck.apple.xcode.GidGenerator
-
- glob(SkylarkList<String>, SkylarkList<String>, Boolean, FuncallExpression, Environment) - Method in class com.facebook.buck.skylark.function.SkylarkBuildModule
-
- global - Variable in class com.facebook.buck.android.relinker.Symbols
-
- GLOBAL_HEADER - Static variable in class com.facebook.buck.cxx.toolchain.objectfile.ObjectFileScrubbers
-
- GLOBAL_THIN_HEADER - Static variable in class com.facebook.buck.cxx.toolchain.objectfile.ObjectFileScrubbers
-
- GlobalCliOptions - Class in com.facebook.buck.support.cli.args
-
Contains CLI options that are common to all of the commands.
- GlobalCliOptions() - Constructor for class com.facebook.buck.support.cli.args.GlobalCliOptions
-
- GlobalStateManager - Class in com.facebook.buck.log
-
- GlobalStateManager() - Constructor for class com.facebook.buck.log.GlobalStateManager
-
- GlobalStateManager.LoggerIsMappedToThreadScope - Interface in com.facebook.buck.log
-
- Globber - Interface in com.facebook.buck.skylark.io
-
A contract for globbing functionality that allows resolving file paths based on include patterns
(file patterns that should be returned) minus exclude patterns (file patterns that should be
excluded from the resulting set).
- GlobberFactory - Interface in com.facebook.buck.skylark.io
-
Creates
Globber
instances to save clients from implementation details.
- GlobPatternMatcher - Class in com.facebook.buck.io.filesystem
-
Matcher that matches paths described by the glob pattern.
- globResultsMatchCurrentState(Path, ImmutableList<GlobSpecWithResult>) - Method in class com.facebook.buck.parser.api.ForwardingProjectBuildFileParserDecorator
-
- globResultsMatchCurrentState(Path, ImmutableList<GlobSpecWithResult>) - Method in interface com.facebook.buck.parser.api.ProjectBuildFileParser
-
Checks if existing GlobSpec
s with results are the same as current state in the file
system.
- globResultsMatchCurrentState(Path, ImmutableList<GlobSpecWithResult>) - Method in class com.facebook.buck.parser.ConcurrentProjectBuildFileParser
-
- globResultsMatchCurrentState(Path, ImmutableList<GlobSpecWithResult>) - Method in class com.facebook.buck.parser.HybridProjectBuildFileParser
-
- globResultsMatchCurrentState(Path, ImmutableList<GlobSpecWithResult>) - Method in class com.facebook.buck.parser.PythonDslProjectBuildFileParser
-
- globResultsMatchCurrentState(Path, ImmutableList<GlobSpecWithResult>) - Method in class com.facebook.buck.skylark.parser.SkylarkProjectBuildFileParser
-
- GlobSpec - Class in com.facebook.buck.skylark.io
-
Glob specification includes parameters that affect glob evaluation within a single package.
- GlobSpec() - Constructor for class com.facebook.buck.skylark.io.GlobSpec
-
- GlobSpecWithResult - Class in com.facebook.buck.skylark.io
-
Set of globs performed while executing the build spec and the results they produce.
- GlobSpecWithResult() - Constructor for class com.facebook.buck.skylark.io.GlobSpecWithResult
-
- GnuArchiver - Class in com.facebook.buck.cxx.toolchain
-
Archiver implementation for gcc.
- GnuArchiver(Tool) - Constructor for class com.facebook.buck.cxx.toolchain.GnuArchiver
-
- GnuLinker - Class in com.facebook.buck.cxx.toolchain.linker.impl
-
A specialization of
Linker
containing information specific to the GNU implementation.
- GnuLinker(Tool) - Constructor for class com.facebook.buck.cxx.toolchain.linker.impl.GnuLinker
-
- GoArch - Enum in com.facebook.buck.features.go
-
Represents the GOARCH values in Go found at:
https://github.com/golang/go/blob/master/src/go/build/syslist.go
- GoAssembleStep - Class in com.facebook.buck.features.go
-
- GoAssembleStep(AbsPath, ImmutableMap<String, String>, ImmutableList<String>, ImmutableList<String>, Iterable<Path>, ImmutableList<Path>, GoPlatform, Path) - Constructor for class com.facebook.buck.features.go.GoAssembleStep
-
- GoBinary - Class in com.facebook.buck.features.go
-
- GoBinary(BuildTarget, ProjectFilesystem, BuildRuleParams, ImmutableSortedSet<SourcePath>, SymlinkTree, GoCompile, Tool, Linker, GoLinkStep.LinkMode, ImmutableList<String>, ImmutableList<Arg>, GoPlatform) - Constructor for class com.facebook.buck.features.go.GoBinary
-
- GoBinaryDescription - Class in com.facebook.buck.features.go
-
- GoBinaryDescription(GoBuckConfig, ToolchainProvider) - Constructor for class com.facebook.buck.features.go.GoBinaryDescription
-
- GoBinaryDescriptionArg - Class in com.facebook.buck.features.go
-
Immutable implementation of GoBinaryDescription.AbstractGoBinaryDescriptionArg
.
- GoBinaryDescriptionArg.Builder - Class in com.facebook.buck.features.go
-
- GoBuckConfig - Class in com.facebook.buck.features.go
-
- GoBuckConfig(BuckConfig) - Constructor for class com.facebook.buck.features.go.GoBuckConfig
-
- GoCompile - Class in com.facebook.buck.features.go
-
- GoCompile(BuildTarget, ProjectFilesystem, BuildRuleParams, SymlinkTree, Path, ImmutableMap<Path, Path>, ImmutableSet<SourcePath>, ImmutableSet<SourcePath>, ImmutableList<String>, ImmutableList<String>, GoPlatform, boolean, ImmutableList<SourcePath>, List<GoListStep.ListType>) - Constructor for class com.facebook.buck.features.go.GoCompile
-
- GoCompileStep - Class in com.facebook.buck.features.go
-
- GoCompileStep(Path, ImmutableMap<String, String>, ImmutableList<String>, ImmutableList<String>, Path, Iterable<Path>, Iterable<Path>, ImmutableMap<Path, Path>, ImmutableList<Path>, Optional<Path>, boolean, GoPlatform, Optional<Path>, Path) - Constructor for class com.facebook.buck.features.go.GoCompileStep
-
- GoDescriptionsProvider - Class in com.facebook.buck.features.go
-
- GoDescriptionsProvider() - Constructor for class com.facebook.buck.features.go.GoDescriptionsProvider
-
- GoLibrary - Class in com.facebook.buck.features.go
-
Provides information about a Go Library rule
- GoLibrary(BuildTarget, ProjectFilesystem, BuildRuleParams, ImmutableSet<SourcePath>) - Constructor for class com.facebook.buck.features.go.GoLibrary
-
- GoLibraryDescription - Class in com.facebook.buck.features.go
-
- GoLibraryDescription(GoBuckConfig, ToolchainProvider) - Constructor for class com.facebook.buck.features.go.GoLibraryDescription
-
- GoLibraryDescriptionArg - Class in com.facebook.buck.features.go
-
Immutable implementation of GoLibraryDescription.AbstractGoLibraryDescriptionArg
.
- GoLibraryDescriptionArg.Builder - Class in com.facebook.buck.features.go
-
- GoLinkStep - Class in com.facebook.buck.features.go
-
- GoLinkStep(Path, ImmutableMap<String, String>, ImmutableList<String>, ImmutableList<String>, ImmutableList<String>, ImmutableList<String>, ImmutableList<Path>, GoPlatform, Path, GoLinkStep.BuildMode, GoLinkStep.LinkMode, Path) - Constructor for class com.facebook.buck.features.go.GoLinkStep
-
- GoListStep - Class in com.facebook.buck.features.go
-
- GoListStep(Path, Optional<Path>, GoPlatform, List<GoListStep.ListType>) - Constructor for class com.facebook.buck.features.go.GoListStep
-
- GoModule - Class in com.facebook.buck.features.go
-
- GoModule() - Constructor for class com.facebook.buck.features.go.GoModule
-
- GoModuleAdapterPlugin - Class in com.facebook.buck.features.go
-
- GoModuleAdapterPlugin(PluginWrapper) - Constructor for class com.facebook.buck.features.go.GoModuleAdapterPlugin
-
- GoOs - Enum in com.facebook.buck.features.go
-
Represents the GOOS values in Go found at:
https://github.com/golang/go/blob/master/src/go/build/syslist.go
- GoPackStep - Class in com.facebook.buck.features.go
-
- GoPackStep(Path, ImmutableMap<String, String>, ImmutableList<String>, GoPackStep.Operation, ImmutableList<Path>, Iterable<Path>, Path) - Constructor for class com.facebook.buck.features.go.GoPackStep
-
- GoPackStep.Operation - Enum in com.facebook.buck.features.go
-
- GoProjectCommandHelper - Class in com.facebook.buck.features.go
-
- GoProjectCommandHelper(CommandRunnerParams, ListeningExecutorService, boolean, Function<Iterable<String>, ImmutableList<TargetNodeSpec>>, ProjectGeneratorParameters, Optional<TargetConfiguration>) - Constructor for class com.facebook.buck.features.go.GoProjectCommandHelper
-
- GoProjectSubCommand - Class in com.facebook.buck.features.go
-
- GoProjectSubCommand() - Constructor for class com.facebook.buck.features.go.GoProjectSubCommand
-
- GoProjectSubCommandFactory - Class in com.facebook.buck.features.go
-
- GoProjectSubCommandFactory() - Constructor for class com.facebook.buck.features.go.GoProjectSubCommandFactory
-
- GoTest - Class in com.facebook.buck.features.go
-
- GoTest(BuildTarget, ProjectFilesystem, BuildRuleParams, GoBinary, ImmutableSet<String>, ImmutableSet<String>, Optional<Long>, ImmutableMap<String, Arg>, boolean, ImmutableSortedSet<SourcePath>, GoTestCoverStep.Mode) - Constructor for class com.facebook.buck.features.go.GoTest
-
- GoTestCoverSource - Class in com.facebook.buck.features.go
-
GoTestCoverSource is responsible for annotating the source files via `go tool cover` utilty.
- GoTestCoverSource(BuildTarget, ProjectFilesystem, SourcePathRuleFinder, GoPlatform, ImmutableSet<SourcePath>, Tool, GoTestCoverStep.Mode) - Constructor for class com.facebook.buck.features.go.GoTestCoverSource
-
- GoTestCoverStep - Class in com.facebook.buck.features.go
-
- GoTestCoverStep(AbsPath, Path, Path, ImmutableMap<String, String>, ImmutableList<String>, GoTestCoverStep.Mode) - Constructor for class com.facebook.buck.features.go.GoTestCoverStep
-
- GoTestDescription - Class in com.facebook.buck.features.go
-
- GoTestDescription(GoBuckConfig, ToolchainProvider) - Constructor for class com.facebook.buck.features.go.GoTestDescription
-
- GoTestDescriptionArg - Class in com.facebook.buck.features.go
-
Immutable implementation of GoTestDescription.AbstractGoTestDescriptionArg
.
- GoTestDescriptionArg.Builder - Class in com.facebook.buck.features.go
-
- GoTestMain - Class in com.facebook.buck.features.go
-
- GoTestMain(BuildTarget, ProjectFilesystem, BuildRuleParams, Tool, ImmutableSet<SourcePath>, Path, GoPlatform, ImmutableMap<Path, ImmutableMap<String, Path>>, GoTestCoverStep.Mode) - Constructor for class com.facebook.buck.features.go.GoTestMain
-
- GoTestMainStep - Class in com.facebook.buck.features.go
-
- GoTestMainStep(AbsPath, ImmutableMap<String, String>, ImmutableList<String>, GoTestCoverStep.Mode, ImmutableMap<Path, ImmutableMap<String, Path>>, Path, Iterable<Path>, Path) - Constructor for class com.facebook.buck.features.go.GoTestMainStep
-
- GoTestRunner - Class in com.facebook.buck.features.go
-
Specifies the test runner for go_test for test protocol.
- GoTestRunner(BuildTarget, ProjectFilesystem, SourcePath) - Constructor for class com.facebook.buck.features.go.GoTestRunner
-
- GoTestRunnerDescription - Class in com.facebook.buck.features.go
-
A rule for specifying go test runners.
- GoTestRunnerDescription() - Constructor for class com.facebook.buck.features.go.GoTestRunnerDescription
-
- GoTestRunnerDescriptionArg - Class in com.facebook.buck.features.go
-
Immutable implementation of GoTestRunnerDescription.AbstractGoTestRunnerDescriptionArg
.
- GoTestRunnerDescriptionArg.Builder - Class in com.facebook.buck.features.go
-
- GoTestStep - Class in com.facebook.buck.features.go
-
Run a go test command and stream the output to a file.
- GoTestStep(ProjectFilesystem, Path, ImmutableList<String>, ImmutableMap<String, String>, Path, Optional<Long>, Path) - Constructor for class com.facebook.buck.features.go.GoTestStep
-
- GoTestX - Class in com.facebook.buck.features.go
-
go test that implements the test protocol
- GoTestX(BuildTarget, ProjectFilesystem, BuildRuleParams, GoBinary, ImmutableSet<String>, ImmutableSet<String>, CoercedTestRunnerSpec, ImmutableSortedSet<SourcePath>) - Constructor for class com.facebook.buck.features.go.GoTestX
-
- GoToolchain - Class in com.facebook.buck.features.go
-
- GoToolchain() - Constructor for class com.facebook.buck.features.go.GoToolchain
-
- GoToolchainFactory - Class in com.facebook.buck.features.go
-
- GoToolchainFactory() - Constructor for class com.facebook.buck.features.go.GoToolchainFactory
-
- GoToolchainSupplier - Class in com.facebook.buck.features.go
-
- GoToolchainSupplier() - Constructor for class com.facebook.buck.features.go.GoToolchainSupplier
-
- GraphComputation<Key extends ComputeKey<Result>,Result extends ComputeResult> - Interface in com.facebook.buck.core.graph.transformation
-
- GraphComputationStage<KeyType extends ComputeKey<ResultType>,ResultType extends ComputeResult> - Class in com.facebook.buck.core.graph.transformation.impl
-
- GraphComputationStage(GraphComputation<KeyType, ResultType>) - Constructor for class com.facebook.buck.core.graph.transformation.impl.GraphComputationStage
-
- GraphComputationStage(GraphComputation<KeyType, ResultType>, GraphEngineCache<KeyType, ResultType>) - Constructor for class com.facebook.buck.core.graph.transformation.impl.GraphComputationStage
-
- GraphEngineCache<Key extends ComputeKey<Value>,Value extends ComputeResult> - Interface in com.facebook.buck.core.graph.transformation
-
Interface for a Cache object that
GraphTransformationEngine
uses to store results that
have finished computing so that the results can be reused.
- GraphEngineFactory - Class in com.facebook.buck.cli
-
- GraphEnhancementQueryEnvironment - Class in com.facebook.buck.rules.query
-
A query environment that can be used for graph-enhancement, including macro expansion or dynamic
dependency resolution.
- GraphEnhancementQueryEnvironment(Optional<ActionGraphBuilder>, Optional<TargetGraph>, TypeCoercerFactory, CellNameResolver, UnconfiguredBuildTargetViewFactory, BaseName, Set<BuildTarget>, TargetConfiguration) - Constructor for class com.facebook.buck.rules.query.GraphEnhancementQueryEnvironment
-
- GraphTransformationEngine - Interface in com.facebook.buck.core.graph.transformation
-
Transformation engine that transforms supplied ComputeKey into ComputeResult via
GraphComputation
.
- GraphTraversable<T> - Interface in com.facebook.buck.core.util.graph
-
- GraphTraversableWithDependencyStack<T> - Interface in com.facebook.buck.core.util.graph
-
- GraphTraversableWithPayload<T,P> - Interface in com.facebook.buck.core.util.graph
-
- GraphTraversableWithPayloadAndDependencyStack<T,P> - Interface in com.facebook.buck.core.util.graph
-
- GroovyBuckConfig - Class in com.facebook.buck.jvm.groovy
-
- GroovyBuckConfig(BuckConfig) - Constructor for class com.facebook.buck.jvm.groovy.GroovyBuckConfig
-
- Groovyc - Class in com.facebook.buck.jvm.groovy
-
- Groovyc(Supplier<? extends SourcePath>, boolean) - Constructor for class com.facebook.buck.jvm.groovy.Groovyc
-
- Groovyc(SourcePath, boolean) - Constructor for class com.facebook.buck.jvm.groovy.Groovyc
-
- GroovyConfiguredCompilerFactory - Class in com.facebook.buck.jvm.groovy
-
- GroovyConfiguredCompilerFactory(GroovyBuckConfig) - Constructor for class com.facebook.buck.jvm.groovy.GroovyConfiguredCompilerFactory
-
- GroovyDescriptionsProvider - Class in com.facebook.buck.jvm.groovy
-
- GroovyDescriptionsProvider() - Constructor for class com.facebook.buck.jvm.groovy.GroovyDescriptionsProvider
-
- GroovyLibraryDescription - Class in com.facebook.buck.jvm.groovy
-
- GroovyLibraryDescription(ToolchainProvider, GroovyBuckConfig, JavaBuckConfig) - Constructor for class com.facebook.buck.jvm.groovy.GroovyLibraryDescription
-
- GroovyLibraryDescription.CoreArg - Interface in com.facebook.buck.jvm.groovy
-
- GroovyLibraryDescriptionArg - Class in com.facebook.buck.jvm.groovy
-
Immutable implementation of GroovyLibraryDescription.AbstractGroovyLibraryDescriptionArg
.
- GroovyLibraryDescriptionArg.Builder - Class in com.facebook.buck.jvm.groovy
-
- GroovyLibraryModuleRule - Class in com.facebook.buck.features.project.intellij.lang.groovy
-
- GroovyLibraryModuleRule(ProjectFilesystem, IjModuleFactoryResolver, IjProjectConfig) - Constructor for class com.facebook.buck.features.project.intellij.lang.groovy.GroovyLibraryModuleRule
-
- GroovyTestDescription - Class in com.facebook.buck.jvm.groovy
-
Description for groovy_test.
- GroovyTestDescription(ToolchainProvider, GroovyBuckConfig, JavaBuckConfig) - Constructor for class com.facebook.buck.jvm.groovy.GroovyTestDescription
-
- GroovyTestDescriptionArg - Class in com.facebook.buck.jvm.groovy
-
Immutable implementation of GroovyTestDescription.AbstractGroovyTestDescriptionArg
.
- GroovyTestDescriptionArg.Builder - Class in com.facebook.buck.jvm.groovy
-
- GroovyTestModuleRule - Class in com.facebook.buck.features.project.intellij.lang.groovy
-
- GroovyTestModuleRule(ProjectFilesystem, IjModuleFactoryResolver, IjProjectConfig) - Constructor for class com.facebook.buck.features.project.intellij.lang.groovy.GroovyTestModuleRule
-
- group(Collection<TargetNode<?>>) - Static method in class com.facebook.buck.core.model.targetgraph.MergedTargetNode
-
Group targets by unflavored target.
- GroupedSource - Class in com.facebook.buck.apple
-
- GroupedSource() - Constructor for class com.facebook.buck.apple.GroupedSource
-
- GroupedSource.Type - Enum in com.facebook.buck.apple
-
The type of grouped source entry this object represents.
- GroupedSource.Visitor - Interface in com.facebook.buck.apple
-
- GrpcAsyncBlobFetcher - Class in com.facebook.buck.remoteexecution.grpc
-
GRPC implementation of the AsyncBlobFetcher.
- GrpcAsyncBlobFetcher(String, ContentAddressableStorageGrpc.ContentAddressableStorageFutureStub, ByteStreamGrpc.ByteStreamStub, BuckEventBus, RemoteExecutionMetadata, Protocol, int) - Constructor for class com.facebook.buck.remoteexecution.grpc.GrpcAsyncBlobFetcher
-
- GrpcCasBlobUploader - Class in com.facebook.buck.remoteexecution.grpc
-
GRPC implementation of the CasBlobUploader.
- GrpcCasBlobUploader(String, ContentAddressableStorageGrpc.ContentAddressableStorageFutureStub, ByteStreamGrpc.ByteStreamStub, BuckEventBus, RemoteExecutionMetadata) - Constructor for class com.facebook.buck.remoteexecution.grpc.GrpcCasBlobUploader
-
- GrpcContentAddressableStorageClient - Class in com.facebook.buck.remoteexecution.grpc
-
Implementation of a CAS client using GRPC.
- GrpcContentAddressableStorageClient(ContentAddressableStorageGrpc.ContentAddressableStorageFutureStub, ByteStreamGrpc.ByteStreamStub, int, String, Protocol, BuckEventBus, RemoteExecutionMetadata, int) - Constructor for class com.facebook.buck.remoteexecution.grpc.GrpcContentAddressableStorageClient
-
- GrpcDigest(Digest) - Constructor for class com.facebook.buck.remoteexecution.grpc.GrpcProtocol.GrpcDigest
-
- GrpcExecutionFactory - Class in com.facebook.buck.remoteexecution.grpc
-
Factory for creating grpc-based strategies.
- GrpcExecutionFactory() - Constructor for class com.facebook.buck.remoteexecution.grpc.GrpcExecutionFactory
-
- GrpcHeaderHandler - Class in com.facebook.buck.remoteexecution.grpc
-
Provides operations over GRPC headers.
- GrpcHeaderHandler.StubAndResponseMetadata<Stub extends io.grpc.stub.AbstractStub<Stub>> - Interface in com.facebook.buck.remoteexecution.grpc
-
Class that contains the GRPC stub and any RemoteExecutionMetadata returned in the GRPC
response.
- GrpcOutputDirectory(OutputDirectory) - Constructor for class com.facebook.buck.remoteexecution.grpc.GrpcProtocol.GrpcOutputDirectory
-
- GrpcOutputFile(OutputFile) - Constructor for class com.facebook.buck.remoteexecution.grpc.GrpcProtocol.GrpcOutputFile
-
- GrpcProtocol - Class in com.facebook.buck.remoteexecution.grpc
-
A Grpc-based Protocol implementation.
- GrpcProtocol() - Constructor for class com.facebook.buck.remoteexecution.grpc.GrpcProtocol
-
- GrpcProtocol.GrpcDigest - Class in com.facebook.buck.remoteexecution.grpc
-
Wrapped Grpc Digest.
- GrpcProtocol.GrpcOutputDirectory - Class in com.facebook.buck.remoteexecution.grpc
-
Wrapped Grpc OutputDirectory.
- GrpcProtocol.GrpcOutputFile - Class in com.facebook.buck.remoteexecution.grpc
-
Wrapped Grpc OutputFile.
- GrpcRemoteExecutionClients - Class in com.facebook.buck.remoteexecution.grpc
-
A RemoteExecution that sends jobs to a grpc-based remote execution service.
- GrpcRemoteExecutionClients(String, ManagedChannel, ManagedChannel, int, MetadataProvider, BuckEventBus, RemoteExecutionStrategyConfig) - Constructor for class com.facebook.buck.remoteexecution.grpc.GrpcRemoteExecutionClients
-
- GrpcRemoteExecutionServiceClient - Class in com.facebook.buck.remoteexecution.grpc
-
Implementation of the GRPC client for the Remote Execution service.
- GrpcRemoteExecutionServiceClient(ExecutionGrpc.ExecutionStub, ByteStreamGrpc.ByteStreamStub, String, Protocol, int) - Constructor for class com.facebook.buck.remoteexecution.grpc.GrpcRemoteExecutionServiceClient
-
- GrpcRemoteExecutionServiceServer - Class in com.facebook.buck.remoteexecution.grpc
-
A really simple implementation of remote execution (and CAS).
- GrpcRemoteExecutionServiceServer(LocalContentAddressedStorage, Path) - Constructor for class com.facebook.buck.remoteexecution.grpc.GrpcRemoteExecutionServiceServer
-
- GrpcServer - Class in com.facebook.buck.remoteexecution.grpc.server
-
A simple remote execution server.
- GrpcServer(int) - Constructor for class com.facebook.buck.remoteexecution.grpc.server.GrpcServer
-
- GrpcServerMain - Class in com.facebook.buck.remoteexecution.grpc.server
-
Runs the GrpcServer remote execution server.
- GrpcServerMain() - Constructor for class com.facebook.buck.remoteexecution.grpc.server.GrpcServerMain
-
- GuavaRuleKeyHasher - Class in com.facebook.buck.rules.keys.hasher
-
- GuavaRuleKeyHasher(Hasher) - Constructor for class com.facebook.buck.rules.keys.hasher.GuavaRuleKeyHasher
-
- GWT_MODULE_FLAVOR - Static variable in interface com.facebook.buck.jvm.core.JavaLibrary
-
This Buildable is expected to support the GWT flavor, which is a
BuildRule
whose output
file is a JAR containing the files necessary to use this
JavaLibrary
as a GWT module.
- GwtBinary - Class in com.facebook.buck.features.gwt
-
Buildable that produces a GWT application as a WAR file, which is a zip of the outputs produced
by the GWT compiler.
- GwtBinaryDescription - Class in com.facebook.buck.features.gwt
-
Description for gwt_binary.
- GwtBinaryDescription(ToolchainProvider) - Constructor for class com.facebook.buck.features.gwt.GwtBinaryDescription
-
- GwtBinaryDescriptionArg - Class in com.facebook.buck.features.gwt
-
Immutable implementation of GwtBinaryDescription.AbstractGwtBinaryDescriptionArg
.
- GwtBinaryDescriptionArg.Builder - Class in com.facebook.buck.features.gwt
-
- GwtBuckModule - Class in com.facebook.buck.features.gwt
-
Module that provides GWT rules.
- GwtBuckModule() - Constructor for class com.facebook.buck.features.gwt.GwtBuckModule
-
- GwtBuckModuleAdapterPlugin - Class in com.facebook.buck.features.gwt
-
- GwtBuckModuleAdapterPlugin(PluginWrapper) - Constructor for class com.facebook.buck.features.gwt.GwtBuckModuleAdapterPlugin
-
- GwtDescriptionsProvider - Class in com.facebook.buck.features.gwt
-
- GwtDescriptionsProvider() - Constructor for class com.facebook.buck.features.gwt.GwtDescriptionsProvider
-
- GwtModule - Class in com.facebook.buck.features.gwt
-
BuildRule
whose output file is a JAR containing the .java files and resources suitable
for a GWT module.
- gzipUnarchiver() - Static method in class com.facebook.buck.util.unarchive.Untar
-
- HALIDE_COMPILE_FLAVOR - Static variable in class com.facebook.buck.features.halide.HalideLibraryDescription
-
- HALIDE_COMPILER_FLAVOR - Static variable in class com.facebook.buck.features.halide.HalideLibraryDescription
-
- HALIDE_SECTION_NAME - Static variable in class com.facebook.buck.features.halide.HalideBuckConfig
-
- HALIDE_XCODE_COMPILE_SCRIPT_KEY - Static variable in class com.facebook.buck.features.halide.HalideBuckConfig
-
- HalideBuckConfig - Class in com.facebook.buck.features.halide
-
A Halide-specific "view" of BuckConfig.
- HalideBuckConfig(BuckConfig) - Constructor for class com.facebook.buck.features.halide.HalideBuckConfig
-
- HalideCompile - Class in com.facebook.buck.features.halide
-
- HalideCompile(BuildTarget, ProjectFilesystem, BuildRuleParams, Tool, String, Optional<ImmutableList<String>>, Optional<String>) - Constructor for class com.facebook.buck.features.halide.HalideCompile
-
- HalideCompilerStep - Class in com.facebook.buck.features.halide
-
- HalideCompilerStep(AbsPath, ImmutableMap<String, String>, ImmutableList<String>, Path, String, String, Optional<ImmutableList<String>>) - Constructor for class com.facebook.buck.features.halide.HalideCompilerStep
-
- HalideDescriptionsProvider - Class in com.facebook.buck.features.halide
-
- HalideDescriptionsProvider() - Constructor for class com.facebook.buck.features.halide.HalideDescriptionsProvider
-
- HalideLibrary - Class in com.facebook.buck.features.halide
-
- HalideLibrary(BuildTarget, ProjectFilesystem, BuildRuleParams, ActionGraphBuilder, Optional<Pattern>) - Constructor for class com.facebook.buck.features.halide.HalideLibrary
-
- HalideLibraryDescription - Class in com.facebook.buck.features.halide
-
- HalideLibraryDescription(ToolchainProvider, CxxBuckConfig, HalideBuckConfig) - Constructor for class com.facebook.buck.features.halide.HalideLibraryDescription
-
- HalideLibraryDescriptionArg - Class in com.facebook.buck.features.halide
-
Immutable implementation of HalideLibraryDescription.AbstractHalideLibraryDescriptionArg
.
- HalideLibraryDescriptionArg.Builder - Class in com.facebook.buck.features.halide
-
- HalideModule - Class in com.facebook.buck.features.halide
-
- HalideModule() - Constructor for class com.facebook.buck.features.halide.HalideModule
-
- HalideModuleAdapterPlugin - Class in com.facebook.buck.features.halide
-
- HalideModuleAdapterPlugin(PluginWrapper) - Constructor for class com.facebook.buck.features.halide.HalideModuleAdapterPlugin
-
- HalideXCodeDescriptionClassSupplier - Class in com.facebook.buck.features.halide
-
- HalideXCodeDescriptionClassSupplier() - Constructor for class com.facebook.buck.features.halide.HalideXCodeDescriptionClassSupplier
-
- handle(Event) - Method in class com.facebook.buck.core.starlark.eventhandler.ConsoleEventHandler
-
- handle(BuckEvent) - Method in class com.facebook.buck.event.listener.ScribeEventListener
-
- handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class com.facebook.buck.httpserver.ArtifactCacheHandler
-
- handleConsoleEvent(ConsoleEvent) - Method in class com.facebook.buck.event.listener.LoggingBuildListener
-
- handleEndOfTests() - Method in interface com.facebook.buck.apple.IdbOutputParsing.IdbResultCallback
-
- handleEndOfTests() - Method in class com.facebook.buck.apple.TestCaseSummariesBuildingIdb
-
- handleException(CmdLineException) - Method in class com.facebook.buck.cli.AbstractCommand
-
Handle CmdLineException when calling parseArguments()
- handleException(CmdLineException, String) - Method in class com.facebook.buck.cli.AbstractCommand
-
Print error message when there are unknown options
- handleException(CmdLineException) - Method in class com.facebook.buck.cli.RunCommand
-
It prints error message when users do not pass arguments to underlying binary correctly.
- handleException(CmdLineException) - Method in class com.facebook.buck.cli.TestCommand
-
It prints error message when users do not pass arguments to underlying binary correctly.
- handleException(T) - Method in class com.facebook.buck.support.exceptions.handler.ExceptionHandler
-
- handleException(Throwable) - Method in class com.facebook.buck.support.exceptions.handler.ExceptionHandlerRegistry
-
- handleFallback(Object) - Method in class com.facebook.buck.event.listener.LoggingBuildListener
-
- handleLine(String) - Method in interface com.facebook.buck.util.InputStreamConsumer.Handler
-
- handleNotification(Notification, Object) - Method in class com.facebook.buck.support.jvm.GCNotificationEventEmitter
-
Handles a JMX
Notification
emitted by one of the GC beans that we're listening to.
- handleTestResult(ImmutableIdbTestResult) - Method in interface com.facebook.buck.apple.IdbOutputParsing.IdbResultCallback
-
- handleTestResult(ImmutableIdbTestResult) - Method in class com.facebook.buck.apple.TestCaseSummariesBuildingIdb
-
- handshake(int) - Method in interface com.facebook.buck.worker.WorkerProcessProtocol.CommandSender
-
- handshake(int) - Method in class com.facebook.buck.worker.WorkerProcessProtocolZero.CommandSender
-
- HangMonitor - Class in com.facebook.buck.cli
-
- HangMonitor(Consumer<String>, Duration) - Constructor for class com.facebook.buck.cli.HangMonitor
-
- HangMonitor.AutoStartInstance - Class in com.facebook.buck.cli
-
- HasAndroidResourceDeps - Interface in com.facebook.buck.android
-
Indicates that this class may have android resources that should be packaged into an APK.
- hasAnnotationProcessing() - Method in interface com.facebook.buck.jvm.core.JavaLibrary
-
- hasAnnotationProcessing() - Method in class com.facebook.buck.jvm.java.CompileToJarStepFactory
-
- hasAnnotationProcessing() - Method in class com.facebook.buck.jvm.java.DefaultJavaLibrary
-
- hasAnnotationProcessing() - Method in class com.facebook.buck.jvm.java.JarBuildStepsFactory
-
- hasAnnotationProcessing() - Method in class com.facebook.buck.jvm.java.JavacToJarStepFactory
-
- hasAnnotationProcessing() - Method in class com.facebook.buck.jvm.java.PrebuiltJar
-
- hasAnnotationProcessing() - Method in class com.facebook.buck.jvm.kotlin.KotlincToJarStepFactory
-
- hasAnnotationProcessing() - Method in class com.facebook.buck.jvm.scala.ScalacToJarStepFactory
-
- hasAny() - Method in class com.facebook.buck.rules.coercer.ManifestEntries
-
- HasAppleBundleFields - Interface in com.facebook.buck.apple
-
- HasAppleBundleResourcesDescription<T extends BuildRuleArg> - Interface in com.facebook.buck.apple
-
Rule description for rules which have apple bundles
- HasAppleCodesignFields - Interface in com.facebook.buck.apple
-
Defines a set of codesign-related fields that are applicable to bundle-like rules.
- HasAppleDebugSymbolDeps - Interface in com.facebook.buck.cxx
-
Returns all archives and object files, or other instances of HasAppleDebugSymbolDeps.
- HasApplicationModuleBlacklist - Interface in com.facebook.buck.core.description.arg
-
Interface for marking a argument list as containing application_module_blacklist
- hasAssumptionViolations() - Method in interface com.facebook.buck.event.external.elements.TestCaseSummaryExternalInterface
-
- hasAssumptionViolations() - Method in interface com.facebook.buck.event.external.elements.TestResultsExternalInterface
-
- hasAssumptionViolations() - Method in class com.facebook.buck.test.TestCaseSummary
-
- hasAssumptionViolations() - Method in class com.facebook.buck.test.TestResults
-
- hasAtLeastOneWriteableRemoteCache() - Method in class com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig
-
- HasBrokenInputBasedRuleKey - Interface in com.facebook.buck.rules.modern
-
Used to indicate that this Buildable's input-based key doesn't properly reflect all the inputs to
this rule.
- hasBuildSteps() - Method in interface com.facebook.buck.core.rules.BuildRule
-
Whether this
BuildRule
may have any steps to build.
- hasBuildSteps() - Method in class com.facebook.buck.core.rules.impl.AbstractBuildRule
-
- hasBuildSteps() - Method in class com.facebook.buck.core.rules.impl.NoopBuildRule
-
- hasBuildSteps() - Method in class com.facebook.buck.core.rules.impl.NoopBuildRuleWithDeclaredAndExtraDeps
-
- HasBuildTarget - Interface in com.facebook.buck.core.model
-
Some object that has a build target.
- HasBundleName - Interface in com.facebook.buck.features.js
-
Common interface for rule args that have a bundle name that can optionally be overridden
depending on the flavors a rule is built with.
- HasClasspathDeps - Interface in com.facebook.buck.jvm.core
-
A convenience interface for items which contribute to the classpath of a java packageable.
- HasClasspathEntries - Interface in com.facebook.buck.jvm.core
-
Implemented by build rules where the output has a classpath environment.
- HasContacts - Interface in com.facebook.buck.core.description.arg
-
- HasCustomDepsLogic - Interface in com.facebook.buck.core.rules.attr
-
Deprecated.
- HasCustomInputsLogic - Interface in com.facebook.buck.core.rules.modern
-
Deriving inputs directly from the @
AddToRuleKey
annotated fields of some objects doesn't
work correctly or is too slow.
- HasDeclaredAndExtraDeps - Interface in com.facebook.buck.core.rules.attr
-
Some rules have a legacy behavior of distinguishing between "declared" deps (i.e.
- HasDeclaredDeps - Interface in com.facebook.buck.core.description.arg
-
- hasDefaultCondition() - Method in class com.facebook.buck.core.select.Selector
-
Returns whether or not this selector has a default condition.
- HasDefaultFlavors - Interface in com.facebook.buck.core.model
-
A constructor arg of rules which have default flavors.
- HasDefaultPlatform - Interface in com.facebook.buck.core.description.arg
-
A constructor arg of rules which have a default platform.
- HasDepsQuery - Interface in com.facebook.buck.core.description.arg
-
- HasDesugarSupport - Interface in com.facebook.buck.jvm.core
-
Implemented by build rules that support desugar process to the lower java versions, for example
java 8 to java 7 desugar for Android builds.
- HasDexFiles - Interface in com.facebook.buck.android
-
- hasDiff - Variable in enum com.facebook.buck.util.versioncontrol.VersionControlStatsGenerator.Mode
-
- HasDuplicateAndroidResourceTypes - Interface in com.facebook.buck.android
-
- HasDuplicateAndroidResourceTypes.DuplicateResourceBehaviour - Enum in com.facebook.buck.android
-
- hasElementClass(Class<?>[]) - Method in class com.facebook.buck.rules.coercer.AbsoluteOutputMacroTypeCoercer
-
- hasElementClass(Class<?>[]) - Method in class com.facebook.buck.rules.coercer.BuildTargetMacroTypeCoercer
-
- hasElementClass(Class<?>...) - Method in class com.facebook.buck.rules.coercer.CollectionTypeCoercer
-
- hasElementClass(Class<?>[]) - Method in class com.facebook.buck.rules.coercer.CxxGenruleFilterAndTargetsMacroTypeCoercer
-
- hasElementClass(Class<?>...) - Method in class com.facebook.buck.rules.coercer.CxxLinkGroupMappingCoercer
-
- hasElementClass(Class<?>...) - Method in class com.facebook.buck.rules.coercer.CxxLinkGroupMappingTargetCoercer
-
- hasElementClass(Class<?>...) - Method in class com.facebook.buck.rules.coercer.EitherTypeCoercer
-
- hasElementClass(Class<?>[]) - Method in class com.facebook.buck.rules.coercer.EnvMacroTypeCoercer
-
- hasElementClass(Class<?>...) - Method in class com.facebook.buck.rules.coercer.FrameworkPathTypeCoercer
-
- hasElementClass(Class<?>...) - Method in class com.facebook.buck.rules.coercer.ImmutableTypeCoercer
-
- hasElementClass(Class<?>...) - Method in class com.facebook.buck.rules.coercer.LeafTypeCoercer
-
- hasElementClass(Class<?>...) - Method in class com.facebook.buck.rules.coercer.LeafTypeNewCoercer
-
- hasElementClass(Class<?>...) - Method in class com.facebook.buck.rules.coercer.MapTypeCoercer
-
- hasElementClass(Class<?>...) - Method in class com.facebook.buck.rules.coercer.NeededCoverageSpecTypeCoercer
-
- hasElementClass(Class<?>...) - Method in class com.facebook.buck.rules.coercer.OptionalTypeCoercer
-
- hasElementClass(Class<?>[]) - Method in class com.facebook.buck.rules.coercer.OutputMacroTypeCoercer
-
- hasElementClass(Class<?>...) - Method in class com.facebook.buck.rules.coercer.PairTypeCoercer
-
- hasElementClass(Class<?>...) - Method in class com.facebook.buck.rules.coercer.PatternMatchedCollectionTypeCoercer
-
- hasElementClass(Class<?>...) - Method in class com.facebook.buck.rules.coercer.QueryCoercer
-
- hasElementClass(Class<?>...) - Method in class com.facebook.buck.rules.coercer.SortedMapTypeCoercer
-
- hasElementClass(Class<?>...) - Method in class com.facebook.buck.rules.coercer.SourceSetTypeCoercer
-
- hasElementClass(Class<?>...) - Method in class com.facebook.buck.rules.coercer.SourceSortedSetTypeCoercer
-
- hasElementClass(Class<?>...) - Method in class com.facebook.buck.rules.coercer.SourceWithFlagsListTypeCoercer
-
- hasElementClass(Class<?>...) - Method in class com.facebook.buck.rules.coercer.SourceWithFlagsTypeCoercer
-
- hasElementClass(Class<?>...) - Method in class com.facebook.buck.rules.coercer.StringWithMacrosTypeCoercer
-
- hasElementClass(Class<?>...) - Method in class com.facebook.buck.rules.coercer.TestRunnerSpecCoercer
-
- hasElementClass(Class<?>...) - Method in interface com.facebook.buck.rules.coercer.TypeCoercer
-
Returns whether the leaf nodes of this type coercer outputs value that is an instance of the
given class or its subclasses.
- hasElementClass(Class<?>...) - Method in class com.facebook.buck.rules.coercer.VersionMatchedCollectionTypeCoercer
-
- hasElementClass(Class<?>[]) - Method in class com.facebook.buck.rules.coercer.ZeroArgMacroTypeCoercer
-
- hasElementTypes(Class<?>...) - Method in class com.facebook.buck.rules.coercer.AbstractParamInfo
-
- hasElementTypes(Class<?>...) - Method in interface com.facebook.buck.rules.coercer.ParamInfo
-
- HasEntitlementsFile - Interface in com.facebook.buck.apple
-
- hasEntries() - Method in class com.facebook.buck.util.zip.DeterministicManifest
-
- HasExopackageArgs - Interface in com.facebook.buck.android
-
- HasExtraJson - Interface in com.facebook.buck.features.js
-
Common interface for rule args that have used-defined JSON that is passed on to the worker.
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.android.AndroidBinaryDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.android.AndroidBundleDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.android.AndroidLibraryDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.android.AndroidPrebuiltAarDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.android.AndroidResourceDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.apple.AppleBinaryDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.apple.AppleBundleDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.apple.AppleLibraryDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.apple.ApplePackageDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.apple.AppleResourceDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.apple.AppleTestDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.apple.CoreDataModelDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.apple.PrebuiltAppleFrameworkDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.apple.SceneKitAssetsDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.apple.XcodePrebuildScriptDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in interface com.facebook.buck.core.model.Flavored
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.cxx.CxxBinaryDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.cxx.CxxBinaryFlavored
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.cxx.CxxGenruleDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.cxx.CxxLibraryDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.cxx.CxxLibraryFlavored
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.cxx.CxxTestDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.features.go.CgoLibraryDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.features.go.GoBinaryDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.features.go.GoLibraryDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.features.go.GoTestDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.features.halide.HalideLibraryDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.features.haskell.HaskellBinaryDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.features.haskell.HaskellLibraryDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.features.js.JsBundleDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.features.js.JsBundleGenruleDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.features.js.JsLibraryDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.features.ocaml.OcamlLibraryDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.jvm.java.JavaLibraryDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescription
-
- hasFlavors(ImmutableSet<Flavor>, TargetConfiguration) - Method in class com.facebook.buck.swift.SwiftLibraryDescription
-
- hasFocus() - Method in class com.facebook.buck.features.apple.project.FocusedModuleTargetMatcher
-
Returns whether any focus is set.
- HasGoLinkable - Interface in com.facebook.buck.features.go
-
- hash(TargetConfiguration) - Static method in class com.facebook.buck.core.model.impl.TargetConfigurationHasher
-
Hashes a target configuration.
- hash() - Method in class com.facebook.buck.rules.keys.hasher.CountingRuleKeyHasher
-
- hash() - Method in class com.facebook.buck.rules.keys.hasher.ForwardingRuleKeyHasher
-
- hash() - Method in class com.facebook.buck.rules.keys.hasher.GuavaRuleKeyHasher
-
- hash() - Method in interface com.facebook.buck.rules.keys.hasher.RuleKeyHasher
-
Computes the final hash.
- hash() - Method in class com.facebook.buck.rules.keys.hasher.StringRuleKeyHasher
-
- hash() - Method in class com.facebook.buck.rules.keys.hasher.ThriftRuleKeyHasher
-
Finishes populating the ruleKey with remaining key/value pairs and returns it
- hashCode() - Method in class com.facebook.buck.android.aapt.RDotTxtEntry
-
- hashCode() - Method in class com.facebook.buck.android.AndroidAarDescriptionArg
-
Computes a hash code from attributes: manifestSkeleton
, buildConfigValues
, includeBuildConfigClass
, enableRelinker
, manifest
, resourceUnionPackage
, skipNonUnionRDotJava
, finalRName
, resources
, proguardConfig
, postprocessClassesCommands
, resourcesRoot
, unbundledResourcesRoot
, manifestFile
, mavenCoords
, mavenPomTemplate
, exportedDeps
, sourceOnlyAbiDeps
, runtimeDeps
, source
, target
, javaVersion
, javac
, javacJar
, compilerClassName
, compiler
, extraArguments
, removeClasses
, annotationProcessorDeps
, annotationProcessorParams
, javaPluginParams
, annotationProcessors
, annotationProcessorOnly
, plugins
, abiGenerationMode
, compileAgainst
, sourceAbiVerificationMode
, onUnusedDependencies
, neverMarkAsUnusedDependency
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, requiredForSourceOnlyAbi
, deps
, providedDeps
, exportedProvidedDeps
, srcs
, tests
, language
, freeCompilerArgs
, allWarningsAsErrors
, suppressWarnings
, verbose
, includeRuntime
, jvmTarget
, jdkHome
, noJdk
, noStdlib
, noReflect
, javaParameters
, apiVersion
, languageVersion
, annotationProcessingTool
, friendPaths
, kaptApOptions
, kotlincPlugins
, depsQuery
, providedDepsQuery
.
- hashCode() - Method in class com.facebook.buck.android.AndroidAppModularityDescriptionArg
-
Computes a hash code from attributes: applicationModuleConfigs
, applicationModuleDependencies
, noDx
, shouldIncludeClasses
, shouldIncludeLibraries
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, deps
, applicationModuleBlacklist
.
- hashCode() - Method in class com.facebook.buck.android.AndroidBinaryDescriptionArg
-
Computes a hash code from attributes: keystore
, useSplitDex
, minimizePrimaryDexSize
, dexCompression
, primaryDexPatterns
, primaryDexClassesFile
, primaryDexScenarioFile
, primaryDexScenarioOverflowAllowed
, secondaryDexHeadClassesFile
, secondaryDexTailClassesFile
, androidAppModularityResult
, linearAllocHardLimit
, dexGroupLibLimit
, resourceFilter
, preprocessJavaClassesDeps
, xzCompressionLevel
, packageAssetLibraries
, compressAssetLibraries
, assetCompressionAlgorithm
, redex
, redexConfig
, redexExtraArgs
, deps
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, exopackage
, exopackageModes
, tests
, manifest
, manifestSkeleton
, moduleManifestSkeleton
, packageType
, noDx
, disablePreDex
, androidSdkProguardConfig
, optimizationPasses
, proguardJvmArgs
, proguardConfig
, resourceCompression
, skipCrunchPngs
, includesVectorDrawables
, noAutoVersionResources
, noVersionTransitionsResources
, noAutoAddOverlayResources
, applicationModuleTargets
, applicationModuleConfigs
, applicationModulesWithResources
, applicationModulesWithManifest
, applicationModuleDependencies
, isCacheable
, additionalAaptParams
, aaptMode
, trimResourceIds
, allowRDotJavaInSecondaryDex
, keepResourcePattern
, resourceUnionPackage
, locales
, aapt2LocaleFiltering
, localizedStringFileName
, buildStringSourceMap
, ignoreAaptProguardConfig
, cpuFilters
, preprocessJavaClassesBash
, reorderClassesIntraDex
, dexTool
, dexReorderToolFile
, dexReorderDataDumpFile
, nativeLibraryMergeMap
, nativeLibraryMergeGlue
, nativeLibraryMergeCodeGenerator
, nativeLibraryMergeLocalizedSymbols
, nativeLibraryProguardConfigGenerator
, enableRelinker
, relinkerWhitelist
, manifestEntries
, buildConfigValues
, postFilterResourcesCmd
, buildConfigValuesFile
, skipProguard
, useDynamicFeature
, extraFilteredResources
, duplicateResourceBehavior
, allowedDuplicateResourceTypes
, bannedDuplicateResourceTypes
, duplicateResourceWhitelist
, effectiveBannedDuplicateResourceTypes
, applicationModuleBlacklist
.
- hashCode() - Method in class com.facebook.buck.android.AndroidBuildConfigDescriptionArg
-
Computes a hash code from attributes: getPackage
, values
, valuesFile
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
.
- hashCode() - Method in class com.facebook.buck.android.AndroidBundleDescriptionArg
-
Computes a hash code from attributes: keystore
, useSplitDex
, minimizePrimaryDexSize
, dexCompression
, primaryDexPatterns
, primaryDexClassesFile
, primaryDexScenarioFile
, primaryDexScenarioOverflowAllowed
, secondaryDexHeadClassesFile
, secondaryDexTailClassesFile
, bundleConfigFile
, androidAppModularityResult
, linearAllocHardLimit
, dexGroupLibLimit
, resourceFilter
, preprocessJavaClassesDeps
, xzCompressionLevel
, packageAssetLibraries
, compressAssetLibraries
, assetCompressionAlgorithm
, redex
, redexConfig
, redexExtraArgs
, aaptMode
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, deps
, exopackage
, exopackageModes
, tests
, manifest
, manifestSkeleton
, moduleManifestSkeleton
, packageType
, noDx
, disablePreDex
, androidSdkProguardConfig
, optimizationPasses
, proguardJvmArgs
, proguardConfig
, resourceCompression
, skipCrunchPngs
, includesVectorDrawables
, noAutoVersionResources
, noVersionTransitionsResources
, noAutoAddOverlayResources
, applicationModuleTargets
, applicationModuleConfigs
, applicationModulesWithResources
, applicationModulesWithManifest
, applicationModuleDependencies
, isCacheable
, additionalAaptParams
, trimResourceIds
, allowRDotJavaInSecondaryDex
, keepResourcePattern
, resourceUnionPackage
, locales
, aapt2LocaleFiltering
, localizedStringFileName
, buildStringSourceMap
, ignoreAaptProguardConfig
, cpuFilters
, preprocessJavaClassesBash
, reorderClassesIntraDex
, dexTool
, dexReorderToolFile
, dexReorderDataDumpFile
, nativeLibraryMergeMap
, nativeLibraryMergeGlue
, nativeLibraryMergeCodeGenerator
, nativeLibraryMergeLocalizedSymbols
, nativeLibraryProguardConfigGenerator
, enableRelinker
, relinkerWhitelist
, manifestEntries
, buildConfigValues
, postFilterResourcesCmd
, buildConfigValuesFile
, skipProguard
, useDynamicFeature
, extraFilteredResources
, duplicateResourceBehavior
, allowedDuplicateResourceTypes
, bannedDuplicateResourceTypes
, duplicateResourceWhitelist
, effectiveBannedDuplicateResourceTypes
, applicationModuleBlacklist
.
- hashCode() - Method in class com.facebook.buck.android.AndroidInstrumentationApkDescriptionArg
-
Computes a hash code from attributes: manifest
, manifestSkeleton
, apk
, aaptMode
, includesVectorDrawables
, dexTool
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, deps
.
- hashCode() - Method in class com.facebook.buck.android.AndroidInstrumentationTestDescriptionArg
-
Computes a hash code from attributes: apk
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, contacts
, testRuleTimeoutMs
.
- hashCode() - Method in class com.facebook.buck.android.AndroidLibraryDescriptionArg
-
Computes a hash code from attributes: manifest
, resourceUnionPackage
, skipNonUnionRDotJava
, finalRName
, resources
, proguardConfig
, postprocessClassesCommands
, resourcesRoot
, unbundledResourcesRoot
, manifestFile
, mavenCoords
, mavenPomTemplate
, exportedDeps
, sourceOnlyAbiDeps
, runtimeDeps
, source
, target
, javaVersion
, javac
, javacJar
, compilerClassName
, compiler
, extraArguments
, removeClasses
, annotationProcessorDeps
, annotationProcessorParams
, javaPluginParams
, annotationProcessors
, annotationProcessorOnly
, plugins
, abiGenerationMode
, compileAgainst
, sourceAbiVerificationMode
, onUnusedDependencies
, neverMarkAsUnusedDependency
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, requiredForSourceOnlyAbi
, deps
, providedDeps
, exportedProvidedDeps
, srcs
, tests
, language
, freeCompilerArgs
, allWarningsAsErrors
, suppressWarnings
, verbose
, includeRuntime
, jvmTarget
, jdkHome
, noJdk
, noStdlib
, noReflect
, javaParameters
, apiVersion
, languageVersion
, annotationProcessingTool
, friendPaths
, kaptApOptions
, kotlincPlugins
, depsQuery
, providedDepsQuery
.
- hashCode() - Method in class com.facebook.buck.android.AndroidManifestDescriptionArg
-
Computes a hash code from attributes: skeleton
, deps
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
.
- hashCode() - Method in class com.facebook.buck.android.AndroidPrebuiltAarDescriptionArg
-
Computes a hash code from attributes: aar
, sourceJar
, javadocUrl
, mavenCoords
, requiredForSourceOnlyAbi
, useSystemLibraryLoader
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, deps
.
- hashCode() - Method in class com.facebook.buck.android.AndroidResourceDescriptionArg
-
Computes a hash code from attributes: res
, assets
, projectRes
, projectAssets
, hasWhitelistedStrings
, getPackage
, manifest
, resourceUnion
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, deps
.
- hashCode() - Method in class com.facebook.buck.android.ApkGenruleDescriptionArg
-
Computes a hash code from attributes: out
, apk
, isCacheable
, bash
, cmd
, cmdExe
, srcs
, enableSandbox
, environmentExpansionSeparator
, remote
, cacheable
, needAndroidTools
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, tests
.
- hashCode() - Method in class com.facebook.buck.android.GenAidlDescriptionArg
-
Computes a hash code from attributes: aidl
, importPath
, aidlSrcs
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, deps
.
- hashCode() - Method in class com.facebook.buck.android.GenerateBuildConfigStep
-
- hashCode() - Method in class com.facebook.buck.android.NdkLibraryDescriptionArg
-
Computes a hash code from attributes: flags
, isAsset
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, deps
, srcs
.
- hashCode() - Method in class com.facebook.buck.android.NdkToolchainDescriptionArg
-
Computes a hash code from attributes: cxxToolchain
, sharedRuntimePath
, objdump
, cxxRuntime
, ndkPath
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
.
- hashCode() - Method in class com.facebook.buck.android.PrebuiltNativeLibraryDescriptionArg
-
Computes a hash code from attributes: isAsset
, nativeLibs
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, deps
.
- hashCode() - Method in class com.facebook.buck.android.ProGuardObfuscateStep
-
- hashCode() - Method in class com.facebook.buck.android.RobolectricTestDescriptionArg
-
Computes a hash code from attributes: robolectricRuntimeDependency
, robolectricManifest
, resourceUnionPackage
, useOldStyleableFormat
, forceFinalResourceIds
, useBinaryResources
, vmArgs
, testType
, runTestSeparately
, forkMode
, stdErrLogLevel
, stdOutLogLevel
, useCxxLibraries
, cxxLibraryWhitelist
, testCaseTimeoutMs
, env
, defaultCxxPlatform
, contacts
, testRuleTimeoutMs
, resources
, proguardConfig
, postprocessClassesCommands
, resourcesRoot
, unbundledResourcesRoot
, manifestFile
, mavenCoords
, mavenPomTemplate
, exportedDeps
, sourceOnlyAbiDeps
, runtimeDeps
, source
, target
, javaVersion
, javac
, javacJar
, compilerClassName
, compiler
, extraArguments
, removeClasses
, annotationProcessorDeps
, annotationProcessorParams
, javaPluginParams
, annotationProcessors
, annotationProcessorOnly
, plugins
, abiGenerationMode
, compileAgainst
, sourceAbiVerificationMode
, onUnusedDependencies
, neverMarkAsUnusedDependency
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, requiredForSourceOnlyAbi
, deps
, providedDeps
, exportedProvidedDeps
, srcs
, tests
, language
, freeCompilerArgs
, allWarningsAsErrors
, suppressWarnings
, verbose
, includeRuntime
, jvmTarget
, jdkHome
, noJdk
, noStdlib
, noReflect
, javaParameters
, apiVersion
, languageVersion
, annotationProcessingTool
, friendPaths
, kaptApOptions
, kotlincPlugins
, runner
, specs
.
- hashCode() - Method in class com.facebook.buck.android.toolchain.impl.AndroidBuildToolsResolver
-
- hashCode() - Method in class com.facebook.buck.android.toolchain.ndk.impl.AndroidNdkResolver
-
- hashCode() - Method in class com.facebook.buck.android.toolchain.platform.AndroidPlatformArg
-
Computes a hash code from attributes: basePlatform
, nativePlatforms
, name
.
- hashCode() - Method in class com.facebook.buck.apple.AppleAssetCatalogDescriptionArg
-
Computes a hash code from attributes: dirs
, appIcon
, launchImage
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
.
- hashCode() - Method in class com.facebook.buck.apple.AppleAssetCatalogsCompilationOptions
-
Computes a hash code from attributes: notices
, warnings
, errors
, compressPngs
, optimization
, outputFormat
, extraFlags
.
- hashCode() - Method in class com.facebook.buck.apple.AppleBinaryDescriptionArg
-
Computes a hash code from attributes: infoPlist
, infoPlistSubstitutions
, configs
, headerPathPrefix
, modular
, modulemapMode
, targetSdkVersion
, exportedHeaders
, exportedPlatformHeaders
, exportedPreprocessorFlags
, exportedPlatformPreprocessorFlags
, exportedLangPreprocessorFlags
, exportedLangPlatformPreprocessorFlags
, exportedLinkerFlags
, exportedPostLinkerFlags
, exportedPlatformLinkerFlags
, exportedPostPlatformLinkerFlags
, exportedDeps
, exportedPlatformDeps
, supportedPlatformsRegex
, soname
, staticLibraryBasename
, forceStatic
, linkWhole
, canBeAsset
, preferredLinkage
, xcodePublicHeadersSymlinks
, xcodePrivateHeadersSymlinks
, extraXcodeSources
, extraXcodeFiles
, reexportAllHeaderDependencies
, bridgingHeader
, moduleName
, publicIncludeDirectories
, publicSystemIncludeDirectories
, exportedCxxDeps
, cxxDeps
, exportedHeaderStyle
, supportsMergedLinking
, linkStyle
, linkGroupMap
, linkGroup
, thinLto
, fatLto
, srcs
, platformSrcs
, headers
, rawHeaders
, includeDirectories
, platformHeaders
, prefixHeader
, precompiledHeader
, compilerFlags
, langCompilerFlags
, langPlatformCompilerFlags
, platformCompilerFlags
, preprocessorFlags
, platformPreprocessorFlags
, langPreprocessorFlags
, langPlatformPreprocessorFlags
, linkerFlags
, postLinkerFlags
, linkerExtraOutputs
, platformLinkerFlags
, executableName
, postPlatformLinkerFlags
, platformDeps
, headerNamespace
, cxxRuntimeType
, defaults
, defaultFlavors
, privateCxxDeps
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, deps
, defaultPlatform
, tests
, frameworks
, libraries
, swiftCompilerFlags
, swiftVersion
, contacts
, entitlementsFile
.
- hashCode() - Method in class com.facebook.buck.apple.AppleBundleDescriptionArg
-
Computes a hash code from attributes: binary
, platformBinary
, ibtoolModuleFlag
, ibtoolFlags
, resourceGroupMap
, resourceGroup
, deps
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, extension
, infoPlist
, productName
, xcodeProductType
, isAppClip
, infoPlistSubstitutions
, assetCatalogsCompilationOptions
, codesignFlags
, codesignIdentity
, contacts
, defaultPlatform
, tests
.
- hashCode() - Method in class com.facebook.buck.apple.AppleLibraryDescriptionArg
-
Computes a hash code from attributes: infoPlist
, infoPlistSubstitutions
, configs
, headerPathPrefix
, modular
, modulemapMode
, targetSdkVersion
, exportedHeaders
, exportedPlatformHeaders
, exportedPreprocessorFlags
, exportedPlatformPreprocessorFlags
, exportedLangPreprocessorFlags
, exportedLangPlatformPreprocessorFlags
, exportedLinkerFlags
, exportedPostLinkerFlags
, exportedPlatformLinkerFlags
, exportedPostPlatformLinkerFlags
, exportedDeps
, exportedPlatformDeps
, supportedPlatformsRegex
, soname
, staticLibraryBasename
, forceStatic
, linkWhole
, canBeAsset
, preferredLinkage
, xcodePublicHeadersSymlinks
, xcodePrivateHeadersSymlinks
, extraXcodeSources
, extraXcodeFiles
, reexportAllHeaderDependencies
, bridgingHeader
, moduleName
, publicIncludeDirectories
, publicSystemIncludeDirectories
, exportedCxxDeps
, cxxDeps
, exportedHeaderStyle
, supportsMergedLinking
, linkStyle
, linkGroupMap
, linkGroup
, thinLto
, fatLto
, srcs
, platformSrcs
, headers
, rawHeaders
, includeDirectories
, platformHeaders
, prefixHeader
, precompiledHeader
, compilerFlags
, langCompilerFlags
, langPlatformCompilerFlags
, platformCompilerFlags
, preprocessorFlags
, platformPreprocessorFlags
, langPreprocessorFlags
, langPlatformPreprocessorFlags
, linkerFlags
, postLinkerFlags
, linkerExtraOutputs
, platformLinkerFlags
, executableName
, postPlatformLinkerFlags
, platformDeps
, headerNamespace
, cxxRuntimeType
, defaults
, defaultFlavors
, privateCxxDeps
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, deps
, defaultPlatform
, tests
, frameworks
, libraries
, swiftCompilerFlags
, swiftVersion
, contacts
.
- hashCode() - Method in class com.facebook.buck.apple.ApplePackageDescriptionArg
-
Computes a hash code from attributes: bundle
, needAndroidTools
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, defaultPlatform
.
- hashCode() - Method in class com.facebook.buck.apple.AppleResourceDescriptionArg
-
Computes a hash code from attributes: dirs
, files
, variants
, resourcesFromDeps
, destination
, codesignOnCopy
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
.
- hashCode() - Method in class com.facebook.buck.apple.AppleTestDescriptionArg
-
Computes a hash code from attributes: runTestSeparately
, isUiTest
, testHostApp
, uiTestTargetApp
, snapshotReferenceImagesPath
, snapshotImagesDiffPath
, destinationSpecifier
, env
, configs
, headerPathPrefix
, modular
, modulemapMode
, targetSdkVersion
, exportedHeaders
, exportedPlatformHeaders
, exportedPreprocessorFlags
, exportedPlatformPreprocessorFlags
, exportedLangPreprocessorFlags
, exportedLangPlatformPreprocessorFlags
, exportedLinkerFlags
, exportedPostLinkerFlags
, exportedPlatformLinkerFlags
, exportedPostPlatformLinkerFlags
, exportedDeps
, exportedPlatformDeps
, supportedPlatformsRegex
, soname
, staticLibraryBasename
, forceStatic
, linkWhole
, canBeAsset
, preferredLinkage
, xcodePublicHeadersSymlinks
, xcodePrivateHeadersSymlinks
, extraXcodeSources
, extraXcodeFiles
, reexportAllHeaderDependencies
, bridgingHeader
, moduleName
, publicIncludeDirectories
, publicSystemIncludeDirectories
, exportedCxxDeps
, cxxDeps
, exportedHeaderStyle
, supportsMergedLinking
, linkStyle
, linkGroupMap
, linkGroup
, thinLto
, fatLto
, srcs
, platformSrcs
, headers
, rawHeaders
, includeDirectories
, platformHeaders
, prefixHeader
, precompiledHeader
, compilerFlags
, langCompilerFlags
, langPlatformCompilerFlags
, platformCompilerFlags
, preprocessorFlags
, platformPreprocessorFlags
, langPreprocessorFlags
, langPlatformPreprocessorFlags
, linkerFlags
, postLinkerFlags
, linkerExtraOutputs
, platformLinkerFlags
, executableName
, postPlatformLinkerFlags
, platformDeps
, headerNamespace
, cxxRuntimeType
, defaults
, defaultFlavors
, privateCxxDeps
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, deps
, defaultPlatform
, tests
, frameworks
, libraries
, swiftCompilerFlags
, swiftVersion
, infoPlist
, xcodeProductType
, isAppClip
, infoPlistSubstitutions
, assetCatalogsCompilationOptions
, codesignFlags
, codesignIdentity
, contacts
, entitlementsFile
, testRuleTimeoutMs
, runner
, specs
.
- hashCode() - Method in class com.facebook.buck.apple.AppleToolchainDescriptionArg
-
Computes a hash code from attributes: sdkName
, architecture
, platformPath
, sdkPath
, version
, buildVersion
, minVersion
, actool
, dsymutil
, ibtool
, libtool
, lipo
, lldb
, momc
, xctest
, copySceneKitAssets
, codesign
, codesignAllocate
, cxxToolchain
, swiftToolchain
, developerPath
, xcodeVersion
, xcodeBuildVersion
, workAroundDsymutilLtoStackOverflowBug
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
.
- hashCode() - Method in class com.facebook.buck.apple.AppleToolchainSetDescriptionArg
-
Computes a hash code from attributes: appleToolchains
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
.
- hashCode() - Method in class com.facebook.buck.apple.AppleWrapperResourceArg
-
Computes a hash code from attributes: path
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
.
- hashCode() - Method in class com.facebook.buck.apple.clang.UmbrellaHeaderModuleMap
-
- hashCode() - Method in class com.facebook.buck.apple.PrebuiltAppleFrameworkDescriptionArg
-
Computes a hash code from attributes: framework
, supportedPlatformsRegex
, exportedLinkerFlags
, codeSignOnCopy
, exportedPlatformLinkerFlags
, preferredLinkage
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, deps
, frameworks
, libraries
.
- hashCode() - Method in class com.facebook.buck.apple.xcode.xcodeproj.SourceTreePath
-
- hashCode() - Method in class com.facebook.buck.apple.XcodeScriptDescriptionArg
-
Computes a hash code from attributes: inputs
, inputFileLists
, outputs
, outputFileLists
, cmd
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, srcs
.
- hashCode() - Method in class com.facebook.buck.artifact_cache.ArtifactCacheEvent.Finished
-
- hashCode() - Method in class com.facebook.buck.core.build.event.BuildEvent.BuildReport
-
- hashCode() - Method in class com.facebook.buck.core.build.event.BuildEvent.Finished
-
- hashCode() - Method in class com.facebook.buck.core.build.event.BuildEvent.RuleCountCalculated
-
- hashCode() - Method in class com.facebook.buck.core.build.event.BuildEvent.UnskippedRuleCountUpdated
-
- hashCode() - Method in class com.facebook.buck.core.cell.CellPathResolverView
-
- hashCode() - Method in class com.facebook.buck.core.config.BuckConfig
-
- hashCode() - Method in class com.facebook.buck.core.exceptions.DependencyStack
-
- hashCode() - Method in class com.facebook.buck.core.filesystems.BuckUnixPath
-
- hashCode() - Method in interface com.facebook.buck.core.filesystems.PathWrapper
-
- hashCode() - Method in class com.facebook.buck.core.graph.transformation.model.ClassBasedComputationIdentifier
-
- hashCode() - Method in class com.facebook.buck.core.graph.transformation.model.ComposedComputationIdentifier
-
- hashCode() - Method in class com.facebook.buck.core.model.BaseName
-
- hashCode() - Method in class com.facebook.buck.core.model.BuildId
-
- hashCode() - Method in class com.facebook.buck.core.model.BuildTarget
-
- hashCode() - Method in class com.facebook.buck.core.model.ConfigurationForConfigurationTargets
-
- hashCode() - Method in class com.facebook.buck.core.model.ErrorTargetConfiguration
-
- hashCode() - Method in class com.facebook.buck.core.model.FlavorSet
-
- hashCode() - Method in class com.facebook.buck.core.model.InternalFlavor
-
- hashCode() - Method in class com.facebook.buck.core.model.OutputLabel
-
- hashCode() - Method in class com.facebook.buck.core.model.platform.impl.EmptyPlatform
-
- hashCode() - Method in class com.facebook.buck.core.model.platform.impl.UnconfiguredPlatform
-
- hashCode() - Method in class com.facebook.buck.core.model.targetgraph.impl.TargetNodeFactory
-
- hashCode() - Method in class com.facebook.buck.core.model.targetgraph.TargetGraph
-
- hashCode() - Method in class com.facebook.buck.core.model.UnconfiguredBuildTarget
-
- hashCode() - Method in class com.facebook.buck.core.model.UnconfiguredTargetConfiguration
-
- hashCode() - Method in class com.facebook.buck.core.model.UnflavoredBuildTarget
-
- hashCode() - Method in class com.facebook.buck.core.model.UserFlavor
-
- hashCode() - Method in class com.facebook.buck.core.path.ForwardRelativePath
-
- hashCode() - Method in class com.facebook.buck.core.rulekey.RuleKey
-
- hashCode() - Method in class com.facebook.buck.core.rules.configsetting.ConfigSettingArg
-
Computes a hash code from attributes: values
, constraintValues
, name
.
- hashCode() - Method in class com.facebook.buck.core.rules.impl.AbstractBuildRule
-
- hashCode() - Method in class com.facebook.buck.core.rules.platform.ConstraintSettingArg
-
Computes a hash code from attributes: name
.
- hashCode() - Method in class com.facebook.buck.core.rules.platform.ConstraintValueArg
-
Computes a hash code from attributes: constraintSetting
, name
.
- hashCode() - Method in class com.facebook.buck.core.rules.platform.PlatformArg
-
Computes a hash code from attributes: constraintValues
, deps
, name
.
- hashCode() - Method in class com.facebook.buck.core.rules.providers.lib.ImmutableDefaultInfo
-
Computes a hash code from attributes: namedOutputs
, defaultOutputs
.
- hashCode() - Method in class com.facebook.buck.core.rules.providers.lib.ImmutableRunInfo
-
Computes a hash code from attributes: env
, args
.
- hashCode() - Method in class com.facebook.buck.core.rules.providers.lib.ImmutableTestInfo
-
Computes a hash code from attributes: testName
, testCaseName
, labels
, contacts
, timeoutMs
, runTestsSeparately
, type
.
- hashCode() - Method in class com.facebook.buck.core.select.Selector
-
- hashCode() - Method in class com.facebook.buck.core.select.SelectorKey
-
- hashCode() - Method in class com.facebook.buck.core.select.SelectorList
-
- hashCode() - Method in class com.facebook.buck.core.sourcepath.DefaultBuildTargetSourcePath
-
- hashCode() - Method in class com.facebook.buck.core.sourcepath.ExplicitBuildTargetSourcePath
-
- hashCode() - Method in class com.facebook.buck.core.sourcepath.ForwardingBuildTargetSourcePath
-
- hashCode() - Method in class com.facebook.buck.core.sourcepath.PathSourcePath
-
- hashCode() - Method in class com.facebook.buck.core.sourcepath.UnconfiguredSourcePath.BuildTarget
-
- hashCode() - Method in class com.facebook.buck.core.sourcepath.UnconfiguredSourcePath.Path
-
- hashCode() - Method in class com.facebook.buck.core.test.rule.impl.ExternalTestRunnerDescriptionArg
-
Computes a hash code from attributes: binary
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
.
- hashCode() - Method in class com.facebook.buck.core.toolchain.rule.LegacyToolchainDescriptionArg
-
Computes a hash code from attributes: toolchainName
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
.
- hashCode() - Method in class com.facebook.buck.core.util.graph.DirectedAcyclicGraph
-
- hashCode() - Method in class com.facebook.buck.counters.Counter
-
- hashCode() - Method in class com.facebook.buck.cxx.CxxBinaryDescriptionArg
-
Computes a hash code from attributes: linkDepsQueryWhole
, linkStyle
, linkGroupMap
, linkGroup
, thinLto
, fatLto
, srcs
, platformSrcs
, headers
, rawHeaders
, includeDirectories
, platformHeaders
, prefixHeader
, precompiledHeader
, compilerFlags
, langCompilerFlags
, langPlatformCompilerFlags
, platformCompilerFlags
, preprocessorFlags
, platformPreprocessorFlags
, langPreprocessorFlags
, langPlatformPreprocessorFlags
, linkerFlags
, postLinkerFlags
, linkerExtraOutputs
, platformLinkerFlags
, executableName
, postPlatformLinkerFlags
, platformDeps
, headerNamespace
, cxxRuntimeType
, defaults
, defaultFlavors
, cxxDeps
, privateCxxDeps
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, deps
, defaultPlatform
, tests
, frameworks
, libraries
, versionUniverse
, depsQuery
.
- hashCode() - Method in class com.facebook.buck.cxx.CxxGenruleDescriptionArg
-
Computes a hash code from attributes: out
, bash
, cmd
, cmdExe
, type
, srcs
, enableSandbox
, environmentExpansionSeparator
, remote
, cacheable
, needAndroidTools
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, tests
.
- hashCode() - Method in class com.facebook.buck.cxx.CxxLibraryDescriptionArg
-
Computes a hash code from attributes: exportedHeaders
, exportedPlatformHeaders
, exportedPreprocessorFlags
, exportedPlatformPreprocessorFlags
, exportedLangPreprocessorFlags
, exportedLangPlatformPreprocessorFlags
, exportedLinkerFlags
, exportedPostLinkerFlags
, exportedPlatformLinkerFlags
, exportedPostPlatformLinkerFlags
, exportedDeps
, exportedPlatformDeps
, supportedPlatformsRegex
, soname
, staticLibraryBasename
, forceStatic
, linkWhole
, canBeAsset
, preferredLinkage
, xcodePublicHeadersSymlinks
, xcodePrivateHeadersSymlinks
, extraXcodeSources
, extraXcodeFiles
, reexportAllHeaderDependencies
, bridgingHeader
, moduleName
, publicIncludeDirectories
, publicSystemIncludeDirectories
, exportedCxxDeps
, cxxDeps
, exportedHeaderStyle
, supportsMergedLinking
, linkStyle
, linkGroupMap
, linkGroup
, thinLto
, fatLto
, srcs
, platformSrcs
, headers
, rawHeaders
, includeDirectories
, platformHeaders
, prefixHeader
, precompiledHeader
, compilerFlags
, langCompilerFlags
, langPlatformCompilerFlags
, platformCompilerFlags
, preprocessorFlags
, platformPreprocessorFlags
, langPreprocessorFlags
, langPlatformPreprocessorFlags
, linkerFlags
, postLinkerFlags
, linkerExtraOutputs
, platformLinkerFlags
, executableName
, postPlatformLinkerFlags
, platformDeps
, headerNamespace
, cxxRuntimeType
, defaults
, defaultFlavors
, privateCxxDeps
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, deps
, defaultPlatform
, tests
, frameworks
, libraries
.
- hashCode() - Method in class com.facebook.buck.cxx.CxxPrecompiledHeaderDescriptionArg
-
Computes a hash code from attributes: src
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, deps
.
- hashCode() - Method in class com.facebook.buck.cxx.CxxTestDescriptionArg
-
Computes a hash code from attributes: framework
, env
, args
, runTestSeparately
, useDefaultTestMain
, resources
, additionalCoverageTargets
, linkDepsQueryWhole
, linkStyle
, linkGroupMap
, linkGroup
, thinLto
, fatLto
, srcs
, platformSrcs
, headers
, rawHeaders
, includeDirectories
, platformHeaders
, prefixHeader
, precompiledHeader
, compilerFlags
, langCompilerFlags
, langPlatformCompilerFlags
, platformCompilerFlags
, preprocessorFlags
, platformPreprocessorFlags
, langPreprocessorFlags
, langPlatformPreprocessorFlags
, linkerFlags
, postLinkerFlags
, linkerExtraOutputs
, platformLinkerFlags
, executableName
, postPlatformLinkerFlags
, platformDeps
, headerNamespace
, cxxRuntimeType
, defaults
, defaultFlavors
, cxxDeps
, privateCxxDeps
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, deps
, defaultPlatform
, tests
, frameworks
, libraries
, versionUniverse
, depsQuery
, contacts
, testRuleTimeoutMs
.
- hashCode() - Method in class com.facebook.buck.cxx.CxxToolchainDescriptionArg
-
Computes a hash code from attributes: privateHeadersSymlinksEnabled
, publicHeadersSymlinksEnabled
, useArgFile
, sharedLibraryExtension
, sharedLibraryVersionedExtensionFormat
, staticLibraryExtension
, objectFileExtension
, binaryExtension
, compilerType
, linkerType
, assembler
, assemblerFlags
, cCompiler
, cCompilerFlags
, cxxCompiler
, cxxCompilerFlags
, linker
, linkerFlags
, archiver
, archiverFlags
, archiverType
, strip
, ranlib
, ranlibFlags
, stripFlags
, staticDepRuntimeLdFlags
, staticPicDepRuntimeLdFlags
, sharedDepRuntimeLdFlags
, nm
, sharedLibraryInterfaceType
, objcopyForSharedLibraryInterface
, useHeaderMap
, filepathLengthLimited
, headersWhitelist
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
.
- hashCode() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryDescriptionArg
-
Computes a hash code from attributes: headerDirs
, platformHeaderDirs
, versionedHeaderDirs
, importLib
, platformImportLib
, versionedImportLib
, sharedLib
, platformSharedLib
, versionedSharedLib
, staticLib
, platformStaticLib
, versionedStaticLib
, staticPicLib
, platformStaticPicLib
, versionedStaticPicLib
, headerOnly
, exportedHeaders
, exportedPlatformHeaders
, headerNamespace
, provided
, linkWhole
, forceStatic
, preferredLinkage
, exportedPreprocessorFlags
, exportedPlatformPreprocessorFlags
, exportedLangPreprocessorFlags
, exportedLangPlatformPreprocessorFlags
, versionedExportedPreprocessorFlags
, versionedExportedPlatformPreprocessorFlags
, versionedExportedLangPreprocessorFlags
, versionedExportedLangPlatformPreprocessorFlags
, exportedLinkerFlags
, exportedPostLinkerFlags
, exportedPlatformLinkerFlags
, exportedPostPlatformLinkerFlags
, soname
, linkWithoutSoname
, canBeAsset
, frameworks
, libraries
, exportedDeps
, exportedPlatformDeps
, supportedPlatformsRegex
, supportsSharedLibraryInterface
, supportsMergedLinking
, privateCxxDeps
, exportedCxxDeps
, cxxDeps
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, deps
.
- hashCode() - Method in class com.facebook.buck.cxx.PrebuiltCxxLibraryGroupDescriptionArg
-
Computes a hash code from attributes: exportedPreprocessorFlags
, includeDirs
, staticLink
, staticLibs
, staticPicLink
, staticPicLibs
, sharedLink
, sharedLibs
, importLibs
, providedSharedLibs
, exportedDeps
, exportedPlatformDeps
, supportedPlatformsRegex
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, deps
.
- hashCode() - Method in class com.facebook.buck.cxx.RelativeLinkArg
-
- hashCode() - Method in class com.facebook.buck.event.AbstractBuckEvent
-
- hashCode() - Method in class com.facebook.buck.event.InstallEvent.Finished
-
- hashCode() - Method in class com.facebook.buck.event.StartActivityEvent.Finished
-
- hashCode() - Method in class com.facebook.buck.event.UninstallEvent.Finished
-
- hashCode() - Method in class com.facebook.buck.features.apple.common.XcodeWorkspaceConfigDescriptionArg
-
Computes a hash code from attributes: srcTarget
, extraTests
, extraTargets
, extraShallowTargets
, workspaceName
, actionConfigNames
, extraSchemes
, environmentVariables
, commandLineArguments
, applicationLanguage
, applicationRegion
, expandVariablesBasedOn
, wasCreatedForAppExtension
, isRemoteRunnable
, explicitRunnablePath
, notificationPayloadFile
, watchInterface
, launchStyle
, additionalSchemeActions
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
.
- hashCode() - Method in class com.facebook.buck.features.d.DBinaryDescriptionArg
-
Computes a hash code from attributes: srcs
, linkerFlags
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, deps
.
- hashCode() - Method in class com.facebook.buck.features.d.DLibraryDescriptionArg
-
Computes a hash code from attributes: srcs
, linkerFlags
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, deps
.
- hashCode() - Method in class com.facebook.buck.features.d.DTestDescriptionArg
-
Computes a hash code from attributes: srcs
, linkerFlags
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, contacts
, deps
, testRuleTimeoutMs
.
- hashCode() - Method in class com.facebook.buck.features.d.DTestStep
-
- hashCode() - Method in class com.facebook.buck.features.dotnet.CsharpLibraryDescriptionArg
-
Computes a hash code from attributes: frameworkVer
, resources
, dllName
, deps
, compilerFlags
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, srcs
.
- hashCode() - Method in class com.facebook.buck.features.dotnet.DotnetFramework
-
- hashCode() - Method in class com.facebook.buck.features.dotnet.ImmutableDotnetLegacyToolchainInfo
-
Computes a hash code from attributes: compiler
.
- hashCode() - Method in class com.facebook.buck.features.dotnet.ImmutableDotnetLibraryProviderInfo
-
Computes a hash code from attributes: dll
.
- hashCode() - Method in class com.facebook.buck.features.dotnet.PrebuiltDotnetLibraryDescriptionArg
-
Computes a hash code from attributes: assembly
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
.
- hashCode() - Method in class com.facebook.buck.features.filegroup.FileGroupDescriptionArg
-
Computes a hash code from attributes: compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, srcs
.
- hashCode() - Method in class com.facebook.buck.features.go.CgoLibraryDescriptionArg
-
Computes a hash code from attributes: cgoCompilerFlags
, goCompilerFlags
, goAssemblerFlags
, packageName
, goSrcs
, exportedDeps
, compilerFlags
, linkDepsQueryWhole
, fatLto
, linkGroup
, linkGroupMap
, linkStyle
, thinLto
, cxxDeps
, cxxRuntimeType
, defaultFlavors
, defaults
, executableName
, headerNamespace
, headers
, includeDirectories
, langCompilerFlags
, langPlatformCompilerFlags
, langPlatformPreprocessorFlags
, langPreprocessorFlags
, linkerExtraOutputs
, linkerFlags
, platformCompilerFlags
, platformDeps
, platformHeaders
, platformLinkerFlags
, platformPreprocessorFlags
, platformSrcs
, postLinkerFlags
, postPlatformLinkerFlags
, precompiledHeader
, prefixHeader
, preprocessorFlags
, privateCxxDeps
, rawHeaders
, srcs
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, deps
, defaultPlatform
, tests
, frameworks
, libraries
, versionUniverse
, depsQuery
.
- hashCode() - Method in class com.facebook.buck.features.go.GoBinaryDescriptionArg
-
Computes a hash code from attributes: compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, deps
, srcs
, platform
, linkStyle
, linkMode
, compilerFlags
, assemblerFlags
, linkerFlags
, externalLinkerFlags
, resources
.
- hashCode() - Method in class com.facebook.buck.features.go.GoLibraryDescriptionArg
-
Computes a hash code from attributes: compilerFlags
, assemblerFlags
, packageName
, exportedDeps
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, deps
, srcs
, tests
.
- hashCode() - Method in class com.facebook.buck.features.go.GoTestDescriptionArg
-
Computes a hash code from attributes: library
, packageName
, coverageMode
, env
, runTestSeparately
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, contacts
, deps
, srcs
, runner
, specs
, testRuleTimeoutMs
, platform
, linkStyle
, linkMode
, compilerFlags
, assemblerFlags
, linkerFlags
, externalLinkerFlags
, resources
.
- hashCode() - Method in class com.facebook.buck.features.go.GoTestRunnerDescriptionArg
-
Computes a hash code from attributes: testRunnerGenerator
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
.
- hashCode() - Method in class com.facebook.buck.features.go.GoTestStep
-
- hashCode() - Method in class com.facebook.buck.features.go.PrebuiltGoLibraryDescriptionArg
-
Computes a hash code from attributes: library
, packageName
, exportedDeps
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, deps
.
- hashCode() - Method in class com.facebook.buck.features.gwt.GwtBinaryDescriptionArg
-
Computes a hash code from attributes: modules
, moduleDeps
, vmArgs
, style
, draftCompile
, optimize
, localWorkers
, strict
, experimentalArgs
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, deps
.
- hashCode() - Method in class com.facebook.buck.features.halide.HalideLibraryDescriptionArg
-
Computes a hash code from attributes: compilerDeps
, configs
, supportedPlatformsRegex
, compilerInvocationFlags
, functionName
, linkDepsQueryWhole
, fatLto
, linkGroup
, linkGroupMap
, linkStyle
, thinLto
, compilerFlags
, cxxDeps
, cxxRuntimeType
, defaultFlavors
, defaults
, executableName
, headerNamespace
, headers
, includeDirectories
, langCompilerFlags
, langPlatformCompilerFlags
, langPlatformPreprocessorFlags
, langPreprocessorFlags
, linkerExtraOutputs
, linkerFlags
, platformCompilerFlags
, platformDeps
, platformHeaders
, platformLinkerFlags
, platformPreprocessorFlags
, platformSrcs
, postLinkerFlags
, postPlatformLinkerFlags
, precompiledHeader
, prefixHeader
, preprocessorFlags
, privateCxxDeps
, rawHeaders
, srcs
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, deps
, defaultPlatform
, tests
, frameworks
, libraries
, versionUniverse
, depsQuery
.
- hashCode() - Method in class com.facebook.buck.features.haskell.HaskellBinaryDescriptionArg
-
Computes a hash code from attributes: srcs
, compilerFlags
, linkerFlags
, platformDeps
, linkDepsQueryWhole
, main
, linkStyle
, platform
, enableProfiling
, ghciPreloadDeps
, ghciPlatformPreloadDeps
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, depsQuery
, deps
.
- hashCode() - Method in class com.facebook.buck.features.haskell.HaskellGhciDescriptionArg
-
Computes a hash code from attributes: srcs
, compilerFlags
, linkerFlags
, platformDeps
, enableProfiling
, ghciBinDep
, ghciInit
, platform
, extraScriptTemplates
, preloadDeps
, platformPreloadDeps
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, depsQuery
, deps
.
- hashCode() - Method in class com.facebook.buck.features.haskell.HaskellHaddockDescriptionArg
-
Computes a hash code from attributes: platform
, haddockFlags
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, depsQuery
, deps
.
- hashCode() - Method in class com.facebook.buck.features.haskell.HaskellLibraryDescriptionArg
-
Computes a hash code from attributes: srcs
, linkerFlags
, compilerFlags
, platformDeps
, linkWhole
, preferredLinkage
, enableProfiling
, haddockFlags
, ghciPreloadDeps
, ghciPlatformPreloadDeps
, platform
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, deps
.
- hashCode() - Method in class com.facebook.buck.features.haskell.HaskellPrebuiltLibraryDescriptionArg
-
Computes a hash code from attributes: version
, id
, db
, importDirs
, staticLibs
, profiledStaticLibs
, sharedLibs
, exportedLinkerFlags
, exportedCompilerFlags
, cxxHeaderDirs
, enableProfiling
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, deps
.
- hashCode() - Method in class com.facebook.buck.features.js.JsBundleDescriptionArg
-
Computes a hash code from attributes: entry
, worker
, androidPackage
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, deps
, extraJson
, bundleName
, bundleNameForFlavor
.
- hashCode() - Method in class com.facebook.buck.features.js.JsBundleGenruleDescriptionArg
-
Computes a hash code from attributes: jsBundle
, rewriteSourcemap
, rewriteMisc
, skipResources
, rewriteDepsFile
, bash
, cacheable
, cmd
, cmdExe
, enableSandbox
, environmentExpansionSeparator
, remote
, srcs
, needAndroidTools
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, tests
, bundleName
, bundleNameForFlavor
.
- hashCode() - Method in class com.facebook.buck.features.js.JsLibraryDescriptionArg
-
Computes a hash code from attributes: srcs
, worker
, basePath
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, depsQuery
, deps
, extraJson
, tests
.
- hashCode() - Method in class com.facebook.buck.features.lua.CxxLuaExtensionDescriptionArg
-
Computes a hash code from attributes: baseModule
, compilerFlags
, cxxDeps
, cxxRuntimeType
, defaultFlavors
, defaults
, executableName
, headerNamespace
, headers
, includeDirectories
, langCompilerFlags
, langPlatformCompilerFlags
, langPlatformPreprocessorFlags
, langPreprocessorFlags
, linkerExtraOutputs
, linkerFlags
, platformCompilerFlags
, platformDeps
, platformHeaders
, platformLinkerFlags
, platformPreprocessorFlags
, platformSrcs
, postLinkerFlags
, postPlatformLinkerFlags
, precompiledHeader
, prefixHeader
, preprocessorFlags
, privateCxxDeps
, rawHeaders
, srcs
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, deps
, defaultPlatform
, tests
, frameworks
, libraries
.
- hashCode() - Method in class com.facebook.buck.features.lua.LuaBinaryDescriptionArg
-
Computes a hash code from attributes: mainModule
, nativeStarterLibrary
, pythonPlatform
, platform
, packageStyle
, platformDeps
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, deps
.
- hashCode() - Method in class com.facebook.buck.features.lua.LuaLibraryDescriptionArg
-
Computes a hash code from attributes: srcs
, baseModule
, platformDeps
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, deps
.
- hashCode() - Method in class com.facebook.buck.features.ocaml.OcamlBinaryDescriptionArg
-
Computes a hash code from attributes: srcs
, compilerFlags
, linkerFlags
, ocamldepFlags
, warningsFlags
, bytecodeOnly
, platform
, platformDeps
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, deps
.
- hashCode() - Method in class com.facebook.buck.features.ocaml.OcamlLibraryDescriptionArg
-
Computes a hash code from attributes: srcs
, compilerFlags
, ocamldepFlags
, linkerFlags
, warningsFlags
, bytecodeOnly
, nativePlugin
, platformDeps
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, deps
.
- hashCode() - Method in class com.facebook.buck.features.ocaml.PrebuiltOcamlLibraryDescriptionArg
-
Computes a hash code from attributes: libDir
, includeDir
, libName
, nativeLib
, bytecodeLib
, cLibs
, nativeCLibs
, bytecodeCLibs
, bytecodeOnly
, platformDeps
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, deps
.
- hashCode() - Method in class com.facebook.buck.features.project.intellij.model.folders.IjFolder
-
- hashCode() - Method in class com.facebook.buck.features.project.intellij.model.folders.ResourceFolder
-
- hashCode() - Method in class com.facebook.buck.features.project.intellij.model.IjModule
-
- hashCode() - Method in class com.facebook.buck.features.python.CxxPythonExtensionDescriptionArg
-
Computes a hash code from attributes: baseModule
, moduleName
, compilerFlags
, cxxDeps
, cxxRuntimeType
, defaultFlavors
, defaults
, executableName
, headerNamespace
, headers
, includeDirectories
, langCompilerFlags
, langPlatformCompilerFlags
, langPlatformPreprocessorFlags
, langPreprocessorFlags
, linkerExtraOutputs
, linkerFlags
, platformCompilerFlags
, platformDeps
, platformHeaders
, platformLinkerFlags
, platformPreprocessorFlags
, platformSrcs
, postLinkerFlags
, postPlatformLinkerFlags
, precompiledHeader
, prefixHeader
, preprocessorFlags
, privateCxxDeps
, rawHeaders
, srcs
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, deps
, defaultPlatform
, tests
, frameworks
, libraries
.
- hashCode() - Method in class com.facebook.buck.features.python.PrebuiltPythonLibraryDescriptionArg
-
Computes a hash code from attributes: binarySrc
, excludeDepsFromMergedLinking
, ignoreCompileErrors
, compile
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, deps
.
- hashCode() - Method in class com.facebook.buck.features.python.PythonBinaryDescriptionArg
-
Computes a hash code from attributes: main
, mainModule
, platformDeps
, baseModule
, zipSafe
, buildArgs
, platform
, cxxPlatform
, packageStyle
, preloadDeps
, linkerFlags
, extension
, compile
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, deps
, tests
, versionUniverse
.
- hashCode() - Method in class com.facebook.buck.features.python.PythonLibraryDescriptionArg
-
Computes a hash code from attributes: srcs
, versionedSrcs
, platformSrcs
, resources
, versionedResources
, platformResources
, platformDeps
, baseModule
, zipSafe
, excludeDepsFromMergedLinking
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, deps
, tests
.
- hashCode() - Method in class com.facebook.buck.features.python.PythonTestDescriptionArg
-
Computes a hash code from attributes: mainModule
, platform
, cxxPlatform
, extension
, packageStyle
, preloadDeps
, linkerFlags
, neededCoverage
, buildArgs
, env
, additionalCoverageTargets
, compile
, contacts
, runner
, specs
, testRuleTimeoutMs
, srcs
, versionedSrcs
, platformSrcs
, resources
, versionedResources
, platformResources
, platformDeps
, baseModule
, zipSafe
, excludeDepsFromMergedLinking
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, deps
, tests
, versionUniverse
.
- hashCode() - Method in class com.facebook.buck.features.python.PythonTestRunnerDescriptionArg
-
Computes a hash code from attributes: src
, mainModule
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
.
- hashCode() - Method in class com.facebook.buck.features.rust.PrebuiltRustLibraryDescriptionArg
-
Computes a hash code from attributes: rlib
, crate
, linkStyle
, procMacro
, platformDeps
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, deps
.
- hashCode() - Method in class com.facebook.buck.features.rust.RustBinaryDescriptionArg
-
Computes a hash code from attributes: linkerFlags
, linkStyle
, rpath
, mappedSrcs
, env
, edition
, features
, rustcFlags
, crate
, crateRoot
, platformDeps
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, namedDeps
, deps
, srcs
, defaultPlatform
, tests
, versionUniverse
.
- hashCode() - Method in class com.facebook.buck.features.rust.RustLibraryArg
-
- hashCode() - Method in class com.facebook.buck.features.rust.RustLibraryDescriptionArg
-
Computes a hash code from attributes: preferredLinkage
, procMacro
, mappedSrcs
, env
, edition
, features
, rustcFlags
, crate
, crateRoot
, platformDeps
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, namedDeps
, deps
, srcs
, defaultPlatform
, tests
.
- hashCode() - Method in class com.facebook.buck.features.rust.RustTestDescriptionArg
-
Computes a hash code from attributes: contacts
, linkerFlags
, linkStyle
, rpath
, framework
, mappedSrcs
, env
, edition
, features
, rustcFlags
, crate
, crateRoot
, platformDeps
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
, namedDeps
, deps
, srcs
, defaultPlatform
, versionUniverse
.
- hashCode() - Method in class com.facebook.buck.features.zip.rules.ZipFileDescriptionArg
-
Computes a hash code from attributes: out
, srcs
, entriesToExclude
, zipSrcs
, onDuplicateEntry
, compatibleWith
, defaultTargetPlatform
, labels
, licenses
, name
.
- hashCode() - Method in class com.facebook.buck.file.FileHash
-
- hashCode() - Method in class com.facebook.buck.file.HttpArchiveDescriptionArg
-
Computes a hash code from attributes: stripPrefix
, type
, sha256
, urls
, out
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
.
- hashCode() - Method in class com.facebook.buck.file.HttpFileDescriptionArg
-
Computes a hash code from attributes: executable
, sha256
, urls
, out
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
.
- hashCode() - Method in class com.facebook.buck.file.RemoteFileDescriptionArg
-
Computes a hash code from attributes: url
, sha1
, out
, type
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
.
- hashCode() - Method in class com.facebook.buck.io.filesystem.ExactPathMatcher
-
- hashCode() - Method in class com.facebook.buck.io.filesystem.FileExtensionMatcher
-
- hashCode() - Method in class com.facebook.buck.io.filesystem.GlobPatternMatcher
-
- hashCode() - Method in class com.facebook.buck.io.filesystem.impl.DefaultProjectFilesystem
-
- hashCode() - Method in class com.facebook.buck.io.filesystem.RecursiveFileMatcher
-
- hashCode() - Method in class com.facebook.buck.jvm.groovy.GroovyLibraryDescriptionArg
-
Computes a hash code from attributes: extraGroovycArguments
, resources
, proguardConfig
, postprocessClassesCommands
, resourcesRoot
, unbundledResourcesRoot
, manifestFile
, mavenCoords
, mavenPomTemplate
, exportedDeps
, sourceOnlyAbiDeps
, runtimeDeps
, source
, target
, javaVersion
, javac
, javacJar
, compilerClassName
, compiler
, extraArguments
, removeClasses
, annotationProcessorDeps
, annotationProcessorParams
, javaPluginParams
, annotationProcessors
, annotationProcessorOnly
, plugins
, compileAgainst
, sourceAbiVerificationMode
, onUnusedDependencies
, neverMarkAsUnusedDependency
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, requiredForSourceOnlyAbi
, deps
, providedDeps
, exportedProvidedDeps
, srcs
, tests
.
- hashCode() - Method in class com.facebook.buck.jvm.groovy.GroovyTestDescriptionArg
-
Computes a hash code from attributes: extraGroovycArguments
, resources
, proguardConfig
, postprocessClassesCommands
, resourcesRoot
, unbundledResourcesRoot
, manifestFile
, mavenCoords
, mavenPomTemplate
, exportedDeps
, sourceOnlyAbiDeps
, runtimeDeps
, source
, target
, javaVersion
, javac
, javacJar
, compilerClassName
, compiler
, extraArguments
, removeClasses
, annotationProcessorDeps
, annotationProcessorParams
, javaPluginParams
, annotationProcessors
, annotationProcessorOnly
, plugins
, compileAgainst
, sourceAbiVerificationMode
, onUnusedDependencies
, neverMarkAsUnusedDependency
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, requiredForSourceOnlyAbi
, deps
, providedDeps
, exportedProvidedDeps
, srcs
, tests
, vmArgs
, testType
, runTestSeparately
, forkMode
, stdErrLogLevel
, stdOutLogLevel
, useCxxLibraries
, cxxLibraryWhitelist
, testCaseTimeoutMs
, env
, defaultCxxPlatform
, contacts
, testRuleTimeoutMs
.
- hashCode() - Method in class com.facebook.buck.jvm.java.JarGenruleDescriptionArg
-
Computes a hash code from attributes: bash
, cmd
, cmdExe
, type
, srcs
, enableSandbox
, environmentExpansionSeparator
, remote
, cacheable
, needAndroidTools
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, tests
.
- hashCode() - Method in class com.facebook.buck.jvm.java.JavaAnnotationProcessorDescriptionArg
-
Computes a hash code from attributes: processorClass
, processorClasses
, isolateClassLoader
, doesNotAffectAbi
, supportsAbiGenerationFromSource
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, deps
.
- hashCode() - Method in class com.facebook.buck.jvm.java.JavaBinaryDescriptionArg
-
Computes a hash code from attributes: mainClass
, manifestFile
, mergeManifests
, disallowAllDuplicates
, metaInfDirectory
, blacklist
, defaultCxxPlatform
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, deps
, tests
.
- hashCode() - Method in class com.facebook.buck.jvm.java.JavaLibraryDescriptionArg
-
Computes a hash code from attributes: resources
, proguardConfig
, postprocessClassesCommands
, resourcesRoot
, unbundledResourcesRoot
, manifestFile
, mavenCoords
, mavenPomTemplate
, exportedDeps
, sourceOnlyAbiDeps
, runtimeDeps
, source
, target
, javaVersion
, javac
, javacJar
, compilerClassName
, compiler
, extraArguments
, removeClasses
, annotationProcessorDeps
, annotationProcessorParams
, javaPluginParams
, annotationProcessors
, annotationProcessorOnly
, plugins
, abiGenerationMode
, compileAgainst
, sourceAbiVerificationMode
, onUnusedDependencies
, neverMarkAsUnusedDependency
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, requiredForSourceOnlyAbi
, deps
, providedDeps
, exportedProvidedDeps
, srcs
, tests
.
- hashCode() - Method in class com.facebook.buck.jvm.java.JavaPluginDescriptionArg
-
Computes a hash code from attributes: pluginName
, isolateClassLoader
, doesNotAffectAbi
, supportsAbiGenerationFromSource
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, deps
.
- hashCode() - Method in class com.facebook.buck.jvm.java.JavaTestDescriptionArg
-
Computes a hash code from attributes: vmArgs
, testType
, runTestSeparately
, forkMode
, stdErrLogLevel
, stdOutLogLevel
, useCxxLibraries
, cxxLibraryWhitelist
, testCaseTimeoutMs
, env
, defaultCxxPlatform
, contacts
, testRuleTimeoutMs
, resources
, proguardConfig
, postprocessClassesCommands
, resourcesRoot
, unbundledResourcesRoot
, manifestFile
, mavenCoords
, mavenPomTemplate
, exportedDeps
, sourceOnlyAbiDeps
, runtimeDeps
, source
, target
, javaVersion
, javac
, javacJar
, compilerClassName
, compiler
, extraArguments
, removeClasses
, annotationProcessorDeps
, annotationProcessorParams
, javaPluginParams
, annotationProcessors
, annotationProcessorOnly
, plugins
, abiGenerationMode
, compileAgainst
, sourceAbiVerificationMode
, onUnusedDependencies
, neverMarkAsUnusedDependency
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, requiredForSourceOnlyAbi
, deps
, providedDeps
, exportedProvidedDeps
, srcs
, tests
, runner
, specs
.
- hashCode() - Method in class com.facebook.buck.jvm.java.JavaTestRunnerDescriptionArg
-
Computes a hash code from attributes: mainClass
, resources
, proguardConfig
, postprocessClassesCommands
, resourcesRoot
, unbundledResourcesRoot
, manifestFile
, mavenCoords
, mavenPomTemplate
, exportedDeps
, sourceOnlyAbiDeps
, runtimeDeps
, source
, target
, javaVersion
, javac
, javacJar
, compilerClassName
, compiler
, extraArguments
, removeClasses
, annotationProcessorDeps
, annotationProcessorParams
, javaPluginParams
, annotationProcessors
, annotationProcessorOnly
, plugins
, abiGenerationMode
, compileAgainst
, sourceAbiVerificationMode
, onUnusedDependencies
, neverMarkAsUnusedDependency
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, requiredForSourceOnlyAbi
, deps
, providedDeps
, exportedProvidedDeps
, srcs
, tests
.
- hashCode() - Method in class com.facebook.buck.jvm.java.KeystoreDescriptionArg
-
Computes a hash code from attributes: store
, properties
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, deps
.
- hashCode() - Method in class com.facebook.buck.jvm.java.lang.model.BridgeMethod
-
- hashCode() - Method in class com.facebook.buck.jvm.java.PrebuiltJarDescriptionArg
-
Computes a hash code from attributes: binaryJar
, sourceJar
, gwtJar
, javadocUrl
, mavenCoords
, provided
, requiredForSourceOnlyAbi
, generateAbi
, neverMarkAsUnusedDependency
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, deps
.
- hashCode() - Method in class com.facebook.buck.jvm.kotlin.KotlinLibraryDescriptionArg
-
Computes a hash code from attributes: freeCompilerArgs
, allWarningsAsErrors
, suppressWarnings
, verbose
, includeRuntime
, jvmTarget
, jdkHome
, noJdk
, noStdlib
, noReflect
, javaParameters
, apiVersion
, languageVersion
, annotationProcessingTool
, friendPaths
, kaptApOptions
, kotlincPlugins
, resources
, proguardConfig
, postprocessClassesCommands
, resourcesRoot
, unbundledResourcesRoot
, manifestFile
, mavenCoords
, mavenPomTemplate
, exportedDeps
, sourceOnlyAbiDeps
, runtimeDeps
, source
, target
, javaVersion
, javac
, javacJar
, compilerClassName
, compiler
, extraArguments
, removeClasses
, annotationProcessorDeps
, annotationProcessorParams
, javaPluginParams
, annotationProcessors
, annotationProcessorOnly
, plugins
, abiGenerationMode
, compileAgainst
, sourceAbiVerificationMode
, onUnusedDependencies
, neverMarkAsUnusedDependency
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, requiredForSourceOnlyAbi
, deps
, providedDeps
, exportedProvidedDeps
, srcs
, tests
.
- hashCode() - Method in class com.facebook.buck.jvm.kotlin.KotlinTestDescriptionArg
-
Computes a hash code from attributes: freeCompilerArgs
, allWarningsAsErrors
, suppressWarnings
, verbose
, includeRuntime
, jvmTarget
, jdkHome
, noJdk
, noStdlib
, noReflect
, javaParameters
, apiVersion
, languageVersion
, annotationProcessingTool
, friendPaths
, kaptApOptions
, kotlincPlugins
, resources
, proguardConfig
, postprocessClassesCommands
, resourcesRoot
, unbundledResourcesRoot
, manifestFile
, mavenCoords
, mavenPomTemplate
, exportedDeps
, sourceOnlyAbiDeps
, runtimeDeps
, source
, target
, javaVersion
, javac
, javacJar
, compilerClassName
, compiler
, extraArguments
, removeClasses
, annotationProcessorDeps
, annotationProcessorParams
, javaPluginParams
, annotationProcessors
, annotationProcessorOnly
, plugins
, abiGenerationMode
, compileAgainst
, sourceAbiVerificationMode
, onUnusedDependencies
, neverMarkAsUnusedDependency
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, requiredForSourceOnlyAbi
, deps
, providedDeps
, exportedProvidedDeps
, srcs
, tests
, vmArgs
, testType
, runTestSeparately
, forkMode
, stdErrLogLevel
, stdOutLogLevel
, useCxxLibraries
, cxxLibraryWhitelist
, testCaseTimeoutMs
, env
, defaultCxxPlatform
, contacts
, testRuleTimeoutMs
.
- hashCode() - Method in class com.facebook.buck.jvm.scala.ScalaLibraryDescriptionArg
-
Computes a hash code from attributes: extraArguments
, resources
, proguardConfig
, postprocessClassesCommands
, resourcesRoot
, unbundledResourcesRoot
, manifestFile
, mavenCoords
, mavenPomTemplate
, exportedDeps
, sourceOnlyAbiDeps
, runtimeDeps
, source
, target
, javaVersion
, javac
, javacJar
, compilerClassName
, compiler
, removeClasses
, annotationProcessorDeps
, annotationProcessorParams
, javaPluginParams
, annotationProcessors
, annotationProcessorOnly
, plugins
, abiGenerationMode
, compileAgainst
, sourceAbiVerificationMode
, onUnusedDependencies
, neverMarkAsUnusedDependency
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, requiredForSourceOnlyAbi
, deps
, providedDeps
, exportedProvidedDeps
, srcs
, tests
.
- hashCode() - Method in class com.facebook.buck.jvm.scala.ScalaTestDescriptionArg
-
Computes a hash code from attributes: extraArguments
, resources
, proguardConfig
, postprocessClassesCommands
, resourcesRoot
, unbundledResourcesRoot
, manifestFile
, mavenCoords
, mavenPomTemplate
, exportedDeps
, sourceOnlyAbiDeps
, runtimeDeps
, source
, target
, javaVersion
, javac
, javacJar
, compilerClassName
, compiler
, removeClasses
, annotationProcessorDeps
, annotationProcessorParams
, javaPluginParams
, annotationProcessors
, annotationProcessorOnly
, plugins
, abiGenerationMode
, compileAgainst
, sourceAbiVerificationMode
, onUnusedDependencies
, neverMarkAsUnusedDependency
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, requiredForSourceOnlyAbi
, deps
, providedDeps
, exportedProvidedDeps
, srcs
, tests
, vmArgs
, testType
, runTestSeparately
, forkMode
, stdErrLogLevel
, stdOutLogLevel
, useCxxLibraries
, cxxLibraryWhitelist
, testCaseTimeoutMs
, env
, defaultCxxPlatform
, contacts
, testRuleTimeoutMs
.
- hashCode() - Method in class com.facebook.buck.parser.events.ParseBuckFileEvent.Finished
-
- hashCode() - Method in class com.facebook.buck.query.QueryBuildTarget
-
- hashCode() - Method in class com.facebook.buck.query.QueryEnvironment.Argument
-
- hashCode() - Method in class com.facebook.buck.query.QueryFileTarget
-
- hashCode() - Method in class com.facebook.buck.query.TargetLiteral
-
- hashCode() - Method in class com.facebook.buck.remoteexecution.grpc.GrpcProtocol.GrpcDigest
-
- hashCode() - Method in class com.facebook.buck.remoteexecution.util.MerkleTreeNodeCache.MerkleTreeNode
-
- hashCode() - Method in interface com.facebook.buck.rules.args.Arg
-
- hashCode() - Method in class com.facebook.buck.rules.args.FileListableLinkerInputArg
-
- hashCode() - Method in class com.facebook.buck.rules.args.ProxyArg
-
- hashCode() - Method in class com.facebook.buck.rules.args.SanitizedArg
-
- hashCode() - Method in class com.facebook.buck.rules.coercer.PatternMatchedCollection
-
- hashCode() - Method in class com.facebook.buck.rules.coercer.VersionMatchedCollection
-
- hashCode() - Method in class com.facebook.buck.rules.keys.RuleKeyResult
-
- hashCode() - Method in class com.facebook.buck.rules.macros.BuildTargetMacro
-
- hashCode() - Method in class com.facebook.buck.rules.macros.LocationPlatformMacro
-
- hashCode() - Method in class com.facebook.buck.rules.macros.StringWithMacros
-
- hashCode() - Method in class com.facebook.buck.shell.CommandAliasDescriptionArg
-
Computes a hash code from attributes: args
, exe
, platformExe
, env
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
.
- hashCode() - Method in class com.facebook.buck.shell.ExportFileDescriptionArg
-
Computes a hash code from attributes: src
, out
, mode
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
.
- hashCode() - Method in class com.facebook.buck.shell.GenruleDescriptionArg
-
Computes a hash code from attributes: out
, outs
, executable
, bash
, cmd
, cmdExe
, type
, srcs
, enableSandbox
, environmentExpansionSeparator
, remote
, cacheable
, needAndroidTools
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, tests
.
- hashCode() - Method in class com.facebook.buck.shell.ShBinaryDescriptionArg
-
Computes a hash code from attributes: main
, resources
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, deps
, tests
.
- hashCode() - Method in class com.facebook.buck.shell.ShTestDescriptionArg
-
Computes a hash code from attributes: test
, args
, type
, runTestSeparately
, resources
, env
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, contacts
, deps
, testRuleTimeoutMs
.
- hashCode() - Method in class com.facebook.buck.shell.TestSuiteDescriptionArg
-
Computes a hash code from attributes: tests
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
.
- hashCode() - Method in class com.facebook.buck.shell.WorkerToolDescriptionArg
-
Computes a hash code from attributes: env
, args
, exe
, maxWorkers
, maxWorkersPerThreadPercent
, persistent
, soloAsync
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
.
- hashCode() - Method in class com.facebook.buck.step.AbstractTestStep
-
- hashCode() - Method in class com.facebook.buck.step.fs.SymlinkMapsPaths
-
- hashCode() - Method in class com.facebook.buck.step.fs.SymlinkPackPaths
-
- hashCode() - Method in class com.facebook.buck.step.fs.SymlinkTreeMergeStep
-
- hashCode() - Method in class com.facebook.buck.step.fs.SymlinkTreeStep
-
- hashCode() - Method in class com.facebook.buck.step.fs.TouchStep
-
- hashCode() - Method in class com.facebook.buck.step.StepEvent.Finished
-
- hashCode() - Method in class com.facebook.buck.swift.SwiftLibraryDescriptionArg
-
Computes a hash code from attributes: moduleName
, compilerFlags
, version
, frameworks
, libraries
, enableObjcInterop
, supportedPlatformsRegex
, soname
, bridgingHeader
, preferredLinkage
, targetSdkVersion
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
, deps
, srcs
.
- hashCode() - Method in class com.facebook.buck.swift.SwiftToolchainDescriptionArg
-
Computes a hash code from attributes: swiftc
, swiftcFlags
, swiftStdlibTool
, swiftStdlibToolFlags
, runtimePathsForBundling
, runtimePathsForLinking
, staticRuntimePaths
, runtimeRunPaths
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
.
- hashCode() - Method in class com.facebook.buck.test.selectors.TestDescription
-
- hashCode() - Method in class com.facebook.buck.test.TestResultSummary
-
- hashCode() - Method in class com.facebook.buck.util.cache.HashCodeAndFileType
-
Computes a hash code from attributes: type
, hashCode
.
- hashCode() - Method in class com.facebook.buck.util.charset.NulTerminatedCharsetDecoder.Result
-
- hashCode() - Method in class com.facebook.buck.util.config.Config
-
- hashCode() - Method in class com.facebook.buck.util.ImmutableMapWithNullValues
-
- hashCode() - Method in class com.facebook.buck.util.network.AbstractBatchingLogger.BatchEntry
-
- hashCode() - Method in class com.facebook.buck.util.sha1.Sha1HashCode
-
- hashCode() - Method in class com.facebook.buck.util.timing.ClockDuration
-
- hashCode() - Method in class com.facebook.buck.util.types.Pair
-
- hashCode() - Method in class com.facebook.buck.versions.VersionedAliasDescriptionArg
-
Computes a hash code from attributes: versions
, licenses
, labels
, defaultTargetPlatform
, compatibleWith
, name
.
- HashCodeAndFileType - Class in com.facebook.buck.util.cache
-
Data container to hold hash value for a file or directory
- HashCodeAndFileType(byte, HashCode) - Constructor for class com.facebook.buck.util.cache.HashCodeAndFileType
-
- HashCodeValueTypeInfo - Class in com.facebook.buck.rules.modern.impl
-
ValueTypeInfo for HashCode.
- HashCodeValueTypeInfo() - Constructor for class com.facebook.buck.rules.modern.impl.HashCodeValueTypeInfo
-
- HashedBuckOutLinkMode - Enum in com.facebook.buck.core.model.impl
-
Defines which type of link to create to hashed buck-out paths.
- HashedFileTool - Class in com.facebook.buck.core.toolchain.tool.impl
-
A tool with a single file input.
- HashedFileTool(Supplier<? extends SourcePath>) - Constructor for class com.facebook.buck.core.toolchain.tool.impl.HashedFileTool
-
- HashedFileTool(SourcePath) - Constructor for class com.facebook.buck.core.toolchain.tool.impl.HashedFileTool
-
- HasherInputStream - Class in com.facebook.buck.util.hash
-
An
InputStream
which appends the hash of the data read from it to a
Hasher
.
- HasherInputStream(Hasher, InputStream) - Constructor for class com.facebook.buck.util.hash.HasherInputStream
-
- HasherOutputStream - Class in com.facebook.buck.util.hash
-
An
OutputStream
which appends the hash of the data written to it to a
Hasher
.
- HasherOutputStream(Hasher, OutputStream) - Constructor for class com.facebook.buck.util.hash.HasherOutputStream
-
- hasHigherPriorityThan(IjModuleType) - Method in enum com.facebook.buck.features.project.intellij.model.IjModuleType
-
- HashInputJarsToDexStep - Class in com.facebook.buck.android
-
- HashInputJarsToDexStep(ProjectFilesystem, Supplier<Set<Path>>, Optional<Supplier<Multimap<Path, Path>>>, Supplier<ImmutableMap<String, HashCode>>) - Constructor for class com.facebook.buck.android.HashInputJarsToDexStep
-
- hashJsonObject(Hasher, Object) - Static method in class com.facebook.buck.json.JsonObjectHashing
-
Given a Hasher
and a parsed BUCK file object, updates the Hasher with the contents of
the JSON object.
- hashPath(Hasher, ProjectFileHashLoader, ProjectFilesystem, Path) - Static method in class com.facebook.buck.util.hashing.PathHashing
-
- hashPathFast(Hasher, Path) - Static method in class com.facebook.buck.io.file.FastPaths
-
Adds the Path to the hasher as unencoded chars.
- hashStringAndLength(Hasher, String) - Static method in class com.facebook.buck.util.hashing.StringHashing
-
Encodes the length of the string in UTF-16 code units, then the UTF-16 code units of the
string.
- hashTargetGraph() - Method in class com.facebook.buck.core.model.targetgraph.impl.TargetGraphHashing
-
Given a
TargetGraph
and any number of root nodes to traverse, returns a map of
(BuildTarget, HashCode)
pairs for all root build targets and their dependencies.
- HasImportLibrary - Interface in com.facebook.buck.cxx.toolchain.linker
-
A windows shared library consists of two files: (1) a dll to be used at runtime and (2) an import
library (static library) to be used to link against a given shared library.
- hasIncomingEdges(T) - Method in class com.facebook.buck.core.util.graph.MutableDirectedGraph
-
- HasIncrementalThinLTO - Interface in com.facebook.buck.cxx.toolchain.linker
-
Indicates a linker can support incremental ThinLTO
- HasInstallableApk - Interface in com.facebook.buck.android
-
Build rule that generates an APK that can be installed with the install command.
- HasInstallableApk.ApkInfo - Class in com.facebook.buck.android
-
- HasInstallHelpers - Interface in com.facebook.buck.core.rules.attr
-
- HasJavaAbi - Interface in com.facebook.buck.jvm.core
-
- HasJavaClassHashes - Interface in com.facebook.buck.jvm.core
-
This should be considered deprecated.
- hasJavacSpec() - Method in interface com.facebook.buck.jvm.java.JvmLibraryArg
-
- HaskellBinary - Class in com.facebook.buck.features.haskell
-
- HaskellBinary(BuildTarget, ProjectFilesystem, BuildRuleParams, ImmutableSet<BuildRule>, Tool, SourcePath) - Constructor for class com.facebook.buck.features.haskell.HaskellBinary
-
- HaskellBinaryDescription - Class in com.facebook.buck.features.haskell
-
- HaskellBinaryDescription(ToolchainProvider, CxxBuckConfig) - Constructor for class com.facebook.buck.features.haskell.HaskellBinaryDescription
-
- HaskellBinaryDescription.Type - Enum in com.facebook.buck.features.haskell
-
- HaskellBinaryDescriptionArg - Class in com.facebook.buck.features.haskell
-
Immutable implementation of HaskellBinaryDescription.AbstractHaskellBinaryDescriptionArg
.
- HaskellBinaryDescriptionArg.Builder - Class in com.facebook.buck.features.haskell
-
- HaskellBuckConfig - Class in com.facebook.buck.features.haskell
-
- HaskellBuckConfig(BuckConfig) - Constructor for class com.facebook.buck.features.haskell.HaskellBuckConfig
-
- HaskellCompileDep - Interface in com.facebook.buck.features.haskell
-
An interface for rule which can provide interfaces files for a haskell compilation.
- HaskellCompileRule - Class in com.facebook.buck.features.haskell
-
- HaskellDescriptionsProvider - Class in com.facebook.buck.features.haskell
-
- HaskellDescriptionsProvider() - Constructor for class com.facebook.buck.features.haskell.HaskellDescriptionsProvider
-
- HaskellDescriptionUtils - Class in com.facebook.buck.features.haskell
-
- HaskellGhciDescription - Class in com.facebook.buck.features.haskell
-
- HaskellGhciDescription(ToolchainProvider, CxxBuckConfig) - Constructor for class com.facebook.buck.features.haskell.HaskellGhciDescription
-
- HaskellGhciDescriptionArg - Class in com.facebook.buck.features.haskell
-
Immutable implementation of HaskellGhciDescription.AbstractHaskellGhciDescriptionArg
.
- HaskellGhciDescriptionArg.Builder - Class in com.facebook.buck.features.haskell
-
- HaskellGhciRule - Class in com.facebook.buck.features.haskell
-
- HaskellHaddockDescription - Class in com.facebook.buck.features.haskell
-
- HaskellHaddockDescription(ToolchainProvider) - Constructor for class com.facebook.buck.features.haskell.HaskellHaddockDescription
-
- HaskellHaddockDescriptionArg - Class in com.facebook.buck.features.haskell
-
Immutable implementation of HaskellHaddockDescription.AbstractHaskellHaddockDescriptionArg
.
- HaskellHaddockDescriptionArg.Builder - Class in com.facebook.buck.features.haskell
-
- HaskellHaddockLibRule - Class in com.facebook.buck.features.haskell
-
- HaskellHaddockRule - Class in com.facebook.buck.features.haskell
-
- HaskellLibrary - Class in com.facebook.buck.features.haskell
-
- HaskellLibrary(BuildTarget, ProjectFilesystem, BuildRuleParams) - Constructor for class com.facebook.buck.features.haskell.HaskellLibrary
-
- HaskellLibraryDescription - Class in com.facebook.buck.features.haskell
-
- HaskellLibraryDescription(ToolchainProvider, CxxBuckConfig) - Constructor for class com.facebook.buck.features.haskell.HaskellLibraryDescription
-
- HaskellLibraryDescription.Type - Enum in com.facebook.buck.features.haskell
-
- HaskellLibraryDescriptionArg - Class in com.facebook.buck.features.haskell
-
Immutable implementation of HaskellLibraryDescription.AbstractHaskellLibraryDescriptionArg
.
- HaskellLibraryDescriptionArg.Builder - Class in com.facebook.buck.features.haskell
-
- HaskellLinkRule - Class in com.facebook.buck.features.haskell
-
- HaskellLinkRule(BuildTarget, ProjectFilesystem, BuildRuleParams, Tool, Path, ImmutableList<Arg>, ImmutableList<Arg>, boolean, boolean) - Constructor for class com.facebook.buck.features.haskell.HaskellLinkRule
-
- HaskellModule - Class in com.facebook.buck.features.haskell
-
- HaskellModule() - Constructor for class com.facebook.buck.features.haskell.HaskellModule
-
- HaskellModuleAdapterPlugin - Class in com.facebook.buck.features.haskell
-
- HaskellModuleAdapterPlugin(PluginWrapper) - Constructor for class com.facebook.buck.features.haskell.HaskellModuleAdapterPlugin
-
- HaskellOmnibusLinkable - Interface in com.facebook.buck.features.haskell
-
Represents an object with some special behavior for finding the linkable roots for Haskell's
omnibus computation.
- HaskellPackageRule - Class in com.facebook.buck.features.haskell
-
- HaskellPackageRule(BuildTarget, ProjectFilesystem, BuildRuleParams, Tool, HaskellVersion, Linker.LinkableDepType, HaskellPackageInfo, ImmutableSortedMap<String, HaskellPackage>, ImmutableSortedSet<String>, ImmutableSortedSet<SourcePath>, ImmutableSortedSet<SourcePath>, ImmutableSortedSet<SourcePath>) - Constructor for class com.facebook.buck.features.haskell.HaskellPackageRule
-
- HaskellPlatformsFactory - Class in com.facebook.buck.features.haskell
-
- HaskellPlatformsFactory(BuckConfig, ExecutableFinder) - Constructor for class com.facebook.buck.features.haskell.HaskellPlatformsFactory
-
- HaskellPlatformsProvider - Interface in com.facebook.buck.features.haskell
-
- HaskellPlatformsProviderFactory - Class in com.facebook.buck.features.haskell
-
- HaskellPlatformsProviderFactory() - Constructor for class com.facebook.buck.features.haskell.HaskellPlatformsProviderFactory
-
- HaskellPrebuiltLibraryDescription - Class in com.facebook.buck.features.haskell
-
- HaskellPrebuiltLibraryDescription() - Constructor for class com.facebook.buck.features.haskell.HaskellPrebuiltLibraryDescription
-
- HaskellPrebuiltLibraryDescriptionArg - Class in com.facebook.buck.features.haskell
-
Immutable implementation of HaskellPrebuiltLibraryDescription.AbstractHaskellPrebuiltLibraryDescriptionArg
.
- HaskellPrebuiltLibraryDescriptionArg.Builder - Class in com.facebook.buck.features.haskell
-
- HaskellToolchainSupplier - Class in com.facebook.buck.features.haskell
-
- HaskellToolchainSupplier() - Constructor for class com.facebook.buck.features.haskell.HaskellToolchainSupplier
-
- HasLinkerMap - Interface in com.facebook.buck.cxx.toolchain.linker
-
- HasLTO - Interface in com.facebook.buck.cxx.toolchain.linker
-
- hasManifest() - Method in class com.facebook.buck.android.apkmodule.APKModule
-
- HasMavenCoordinates - Interface in com.facebook.buck.jvm.core
-
- HasMultipleOutputs - Interface in com.facebook.buck.core.rules.attr
-
BuildRule
instances that support multiple outputs via output
labels.
- HasNameAndType - Interface in com.facebook.buck.core.rules
-
The type of rule descriptions that have both a name and a type, for use in eventing and logging.
- HasNamedDeclaredDeps - Interface in com.facebook.buck.features.rust
-
- hasNext() - Method in class com.facebook.buck.core.files.FileTreeFileNameIterator
-
- hasNext() - Method in class com.facebook.buck.core.macros.MacroFinderAutomaton
-
- hasOutput() - Method in class com.facebook.buck.android.DexProducedFromJavaLibrary
-
- HasOutputName - Interface in com.facebook.buck.core.model
-
Interface for
BuildRule
instances which generate sources
with logical "names" (e.g.
- hasPathsChangedInWorkingDirectory - Variable in enum com.facebook.buck.util.versioncontrol.VersionControlStatsGenerator.Mode
-
- hasPendingWrites() - Method in interface com.facebook.buck.util.ListeningProcessExecutor.LaunchedProcess
-
Returns true
if the process has any data queued to write to stdin, false
otherwise.
- HasPostBuildSteps - Interface in com.facebook.buck.core.rules.attr
-
Deprecated interface used by
BuildRule
s which perform operations after the build.
- hasProcessFinished(Object) - Method in class com.facebook.buck.util.ProcessHelper
-
- HasProvidedDeps - Interface in com.facebook.buck.core.description.arg
-
- HasProvidedDepsQuery - Interface in com.facebook.buck.core.description.arg
-
- hasResources() - Method in class com.facebook.buck.android.apkmodule.APKModule
-
- hasResources() - Method in interface com.facebook.buck.android.FilteredResourcesProvider
-
- hasResources() - Method in class com.facebook.buck.android.IdentityResourcesProvider
-
- hasResources() - Method in class com.facebook.buck.android.packageable.AndroidPackageableCollection.ResourceDetails
-
- hasResources() - Method in class com.facebook.buck.android.ResourcesFilter
-
- hasRule(String) - Method in class com.facebook.buck.skylark.parser.context.ParseContext
-
- HasRuntimeDeps - Interface in com.facebook.buck.core.rules.attr
-
Provides a facility for a rule to list dependencies it'll need at runtime.
- HasSourcePath - Interface in com.facebook.buck.rules.args
-
Interface for extracting a SourcePath from an Arg which has one.
- HasSources - Interface in com.facebook.buck.jvm.core
-
Provides information about sources that build rule have.
- HasSrcs - Interface in com.facebook.buck.core.description.arg
-
- hasStoredBuckGlobalState() - Method in class com.facebook.buck.support.state.BuckGlobalStateLifecycleManager
-
- HasSupplementaryOutputs - Interface in com.facebook.buck.core.rules.attr
-
BuildRules which supports supplementary outputs.
- HasSystemFrameworkAndLibraries - Interface in com.facebook.buck.cxx.toolchain
-
Constructor args which specify system framework and library fields.
- hasTestHost() - Method in class com.facebook.buck.apple.AppleTest
-
- HasTestRunner - Interface in com.facebook.buck.core.test.rule
-
This marks a Description Arg for a test rule as having a test runner that knows how to run the
test.
- HasTests - Interface in com.facebook.buck.core.description.arg
-
A constructor arg of source rules with a list of their tests.
- HasTestTimeout - Interface in com.facebook.buck.core.description.arg
-
- hasTimedOut() - Method in class com.facebook.buck.jvm.java.JUnitStep
-
- hasUiTestTarget() - Method in class com.facebook.buck.apple.AppleTest
-
- hasUserDefinedValue(String, String) - Method in class com.facebook.buck.core.config.BuckConfig
-
- hasValidAndroidManifest() - Method in class com.facebook.buck.features.project.intellij.model.IjModuleAndroidFacet
-
AndroidManifest.xml can be generated when package name is known.
- HasVersionUniverse - Interface in com.facebook.buck.versions
-
- hasWildmatchGlob() - Method in class com.facebook.buck.io.watchman.Watchman
-
- haveUploadsFinished() - Method in class com.facebook.buck.event.listener.stats.cache.NetworkStatsTracker
-
- haveUploadsStarted() - Method in class com.facebook.buck.event.listener.stats.cache.NetworkStatsTracker
-
- header - Variable in class com.facebook.buck.cxx.toolchain.elf.Elf
-
- header - Variable in class com.facebook.buck.cxx.toolchain.elf.ElfSection
-
- HEADER_MODE - Static variable in class com.facebook.buck.cxx.CxxLibraryDescription
-
- HEADER_SIZE - Static variable in class com.facebook.buck.android.resources.ResourcesXml
-
- HEADER_SIZE - Static variable in class com.facebook.buck.android.resources.ResourceTable
-
- HEADER_SIZE - Static variable in class com.facebook.buck.android.resources.ResTablePackage
-
- HEADER_SYMLINK_TREE_FLAVOR - Static variable in class com.facebook.buck.cxx.CxxDescriptionEnhancer
-
- HEADER_VISIBILITY - Static variable in class com.facebook.buck.cxx.CxxLibraryDescription
-
- HeaderMap - Class in com.facebook.buck.apple.clang
-
Header maps are essentially hash maps from strings to paths (coded as two strings: a prefix and a
suffix).
- HeaderMap.Builder - Class in com.facebook.buck.apple.clang
-
Build a header map from individual mappings.
- HeaderMap.HeaderMapVisitor - Interface in com.facebook.buck.apple.clang
-
- HeaderMode - Enum in com.facebook.buck.cxx.toolchain
-
- headerOutputPath(BuildTarget, ProjectFilesystem, Optional<String>) - Static method in class com.facebook.buck.features.halide.HalideCompile
-
- headerSearchPathAttributes - Variable in class com.facebook.buck.features.apple.projectV2.XcodeNativeTargetGenerator.Result
-
- HeadersModuleMap - Class in com.facebook.buck.apple.clang
-
Creates a modulemap file that uses an explicit `header` declaration for each header in the
module.
- HeaderSymlinkTree - Class in com.facebook.buck.cxx.toolchain
-
- HeaderSymlinkTree(BuildTarget, ProjectFilesystem, Path, ImmutableMap<Path, SourcePath>) - Constructor for class com.facebook.buck.cxx.toolchain.HeaderSymlinkTree
-
- headerSymlinkTrees - Variable in class com.facebook.buck.features.apple.projectV2.ProjectGenerator.Result
-
- HeaderSymlinkTreeWithHeaderMap - Class in com.facebook.buck.cxx
-
- HeaderSymlinkTreeWithModuleMap - Class in com.facebook.buck.cxx.toolchain
-
- HeaderVerification - Class in com.facebook.buck.cxx.toolchain
-
Defines how to handle headers that get included during the build but aren't explicitly tracked in
any build files.
- HeaderVerification() - Constructor for class com.facebook.buck.cxx.toolchain.HeaderVerification
-
- HeaderVerification.Mode - Enum in com.facebook.buck.cxx.toolchain
-
- HeaderVisibility - Enum in com.facebook.buck.cxx.toolchain
-
- HeapDumper - Class in com.facebook.buck.cli
-
Lightweight utility for capturing a heap dump programmatically.
- HeapDumper() - Constructor for class com.facebook.buck.cli.HeapDumper
-
- HELP_LONG_ARG - Static variable in class com.facebook.buck.support.cli.args.GlobalCliOptions
-
- HelpCommand - Class in com.facebook.buck.cli
-
- HelpCommand() - Constructor for class com.facebook.buck.cli.HelpCommand
-
- HgCmdLineInterface - Class in com.facebook.buck.util.versioncontrol
-
- HgCmdLineInterface(ProcessExecutorFactory, Path, String, ImmutableMap<String, String>) - Constructor for class com.facebook.buck.util.versioncontrol.HgCmdLineInterface
-
- HIDDEN_IMPLICIT_ATTRIBUTES - Static variable in class com.facebook.buck.skylark.function.SkylarkRuleFunctions
-
The hidden attributes from IMPLICIT_ATTRIBUTES that are hidden from user's for user defined
rules
- Hint - Annotation Type in com.facebook.buck.core.description.arg
-
- hit(String, ArtifactCacheMode, ImmutableMap<String, String>, long) - Static method in class com.facebook.buck.artifact_cache.CacheResult
-
- hit(String, ArtifactCacheMode) - Static method in class com.facebook.buck.artifact_cache.CacheResult
-
- hit() - Static method in class com.facebook.buck.event.ActionGraphEvent.Cache
-
- Hit() - Constructor for class com.facebook.buck.event.ActionGraphEvent.Cache.Hit
-
- hit() - Static method in class com.facebook.buck.versions.VersionedTargetGraphEvent.Cache
-
- hitRate() - Method in class com.facebook.buck.util.cache.CacheStats
-
Returns the ratio of cache requests which were hits.
- HiveRowFormatter - Class in com.facebook.buck.util.network
-
Use this formatter as you would use a Builder to create Hive formatted rows that will transmit
correctly according to Scribe/Hive protocol.
- HOST_INFO - Static variable in class com.facebook.buck.skylark.function.HostInfo
-
- HOST_PLATFORM_LONG_ARG - Static variable in class com.facebook.buck.support.cli.args.GlobalCliOptions
-
- HostInfo - Class in com.facebook.buck.skylark.function
-
A factory for host_info
built-in function available
- hostInfo() - Method in class com.facebook.buck.skylark.function.SkylarkBuildModule
-
- HostnameFetching - Class in com.facebook.buck.util.network.hostname
-
- HostnameFetchingPosixLibrary - Class in com.facebook.buck.util.network.hostname
-
- HostnameFetchingWin32Library - Interface in com.facebook.buck.util.network.hostname
-
- HttpArchive - Class in com.facebook.buck.file
-
Represents a remote file that needs to be downloaded.
- HttpArchive(BuildTarget, ProjectFilesystem, BuildRuleParams, HttpFile, String, ArchiveFormat, Optional<Path>) - Constructor for class com.facebook.buck.file.HttpArchive
-
- HttpArchiveDescription - Class in com.facebook.buck.file
-
A description for downloading an archive over http and extracting it (versus the combo logic
contained in
RemoteFileDescription
.
- HttpArchiveDescription() - Constructor for class com.facebook.buck.file.HttpArchiveDescription
-
- HttpArchiveDescriptionArg - Class in com.facebook.buck.file
-
Arguments for an http_archive rule
- HttpArchiveDescriptionArg.Builder - Class in com.facebook.buck.file
-
- HttpArtifactCache - Class in com.facebook.buck.artifact_cache
-
- HttpArtifactCache(NetworkCacheArgs) - Constructor for class com.facebook.buck.artifact_cache.HttpArtifactCache
-
- HttpArtifactCacheBinaryProtocol - Class in com.facebook.buck.artifact_cache
-
Implements the binary protocol used by Buck to talk to the cache server.
- HttpArtifactCacheBinaryProtocol.FetchResponse - Class in com.facebook.buck.artifact_cache
-
- HttpArtifactCacheBinaryProtocol.MetadataAndPayloadReadResult - Class in com.facebook.buck.artifact_cache
-
- HttpArtifactCacheBinaryProtocol.StoreRequest - Class in com.facebook.buck.artifact_cache
-
- HttpArtifactCacheBinaryProtocol.StoreResponseReadResult - Class in com.facebook.buck.artifact_cache
-
- HttpArtifactCacheEvent - Class in com.facebook.buck.artifact_cache
-
Event produced for HttpArtifactCache operations containing different stats.
- HttpArtifactCacheEvent(EventKey, ArtifactCacheEvent.Operation, Optional<BuildTarget>, ImmutableSet<RuleKey>, ArtifactCacheEvent.InvocationType, ArtifactCacheEvent.StoreType) - Constructor for class com.facebook.buck.artifact_cache.HttpArtifactCacheEvent
-
- HttpArtifactCacheEvent.Finished - Class in com.facebook.buck.artifact_cache
-
- HttpArtifactCacheEvent.Finished.Builder - Class in com.facebook.buck.artifact_cache
-
- HttpArtifactCacheEvent.HttpArtifactCacheEventFetchData - Interface in com.facebook.buck.artifact_cache
-
- HttpArtifactCacheEvent.HttpArtifactCacheEventFetchData.Builder - Class in com.facebook.buck.artifact_cache
-
- HttpArtifactCacheEvent.HttpArtifactCacheEventStoreData - Interface in com.facebook.buck.artifact_cache
-
- HttpArtifactCacheEvent.HttpArtifactCacheEventStoreData.Builder - Class in com.facebook.buck.artifact_cache
-
- HttpArtifactCacheEvent.Scheduled - Class in com.facebook.buck.artifact_cache
-
- HttpArtifactCacheEvent.Shutdown - Class in com.facebook.buck.artifact_cache
-
- HttpArtifactCacheEvent.Started - Class in com.facebook.buck.artifact_cache
-
- HttpArtifactCacheEventListener - Class in com.facebook.buck.event.listener
-
Listens to HttpArtifactCacheEvents and logs stats data in Hive row format.
- HttpArtifactCacheEventListener(BatchingLogger, BatchingLogger, TaskManagerCommandScope) - Constructor for class com.facebook.buck.event.listener.HttpArtifactCacheEventListener
-
- HttpArtifactCacheUploadListener - Class in com.facebook.buck.event.listener
-
In charge for monitoring builds that store artifacts to the remote cache and computing stateful
cache upload stats.
- HttpArtifactCacheUploadListener(BuckEventBus, int) - Constructor for class com.facebook.buck.event.listener.HttpArtifactCacheUploadListener
-
- HttpCacheEntry - Class in com.facebook.buck.artifact_cache.config
-
- HttpCacheEntry() - Constructor for class com.facebook.buck.artifact_cache.config.HttpCacheEntry
-
- HttpDownloader - Class in com.facebook.buck.file.downloader.impl
-
Download a file over HTTP.
- HttpDownloader() - Constructor for class com.facebook.buck.file.downloader.impl.HttpDownloader
-
- HttpDownloader(Optional<Proxy>) - Constructor for class com.facebook.buck.file.downloader.impl.HttpDownloader
-
- HttpEndpoint - Interface in com.facebook.buck.util.network
-
- HttpFile - Class in com.facebook.buck.file
-
Represents a remote file that needs to be downloaded.
- HttpFile(BuildTarget, ProjectFilesystem, BuildRuleParams, Downloader, ImmutableList<URI>, HashCode, String, boolean) - Constructor for class com.facebook.buck.file.HttpFile
-
- HttpFileBinary - Class in com.facebook.buck.file
-
Represents an executable
HttpFile
, which means that it can be invoked using
buck
run
.
- HttpFileBinary(BuildTarget, ProjectFilesystem, BuildRuleParams, Downloader, ImmutableList<URI>, HashCode, String) - Constructor for class com.facebook.buck.file.HttpFileBinary
-
- HttpFileDescription - Class in com.facebook.buck.file
-
A description for downloading a single HttpFile (versus the combo logic contained in
RemoteFileDescription
.
- HttpFileDescription() - Constructor for class com.facebook.buck.file.HttpFileDescription
-
- HttpFileDescriptionArg - Class in com.facebook.buck.file
-
Args required for http_rule
- HttpFileDescriptionArg.Builder - Class in com.facebook.buck.file
-
- HttpLoadBalancer - Interface in com.facebook.buck.slb
-
- HttpResponse - Interface in com.facebook.buck.slb
-
- HttpResponse - Class in com.facebook.buck.util.network
-
- HttpResponse(String) - Constructor for class com.facebook.buck.util.network.HttpResponse
-
- HttpService - Interface in com.facebook.buck.slb
-
- humanReadableError() - Method in enum com.facebook.buck.support.fix.BuckFixSpecParser.FixSpecFailure
-
Get a human readable error message for this failure
- HumanReadableException - Exception in com.facebook.buck.core.exceptions
-
Exception with an error message that can sensibly be displayed to the user without a stacktrace.
- HumanReadableException(DependencyStack, String, Object...) - Constructor for exception com.facebook.buck.core.exceptions.HumanReadableException
-
- HumanReadableException(DependencyStack, String) - Constructor for exception com.facebook.buck.core.exceptions.HumanReadableException
-
- HumanReadableException(Throwable, DependencyStack, String) - Constructor for exception com.facebook.buck.core.exceptions.HumanReadableException
-
- HumanReadableException(Throwable, DependencyStack, String, Object...) - Constructor for exception com.facebook.buck.core.exceptions.HumanReadableException
-
- HumanReadableException(String, Object...) - Constructor for exception com.facebook.buck.core.exceptions.HumanReadableException
-
- HumanReadableException(String) - Constructor for exception com.facebook.buck.core.exceptions.HumanReadableException
-
- HumanReadableException(Throwable, String) - Constructor for exception com.facebook.buck.core.exceptions.HumanReadableException
-
- HumanReadableException(Throwable, String, Object...) - Constructor for exception com.facebook.buck.core.exceptions.HumanReadableException
-
- HumanReadableException(ExceptionWithHumanReadableMessage) - Constructor for exception com.facebook.buck.core.exceptions.HumanReadableException
-
- HumanReadableExceptionAugmentor - Class in com.facebook.buck.core.exceptions
-
A class that can append additional information to a HumanReadableException based on configuration
settings.
- HumanReadableExceptionAugmentor(Map<Pattern, String>) - Constructor for class com.facebook.buck.core.exceptions.HumanReadableExceptionAugmentor
-
- HumanReadableExceptions - Class in com.facebook.buck.core.exceptions
-
- HYBRID_THRIFT_STREAM_CONTENT_TYPE - Static variable in class com.facebook.buck.artifact_cache.ThriftArtifactCache
-
- HYBRID_THRIFT_STREAM_CONTENT_TYPE - Static variable in class com.facebook.buck.slb.HybridThriftOverHttpServiceImpl
-
- HybridGlobber - Class in com.facebook.buck.skylark.io.impl
-
A
Globber
implementation that tries to use Watchman if it's available and falls back to a
fallback globber, in case Watchman query cannot be fulfilled.
- HybridGlobber(Globber, WatchmanGlobber) - Constructor for class com.facebook.buck.skylark.io.impl.HybridGlobber
-
- HybridGlobberFactory - Class in com.facebook.buck.skylark.io.impl
-
- HybridKnownRuleTypes - Class in com.facebook.buck.core.rules.knowntypes
-
Provides access to rule types and descriptions for both native and user defined rules.
- HybridKnownRuleTypes(KnownRuleTypes, KnownRuleTypes) - Constructor for class com.facebook.buck.core.rules.knowntypes.HybridKnownRuleTypes
-
- HybridLocalBuildStrategyConfig - Class in com.facebook.buck.rules.modern.config
-
Configuration for the "hybrid_local" build strategy.
- HybridLocalBuildStrategyConfig(int, int, int, ModernBuildRuleStrategyConfig) - Constructor for class com.facebook.buck.rules.modern.config.HybridLocalBuildStrategyConfig
-
- HybridLocalEvent - Class in com.facebook.buck.rules.modern.builders
-
- HybridLocalEvent() - Constructor for class com.facebook.buck.rules.modern.builders.HybridLocalEvent
-
- HybridLocalEvent.Stolen - Class in com.facebook.buck.rules.modern.builders
-
When the HybridLocalStrategy steals a delegate strategy and starts processing it locally.
- HybridLocalStrategy - Class in com.facebook.buck.rules.modern.builders
-
This build strategy sends jobs to both a delegate build strategy and to the build engine to be
run in the default way.
- HybridLocalStrategy(int, int, int, BuildRuleStrategy, WorkerRequirementsProvider, Optional<WorkerRequirements.WorkerSize>, String, BuckEventBus) - Constructor for class com.facebook.buck.rules.modern.builders.HybridLocalStrategy
-
- HybridPayloadGenerator - Class in com.facebook.buck.artifact_cache
-
* Creates example fetch and store requests, encodes them using the hybrid thrift/binary protocol,
and finally prints out the hybrid payload using base 64 encoding.
- HybridPayloadGenerator() - Constructor for class com.facebook.buck.artifact_cache.HybridPayloadGenerator
-
- HybridProjectBuildFileParser - Class in com.facebook.buck.parser
-
Hybrid project build file parser that uses Python DSL, Skylark or any other
Syntax
depending on which one is requested for the individual build file.
- HybridThriftOverHttpService<ThriftRequest extends org.apache.thrift.TBase<?,?>,ThriftResponse extends org.apache.thrift.TBase<?,?>> - Interface in com.facebook.buck.slb
-
Sync and async methods to communicate using the Hybrid Thrift protocol.
- HybridThriftOverHttpServiceImpl<ThriftRequest extends org.apache.thrift.TBase<?,?>,ThriftResponse extends org.apache.thrift.TBase<?,?>> - Class in com.facebook.buck.slb
-
The HTTP body contains: - 4 bytes big endian byte size of the thrift serialised message.
- HybridThriftOverHttpServiceImpl(HybridThriftOverHttpServiceImplArgs) - Constructor for class com.facebook.buck.slb.HybridThriftOverHttpServiceImpl
-
New instances.
- HybridThriftOverHttpServiceImplArgs - Class in com.facebook.buck.slb
-
- HybridThriftOverHttpServiceImplArgs() - Constructor for class com.facebook.buck.slb.HybridThriftOverHttpServiceImplArgs
-
- HybridThriftRequestHandler<ThriftRequest extends org.apache.thrift.TBase<?,?>> - Class in com.facebook.buck.slb
-
Handles the contents of a hybrid thrift request.
- HybridThriftRequestHandler(ThriftRequest) - Constructor for class com.facebook.buck.slb.HybridThriftRequestHandler
-
- HybridThriftResponseHandler<ThriftResponse extends org.apache.thrift.TBase<?,?>> - Class in com.facebook.buck.slb
-
Control struct to receive a hybrid thrift response.
- HybridThriftResponseHandler(ThriftResponse) - Constructor for class com.facebook.buck.slb.HybridThriftResponseHandler
-
- VALID_ABI_KEYS - Static variable in class com.facebook.buck.android.AndroidBuckConfig
-
- validateAliasName(String) - Static method in class com.facebook.buck.support.cli.config.AliasConfig
-
- validateArtifact(Set<Path>) - Method in class com.facebook.buck.core.build.engine.buildinfo.DefaultOnDiskBuildInfo
-
- validateArtifact(Set<Path>) - Method in interface com.facebook.buck.core.build.engine.buildinfo.OnDiskBuildInfo
-
- validateAssetCatalogs(ImmutableSortedSet<SourcePath>, BuildTarget, ProjectFilesystem, SourcePathResolverAdapter, AppleAssetCatalog.ValidationType) - Static method in class com.facebook.buck.apple.AppleAssetCatalog
-
- validateCertificatesOrThrow() - Method in class com.facebook.buck.remoteexecution.config.RemoteExecutionConfig
-
- validateClasspath(String) - Method in class com.facebook.buck.jvm.java.ClasspathChecker
-
Parses a Java classpath string ("path/to/foo:baz.jar:blech.zip:path/to/*") and checks if at
least one entry is valid (exists on disk).
- validateCoercedValue(CoercedType) - Method in class com.facebook.buck.core.starlark.rule.attr.Attribute
-
Validates values post-coercion to ensure other properties besides 'type' are valid
- validateCoercedValue(ImmutableList<BuildTarget>) - Method in class com.facebook.buck.core.starlark.rule.attr.impl.DepListAttribute
-
- validateCoercedValue(Integer) - Method in class com.facebook.buck.core.starlark.rule.attr.impl.IntAttribute
-
- validateCoercedValue(ImmutableList<Integer>) - Method in class com.facebook.buck.core.starlark.rule.attr.impl.IntListAttribute
-
- validateCoercedValue(ImmutableList<String>) - Method in class com.facebook.buck.core.starlark.rule.attr.impl.OutputListAttribute
-
- validateCoercedValue(ImmutableList<SourcePath>) - Method in class com.facebook.buck.core.starlark.rule.attr.impl.SourceListAttribute
-
- validateCoercedValue(ImmutableSortedSet<SourcePath>) - Method in class com.facebook.buck.core.starlark.rule.attr.impl.SourceSortedSetAttribute
-
- validateCoercedValue(String) - Method in class com.facebook.buck.core.starlark.rule.attr.impl.StringAttribute
-
- validateCoercedValue(ImmutableList<String>) - Method in class com.facebook.buck.core.starlark.rule.attr.impl.StringListAttribute
-
- validateCoercedValue(ImmutableSortedSet<String>) - Method in class com.facebook.buck.core.starlark.rule.attr.impl.StringSortedSetAttribute
-
- validateCoercedValue(ImmutableList<UnconfiguredBuildTarget>) - Method in class com.facebook.buck.core.starlark.rule.attr.impl.UnconfiguredDepListAttribute
-
- validateCoercedValue(Optional<UnconfiguredBuildTarget>) - Method in class com.facebook.buck.core.starlark.rule.attr.impl.UnconfiguredOptionalDepAttribute
-
- validateFlavors(ImmutableSet<Flavor>, Iterable<FlavorDomain<?>>) - Static method in class com.facebook.buck.features.js.JsFlavors
-
- validateFormatString(String) - Static method in class com.facebook.buck.core.rules.actions.lib.args.CommandLineArgsFactory
-
Throws an exception if the formatString
is not a valid stringification format string
- validateKwargName(Location, String) - Static method in class com.facebook.buck.core.starlark.compatible.BuckSkylarkTypes
-
Ensure that a name is a valid kwarg/field identifier
- validateLabelName(String) - Static method in class com.facebook.buck.support.cli.config.AliasConfig
-
- validateNoneOrType(Location, Class<?>, Object) - Static method in class com.facebook.buck.core.starlark.compatible.BuckSkylarkTypes
-
Check that a value is either Runtime.NONE
or an instance of clazz
- validateOptions(Function<String, Boolean>) - Method in class com.facebook.buck.jvm.java.JavacOptions
-
- validateProvidersPresent(List<Provider<?>>, BuildTarget, ProviderInfoCollection) - Static method in class com.facebook.buck.core.starlark.rule.attr.Attribute
-
Ensures that all of the
Provider
s in
expectedProviders
are present in
providerInfos
- validateResources(SourcePathResolverAdapter, ProjectFilesystem, ImmutableSortedSet<SourcePath>) - Static method in class com.facebook.buck.jvm.common.ResourceValidator
-
- validateTarget(BuildTarget) - Static method in class com.facebook.buck.core.model.ConfigurationForConfigurationTargets
-
Validate build target is configuration target
- validateUniqueConstraintSettings(String, BuildTarget, DependencyStack, ImmutableSet<ConstraintValue>) - Static method in class com.facebook.buck.core.model.platform.ConstraintValueUtil
-
Buck does not allow duplicate config_setting
in a set of constraint_value
in
config_setting
or platform
rules.
- validateValueInList(List<CoercedType>, CoercedType) - Method in class com.facebook.buck.core.starlark.rule.attr.Attribute
-
Helper method to validate that a value is in a list and throw a reasonable error if not
- ValidatingTaskListener - Class in com.facebook.buck.jvm.java.abi.source
-
A TaskListener
that is used during full compilation to validate the guesses made by
source-based ABI generation.
- ValidatingTaskListener(BuckJavacTaskProxy, SourceOnlyAbiRuleInfoFactory.SourceOnlyAbiRuleInfo, Supplier<Boolean>, Diagnostic.Kind) - Constructor for class com.facebook.buck.jvm.java.abi.source.ValidatingTaskListener
-
- value() - Method in enum com.facebook.buck.android.ResourceFilters.Density
-
- ValueCreator<E extends Exception> - Interface in com.facebook.buck.rules.modern
-
A ValueCreator can be used to create the values referenced from a Buildable.
- ValueExtractor - Interface in com.facebook.buck.rules.keys
-
Extracts a value, e.g.
- ValueMethodValueExtractor - Class in com.facebook.buck.rules.keys
-
Extracts a value of a given field, that is assumed to be accessible.
- valueOf(String) - Static method in enum com.facebook.buck.android.aapt.MiniAapt.ResourceCollectionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.android.aapt.RDotTxtEntry.CustomDrawableType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.android.aapt.RDotTxtEntry.IdType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.android.aapt.RDotTxtEntry.RType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.android.AndroidBuckConfig.NdkSearchOrderEntry
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.android.AndroidInstallConfig.ConcurrentInstall
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.android.AndroidLibraryDescription.JvmLanguage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.android.BinaryType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.android.CompressionAlgorithm
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.android.dalvik.ZipSplitter.DexSplitStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.android.device.TargetDevice.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.android.DxStep.Option
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.android.exopackage.ExopackageMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.android.HasDuplicateAndroidResourceTypes.DuplicateResourceBehaviour
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.android.ResourceFilters.Density
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.android.toolchain.ndk.impl.NdkCxxPlatforms.Host
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.android.toolchain.ndk.impl.NdkCxxPlatforms.ToolchainTarget
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.android.toolchain.ndk.NdkCompilerType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.android.toolchain.ndk.NdkCxxRuntime
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.android.toolchain.ndk.NdkCxxRuntimeType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.android.toolchain.ndk.NdkTargetArch
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.android.toolchain.ndk.NdkTargetArchAbi
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.android.toolchain.ndk.NdkToolchain
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.android.toolchain.ndk.NdkToolchainTarget
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.android.toolchain.ndk.TargetCpuType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.apple.AppleAssetCatalog.ValidationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.apple.AppleBuildRules.RecursiveDependenciesMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.apple.AppleBundleDestination
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.apple.AppleBundleExtension
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.apple.AppleDebugFormat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.apple.AppleLibraryDescription.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.apple.clang.ModuleMapMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.apple.clang.UmbrellaHeaderModuleMap.SwiftMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.apple.GroupedSource.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.apple.LibtoolStep.Style
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.apple.platform_type.ApplePlatformType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.apple.simulator.AppleDeviceController.AppleDeviceKindEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.apple.simulator.AppleDeviceController.LaunchBehavior
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.apple.simulator.AppleSimulatorController.LaunchBehavior
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.apple.simulator.AppleSimulatorState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.apple.xcode.xcodeproj.PBXContainerItemProxy.ProxyType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.apple.xcode.xcodeproj.PBXCopyFilesBuildPhase.Destination
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.apple.xcode.xcodeproj.PBXGroup.SortPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.apple.xcode.xcodeproj.PBXReference.SourceTree
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.apple.xcode.XCScheme.AdditionalActions
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.apple.xcode.XCScheme.BuildActionEntry.BuildFor
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.apple.xcode.XCScheme.LaunchAction.LaunchStyle
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.apple.xcode.XCScheme.LaunchAction.WatchInterface
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.artifact_cache.ArtifactCacheEvent.CacheMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.artifact_cache.ArtifactCacheEvent.InvocationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.artifact_cache.ArtifactCacheEvent.Operation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.artifact_cache.ArtifactCacheEvent.StoreType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in class com.facebook.buck.artifact_cache.CacheResult
-
- valueOf(String) - Static method in enum com.facebook.buck.artifact_cache.CacheResultType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig.Executor
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.artifact_cache.config.ArtifactCacheMode.CacheType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.artifact_cache.config.ArtifactCacheMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.artifact_cache.config.CacheReadMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.artifact_cache.config.LoadBalancingType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.artifact_cache.config.MultiFetchType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.artifact_cache.SecondLevelContentKey.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cli.AbstractQueryCommand.OutputFormat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cli.AbstractQueryCommand.SortOutputFormat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cli.AbstractQueryCommand.WhichQueryCommand
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cli.Dot.OutputOrder
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cli.ProjectTestsMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.core.build.engine.BuildRuleStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.core.build.engine.BuildRuleSuccessType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.core.build.engine.type.BuildType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.core.build.engine.type.DepFiles
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.core.build.engine.type.UploadToCacheResultType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.core.build.event.BuildRuleResumeReason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.core.graph.transformation.executor.factory.DepsAwareExecutorType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.core.linkgroup.CxxLinkGroupMappingTarget.Traversal
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.core.model.actiongraph.computation.IncrementalActionGraphMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.core.model.impl.HashedBuckOutLinkMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.core.model.RuleType.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.core.parser.buildtargetpattern.BuildTargetPattern.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.core.rulekey.RuleKeyDiagnosticsMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.core.rules.analysis.config.RuleAnalysisComputationMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.CxxInferEnhancer.InferFlavors
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.CxxLibraryDescription.MetadataType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.CxxLibraryDescription.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.CxxPreprocessables.IncludeType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.CxxSource.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.ArchiveContents
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.ArchiverProvider.LegacyArchiverType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.ArchiverProvider.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.CxxToolProvider.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.DependencyTrackingMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.elf.ElfDynamicSection.DTag.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.elf.ElfDynamicSection.DTag
-
Returns the enum constant of this type with the specified name.
- valueOf(int) - Static method in enum com.facebook.buck.cxx.toolchain.elf.ElfDynamicSection.DTag
-
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.elf.ElfHeader.EIClass
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.elf.ElfHeader.EIData
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.elf.ElfSectionHeader.SHType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.elf.ElfSymbolTable.Entry.Info.Bind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.elf.ElfSymbolTable.Entry.Info.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.HeaderMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.HeaderVerification.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.HeaderVisibility
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.linker.Linker.CxxRuntimeType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.linker.Linker.LinkableDepType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.linker.Linker.LinkType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.linker.Linker.SharedLibraryLoadingType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.linker.LinkerProvider.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.LinkerMapMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableGroup.Linkage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.nativelink.NativeLinkStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.objectfile.ObjectFileScrubbers.PaddingStyle
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.PicType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.SharedLibraryInterfaceParams.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.SharedLibraryInterfaceParams.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.StripStyle
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.cxx.toolchain.ToolType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.doctor.config.DoctorIssueCategory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.doctor.config.DoctorProtocolVersion
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.doctor.config.DoctorSuggestion.StepStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.event.ArtifactCompressionEvent.Operation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.event.chrome_trace.ChromeTraceEvent.Phase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.event.CompilerErrorEvent.CompilerType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.event.listener.TestResultFormatter.FormatMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.event.LogUploadMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.event.RuleKeyCalculationEvent.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.event.SimplePerfEvent.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.features.apple.common.CopyInXcode.DestinationBase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.features.apple.common.CopyInXcode.SourceType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.features.apple.common.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.features.apple.common.SchemeActionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.features.apple.project.IDEForceKill
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.features.apple.project.ProjectGenerator.FilterFlags
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.features.apple.projectV2.IDEForceKill
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.features.dotnet.FrameworkVersion
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.features.go.GoArch
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.features.go.GoOs
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.features.go.GoPackStep.Operation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.features.haskell.HaskellBinaryDescription.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.features.haskell.HaskellLibraryDescription.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.features.lua.LuaBinaryDescription.StarterType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.features.lua.LuaPlatform.PackageStyle
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.features.project.intellij.FolderTypeWithPackageInfo
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.features.project.intellij.IjDependencyListBuilder.Scope
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.features.project.intellij.IjDependencyListBuilder.SortOrder
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.features.project.intellij.IjDependencyListBuilder.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.features.project.intellij.lang.android.AndroidProjectType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.features.project.intellij.model.DependencyType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.features.project.intellij.model.folders.IjResourceFolderType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.features.project.intellij.model.IjLibrary.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.features.project.intellij.model.IjModuleType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.features.python.CxxPythonExtensionDescription.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.features.python.PythonBuckConfig.PackageStyle
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.features.rust.CrateType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.features.rust.RustBinaryDescription.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.file.RemoteFile.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.io.file.BorrowablePath.Behaviour
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.io.file.MostFiles.DeleteRecursivelyOptions
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.io.file.PathListing.FilterMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.io.filesystem.CopySourceMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.io.watchman.Capability
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.io.watchman.WatchmanDiagnostic.Level
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.io.watchman.WatchmanEvent.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.io.watchman.WatchmanEvent.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.io.watchman.WatchmanWatcher.CursorType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.io.watchman.WatchmanWatcher.FreshInstanceAction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.jvm.java.abi.AbiGenerationMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.jvm.java.abi.source.CompletedTypeKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.jvm.java.AnnotationProcessingEvent.Operation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.jvm.java.BuiltInJavac
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.jvm.java.CompileAgainstLibraryType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.jvm.java.ForkMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.jvm.java.JarShape
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.jvm.java.JavaBuckConfig.DuplicatesLogLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.jvm.java.JavaBuckConfig.SourceAbiVerificationMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.jvm.java.JavaBuckConfig.UnusedDependenciesAction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.jvm.java.JavaBuckConfig.UnusedDependenciesConfig
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.jvm.java.Javac.Source
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.jvm.java.JavacOptions.SpoolMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.jvm.java.plugin.api.TaskEventMirror.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.jvm.java.TestType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.jvm.java.tracing.JavacPhaseEvent.Phase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.jvm.kotlin.KotlinLibraryDescription.AnnotationProcessingTool
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.parser.api.Syntax
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.parser.config.ParserConfig.AllowSymlinks
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.parser.config.ParserConfig.ApplyDefaultFlavorsMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.parser.config.ParserConfig.BuildFileSearchMethod
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.parser.config.ParserConfig.GlobHandler
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.parser.config.ParserConfig.PackageBoundaryEnforcement
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.parser.config.ParserConfig.SkylarkGlobHandler
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.parser.config.ParserConfig.WatchmanGlobSanityCheck
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.parser.events.ParseBuckFileEvent.ParserKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.parser.options.ImplicitNativeRulesState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.parser.options.UserDefinedRulesState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.parser.spec.TargetNodeSpec.TargetType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.parser.SpeculativeParsing
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.query.QueryEnvironment.ArgumentType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.query.QueryEnvironment.TargetEvaluator.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.remoteexecution.config.AutoRemoteExecutionStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.remoteexecution.config.RemoteExecutionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.remoteexecution.event.LocalFallbackEvent.Result
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.rules.coercer.BuildTargetMacroTypeCoercer.TargetOrHost
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.rules.coercer.FrameworkPath.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.rules.coercer.PathTypeCoercer.PathExistenceVerificationMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.rules.coercer.SourceSet.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.rules.coercer.SourceSortedSet.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.rules.coercer.SourceWithFlagsList.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.rules.keys.hasher.RuleKeyHasher.Container
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.rules.keys.hasher.RuleKeyHasher.Wrapper
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.rules.keys.RuleKeyType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.rules.modern.config.ModernBuildRuleBuildStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.shell.ExportFileDescription.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.shell.ExportFileDirectoryAction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.skylark.io.impl.WatchmanGlobber.Option
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.skylark.parser.FileKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.slb.ThriftProtocol
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.step.fs.CopyStep.DirectoryMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.support.cli.config.JsonAttributeFormat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.support.fix.BuckFixSpecParser.FixSpecFailure
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.support.state.BuckGlobalStateLifecycleManager.LifecycleStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.swift.SwiftLibraryDescription.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.swift.toolchain.impl.SwiftSdkLayoutType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.test.CoverageReportFormat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.test.result.type.ResultType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.util.Ansi.SeverityLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.util.bser.BserDeserializer.KeyOrdering
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.util.cache.FileHashCacheMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.util.concurrent.ExecutorPool
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.util.concurrent.ResourceAllocationFairness
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.util.concurrent.ResourcePool.ResourceUsageErrorPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.util.DependencyMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.util.environment.Architecture
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.util.environment.BuckBuildType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.util.environment.CommandMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.util.environment.NetworkMedium
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.util.environment.Platform
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.util.environment.PlatformType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.util.Escaper.Quoter
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.util.ExitCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.util.ProcessExecutor.Option
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.util.randomizedtrial.CommonGroups
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.util.trace.uploader.types.CompressionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.util.types.Unit
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.util.unarchive.ArchiveFormat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.util.unarchive.ExistingFileMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.util.unit.SizeUnit
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.util.Verbosity
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.util.versioncontrol.VersionControlStatsGenerator.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.util.zip.collect.OnDuplicateEntry
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.util.zip.ZipCompressionLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.util.zip.ZipOutputStreams.HandleDuplicates
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.facebook.buck.versions.VersionedTargetGraphCache.ResultType
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum com.facebook.buck.android.aapt.MiniAapt.ResourceCollectionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.android.aapt.RDotTxtEntry.CustomDrawableType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.android.aapt.RDotTxtEntry.IdType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.android.aapt.RDotTxtEntry.RType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.android.AndroidBuckConfig.NdkSearchOrderEntry
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.android.AndroidInstallConfig.ConcurrentInstall
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.android.AndroidLibraryDescription.JvmLanguage
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.android.BinaryType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.android.CompressionAlgorithm
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.android.dalvik.ZipSplitter.DexSplitStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.android.device.TargetDevice.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.android.DxStep.Option
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.android.exopackage.ExopackageMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.android.HasDuplicateAndroidResourceTypes.DuplicateResourceBehaviour
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.android.ResourceFilters.Density
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.android.toolchain.ndk.impl.NdkCxxPlatforms.Host
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.android.toolchain.ndk.impl.NdkCxxPlatforms.ToolchainTarget
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.android.toolchain.ndk.NdkCompilerType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.android.toolchain.ndk.NdkCxxRuntime
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.android.toolchain.ndk.NdkCxxRuntimeType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.android.toolchain.ndk.NdkTargetArch
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.android.toolchain.ndk.NdkTargetArchAbi
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.android.toolchain.ndk.NdkToolchain
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.android.toolchain.ndk.NdkToolchainTarget
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.android.toolchain.ndk.TargetCpuType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.apple.AppleAssetCatalog.ValidationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.apple.AppleBuildRules.RecursiveDependenciesMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.apple.AppleBundleDestination
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.apple.AppleBundleExtension
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.apple.AppleDebugFormat
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.apple.AppleLibraryDescription.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.apple.clang.ModuleMapMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.apple.clang.UmbrellaHeaderModuleMap.SwiftMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.apple.GroupedSource.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.apple.LibtoolStep.Style
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.apple.platform_type.ApplePlatformType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.apple.simulator.AppleDeviceController.AppleDeviceKindEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.apple.simulator.AppleDeviceController.LaunchBehavior
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.apple.simulator.AppleSimulatorController.LaunchBehavior
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.apple.simulator.AppleSimulatorState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.apple.xcode.xcodeproj.PBXContainerItemProxy.ProxyType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.apple.xcode.xcodeproj.PBXCopyFilesBuildPhase.Destination
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.apple.xcode.xcodeproj.PBXGroup.SortPolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.apple.xcode.xcodeproj.PBXReference.SourceTree
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.apple.xcode.XCScheme.AdditionalActions
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.apple.xcode.XCScheme.BuildActionEntry.BuildFor
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.apple.xcode.XCScheme.LaunchAction.LaunchStyle
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.apple.xcode.XCScheme.LaunchAction.WatchInterface
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.artifact_cache.ArtifactCacheEvent.CacheMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.artifact_cache.ArtifactCacheEvent.InvocationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.artifact_cache.ArtifactCacheEvent.Operation
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.artifact_cache.ArtifactCacheEvent.StoreType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.artifact_cache.CacheResultType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.artifact_cache.config.ArtifactCacheBuckConfig.Executor
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.artifact_cache.config.ArtifactCacheMode.CacheType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.artifact_cache.config.ArtifactCacheMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.artifact_cache.config.CacheReadMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.artifact_cache.config.LoadBalancingType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.artifact_cache.config.MultiFetchType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.artifact_cache.SecondLevelContentKey.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cli.AbstractQueryCommand.OutputFormat
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cli.AbstractQueryCommand.SortOutputFormat
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cli.AbstractQueryCommand.WhichQueryCommand
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cli.Dot.OutputOrder
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cli.ProjectTestsMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.core.build.engine.BuildRuleStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.core.build.engine.BuildRuleSuccessType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.core.build.engine.type.BuildType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.core.build.engine.type.DepFiles
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.core.build.engine.type.UploadToCacheResultType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.core.build.event.BuildRuleResumeReason
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.core.graph.transformation.executor.factory.DepsAwareExecutorType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.core.linkgroup.CxxLinkGroupMappingTarget.Traversal
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.core.model.actiongraph.computation.IncrementalActionGraphMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.core.model.impl.HashedBuckOutLinkMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.core.model.RuleType.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.core.parser.buildtargetpattern.BuildTargetPattern.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.core.rulekey.RuleKeyDiagnosticsMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.core.rules.analysis.config.RuleAnalysisComputationMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.CxxInferEnhancer.InferFlavors
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.CxxLibraryDescription.MetadataType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.CxxLibraryDescription.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.CxxPreprocessables.IncludeType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.CxxSource.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.ArchiveContents
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.ArchiverProvider.LegacyArchiverType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.ArchiverProvider.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.CxxToolProvider.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.DependencyTrackingMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.elf.ElfDynamicSection.DTag.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.elf.ElfDynamicSection.DTag
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.elf.ElfHeader.EIClass
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.elf.ElfHeader.EIData
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.elf.ElfSectionHeader.SHType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.elf.ElfSymbolTable.Entry.Info.Bind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.elf.ElfSymbolTable.Entry.Info.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.HeaderMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.HeaderVerification.Mode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.HeaderVisibility
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.linker.Linker.CxxRuntimeType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.linker.Linker.LinkableDepType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.linker.Linker.LinkType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.linker.Linker.SharedLibraryLoadingType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.linker.LinkerProvider.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.LinkerMapMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.nativelink.NativeLinkableGroup.Linkage
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.nativelink.NativeLinkStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.objectfile.ObjectFileScrubbers.PaddingStyle
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.PicType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.SharedLibraryInterfaceParams.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.SharedLibraryInterfaceParams.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.StripStyle
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.cxx.toolchain.ToolType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.doctor.config.DoctorIssueCategory
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.doctor.config.DoctorProtocolVersion
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.doctor.config.DoctorSuggestion.StepStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.event.ArtifactCompressionEvent.Operation
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.event.chrome_trace.ChromeTraceEvent.Phase
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.event.CompilerErrorEvent.CompilerType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.event.listener.TestResultFormatter.FormatMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.event.LogUploadMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.event.RuleKeyCalculationEvent.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.event.SimplePerfEvent.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.features.apple.common.CopyInXcode.DestinationBase
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.features.apple.common.CopyInXcode.SourceType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.features.apple.common.Mode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.features.apple.common.SchemeActionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.features.apple.project.IDEForceKill
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.features.apple.project.ProjectGenerator.FilterFlags
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.features.apple.projectV2.IDEForceKill
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.features.dotnet.FrameworkVersion
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.features.go.GoArch
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.features.go.GoOs
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.features.go.GoPackStep.Operation
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.features.haskell.HaskellBinaryDescription.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.features.haskell.HaskellLibraryDescription.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.features.lua.LuaBinaryDescription.StarterType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.features.lua.LuaPlatform.PackageStyle
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.features.project.intellij.FolderTypeWithPackageInfo
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.features.project.intellij.IjDependencyListBuilder.Scope
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.features.project.intellij.IjDependencyListBuilder.SortOrder
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.features.project.intellij.IjDependencyListBuilder.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.features.project.intellij.lang.android.AndroidProjectType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.features.project.intellij.model.DependencyType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.features.project.intellij.model.folders.IjResourceFolderType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.features.project.intellij.model.IjLibrary.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.features.project.intellij.model.IjModuleType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.features.python.CxxPythonExtensionDescription.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.features.python.PythonBuckConfig.PackageStyle
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.features.rust.CrateType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.features.rust.RustBinaryDescription.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.file.RemoteFile.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.io.file.BorrowablePath.Behaviour
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.io.file.MostFiles.DeleteRecursivelyOptions
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.io.file.PathListing.FilterMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.io.filesystem.CopySourceMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.io.watchman.Capability
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.io.watchman.WatchmanDiagnostic.Level
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.io.watchman.WatchmanEvent.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.io.watchman.WatchmanEvent.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.io.watchman.WatchmanWatcher.CursorType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.io.watchman.WatchmanWatcher.FreshInstanceAction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.jvm.java.abi.AbiGenerationMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.jvm.java.abi.source.CompletedTypeKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.jvm.java.AnnotationProcessingEvent.Operation
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.jvm.java.BuiltInJavac
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.jvm.java.CompileAgainstLibraryType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.jvm.java.ForkMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.jvm.java.JarShape
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.jvm.java.JavaBuckConfig.DuplicatesLogLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.jvm.java.JavaBuckConfig.SourceAbiVerificationMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.jvm.java.JavaBuckConfig.UnusedDependenciesAction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.jvm.java.JavaBuckConfig.UnusedDependenciesConfig
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.jvm.java.Javac.Source
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.jvm.java.JavacOptions.SpoolMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.jvm.java.plugin.api.TaskEventMirror.Kind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.jvm.java.TestType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.jvm.java.tracing.JavacPhaseEvent.Phase
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.jvm.kotlin.KotlinLibraryDescription.AnnotationProcessingTool
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.parser.api.Syntax
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.parser.config.ParserConfig.AllowSymlinks
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.parser.config.ParserConfig.ApplyDefaultFlavorsMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.parser.config.ParserConfig.BuildFileSearchMethod
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.parser.config.ParserConfig.GlobHandler
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.parser.config.ParserConfig.PackageBoundaryEnforcement
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.parser.config.ParserConfig.SkylarkGlobHandler
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.parser.config.ParserConfig.WatchmanGlobSanityCheck
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.parser.events.ParseBuckFileEvent.ParserKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.parser.options.ImplicitNativeRulesState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.parser.options.UserDefinedRulesState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.parser.spec.TargetNodeSpec.TargetType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.parser.SpeculativeParsing
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.query.QueryEnvironment.ArgumentType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.query.QueryEnvironment.TargetEvaluator.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.remoteexecution.config.AutoRemoteExecutionStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.remoteexecution.config.RemoteExecutionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.remoteexecution.event.LocalFallbackEvent.Result
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.remoteexecution.event.RemoteExecutionActionEvent.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.rules.coercer.BuildTargetMacroTypeCoercer.TargetOrHost
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.rules.coercer.FrameworkPath.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.rules.coercer.PathTypeCoercer.PathExistenceVerificationMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.rules.coercer.SourceSet.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.rules.coercer.SourceSortedSet.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.rules.coercer.SourceWithFlagsList.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.rules.keys.hasher.RuleKeyHasher.Container
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.rules.keys.hasher.RuleKeyHasher.Wrapper
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.rules.keys.RuleKeyType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.rules.modern.config.ModernBuildRuleBuildStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.shell.ExportFileDescription.Mode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.shell.ExportFileDirectoryAction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.skylark.io.impl.WatchmanGlobber.Option
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.skylark.parser.FileKind
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.slb.ThriftProtocol
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.step.fs.CopyStep.DirectoryMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.support.cli.config.JsonAttributeFormat
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.support.fix.BuckFixSpecParser.FixSpecFailure
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.support.state.BuckGlobalStateLifecycleManager.LifecycleStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.swift.SwiftLibraryDescription.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.swift.toolchain.impl.SwiftSdkLayoutType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.test.CoverageReportFormat
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.test.result.type.ResultType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.util.Ansi.SeverityLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.util.bser.BserDeserializer.KeyOrdering
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.util.cache.FileHashCacheMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.util.concurrent.ExecutorPool
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.util.concurrent.ResourceAllocationFairness
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.util.concurrent.ResourcePool.ResourceUsageErrorPolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.util.DependencyMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.util.environment.Architecture
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.util.environment.BuckBuildType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.util.environment.CommandMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.util.environment.NetworkMedium
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.util.environment.Platform
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.util.environment.PlatformType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.util.Escaper.Quoter
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.util.ExitCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class com.facebook.buck.util.ImmutableMapWithNullValues
-
- values() - Static method in enum com.facebook.buck.util.ProcessExecutor.Option
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.util.randomizedtrial.CommonGroups
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.util.trace.uploader.types.CompressionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.util.types.Unit
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.util.unarchive.ArchiveFormat
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.util.unarchive.ExistingFileMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.util.unit.SizeUnit
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.util.Verbosity
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.util.versioncontrol.VersionControlStatsGenerator.Mode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.util.zip.collect.OnDuplicateEntry
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.util.zip.ZipCompressionLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.util.zip.ZipOutputStreams.HandleDuplicates
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.facebook.buck.versions.VersionedTargetGraphCache.ResultType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- ValueTypeInfo<T> - Interface in com.facebook.buck.rules.modern
-
ValueTypeInfo<T> provides methods to extract deps, outputs, rulekeys from values of type T.
- ValueTypeInfoFactory - Class in com.facebook.buck.rules.modern.impl
-
Creates ValueTypeInfos for given Types/TypeTokens.
- ValueTypeInfoFactory() - Constructor for class com.facebook.buck.rules.modern.impl.ValueTypeInfoFactory
-
- ValueTypeInfos - Class in com.facebook.buck.rules.modern.impl
-
Some utilities and simple implementations for ValueTypeInfo.
- ValueTypeInfos() - Constructor for class com.facebook.buck.rules.modern.impl.ValueTypeInfos
-
- ValueTypeInfos.ExcludedValueTypeInfo - Class in com.facebook.buck.rules.modern.impl
-
ValueTypeInfo for fields that are not annotated with @AddToRuleKey.
- ValueVisitor<E extends Exception> - Interface in com.facebook.buck.rules.modern
-
A ValueVisitor can be used to visit all the values referenced from a Buildable.
- vd_aux - Variable in class com.facebook.buck.cxx.toolchain.elf.ElfVerDef.Verdef
-
- vd_cnt - Variable in class com.facebook.buck.cxx.toolchain.elf.ElfVerDef.Verdef
-
- vd_flags - Variable in class com.facebook.buck.cxx.toolchain.elf.ElfVerDef.Verdef
-
- vd_hash - Variable in class com.facebook.buck.cxx.toolchain.elf.ElfVerDef.Verdef
-
- vd_ndx - Variable in class com.facebook.buck.cxx.toolchain.elf.ElfVerDef.Verdef
-
- vd_next - Variable in class com.facebook.buck.cxx.toolchain.elf.ElfVerDef.Verdef
-
- vd_version - Variable in class com.facebook.buck.cxx.toolchain.elf.ElfVerDef.Verdef
-
- vda_name - Variable in class com.facebook.buck.cxx.toolchain.elf.ElfVerDef.Verdaux
-
- vda_next - Variable in class com.facebook.buck.cxx.toolchain.elf.ElfVerDef.Verdaux
-
- verbose(String, Object...) - Method in class com.facebook.buck.android.BuckEventAndroidLogger
-
- verbose(Throwable, String) - Method in class com.facebook.buck.core.util.log.Logger
-
Logs a message at VERBOSE level.
- verbose(String) - Method in class com.facebook.buck.core.util.log.Logger
-
Logs a message at VERBOSE level.
- verbose(String, Object...) - Method in class com.facebook.buck.core.util.log.Logger
-
Logs a message at VERBOSE level.
- verbose(Throwable, String, Object...) - Method in class com.facebook.buck.core.util.log.Logger
-
Logs a message at VERBOSE level.
- verbose(String) - Method in class com.facebook.buck.log.TimedLogger
-
- VERBOSE_LONG_ARG - Static variable in class com.facebook.buck.support.cli.args.GlobalCliOptions
-
- VERBOSE_SHORT_ARG - Static variable in class com.facebook.buck.support.cli.args.GlobalCliOptions
-
- verbosity - Variable in class com.facebook.buck.event.listener.AbstractConsoleEventBusListener
-
- Verbosity - Enum in com.facebook.buck.util
-
An indication of how verbose Buck should be.
- VerbosityParser - Class in com.facebook.buck.cli
-
- Verdaux(long, long) - Constructor for class com.facebook.buck.cxx.toolchain.elf.ElfVerDef.Verdaux
-
- Verdef(int, int, int, int, long, long, long) - Constructor for class com.facebook.buck.cxx.toolchain.elf.ElfVerDef.Verdef
-
- VERIFIED_SOURCE_ABI_FLAVOR - Static variable in class com.facebook.buck.jvm.core.JavaAbis
-
- verify(boolean, Object) - Static method in class com.facebook.buck.core.exceptions.UserVerify
-
Verifies that state is true.
- verify(boolean, String, Object...) - Static method in class com.facebook.buck.core.exceptions.UserVerify
-
Verifies that state is true.
- verify(ExecutionContext) - Method in class com.facebook.buck.core.rules.common.InstallTrigger
-
- verify() - Method in interface com.facebook.buck.jvm.java.JvmLibraryArg
-
Verifies some preconditions on the arguments.
- verify() - Method in interface com.facebook.buck.util.cache.FileHashCache
-
- verify() - Method in class com.facebook.buck.util.cache.impl.DefaultFileHashCache
-
- verify() - Method in class com.facebook.buck.util.cache.impl.StackedFileHashCache
-
- verify() - Method in interface com.facebook.buck.util.cache.ProjectFileHashCache
-
- verifyAllArtifactsBound() - Method in class com.facebook.buck.core.artifact.BuildArtifactFactory
-
- verifyAllArtifactsBound() - Method in interface com.facebook.buck.core.rules.actions.ActionRegistry
-
- verifyAllArtifactsBound() - Method in class com.facebook.buck.core.rules.actions.DefaultActionRegistry
-
- VerifyCachesCommand - Class in com.facebook.buck.cli
-
Verify the contents of our FileHashCache.
- VerifyCachesCommand() - Constructor for class com.facebook.buck.cli.VerifyCachesCommand
-
- verifyNotNull(T, Object) - Static method in class com.facebook.buck.core.exceptions.UserVerify
-
Verifies that value is not null, returns the original object if it is not null.
- verifyNotNull(T, String, Object...) - Static method in class com.facebook.buck.core.exceptions.UserVerify
-
Verifies that value is not null, returns the original object if it is not null
- verifyValidFinalType() - Method in enum com.facebook.buck.artifact_cache.CacheResultType
-
- Vernaux(long, int, int, long, long) - Constructor for class com.facebook.buck.cxx.toolchain.elf.ElfVerNeed.Vernaux
-
- Verneed(int, int, long, long, long) - Constructor for class com.facebook.buck.cxx.toolchain.elf.ElfVerNeed.Verneed
-
- Version - Interface in com.facebook.buck.versions
-
- VERSION_NAME - Static variable in class com.facebook.buck.swift.SwiftBuckConfig
-
- VERSION_REGEX_GROUP - Static variable in class com.facebook.buck.maven.Resolver
-
- VersionBuckConfig - Class in com.facebook.buck.versions
-
- VersionBuckConfig(BuckConfig) - Constructor for class com.facebook.buck.versions.VersionBuckConfig
-
- versionCode - Variable in class com.facebook.buck.android.exopackage.PackageInfo
-
- VersionControlBuckConfig - Class in com.facebook.buck.util.versioncontrol
-
* Provides simplified access to settings from the version_control section of a .buckconfig file.
- VersionControlBuckConfig(BuckConfig) - Constructor for class com.facebook.buck.util.versioncontrol.VersionControlBuckConfig
-
- VersionControlCmdLineInterface - Interface in com.facebook.buck.util.versioncontrol
-
Provides meta-data about the version control repository the project being built is using.
- VersionControlCommandFailedException - Exception in com.facebook.buck.util.versioncontrol
-
- VersionControlCommandFailedException(Throwable) - Constructor for exception com.facebook.buck.util.versioncontrol.VersionControlCommandFailedException
-
- VersionControlCommandFailedException(String) - Constructor for exception com.facebook.buck.util.versioncontrol.VersionControlCommandFailedException
-
- versionControlStats(VersionControlStatsEvent) - Method in class com.facebook.buck.event.listener.MachineReadableLoggerListener
-
- versionControlStats() - Method in interface com.facebook.buck.support.build.report.FullBuildReport
-
- VersionControlStatsEvent - Class in com.facebook.buck.util.versioncontrol
-
- VersionControlStatsEvent(CommonSlowVersionControlStats) - Constructor for class com.facebook.buck.util.versioncontrol.VersionControlStatsEvent
-
- VersionControlStatsGenerator - Class in com.facebook.buck.util.versioncontrol
-
- VersionControlStatsGenerator(VersionControlCmdLineInterface, Optional<FastVersionControlStats>) - Constructor for class com.facebook.buck.util.versioncontrol.VersionControlStatsGenerator
-
- VersionControlStatsGenerator.Mode - Enum in com.facebook.buck.util.versioncontrol
-
Modes the generator can get stats in, in order from least comprehensive to most comprehensive.
- VersionControlSupplier<T> - Interface in com.facebook.buck.util.versioncontrol
-
Supplier interface that throws Version Control related exceptions
- VersionDescriptionsProvider - Class in com.facebook.buck.versions
-
- VersionDescriptionsProvider() - Constructor for class com.facebook.buck.versions.VersionDescriptionsProvider
-
- VersionedAliasDescription - Class in com.facebook.buck.versions
-
- VersionedAliasDescription() - Constructor for class com.facebook.buck.versions.VersionedAliasDescription
-
- VersionedAliasDescriptionArg - Class in com.facebook.buck.versions
-
Immutable implementation of VersionedAliasDescription.AbstractVersionedAliasDescriptionArg
.
- VersionedAliasDescriptionArg.Builder - Class in com.facebook.buck.versions
-
- VersionedTargetGraph - Class in com.facebook.buck.versions
-
- VersionedTargetGraph.Builder - Class in com.facebook.buck.versions
-
- VersionedTargetGraphBuilder - Interface in com.facebook.buck.versions
-
Takes a regular
TargetGraph
, resolves any versioned nodes, and returns a new graph with
the versioned nodes removed.
- VersionedTargetGraphCache - Class in com.facebook.buck.versions
-
- VersionedTargetGraphCache() - Constructor for class com.facebook.buck.versions.VersionedTargetGraphCache
-
- VersionedTargetGraphCache.ResultType - Enum in com.facebook.buck.versions
-
The possible result types using the cache.
- VersionedTargetGraphEvent - Class in com.facebook.buck.versions
-
Base class for events about building up the versioned target graph.
- VersionedTargetGraphEvent.Cache - Class in com.facebook.buck.versions
-
- VersionedTargetGraphEvent.Cache.Hit - Class in com.facebook.buck.versions
-
- VersionedTargetGraphEvent.Cache.Miss - Class in com.facebook.buck.versions
-
- VersionedTargetGraphEvent.Finished - Class in com.facebook.buck.versions
-
- VersionedTargetGraphEvent.Started - Class in com.facebook.buck.versions
-
- VersionedTargetGraphEvent.Timeout - Class in com.facebook.buck.versions
-
- VersionedTool - Class in com.facebook.buck.core.toolchain.tool.impl
-
A
Tool
which only contributes a fixed name and version when appended to a rule key.
- VersionedTool() - Constructor for class com.facebook.buck.core.toolchain.tool.impl.VersionedTool
-
- VersionException - Exception in com.facebook.buck.versions
-
Error thrown when version selection fails.
- VersionException(BuildTarget, String) - Constructor for exception com.facebook.buck.versions.VersionException
-
- versionInfo() - Method in class com.facebook.buck.features.apple.projectV2.CoreDataResource
-
- VersionInformation(Path, ImmutableList<Path>) - Constructor for class com.facebook.buck.features.apple.projectV2.CoreDataResource.VersionInformation
-
- VersionMatchedCollection<T> - Class in com.facebook.buck.rules.coercer
-
- VersionMatchedCollection(ImmutableList<Pair<ImmutableMap<BuildTarget, Version>, T>>) - Constructor for class com.facebook.buck.rules.coercer.VersionMatchedCollection
-
- VersionMatchedCollection.Builder<T> - Class in com.facebook.buck.rules.coercer
-
- VersionMatchedCollectionTypeCoercer<T> - Class in com.facebook.buck.rules.coercer
-
- VersionMatchedCollectionTypeCoercer(TypeCoercer<?, ImmutableMap<BuildTarget, Version>>, TypeCoercer<?, T>) - Constructor for class com.facebook.buck.rules.coercer.VersionMatchedCollectionTypeCoercer
-
- VersionPropagator<A extends BuildRuleArg> - Interface in com.facebook.buck.versions
-
A node constitutes the body of a version sub-graph.
- VersionRoot<A extends BuildRuleArg> - Interface in com.facebook.buck.versions
-
A node which is the root of a version sub-graph.
- VersionSelector - Interface in com.facebook.buck.versions
-
Interface for selecting versions for a versioned sub-graph represented by a root node and its
version domain.
- VersionStringComparator - Class in com.facebook.buck.util
-
Compares version strings such as "4.2.2", "17.0", "r10e-rc4".
- VersionStringComparator() - Constructor for class com.facebook.buck.util.VersionStringComparator
-
- VersionUniverse - Class in com.facebook.buck.versions
-
- VersionUniverse() - Constructor for class com.facebook.buck.versions.VersionUniverse
-
- VersionUniverse.Builder - Class in com.facebook.buck.versions
-
- VersionUniverseVersionSelector - Class in com.facebook.buck.versions
-
A fast constraint resolver which selects versions using pre-defined version universes.
- VersionUniverseVersionSelector(TargetGraph, ImmutableMap<String, VersionUniverse>) - Constructor for class com.facebook.buck.versions.VersionUniverseVersionSelector
-
- VFSOverlay - Class in com.facebook.buck.apple.clang
-
VFSOverlays are used for similar purposes to headermaps, but can be used to overlay more than
headers on the filesystem (such as modulemaps)
- VFSOverlay(ImmutableSortedMap<Path, Path>) - Constructor for class com.facebook.buck.apple.clang.VFSOverlay
-
- visibility - Variable in class com.facebook.buck.maven.ArtifactConfig
-
- VISIBILITY - Static variable in class com.facebook.buck.rules.visibility.VisibilityAttributes
-
- VISIBILITY_PUBLIC - Static variable in class com.facebook.buck.rules.visibility.parser.VisibilityPatternParser
-
- VisibilityAttributes - Class in com.facebook.buck.rules.visibility
-
Attributes pertaining to visibility evaluation.
- VisibilityChecker - Class in com.facebook.buck.rules.visibility
-
- VisibilityChecker(ObeysVisibility, ImmutableSet<VisibilityPattern>, ImmutableSet<VisibilityPattern>) - Constructor for class com.facebook.buck.rules.visibility.VisibilityChecker
-
- VisibilityPattern - Interface in com.facebook.buck.rules.visibility
-
- VisibilityPatternParser - Class in com.facebook.buck.rules.visibility.parser
-
- VisibilityPatternParser() - Constructor for class com.facebook.buck.rules.visibility.parser.VisibilityPatternParser
-
- VisibilityPatterns - Class in com.facebook.buck.rules.visibility.parser
-
- visit(int) - Method in interface com.facebook.buck.android.resources.ResChunk.RefVisitor
-
- visit(HeaderMap.HeaderMapVisitor) - Method in class com.facebook.buck.apple.clang.HeaderMap
-
- visit(GroupedSource.Visitor) - Method in class com.facebook.buck.apple.GroupedSource
-
- visit(T) - Method in class com.facebook.buck.core.util.graph.AbstractBottomUpTraversal
-
- visit(Node) - Method in class com.facebook.buck.core.util.graph.AbstractBreadthFirstThrowingTraversal.StaticBreadthFirstTraversal
-
- visit(Node) - Method in class com.facebook.buck.core.util.graph.AbstractBreadthFirstThrowingTraversal
-
To perform a full traversal of the the initialNode
's transitive dependencies, this
function should return all of node
's direct dependencies.
- visit(Node) - Method in interface com.facebook.buck.core.util.graph.AbstractBreadthFirstThrowingTraversal.Visitor
-
- visit(int, int, String, String, String, String[]) - Method in class com.facebook.buck.jvm.java.abi.SourceAbiCompatibleVisitor
-
- visit(FileLike) - Method in class com.facebook.buck.jvm.java.classes.ClasspathTraversal
-
- visit(QueryExpression<NODE_TYPE>) - Method in class com.facebook.buck.query.TargetPatternCollector
-
- visit(T, ValueVisitor<E>) - Method in interface com.facebook.buck.rules.modern.ClassInfo
-
- visit(AddsToRuleKey, ValueVisitor<E>) - Method in class com.facebook.buck.rules.modern.FieldInfo
-
- visit(BuildTarget, ValueVisitor<E>) - Method in class com.facebook.buck.rules.modern.impl.BuildTargetTypeInfo
-
- visit(T, ValueVisitor<E>) - Method in class com.facebook.buck.rules.modern.impl.DefaultClassInfo
-
- visit(AddsToRuleKey, ValueVisitor<E>) - Method in class com.facebook.buck.rules.modern.impl.DynamicTypeInfo
-
- visit(Either<L, R>, ValueVisitor<E>) - Method in class com.facebook.buck.rules.modern.impl.EitherValueTypeInfo
-
- visit(T, ValueVisitor<E>) - Method in class com.facebook.buck.rules.modern.impl.EnumValueTypeInfo
-
- visit(HashCode, ValueVisitor<E>) - Method in class com.facebook.buck.rules.modern.impl.HashCodeValueTypeInfo
-
- visit(ImmutableMap<K, V>, ValueVisitor<E>) - Method in class com.facebook.buck.rules.modern.impl.ImmutableMapValueTypeInfo
-
- visit(ImmutableSet<T>, ValueVisitor<E>) - Method in class com.facebook.buck.rules.modern.impl.ImmutableSetValueTypeInfo
-
- visit(ImmutableSortedMap<K, V>, ValueVisitor<E>) - Method in class com.facebook.buck.rules.modern.impl.ImmutableSortedMapValueTypeInfo
-
- visit(NonHashableSourcePathContainer, ValueVisitor<E>) - Method in class com.facebook.buck.rules.modern.impl.NonHashableSourcePathContainerValueTypeInfo
-
- visit(T, ValueVisitor<E>) - Method in class com.facebook.buck.rules.modern.impl.NullableValueTypeInfo
-
- visit(OutputLabel, ValueVisitor<E>) - Method in class com.facebook.buck.rules.modern.impl.OutputLabelValueTypeInfo
-
- visit(Pattern, ValueVisitor<E>) - Method in class com.facebook.buck.rules.modern.impl.PatternValueTypeInfo
-
- visit(SourcePath, ValueVisitor<E>) - Method in class com.facebook.buck.rules.modern.impl.SourcePathValueTypeInfo
-
- visit(Supplier<T>, ValueVisitor<E>) - Method in class com.facebook.buck.rules.modern.impl.SupplierValueTypeInfo
-
- visit(TargetConfiguration, ValueVisitor<E>) - Method in class com.facebook.buck.rules.modern.impl.TargetConfigurationTypeInfo
-
- visit(T, ValueVisitor<E>) - Method in class com.facebook.buck.rules.modern.impl.ToolchainTypeInfo
-
- visit(UnconfiguredBuildTarget, ValueVisitor<E>) - Method in class com.facebook.buck.rules.modern.impl.UnconfiguredBuildTargetTypeInfo
-
- visit(Object, ValueVisitor<E>) - Method in class com.facebook.buck.rules.modern.impl.ValueTypeInfos.ExcludedValueTypeInfo
-
- visit(T, ValueVisitor<E>) - Method in interface com.facebook.buck.rules.modern.ValueTypeInfo
-
- visit(ZipFile, ZipEntry) - Method in class com.facebook.buck.util.ZipFileTraversal
-
- visitAnnotation(AnnotationMirror, P) - Method in class com.facebook.buck.jvm.java.lang.model.AnnotationValueScanner8
-
- visitArray(ArrayType, P) - Method in class com.facebook.buck.jvm.java.abi.TypeScanner8
-
- visitArray(List<? extends AnnotationValue>, P) - Method in class com.facebook.buck.jvm.java.lang.model.AnnotationValueScanner8
-
- visitBoolean(boolean, P) - Method in class com.facebook.buck.jvm.java.lang.model.AnnotationValueScanner8
-
- visitBoolean(Boolean) - Method in class com.facebook.buck.rules.modern.impl.AbstractValueVisitor
-
- visitBoolean(Boolean) - Method in class com.facebook.buck.rules.modern.impl.StringifyingValueVisitor
-
- visitBoolean(Boolean) - Method in interface com.facebook.buck.rules.modern.ValueVisitor
-
- visitByte(byte, P) - Method in class com.facebook.buck.jvm.java.lang.model.AnnotationValueScanner8
-
- visitByte(Byte) - Method in class com.facebook.buck.rules.modern.impl.AbstractValueVisitor
-
- visitByte(Byte) - Method in class com.facebook.buck.rules.modern.impl.StringifyingValueVisitor
-
- visitByte(Byte) - Method in interface com.facebook.buck.rules.modern.ValueVisitor
-
- visitChar(char, P) - Method in class com.facebook.buck.jvm.java.lang.model.AnnotationValueScanner8
-
- visitCharacter(Character) - Method in class com.facebook.buck.rules.modern.impl.AbstractValueVisitor
-
- visitCharacter(Character) - Method in class com.facebook.buck.rules.modern.impl.StringifyingValueVisitor
-
- visitCharacter(Character) - Method in interface com.facebook.buck.rules.modern.ValueVisitor
-
- visitDeclared(DeclaredType, P) - Method in class com.facebook.buck.jvm.java.abi.TypeScanner8
-
- visitDouble(double, P) - Method in class com.facebook.buck.jvm.java.lang.model.AnnotationValueScanner8
-
- visitDouble(Double) - Method in class com.facebook.buck.rules.modern.impl.AbstractValueVisitor
-
- visitDouble(Double) - Method in class com.facebook.buck.rules.modern.impl.StringifyingValueVisitor
-
- visitDouble(Double) - Method in interface com.facebook.buck.rules.modern.ValueVisitor
-
- visitDynamic(T, ClassInfo<T>) - Method in class com.facebook.buck.rules.modern.impl.AbstractValueVisitor
-
- visitDynamic(T, ClassInfo<T>) - Method in class com.facebook.buck.rules.modern.impl.DepsComputingVisitor
-
- visitDynamic(T, ClassInfo<T>) - Method in class com.facebook.buck.rules.modern.impl.StringifyingValueVisitor
-
- visitDynamic(T, ClassInfo<T>) - Method in interface com.facebook.buck.rules.modern.ValueVisitor
-
- visitEnumConstant(VariableElement, P) - Method in class com.facebook.buck.jvm.java.lang.model.AnnotationValueScanner8
-
- visitError(ErrorType, P) - Method in class com.facebook.buck.jvm.java.abi.TypeScanner8
-
- visitExecutable(ExecutableType, P) - Method in class com.facebook.buck.jvm.java.abi.TypeScanner8
-
- visitField(int, String, String, String, Object) - Method in class com.facebook.buck.jvm.java.abi.SourceAbiCompatibleVisitor
-
- visitField(Field, T, ValueTypeInfo<T>, List<Class<? extends CustomFieldBehaviorTag>>) - Method in class com.facebook.buck.rules.modern.impl.AbstractValueVisitor
-
- visitField(Field, T, ValueTypeInfo<T>, List<Class<? extends CustomFieldBehaviorTag>>) - Method in class com.facebook.buck.rules.modern.impl.DepsComputingVisitor
-
- visitField(Field, T, ValueTypeInfo<T>, List<Class<? extends CustomFieldBehaviorTag>>) - Method in class com.facebook.buck.rules.modern.impl.StringifyingValueVisitor
-
- visitField(Field, T, ValueTypeInfo<T>, List<Class<? extends CustomFieldBehaviorTag>>) - Method in interface com.facebook.buck.rules.modern.ValueVisitor
-
- visitFloat(float, P) - Method in class com.facebook.buck.jvm.java.lang.model.AnnotationValueScanner8
-
- visitFloat(Float) - Method in class com.facebook.buck.rules.modern.impl.AbstractValueVisitor
-
- visitFloat(Float) - Method in class com.facebook.buck.rules.modern.impl.StringifyingValueVisitor
-
- visitFloat(Float) - Method in interface com.facebook.buck.rules.modern.ValueVisitor
-
- visitIgnoredSource(SourcePath) - Method in interface com.facebook.buck.apple.GroupedSource.Visitor
-
- visitInnerClass(String, String, String, int) - Method in class com.facebook.buck.jvm.java.abi.SourceAbiCompatibleVisitor
-
- visitInputsAndOutputs(Consumer<Artifact>, Consumer<OutputArtifact>) - Method in interface com.facebook.buck.core.rules.actions.lib.args.CommandLineArgs
-
- visitInputsAndOutputs(Consumer<Artifact>, Consumer<OutputArtifact>) - Method in class com.facebook.buck.core.rules.providers.lib.RunInfo
-
- visitInt(int, P) - Method in class com.facebook.buck.jvm.java.lang.model.AnnotationValueScanner8
-
- visitInteger(Integer) - Method in class com.facebook.buck.rules.modern.impl.AbstractValueVisitor
-
- visitInteger(Integer) - Method in class com.facebook.buck.rules.modern.impl.StringifyingValueVisitor
-
- visitInteger(Integer) - Method in interface com.facebook.buck.rules.modern.ValueVisitor
-
- visitIntersection(IntersectionType, P) - Method in class com.facebook.buck.jvm.java.abi.TypeScanner8
-
- visitKeyReferences(ResChunk.RefVisitor) - Method in class com.facebook.buck.android.resources.ResTableType
-
- visitKeyReferences(ResChunk.RefVisitor) - Method in class com.facebook.buck.android.resources.ResTableTypeSpec
-
- visitList(ImmutableList<T>, ValueTypeInfo<T>) - Method in class com.facebook.buck.rules.modern.impl.AbstractValueVisitor
-
- visitList(ImmutableList<T>, ValueTypeInfo<T>) - Method in class com.facebook.buck.rules.modern.impl.StringifyingValueVisitor
-
- visitList(ImmutableList<T>, ValueTypeInfo<T>) - Method in interface com.facebook.buck.rules.modern.ValueVisitor
-
- visitLong(long, P) - Method in class com.facebook.buck.jvm.java.lang.model.AnnotationValueScanner8
-
- visitLong(Long) - Method in class com.facebook.buck.rules.modern.impl.AbstractValueVisitor
-
- visitLong(Long) - Method in class com.facebook.buck.rules.modern.impl.StringifyingValueVisitor
-
- visitLong(Long) - Method in interface com.facebook.buck.rules.modern.ValueVisitor
-
- visitMap(ImmutableMap<K, V>, ValueTypeInfo<K>, ValueTypeInfo<V>) - Method in class com.facebook.buck.rules.modern.impl.AbstractValueVisitor
-
- visitMap(ImmutableMap<K, V>, ValueTypeInfo<K>, ValueTypeInfo<V>) - Method in class com.facebook.buck.rules.modern.impl.StringifyingValueVisitor
-
- visitMap(ImmutableMap<K, V>, ValueTypeInfo<K>, ValueTypeInfo<V>) - Method in interface com.facebook.buck.rules.modern.ValueVisitor
-
- visitMethod(int, String, String, String, String[]) - Method in class com.facebook.buck.jvm.java.abi.SourceAbiCompatibleVisitor
-
- visitNoType(NoType, P) - Method in class com.facebook.buck.jvm.java.abi.TypeScanner8
-
- visitNull(NullType, P) - Method in class com.facebook.buck.jvm.java.abi.TypeScanner8
-
- visitNullable(T, ValueTypeInfo<T>) - Method in class com.facebook.buck.rules.modern.impl.AbstractValueVisitor
-
- visitNullable(T, ValueTypeInfo<T>) - Method in class com.facebook.buck.rules.modern.impl.StringifyingValueVisitor
-
- visitNullable(T, ValueTypeInfo<T>) - Method in interface com.facebook.buck.rules.modern.ValueVisitor
-
- visitOptional(Optional<T>, ValueTypeInfo<T>) - Method in class com.facebook.buck.rules.modern.impl.AbstractValueVisitor
-
- visitOptional(Optional<T>, ValueTypeInfo<T>) - Method in class com.facebook.buck.rules.modern.impl.StringifyingValueVisitor
-
- visitOptional(Optional<T>, ValueTypeInfo<T>) - Method in interface com.facebook.buck.rules.modern.ValueVisitor
-
- visitOutputPath(OutputPath) - Method in class com.facebook.buck.rules.modern.impl.DepsComputingVisitor
-
- visitOutputPath(OutputPath) - Method in class com.facebook.buck.rules.modern.impl.OutputPathVisitor
-
- visitOutputPath(OutputPath) - Method in class com.facebook.buck.rules.modern.impl.StringifyingValueVisitor
-
- visitOutputPath(OutputPath) - Method in interface com.facebook.buck.rules.modern.ValueVisitor
-
- visitPath(Path) - Method in class com.facebook.buck.rules.modern.impl.DepsComputingVisitor
-
- visitPath(Path) - Method in class com.facebook.buck.rules.modern.impl.OutputPathVisitor
-
- visitPath(Path) - Method in class com.facebook.buck.rules.modern.impl.StringifyingValueVisitor
-
- visitPath(Path) - Method in interface com.facebook.buck.rules.modern.ValueVisitor
-
- visitPrimitive(PrimitiveType, P) - Method in class com.facebook.buck.jvm.java.abi.TypeScanner8
-
- visitPrivateHeader(SourcePath) - Method in interface com.facebook.buck.apple.GroupedSource.Visitor
-
- visitPublicHeader(SourcePath) - Method in interface com.facebook.buck.apple.GroupedSource.Visitor
-
- visitReferences(ResChunk.RefVisitor) - Method in class com.facebook.buck.android.resources.ResourcesXml
-
- visitReferences(int[], ResChunk.RefVisitor) - Method in class com.facebook.buck.android.resources.ResTableType
-
- visitReferences(int[], ResChunk.RefVisitor) - Method in class com.facebook.buck.android.resources.ResTableTypeSpec
-
- visitSet(ImmutableSet<T>, ValueTypeInfo<T>) - Method in class com.facebook.buck.rules.modern.impl.AbstractValueVisitor
-
- visitSet(ImmutableSet<T>, ValueTypeInfo<T>) - Method in class com.facebook.buck.rules.modern.impl.StringifyingValueVisitor
-
- visitSet(ImmutableSet<T>, ValueTypeInfo<T>) - Method in interface com.facebook.buck.rules.modern.ValueVisitor
-
- visitShort(short, P) - Method in class com.facebook.buck.jvm.java.lang.model.AnnotationValueScanner8
-
- visitShort(Short) - Method in class com.facebook.buck.rules.modern.impl.AbstractValueVisitor
-
- visitShort(Short) - Method in class com.facebook.buck.rules.modern.impl.StringifyingValueVisitor
-
- visitShort(Short) - Method in interface com.facebook.buck.rules.modern.ValueVisitor
-
- visitSimple(Object) - Method in class com.facebook.buck.rules.modern.impl.AbstractValueVisitor
-
- visitSimple(Object) - Method in class com.facebook.buck.rules.modern.impl.DepsComputingVisitor
-
- visitSimple(Object) - Method in class com.facebook.buck.rules.modern.impl.OutputPathVisitor
-
- visitSortedMap(ImmutableSortedMap<K, V>, ValueTypeInfo<K>, ValueTypeInfo<V>) - Method in class com.facebook.buck.rules.modern.impl.AbstractValueVisitor
-
- visitSortedMap(ImmutableSortedMap<K, V>, ValueTypeInfo<K>, ValueTypeInfo<V>) - Method in class com.facebook.buck.rules.modern.impl.StringifyingValueVisitor
-
- visitSortedMap(ImmutableSortedMap<K, V>, ValueTypeInfo<K>, ValueTypeInfo<V>) - Method in interface com.facebook.buck.rules.modern.ValueVisitor
-
- visitSortedSet(ImmutableSortedSet<T>, ValueTypeInfo<T>) - Method in class com.facebook.buck.rules.modern.impl.AbstractValueVisitor
-
- visitSortedSet(ImmutableSortedSet<T>, ValueTypeInfo<T>) - Method in class com.facebook.buck.rules.modern.impl.StringifyingValueVisitor
-
- visitSortedSet(ImmutableSortedSet<T>, ValueTypeInfo<T>) - Method in interface com.facebook.buck.rules.modern.ValueVisitor
-
- visitSourceGroup(String, Path, List<GroupedSource>) - Method in interface com.facebook.buck.apple.GroupedSource.Visitor
-
- visitSourcePath(SourcePath) - Method in class com.facebook.buck.rules.modern.impl.DepsComputingVisitor
-
- visitSourcePath(SourcePath) - Method in class com.facebook.buck.rules.modern.impl.OutputPathVisitor
-
- visitSourcePath(SourcePath) - Method in class com.facebook.buck.rules.modern.impl.StringifyingValueVisitor
-
- visitSourcePath(SourcePath) - Method in interface com.facebook.buck.rules.modern.ValueVisitor
-
- visitSourceWithFlags(SourceWithFlags) - Method in interface com.facebook.buck.apple.GroupedSource.Visitor
-
- visitString(String, P) - Method in class com.facebook.buck.jvm.java.lang.model.AnnotationValueScanner8
-
- visitString(String) - Method in class com.facebook.buck.rules.modern.impl.AbstractValueVisitor
-
- visitString(String) - Method in class com.facebook.buck.rules.modern.impl.StringifyingValueVisitor
-
- visitString(String) - Method in interface com.facebook.buck.rules.modern.ValueVisitor
-
- visitStringReferences(ResChunk.RefVisitor) - Method in class com.facebook.buck.android.resources.ResTablePackage
-
- visitStringReferences(ResChunk.RefVisitor) - Method in class com.facebook.buck.android.resources.ResTableType
-
- visitStringReferences(int[], ResChunk.RefVisitor) - Method in class com.facebook.buck.android.resources.ResTableType
-
- visitStringReferences(ResChunk.RefVisitor) - Method in class com.facebook.buck.android.resources.ResTableTypeSpec
-
- visitStringReferences(int[], ResChunk.RefVisitor) - Method in class com.facebook.buck.android.resources.ResTableTypeSpec
-
- visitTargetConfiguration(TargetConfiguration) - Method in class com.facebook.buck.rules.modern.impl.AbstractValueVisitor
-
- visitTargetConfiguration(TargetConfiguration) - Method in class com.facebook.buck.rules.modern.impl.StringifyingValueVisitor
-
- visitTargetConfiguration(TargetConfiguration) - Method in interface com.facebook.buck.rules.modern.ValueVisitor
-
- visitToolDependencies(TargetConfiguration, Consumer<BuildTarget>) - Method in interface com.facebook.buck.core.toolchain.RuleAnalysisLegacyToolchain
-
Add the dependencies for this toolchain to the graph.
- visitType(TypeMirror, P) - Method in class com.facebook.buck.jvm.java.lang.model.AnnotationValueScanner8
-
- visitTypeVariable(TypeVariable, P) - Method in class com.facebook.buck.jvm.java.abi.TypeScanner8
-
- visitUnion(UnionType, P) - Method in class com.facebook.buck.jvm.java.abi.TypeScanner8
-
- visitUnknown(AnnotationValue, P) - Method in class com.facebook.buck.jvm.java.lang.model.AnnotationValueScanner8
-
- visitWildcard(WildcardType, P) - Method in class com.facebook.buck.jvm.java.abi.TypeScanner8
-
- vn_aux - Variable in class com.facebook.buck.cxx.toolchain.elf.ElfVerNeed.Verneed
-
- vn_cnt - Variable in class com.facebook.buck.cxx.toolchain.elf.ElfVerNeed.Verneed
-
- vn_file - Variable in class com.facebook.buck.cxx.toolchain.elf.ElfVerNeed.Verneed
-
- vn_next - Variable in class com.facebook.buck.cxx.toolchain.elf.ElfVerNeed.Verneed
-
- vn_version - Variable in class com.facebook.buck.cxx.toolchain.elf.ElfVerNeed.Verneed
-
- vna_flags - Variable in class com.facebook.buck.cxx.toolchain.elf.ElfVerNeed.Vernaux
-
- vna_hash - Variable in class com.facebook.buck.cxx.toolchain.elf.ElfVerNeed.Vernaux
-
- vna_name - Variable in class com.facebook.buck.cxx.toolchain.elf.ElfVerNeed.Vernaux
-
- vna_next - Variable in class com.facebook.buck.cxx.toolchain.elf.ElfVerNeed.Vernaux
-
- vna_other - Variable in class com.facebook.buck.cxx.toolchain.elf.ElfVerNeed.Vernaux
-