Crate capability Copy item path Source async_channel An async multi-producer multi-consumer channel, where each message can be received by only
one of all existing consumers. cargo_lock RustSec: cargo-lock
crate cargo_metadata Structured access to the output of cargo metadata
and cargo --message-format=json
.
Usually used from within a cargo-*
executable colored Coloring terminal so simple, you already know how to do it ! derive_builder Derive a builder for a struct dirs The dirs crate is getset Getset, we’re ready to go! language_model_output_format_instructions model_type notify Cross-platform file system notification library pathdiff petgraph petgraph
is a graph data structure library.portpicker ra_ap_syntax Syntax Tree library used throughout the rust-analyzer. regex This crate provides routines for searching strings for matches of a regular
expression (aka “regex”). The regex syntax supported by this crate is similar
to other regex engines, but it lacks several features that are not known how to
implement efficiently. This includes, but is not limited to, look-around and
backreferences. In exchange, all regex searches in this crate have worst case
O(m * n)
time complexity, where m
is proportional to the size of the regex
and n
is proportional to the size of the string being searched. reqwest reqwest rocket Rocket - Core API Documentation serde Adapters for alternative serde
formats. structopt This crate defines the StructOpt
trait and its custom derive. tempfile This is a library for creating temporary files and directories that are automatically deleted
when no longer referenced (i.e., on drop). thread Native threads. timestamp Generating UUIDs from timestamps. toml A serde -compatible TOML -parsing library toml_edit toml_edit
tracing A scoped, structured logging and diagnostics system. T debug Constructs an event at the debug level. error Constructs an event at the error level. error_tree format_smolstr Formats arguments to a SmolStr
, potentially without allocating. formatdoc Unindent and call format!
. impl_default_save_to_file_traits indoc Unindent and produce &'static str
or &'static [u8]
. info Constructs an event at the info level. ix json Construct a serde_json::Value
from a JSON literal. lazy_static match_ast Matches a SyntaxNode
against an ast
type. name Macro to create a name with an optional separator. pretty_assert_eq Asserts that two expressions are equal to each other (using PartialEq
). setup_test_logger trace Constructs an event at the trace level. uuid Parse Uuid
s from string literals at compile time. warn Constructs an event at the warn level. x xp AgentCoordinate AgentCoordinateBuilder Builder for AgentCoordinate
. AggregateChildSpec Use this object to specify per-child optionality and toggle probability for a model branch within an Aggregate
node. AggregateChildSpecBuilder Builder for AggregateChildSpec
. AiTreeBranchingConfidenceConfiguration This struct should define how AI confidence modifies branching factor: AiTreeBranchingConfidenceConfigurationBuilder Builder for AiTreeBranchingConfidenceConfiguration
. AnnotatedLeaf Each AnnotatedLeaf specifies clearly a leaf in our domain model tree. AnnotatedLeafBuilder Builder for AnnotatedLeaf
. AnnotatedLeafHolderExpansions To create this structure, we consider the topology of our model and create for each
LeafHolder leaf a textual descriptor which reads like a handwritten observation taken by
a practitioner in the domain. AnnotatedLeafHolderExpansionsBuilder Builder for AnnotatedLeafHolderExpansions
. AnnotatedLeafHolderNode AnnotatedLeafHolderNodeBuilder Builder for AnnotatedLeafHolderNode
. Arc A thread-safe reference-counting pointer. ‘Arc’ stands for ‘Atomically
Reference Counted’. AstPtr Like SyntaxNodePtr
, but remembers the type of node. AsyncMutex An asynchronous Mutex
-like type. AutomatedFlowStrategy A FlowStrategy
for automated usage: BTreeMap An ordered map based on a B-Tree . BTreeSet An ordered set based on a B-Tree. BadWorkspace In “test_reconcile_unprocessed_input_error_but_mock_processing_fails_action,”
you had a local struct BadWorkspace
referencing workspace_dir()
.
Instead, remove that workspace_dir()
method entirely, and define
a single “BadWorkspace” with full trait impl so it compiles. BatchChoice BatchChoiceBuilder Builder for BatchChoice
. BatchErrorData BatchErrorDataBuilder Builder for BatchErrorData
. BatchErrorDetails BatchErrorDetailsBuilder Builder for BatchErrorDetails
. BatchErrorResponseBody BatchErrorResponseBodyBuilder Builder for BatchErrorResponseBody
. BatchExecutionResult BatchExecutionResultBuilder Builder for BatchExecutionResult
. BatchFileReconciliationRecommendedCourseOfAction BatchFileTriple Represents the batch files associated with a specific index. BatchFileTripleBuilder Builder for BatchFileTriple
. BatchInputData BatchInputDataBuilder Builder for BatchInputData
. BatchMessage BatchMessageBuilder Builder for BatchMessage
. BatchMessageContent BatchMessageContentBuilder Builder for BatchMessageContent
. BatchMetadata BatchMetadataBuilder Builder for BatchMetadata
. BatchOnlineStatus BatchOutputData BatchOutputDataBuilder Builder for BatchOutputData
. BatchRequestId BatchRequestRecord BatchRequestRecordBuilder Builder for BatchRequestRecord
. BatchResponseContent BatchResponseContentBuilder Builder for BatchResponseContent
. BatchResponseRecord BatchResponseRecordBuilder Builder for BatchResponseRecord
. BatchSuccessResponseBody BatchSuccessResponseBodyBuilder Builder for BatchSuccessResponseBody
. BatchTokenDetails BatchTokenDetailsBuilder Builder for BatchTokenDetails
. BatchUsage BatchUsageBuilder Builder for BatchUsage
. BatchWorkspace BatchWorkspaceBuilder Builder for BatchWorkspace
. BufReader The BufReader
struct adds buffering to any reader. BufferedLayer BufferedSubscriberLayer Builder A builder for creating a UUID. CamelCaseTokenWithComment CamelCaseTokenWithCommentBuilder Builder for CamelCaseTokenWithComment
. CancellationToken A token which can be used to signal a cancellation request to one or more
tasks. CapstoneGenerationConfiguration In the context of our tree-generation system, a capstone node is a special type of leaf node
that represents a culminating skill, concept, or endpoint of a hierarchical branch. CapstoneGenerationConfigurationBuilder Builder for CapstoneGenerationConfiguration
. ChatCompletionRequestSystemMessage ChatCompletionRequestUserMessage Command This structure mimics the API of std::process::Command
found in the standard library, but
replaces functions that create a process with an asynchronous variant. The main provided
asynchronous functions are spawn , status , and
output . ComparisonContext A context that can store additional info used to scale thresholds
or to handle statistical significance (e.g. “sample size,” aggregator count). CoreSkeletalAggregateNode With the exception of generating the descriptor
field for this node, we source the fields
from the corresponding fields in StrippedStringSkeleton
. CoreSkeletalAggregateNodeBuilder Builder for CoreSkeletalAggregateNode
. CoreSkeletalDispatchNode With the exception of generating the descriptor
field for this node, we source the fields
from the corresponding fields in StrippedStringSkeleton
. CoreSkeletalDispatchNodeBuilder Builder for CoreSkeletalDispatchNode
. CoreSkeletalLeafHolderNode We generate this data structure by expanding and mapping each LeafHolder node in the
input set into a well-chosen set of unit variants. CoreSkeletalLeafHolderNodeBuilder Builder for CoreSkeletalLeafHolderNode
. CoreStringSkeleton To generate this structure, we determine each node in the stripped-down model. CoreStringSkeletonBuilder Builder for CoreStringSkeleton
. CreateChatCompletionRequestArgs Builder for CreateChatCompletionRequest
. CustomRequestId Cycle An algorithm error: a cycle was found in the graph. Data Type representing the body data of a request. DeltaThresholds Thresholds for deciding whether a difference in a field is large enough
to produce a ConfigDelta
. DeltaThresholdsBuilder Builder for DeltaThresholds
. Dependency A dependency of the main crate DepthBasedNodeVariantPolicy This picks which variant to use based on current depth. DepthBasedNodeVariantPolicyBuilder Builder for DepthBasedNodeVariantPolicy
. DispatchChildSpec Use this object to configure per-child selection probability within a Dispatch node DispatchChildSpecBuilder Builder for DispatchChildSpec
. DontUseMe A mutual exclusion primitive useful for protecting shared data Dot Dot
implements output to graphviz .dot format for a graph.Duration A Duration
type to represent a span of time, typically used for system
timeouts. Error A general error that can occur when working with UUIDs. Event Notify event. FailingWorkspace File A reference to an open file on the filesystem. FileLoggingConfiguration Graph Graph<N, E, Ty, Ix>
is a graph datastructure using an adjacency list representation.GreenNode Internal node in the immutable tree.
It has other nodes and tokens as children. GrowerInputs Represents the primary user- or AI-supplied environment
description and other essential context. These inputs are
typically consumed by later crates to shape tree parameters,
regenerate models, etc. GrowerInputsBuilder Builder for GrowerInputs
. GrowerLanguageModelClient Our language-model client using async-openai
0.27.x
with a synchronous facade around the actual async calls. GrowerModel GrowerModelBuilder Builder for GrowerModel
. GrowerTreeConfiguration We set the GrowerTreeConfiguration to refine the shape of our model trees: GrowerTreeConfigurationBuilder Builder for GrowerTreeConfiguration
. HashMap A hash map implemented with quadratic probing and SIMD lookup. HashSet A hash set implemented as a HashMap
where the value is ()
. InstructedLanguageModelAtCoordinate InstructedLanguageModelAtCoordinateBuilder Builder for InstructedLanguageModelAtCoordinate
. Iter Immutable slice iterator JustifiedAggregateChildSpec JustifiedAiTreeBranchingConfidenceConfiguration JustifiedCapstoneGenerationConfiguration JustifiedDepthBasedNodeVariantPolicy JustifiedDispatchChildSpec JustifiedGrowerTreeConfiguration JustifiedLevelSkippingConfiguration JustifiedNodeVariantLevelWeights JustifiedNodeVariantPhaseRange JustifiedPhasedNodeVariantPolicy JustifiedScriptedNodeVariantPolicy JustifiedStringSkeleton JustifiedTreeLevelSpecificConfiguration JustifiedWeightedBranchingConfiguration JustifiedWeightedNodeVariantPolicy JustifiedWeightedNodeVariantPolicyWithLimits LanguageModelBatchAPIRequest Represents the complete request structure. LanguageModelMessage Individual message details in the request body. LanguageModelRequestBody Body details of the API request. LanguageModelTokenExpander LevelSkippingConfiguration This struct should define how you skip certain levels early, turning them into leaves based on probabilities. LevelSkippingConfigurationBuilder Builder for LevelSkippingConfiguration
. ManualFlowStrategy A FlowStrategy
for purely manual usage: ManualGrowerFlowCliArgs ManualGrowerFlowCliArgsBuilder Builder for ManualGrowerFlowCliArgs
. Metadata Starting point for metadata returned by cargo metadata
MetadataCommand A builder for configurating cargo metadata
invocation. MockBatchConfig MockBatchConfigBuilder Builder for MockBatchConfig
. MockBatchWorkspace MockBatchWorkspaceBuilder Builder for MockBatchWorkspace
. MockItem A minimal item that could implement GetTargetPathForAIExpansion
.
We’ll just call it MockItem
for demonstration. MockLanguageModelClient MockLanguageModelClientBuilder Builder for MockLanguageModelClient
. NameValidator Validator struct to validate names using a regular expression. NamedChildSpec To generate this structure, describe a single child entry beneath a Dispatch
or Aggregate
node.
This description includes: NamedChildSpecBuilder Builder for NamedChildSpec
. NamedTempFile A named temporary file. NoContext An empty counter that will always return the value 0
. NodeIndex Node identifier. NodeVariantLevelWeights A single “probability triple” used in ScriptedNodeVariantPolicy.levels
, specifying
aggregator/dispatch/leaf probabilities at that level. NodeVariantLevelWeightsBuilder Builder for NodeVariantLevelWeights
. NodeVariantPhaseRange A single phase range used in PhasedNodeVariantPolicy.phases
. NodeVariantPhaseRangeBuilder Builder for NodeVariantPhaseRange
. NonNilUuid A UUID that is guaranteed not to be the nil UUID . NotifyConfig Watcher Backend configuration OpenAIClientHandle OpenAiClient Client is a container for config, backoff and http_client
used to make API calls. OrderedFloat A wrapper around floats providing implementations of Eq
, Ord
, and Hash
. Package One or more crates described by a single Cargo.toml
PackageId An “opaque” identifier for a package. Parse Parse
is the result of the parsing: a syntax tree and a collection of
errors.PartiallyGrownModel PartiallyGrownModelBuilder Builder for PartiallyGrownModel
. Path A slice of a path (akin to str
). PathBuf An owned, mutable path (akin to String
). PathDeserializer Deserializer adapter that records path to deserialization errors. PhasedNodeVariantPolicy A list of “phases,” each specifying a start depth plus aggregator/dispatch/leaf weights.
Once you pass a phase’s start_level
, you use those weights until the next phase’s
start_level
or the end of the tree. PhasedNodeVariantPolicyBuilder Builder for PhasedNodeVariantPolicy
. Preorder ReceiverStream A wrapper around tokio::sync::mpsc::Receiver
that implements Stream
. Regex A compiled regular expression for searching Unicode haystacks. Request The type of an incoming web request. ResponseRequestId RigorousJsonCommandBuilder Runtime The Tokio runtime. ScriptedNodeVariantPolicy A direct “per-level” approach using a map of level => aggregator/dispatch/leaf probabilities. ScriptedNodeVariantPolicyBuilder Builder for ScriptedNodeVariantPolicy
. SemverVersion SemVer version as defined by https://semver.org .Sender Sends values to the associated Receiver
. Skeleton The entire skeleton, storing a list of nodes plus an optional root_id. SkeletonBuilder Builder for Skeleton
. SkeletonNodeBuilder A builder so you can still do e.g.: SkeletonValidationReport The overall validation result, containing zero or more DeviationFlag
s. SmolStr A SmolStr
is a string type that has the following properties: SmolStrBuilder A builder that can be used to efficiently build a SmolStr
. SourceFile Status Structure representing an HTTP status: an integer code. StdRng A strong, fast (amortized), non-portable RNG Stdio Describes what to do with a standard I/O stream for a child process when
passed to the stdin
, stdout
, and stderr
methods of Command
. StringSkeleton Use this object to specify our whole tree of generated data. StringSkeletonBuilder Builder for StringSkeleton
. StrippedNodeData StrippedNodeDataBuilder Builder for StrippedNodeData
. StrippedStringSkeleton We want to create a stripped version of our StringSkeleton
, called a StrippedStringSkeleton . StrippedStringSkeletonBuilder Builder for StrippedStringSkeleton
. SyntaxError Represents the result of unsuccessful tokenization, parsing
or tree validation. SyntaxText SyntaxTreeBuilder SystemMessageHeader TempDir A directory in the filesystem that is automatically deleted when
it goes out of scope. TextRange A range in text, represented as a pair of TextSize
. TextSize A measure of text length. Also, equivalently, an index into text. Timestamp A timestamp that can be encoded into a UUID. TokenPackagedForExpansion TokenText TomlEditArray A TOML Value
that contains a sequence of Value
s Track State for bookkeeping across nested deserializer calls. TreeLevelAggregate A helper struct summarizing counts at a single level in the tree.
No public fields, so we use getset to provide read-only access. TreeLevelAggregateBuilder Builder for TreeLevelAggregate
. TreeLevelSkippingStats Describes skip-related stats at a given level. No public fields. TreeLevelSkippingStatsBuilder Builder for TreeLevelSkippingStats
. TreeLevelSpecificConfiguration This struct should define level-specific overrides for breadth and density at each tree layer. TreeLevelSpecificConfigurationBuilder Builder for TreeLevelSpecificConfiguration
. TreeWeightedBranchingStats Summarizes child-count distribution stats for weighted branching validation.
No public fields; use getset
for read access. TreeWeightedBranchingStatsBuilder Builder for TreeWeightedBranchingStats
. UniqueNameEnforcer Trait for ensuring unique names across a collection or context. Uuid A Universally Unique Identifier (UUID). VecDeque A double-ended queue implemented with a growable ring buffer. WeightedBranchingConfiguration This struct should define a mean ± variance approach for branching factor,
letting you generate more natural/organic trees rather than uniform child counts. WeightedBranchingConfigurationBuilder Builder for WeightedBranchingConfiguration
. WeightedIndex A distribution using weighted sampling of discrete items. WeightedNodeVariantPolicy Probability-based selection among aggregator/dispatch/leaf, with no extra constraints. WeightedNodeVariantPolicyBuilder Builder for WeightedNodeVariantPolicy
. WeightedNodeVariantPolicyWithLimits This policy is the same as Weighted, but with built-in depth constraints to forbid aggregator or
dispatch nodes beyond a certain depth. We can use it to forbid leaves before a certain depth. WeightedNodeVariantPolicyWithLimitsBuilder Builder for WeightedNodeVariantPolicyWithLimits
. AgentCoordinateBuilderError Error type for AgentCoordinateBuilder AggregateChildSpecBuilderError Error type for AggregateChildSpecBuilder AiTreeBranchingConfidenceConfigurationBuilderError Error type for AiTreeBranchingConfidenceConfigurationBuilder AnnotatedLeafBuilderError Error type for AnnotatedLeafBuilder AnnotatedLeafHolderExpansionsBuilderError Error type for AnnotatedLeafHolderExpansionsBuilder AnnotatedLeafHolderNodeBuilderError Error type for AnnotatedLeafHolderNodeBuilder BatchChoiceBuilderError Error type for BatchChoiceBuilder BatchDownloadError BatchErrorDataBuilderError Error type for BatchErrorDataBuilder BatchErrorDetailsBuilderError Error type for BatchErrorDetailsBuilder BatchErrorFileProcessingOperation BatchErrorProcessingError BatchErrorResponseBodyBuilderError Error type for BatchErrorResponseBodyBuilder BatchExecutionResultBuilderError Error type for BatchExecutionResultBuilder BatchFileState Represents the state of batch files based on the presence of input, output, and error files. BatchFileTripleBuilderError Error type for BatchFileTripleBuilder BatchFileTripleReconciliationOperation BatchIndex Represents the type of index found in the file names. BatchIndexType BatchInputCreationError BatchInputDataBuilderError Error type for BatchInputDataBuilder BatchMessageBuilderError Error type for BatchMessageBuilder BatchMessageContentBuilderError Error type for BatchMessageContentBuilder BatchMetadataBuilderError Error type for BatchMetadataBuilder BatchMetadataError BatchOutputDataBuilderError Error type for BatchOutputDataBuilder BatchOutputProcessingError BatchProcessingError BatchReconciliationError BatchRequestRecordBuilderError Error type for BatchRequestRecordBuilder BatchResponseBody BatchResponseContentBuilderError Error type for BatchResponseContentBuilder BatchResponseRecordBuilderError Error type for BatchResponseRecordBuilder BatchSuccessResponseBodyBuilderError Error type for BatchSuccessResponseBodyBuilder BatchSuccessResponseHandlingError BatchTokenDetailsBuilderError Error type for BatchTokenDetailsBuilder BatchUsageBuilderError Error type for BatchUsageBuilder BatchValidationError BatchWorkspaceBuilderError Error type for BatchWorkspaceBuilder BatchWorkspaceError CamelCaseTokenWithCommentBuilderError Error type for CamelCaseTokenWithCommentBuilder CapstoneGenerationConfigurationBuilderError Error type for CapstoneGenerationConfigurationBuilder CapstoneMode This enum should specify how we generate “capstone” nodes per tree. Case Defines the type of casing a string can be. ChatCompletionRequestMessage ChatCompletionRequestSystemMessageContent ChatCompletionRequestUserMessageContent ClipboardSnippet Simple enum to hold whichever snippet we parsed successfully. CompareOutcome ConfigDelta Describes how to change config A → B for one specific field/feature.
If a difference is small enough to be within thresholds, no ConfigDelta
is produced. ConfigurationComplexity This enum should be set to reflect the overall complexity vs. usability level. ContentParseError CoreSkeletalAggregateNodeBuilderError Error type for CoreSkeletalAggregateNodeBuilder CoreSkeletalDispatchNodeBuilderError Error type for CoreSkeletalDispatchNodeBuilder CoreSkeletalLeafHolderNodeBuilderError Error type for CoreSkeletalLeafHolderNodeBuilder CoreSkeletalNode A single node value covering every category, used for top‑down traversal. CoreStringSkeletonBuilderError Error type for CoreStringSkeletonBuilder Cow A clone-on-write smart pointer. DeltaThresholdsBuilderError Error type for DeltaThresholdsBuilder DepthBasedNodeVariantPolicyBuilderError Error type for DepthBasedNodeVariantPolicyBuilder DetectedTreeConfigurationComplexity Potential result for a measured complexity. We might not know, so we have Unknown
. DeviationFlag Enumerates every possible way a Skeleton can deviate from GrowerTreeConfiguration,
storing only numeric data (no strings). Direction DispatchChildSpecBuilderError Error type for DispatchChildSpecBuilder DotConfig Dot
configuration.Edition ErrorKind A list specifying general categories of I/O error. ErrorSavingFailedBatchEntries ErrorType EventKind Top-level event kind. EventPrinter ExpectedContentType FileMoveError FinishReason FuzzyLoadPartiallyGrownModelError GrowerAnnotatedLeafHolderExpansionsGenerationError GrowerCoreStringSkeletonGenerationError GrowerInputError GrowerInputsBuilderError Error type for GrowerInputsBuilder GrowerLanguageModelClientError GrowerModelBuilderError Error type for GrowerModelBuilder GrowerModelGenerationError GrowerModelGenerationInvalidPartial GrowerModelWriteSkillTreeError GrowerStringSkeletonGenerationError GrowerTreeConfigurationBuilderError Error type for GrowerTreeConfigurationBuilder GrowerTreeConfigurationError GrowerTreeConfigurationGenerationError HttpMethod Enumeration of possible HTTP methods. InstructedLanguageModelAtCoordinateBuilderError Error type for InstructedLanguageModelAtCoordinateBuilder JsonParseError JsonValue Represents any valid JSON value. JustifiedCapstoneMode JustifiedConfigurationComplexity JustifiedStringSkeletonNode JustifiedSubBranchOrdering JustifiedTreeExpansionPolicy Language Enumerates languages.
This enum covers a wide range of languages, including major world languages, regional languages,
and some languages with smaller populations for inclusivity. LanguageModelApiUrl Enumeration of API URLs. LanguageModelBatchCreationError LanguageModelBatchWorkflowError LanguageModelMessageRole Enumeration of roles in a message. LanguageModelOutputFormatInstruction LanguageModelType Supported model types. LevelSkippingConfigurationBuilderError Error type for LevelSkippingConfigurationBuilder LogLevel ManualGrowerFlowCliArgsBuilderError Error type for ManualGrowerFlowCliArgsBuilder ManualGrowerFlowError Represents errors that can occur during the manual grower flow. MessageRole MockBatchClientError MockBatchConfigBuilderError Error type for MockBatchConfigBuilder MockBatchWorkspaceBuilderError Error type for MockBatchWorkspaceBuilder MockLanguageModelClientBuilderError Error type for MockLanguageModelClientBuilder NameError Custom error type for handling name-related issues. NamedChildSpecBuilderError Error type for NamedChildSpecBuilder NodeKind A small enum controlling which variant we build (Dispatch vs Aggregate vs LeafHolder). NodeOrToken NodeVariantLevelWeightsBuilderError Error type for NodeVariantLevelWeightsBuilder NodeVariantPhaseRangeBuilderError Error type for NodeVariantPhaseRangeBuilder OpenAIClientError OpenAiClientRole ParseTokenDescriptionLineError PartiallyGrownModelBuilderError Error type for PartiallyGrownModelBuilder PhasedNodeVariantPolicyBuilderError Error type for PhasedNodeVariantPolicyBuilder RecursiveMode Indicates whether only the provided directory or its sub-directories as well should be watched RigorousJsonCommandBuilderStage RustLanguage SaveLoadError ScriptedNodeVariantPolicyBuilderError Error type for ScriptedNodeVariantPolicyBuilder SkeletonBuilderError Error type for SkeletonBuilder SkeletonError Errors that may occur while building/reading/writing a Skeleton. SkeletonNode A single node in our skeleton, identified by: SkeletonToGrowerConfigError Error type for converting a Skeleton into a GrowerTreeConfiguration. SkeletonValidationError Errors that might appear while validating a Skeleton vs. the config. SkillTreeNodeKind To make this selection, categorize each type of node in our skill tree scaffold. StringSkeletonBuilderError Error type for StringSkeletonBuilder StringSkeletonError Errors that may arise when converting between string-based skeleton and numeric skeleton. StringSkeletonNode Set this object to configure a single node in the string skeleton, tagged by its role. StrippedNodeDataBuilderError Error type for StrippedNodeDataBuilder StrippedStringSkeletonBuilderError Error type for StrippedStringSkeletonBuilder SubBranchOrdering This enum indicates how we want to sort sub-branches: SyntaxKind The kind of syntax node, e.g. IDENT
, USE_KW
, or STRUCT
. TokenAtOffset There might be zero, one or two leaves at a given offset. TokenExpanderError TokenExpansionStep TokenParseError TokenizerError TomlEditItem Type representing either a value, a table, an array of tables, or none. TomlEditValue For Key
/Value pairs under a Table
header or inside another
Value TomlValue Representation of a TOML value. TreeExpansionPolicy This structure is the primary enum for controlling how we choose among Dispatch
, Aggregate
, and
LeafHolder
nodes at each level of the tree generation procedure. TreeLevelAggregateBuilderError Error type for TreeLevelAggregateBuilder TreeLevelSkippingStatsBuilderError Error type for TreeLevelSkippingStatsBuilder TreeLevelSpecificConfigurationBuilderError Error type for TreeLevelSpecificConfigurationBuilder TreeWeightedBranchingStatsBuilderError Error type for TreeWeightedBranchingStatsBuilder UuidParseError Variant The reserved variants of UUIDs. Version The version of the UUID, denoting the generating algorithm. WalkEvent WalkEvent
describes tree walking process.WeightedBranchingConfigurationBuilderError Error type for WeightedBranchingConfigurationBuilder WeightedNodeVariantPolicyBuilderError Error type for WeightedNodeVariantPolicyBuilder WeightedNodeVariantPolicyWithLimitsBuilderError Error type for WeightedNodeVariantPolicyWithLimitsBuilder WhichError DEFAULT_OUTPUT_FILE_BRIDGE The const pointer the macro references. PROCESS_ERROR_FILE_BRIDGE We expose a CONST of type BatchWorkflowProcessErrorFileFn
, so passing &PROCESS_ERROR_FILE_BRIDGE
exactly matches the trait’s needed function pointer type. AiJsonTemplate The derived code implements AiJsonTemplate
for each struct, letting you
call MyStruct::to_template()
to get a JSON “schema” describing how the
AI should produce data that matches this layout. AiJsonTemplateWithJustification Extended trait that demands both a normal AiJsonTemplate
and
a ...Justification
structure for nested usage. ApplyClipboardSnippet AsRef Used to do a cheap reference-to-reference conversion. AstNode The main trait to go from untyped SyntaxNode
to a typed ast. The
conversion itself has zero runtime cost: ast and syntax nodes have exactly
the same representation: a pointer to the tree root and a pointer to the
node itself. AstToken Like AstNode
, but wraps tokens rather than interior nodes. AsyncBufReadExt An extension trait which adds utility methods to AsyncBufRead
types. AsyncCreateWithAndValidate Trait that combines async creation with integrity validation AsyncCreateWithAndValidateEnv Trait that combines the environment creation with ValidateIntegrity
. AsyncCreateWithAndValidateFile Trait that combines file-based creation with ValidateIntegrity
. AsyncFindItems AsyncPathValidator AsyncReadExt Reads bytes from a source. AsyncTryFrom Trait for creating instances asynchronously with input X
AsyncTryFromEnv Trait for asynchronously creating Self
specifically from an environment variable name. AsyncTryFromFile Trait for asynchronously creating Self
from a filesystem path. AsyncWriteExt Writes bytes to a sink. AxisDescription A trait that describes the axis in textual form. Implementations usually
associate a descriptive string per enum variant, used for instructing
the end user or prompting an LLM how to expand that axis. AxisName A trait that describes the name of an axis. Implementations usually
associate one distinct axis name string per enum variant. BatchWorkspaceInterface BufferedSubscriber CalculateUnseenInputs Casing Describes items that can be converted into a case. CheckAndDownloadInterface CheckBatchStatusOnline CheckForAndDownloadOutputAndErrorOnline ClipboardProvider Trait for clipboard access ClockSequence A counter that can be used by versions 1 and 6 UUIDs to support
the uniqueness of timestamps. CloneAsFreshTemporary A trait defining how to “deep clone” a BatchWorkspace
into a fully fresh temporary directory,
replicating its directory structure (workdir, logs, done, etc.), as well as copying over any
existing files. CompareAggregatorPreference CompareAiConfidence CompareAllowEarlyLeaves CompareBalanceSymmetry CompareBreadth CompareCapstone CompareComplexity CompareDensity CompareDepth CompareDepthLimits CompareFullConfiguration CompareLeafGranularity CompareLevelSkipping CompareLevelSpecific ComparePartialSubbranchProbability CompareSubBranchOrdering CompareTreeExpansionPolicy CompareWeightedBranching ComputeLanguageModelCoreQuery ComputeLanguageModelRequests This is the trait we will typically need to implement manually ComputeSystemMessage Two new traits that users must implement: CreateBatch CreateLanguageModelQueryAtAgentCoordinate Debug ?
formatting.DeepClone DefaultName Trait for providing a default name. Deserialize A data structure that can be deserialized from any data format supported
by Serde. DeserializeOwned A data structure that can be deserialized without borrowing any data from
the deserializer. Display Format trait for an empty format, {}
. Distribution Types (distributions) that can be used to create a random instance of T
. DownloadErrorFile DownloadOutputFile EdgeRef An edge reference. ExecuteReconciliationOperation ExitStatusExt Unix-specific extensions to process::ExitStatus
and
ExitStatusError
. ExpandedToken This trait marks types which represent expanded tokens.
It is helpful to have a way to treat them generically FilePattern FindExistingBatchFileIndices FindSimilarTargetPath FinishProcessingUncompletedBatches Flushable FreshExecute FromStr Parse a value from a string FullBatchWorkspaceInterface GatherAllBatchTriples GetBatchFileContent GetBatchWorkspace GetDoneDirectory GetErrorFilenameAtIndex GetFailedItemsDir GetFailedJsonRepairsDir GetInputFilenameAtIndex GetLanguageModelClient GetMetadataFilenameAtIndex GetOutputFilenameAtIndex GetSystemMessageAtAgentCoordinate GetTargetDir GetTargetDirectoryFiles GetTargetPath GetTargetPathForAIExpansion GetTargetPathForAIExpansionFromSeed GetTextStoragePath GetTokenExpansionAxes GetWorkdir GrowerFlowStrategy A trait representing how we fill in any missing partial-model fields.
We can have multiple implementations of this: HasAssociatedOutputName HasAttrs HasGenericParams HasModuleItem HasName HasVisibility InferBaselineBreadth Inflector IntoEnumIterator This trait designates that an Enum
can be iterated over. It can
be auto generated using the EnumIter
derive macro. IntoLanguageModelQueryString LanguageModelBatchWorkflow Trait describing a more general “batch workflow”
specialized to GPT expansions. LanguageModelBatchWorkflowGatherResults This new trait is used to gather the final AI expansions from disk,
matching each seed item to its parsed output JSON. LanguageModelClientInterface LoadFromDirectory Trait for loading objects from a directory asynchronously. LoadFromFile LocateBatchFiles MaybeThrow MultilingualName Trait for supporting names in multiple languages. NameHistory Provides a history of names an item has had. Named Trait for getting the name of an item. NamedAlias Trait for handling multiple names or aliases. NamespaceName Trait for namespacing names. NormalizeName Trait for normalizing the case of a name (e.g., lowercase). OpenAiConfig crate::Client relies on this for every API call on OpenAI
or Azure OpenAI servicePermissionsExt Unix-specific extensions to fs::Permissions
. ProcessBatchRequests Read The Read
trait allows for reading bytes from a source. RecalculateRecommendedActions ReconcileUnprocessed Trait describing how a BatchFileTriple
can be reconciled if unprocessed. ResetName Trait for resetting the name of an item to its default. RetrieveBatchById Rng User-level interface for RNGs SaveToFile SeedableRng A random number generator that can be explicitly seeded. Serialize A data structure that can be serialized into any data format supported
by Serde. SetName Trait for setting the name of an item with error handling. SetNameWithHistory Trait for setting the name while maintaining a history of changes. SkillTreeCrateWriter StreamExt An extension trait for the Stream
trait that provides a variety of
convenient combinator functions. StructOpt A struct that is converted from command line arguments. SystemMessageGoal A trait that describes the system message goal for a given axis set.
This is typically implemented for the entire enum and returns a single,
static system message goal string for the entire type. ToByteUnit Extension trait for conversion from integer types to ByteUnit
. ToSmolStr Convert value to SmolStr
using fmt::Display
, potentially without allocating. TokenExpander This trait we use as a generic expander of tokens. It leverages a collection of
TokenExpanderAxes and has its implementation typically automatically generated by the
TokenExpansionAxis proc macro TokenExpansionAxis Trait defining the capabilities of a TokenExpansionAxis. TreeBalanceSymmetryMeasurer TreeBreadthMeasurer
TreeConfigurationComplexityMeasurer
TreeDensityMeasurer
TreeDepthMeasurer We want to define a trait hierarchy for “measuring” each portion of a GrowerTreeConfiguration
against arbitrary tree-like data structures (e.g., Skeleton
, StringSkeleton
, or others). TreeLeafGranularityMeasurer TreeLevelSkippingMeasurer
TreeLevelSpecificMeasurer
TreeSubBranchOrderingMeasurer
TreeWeightedBranchingMeasurer
TryInferAggregatorDepthLimit Infers an upper depth limit for aggregator nodes.
If no limit can be inferred, returns None
. TryInferAggregatorPreference Infers how often aggregator nodes should be preferred vs. dispatch nodes.
Returns a f32
in [0..1]
, where 0.0
means “almost never aggregator”
and 1.0
means “always aggregator,” or None
if we cannot infer. TryInferAiConfidence TryInferAllowEarlyLeaves TryInferCapstoneConfiguration TryInferConfiguration TryInferDensity Try to infer a global “children-per-node density” (u8). TryInferDepth TryInferDispatchDepthLimit Infers an upper depth limit for dispatch nodes.
If no limit can be inferred, returns None
. TryInferLeafMinDepth Infers a minimum depth required before leaf nodes can appear.
If we cannot guess, returns None
. TryInferLevelSkippingConfiguration TryInferLevelSpecificConfiguration TryInferPartialSubbranchProbability Infers the probability of including each child sub-branch partially.
The fraction is in [0..1]
, or None
if we cannot guess. TryInferSubBranchOrdering Try to pick a single, global SubBranchOrdering
by looking at each node’s detected ordering and
choosing the most‐frequent non‑None variant. TryInferTreeExpansionPolicy Infers which TreeExpansionPolicy
is most consistent with the Skeleton.
Returns None
if skeleton is empty. TryInferWeightedBranchingConfiguration UploadBatchFileCore UploadBatchFileExt ValidateIntegrity Trait for validating integrity of a component (e.g., Workspace or Crate) ValidateName Trait for validating a name, returning a Result
. WaitForBatchCompletion Watcher Type that can deliver file activity notifications Write A trait for objects which are byte-oriented sinks. aquatic_animal_skill_tree_grower_inputs arboreal_mammal_skill_tree_grower_inputs attempt_snippet_parse Tries to parse the raw clipboard as type T.
Returns:
Ok(Some(value)) if parse succeeded,
Ok(None) if it wasn’t valid at all for that type (like a total JSON parse fail),
Err(()) if it was valid JSON but fuzzy parse failed => we store it in fail-dir. basketball_aux_skill_tree_grower_inputs basketball_skill_tree_grower_inputs bat_skill_tree_grower_inputs bear_skill_tree_grower_inputs bird_skill_tree_grower_inputs build_large_skeleton Builds a skeleton with the specified number of aggregator, dispatch, and leaf nodes.
The root node’s kind is determined automatically. If aggregator_count>0
, the root is aggregator,
etc. Then we SUBTRACT 1 from that category’s count (so we don’t double‐count the root). build_node_level_map A local BFS returning node_id => level, skipping unconnected nodes. build_random_skeleton A random skeleton generator for “stress” tests. The BFS might only produce
1 or 2 levels, so it’s not guaranteed to have early leaves, etc.—that’s a random approach. build_skeleton_level_map channel Creates a new asynchronous channel, returning the sender/receiver halves. circus_skill_tree_grower_inputs compare_full_config Helper function to compare two configurations fully compute_config_delta computer_system_skill_tree_grower_inputs configure_tracing Initializes the logging subscriber. construct_batches Break requests into workable batches. create_batch_input_file create_dir_all Recursively create a directory and all of its parent components if they
are missing. create_file_logging_subscriber cross_species_skill_tree_grower_inputs cryptographic_escape_skill_tree_grower_inputs dao_business_skill_tree_grower_inputs deer_skill_tree_grower_inputs default_output_file_bridge_fn A default bridging function, if the user doesn’t specify a particular T type.
We’ll parse each line as a CamelCaseTokenWithComment
or whichever default type we prefer. deserialize_json_with_optional_fields_wrapper Attempt to deserialize json_value
into T
.
If the top‐level attempt fails, the function looks for a nested "fields"
object and tries again.
All paths are heavily traced so we can see exactly where deserialization
succeeds or fails. drone_skill_tree_grower_inputs electronic_music_skill_tree_grower_inputs elephant_skill_tree_grower_inputs extract_json_from_possible_backticks_block Extracts JSON from a content string by removing surrounding json\n and \n
markers if present,
and trims any leading or trailing whitespace from the input. extract_token_name_field Extracts the “token_name” field from a JSON object. falcon_skill_tree_grower_inputs flatten_all_fields Iteratively flattens all nested "fields"
objects in this map (and any
sub-objects), so that any key-value pairs inside "fields"
get merged
into the map that contains them. Avoids infinite recursion using
BFS plus a pointer-based visited set. fox_skill_tree_grower_inputs handle_failed_json_repair handle_finish_reason_length handle_successful_response hawk_skill_tree_grower_inputs hypnosis_skill_tree_grower_inputs init_default_file_logging init_file_logging init_test_logger init_test_logger_with_max_level_filter juggler_skill_tree_grower_inputs_A juggler_skill_tree_grower_inputs_B juggler_skill_tree_grower_inputs_C NOTE: this set is a combination of the others. it should not contain anything new lion_skill_tree_grower_inputs load_error_file ALL-OR-NOTHING loader for the error file. load_input_file ALL-OR-NOTHING loader for the input file. load_output_file ALL-OR-NOTHING loader for the output file. make_aggregate_node Helper to build a single aggregator node, ensuring name is set. make_bfs_friendly_skeleton_ok BFS with aggregator at level0, giving each aggregator 2 children at next level, etc.
If depth=0
, empty. If final level => leaf_count = density
. make_dispatch_node Helper to build a single dispatch node, ensuring name is set. make_general_bfs_skeleton A BFS for advanced usage, letting a closure decide how many children at each level. make_leaf_node Helper to build a leaf node, ensuring name is set. make_missing_root_skeleton A skeleton with no root (root_id(None)) => BFS is empty => used by tests that want “no root”. make_valid_lmb_api_request_json_mock manual_flow_try_to_fix_missing_field Called when validation of the partial model fails with a known “missing partial” error.
We query the FlowStrategy
to see if it can fill in the missing piece automatically or by prompting the user. math_skill_tree_grower_inputs maybe_write_initial_partial_model_file missing_field_rank Return an integer rank for a missing partial step:
0 => partial is not missing anything (fully valid)
1 => MissingJustifiedGrowerTreeConfiguration
2 => MissingJustifiedStringSkeleton
3 => MissingStrippedStringSkeleton
4 => MissingCoreStringSkeleton
5 => MissingAnnotatedLeafHolderExpansions otter_skill_tree_grower_inputs owl_skill_tree_grower_inputs parse_token_file precise_parse_clipboard_stripped_skeleton Helper function for “precise parse” of StrippedStringSkeleton process_batch_output_and_errors We add 'static + Send + Sync
to T
, so that storing it in an
Arc<dyn ... + Send + Sync + 'static>
is valid and the resulting
Future
can be Send
. process_error_data process_error_file This is the real async function that processes the error file for a given triple,using the list of error operations. Now uses NDJSON approach line by line. process_output_data process_output_file The core async function to process the output file for a given triple.Now we do NDJSON line-by-line parsing, just like the older batch-mode approach. process_output_file_bridge_fn The bridging function EXACTLY matches the BatchWorkflowProcessOutputFileFn
type: promote_missing_child_nodes_with_defaults This helper function scans a StringSkeleton
for any child references
(in Aggregate
or Dispatch
) whose child names do not appear as keys
in the StringSkeleton.map
. For each such missing child, we “promote” it
into a synthetic LeafHolder
entry, with default parameters (e.g.
n_leaves=9
, capstone=false
). This prevents aggregator or dispatch
children from disappearing when we later convert to a StrippedStringSkeleton
. root_with_children Root => id=0 => dispatch => children => leaf_count save_failed_entries setup_buffered_tracing setup_default_buffered_tracing setup_dynamic_tracing shelter_skill_tree_grower_inputs single_node_skeleton A single node skeleton with leaf_count
. small_business_skill_tree_grower_inputs snippet_field_rank Return a similar rank for each ClipboardSnippet variant: store_failed_snippet street_performance_skill_tree_grower_inputs tarjan_scc [Generic] Compute the strongly connected components using Tarjan’s algorithm . tempdir Create a new temporary directory. Also see tempdir_in
. three_level_chain Three-level chain => 0->1->2 => BFS => depth=3 tiger_skill_tree_grower_inputs toposort [Generic] Perform a topological sort of a directed graph. try_deserialize_with_path Attempt to deserialize val
into T
, returning an error string on failure
that includes the JSON path (e.g. .capstone.probability
). unify_complex_enum_single_variant_inplace Finally, the single public function you call on the entire Value: which Find an executable binary’s path by name. wolf_skill_tree_grower_inputs woodpecker_skill_tree_grower_inputs write_to_file Writes serialized JSON content to a file asynchronously. BatchWorkflowProcessErrorFileFn BatchWorkflowProcessOutputFileFn Bytes A 128-bit (16 byte) buffer containing the UUID. ClipboardContext DiGraph A Graph
with directed edges. DiGraphMap A GraphMap
with directed edges. FmtResult The type returned by formatter methods. LanguageModelClientArc LeafDescriptor LeafHolderDescriptor LeafHolderName LeafName PreorderWithTokens RecommendedWatcher The recommended Watcher
implementation for the current platform SyntaxElement SyntaxElementChildren SyntaxNode SyntaxNodeChildren SyntaxNodePtr A “pointer” to a SyntaxNode
, via location in the source code. SyntaxToken TokenExpansionAxes TokenQuad TomlEditDocument Deprecated Deprecated, replaced with DocumentMut
async_trait catch Attribute to generate a Catcher
and associated metadata. disable instrument Instruments a function to create and enter a tracing
span every time
the function is called. post Attribute to generate a Route
and associated metadata. traced_test AiJsonTemplate This new implementation supports: AiJsonTemplateWithJustification The main entrypoint for #[derive(AiJsonTemplateWithJustification)]
.
We generate (a) the typed justification structs/enums, and
(b) the FlatJustified expansions if desired by the test suite. Builder Create a builder struct for the deriving struct. Debug Derive macro generating an impl of the trait Debug
. Deserialize EnumIter Creates a new type that iterates over the variants of an enum. Getters LanguageModelBatchWorkflow MutGetters SaveLoad Serialize Setters StructOpt Generates the StructOpt
impl. TokenExpansionAxis OpenAIConfigInterface