List of all items
Structs
- agent::Task
- agent::TaskResult
- auth::FileAuthStorage
- auth::anthropic::AnthropicAuth
- auth::anthropic::OAuthFlow
- auth::anthropic::TokenResponse
- auth::github_copilot::GitHubCopilotAuth
- auth::manager::AuthManager
- config::AgentConfig
- config::AppConfig
- config::AuthConfig
- config::BackupConfig
- config::Config
- config::ConfigManager
- config::ContextWindowConfig
- config::CostConfig
- config::EncryptionConfig
- config::FeatureConfig
- config::IndexingConfig
- config::MemoryConfig
- config::ModelConfig
- config::ProviderConfig
- config::RateLimitConfig
- config::RetryConfig
- config::SandboxConfig
- config::SecurityConfig
- config::SessionConfig
- config::StorageConfig
- config::TimeoutConfig
- config::ToolConfig
- config::ToolSpecificConfig
- events::EventBus
- events::events::DataRetrieved
- events::events::DataStored
- events::events::ErrorOccurred
- events::events::MessageReceived
- events::events::MessageSent
- events::events::ProviderConnected
- events::events::ProviderDisconnected
- events::events::SessionCreated
- events::events::SessionEnded
- events::events::SystemShutdown
- events::events::SystemStarted
- events::events::ToolExecuted
- events::events::ToolFailed
- llm::GenerateOptions
- llm::GenerateResult
- llm::ImageData
- llm::Message
- llm::StreamChunk
- llm::StreamOptions
- llm::ToolCall
- llm::ToolDefinition
- llm::Usage
- llm::anthropic::AnthropicModel
- llm::anthropic::AnthropicModelWithProvider
- llm::anthropic::AnthropicModelWrapper
- llm::anthropic::AnthropicProvider
- llm::github_copilot::GitHubCopilotModel
- llm::github_copilot::GitHubCopilotModelWithProvider
- llm::github_copilot::GitHubCopilotProvider
- llm::openai::AzureOpenAIModelWithProvider
- llm::openai::AzureOpenAIProvider
- llm::openai::OpenAIModel
- llm::openai::OpenAIModelWithProvider
- llm::openai::OpenAIProvider
- llm::provider::Cost
- llm::provider::CurrentUsage
- llm::provider::Limits
- llm::provider::ModelCapabilities
- llm::provider::ModelConfig
- llm::provider::ModelInfo
- llm::provider::ModelLimits
- llm::provider::ModelMetadata
- llm::provider::ModelPricing
- llm::provider::ModelUsage
- llm::provider::PeriodUsage
- llm::provider::ProviderConfig
- llm::provider::ProviderHealth
- llm::provider::ProviderRegistry
- llm::provider::RateLimitInfo
- llm::provider::RetryConfig
- llm::provider::UsageStats
- llm::registry::LLMRegistry
- memory::MemoryMetadata
- memory::MemoryValue
- permission::Permission
- permission::PermissionContext
- permission::PermissionManager
- planner::Dependency
- planner::Plan
- planner::PlanContext
- planner::Progress
- planner::Step
- runtime::fs::DirBuilder
- runtime::fs::DirEntry
- runtime::fs::File
- runtime::fs::OpenOptions
- runtime::fs::ReadDir
- runtime::io::BufReader
- runtime::io::BufStream
- runtime::io::BufWriter
- runtime::io::DuplexStream
- runtime::io::Empty
- runtime::io::Error
- runtime::io::Interest
- runtime::io::Join
- runtime::io::Lines
- runtime::io::ReadBuf
- runtime::io::ReadHalf
- runtime::io::Ready
- runtime::io::Repeat
- runtime::io::SimplexStream
- runtime::io::Sink
- runtime::io::Split
- runtime::io::Stderr
- runtime::io::Stdin
- runtime::io::Stdout
- runtime::io::Take
- runtime::io::WriteHalf
- runtime::io::unix::AsyncFd
- runtime::io::unix::AsyncFdReadyGuard
- runtime::io::unix::AsyncFdReadyMutGuard
- runtime::io::unix::AsyncFdTryNewError
- runtime::io::unix::TryIoError
- runtime::net::TcpListener
- runtime::net::TcpSocket
- runtime::net::TcpStream
- runtime::net::UdpSocket
- runtime::net::UnixDatagram
- runtime::net::UnixListener
- runtime::net::UnixSocket
- runtime::net::UnixStream
- runtime::net::tcp::OwnedReadHalf
- runtime::net::tcp::OwnedWriteHalf
- runtime::net::tcp::ReadHalf
- runtime::net::tcp::ReuniteError
- runtime::net::tcp::WriteHalf
- runtime::net::unix::OwnedReadHalf
- runtime::net::unix::OwnedWriteHalf
- runtime::net::unix::ReadHalf
- runtime::net::unix::ReuniteError
- runtime::net::unix::SocketAddr
- runtime::net::unix::UCred
- runtime::net::unix::WriteHalf
- runtime::net::unix::pipe::OpenOptions
- runtime::net::unix::pipe::Receiver
- runtime::net::unix::pipe::Sender
- runtime::process::Child
- runtime::process::ChildStderr
- runtime::process::ChildStdin
- runtime::process::ChildStdout
- runtime::process::Command
- runtime::runtime::Builder
- runtime::runtime::EnterGuard
- runtime::runtime::Handle
- runtime::runtime::Runtime
- runtime::runtime::RuntimeMetrics
- runtime::runtime::TryCurrentError
- runtime::signal::unix::Signal
- runtime::signal::unix::SignalKind
- runtime::sync::AcquireError
- runtime::sync::Barrier
- runtime::sync::BarrierWaitResult
- runtime::sync::MappedMutexGuard
- runtime::sync::Mutex
- runtime::sync::MutexGuard
- runtime::sync::Notify
- runtime::sync::OnceCell
- runtime::sync::OwnedMappedMutexGuard
- runtime::sync::OwnedMutexGuard
- runtime::sync::OwnedRwLockMappedWriteGuard
- runtime::sync::OwnedRwLockReadGuard
- runtime::sync::OwnedRwLockWriteGuard
- runtime::sync::OwnedSemaphorePermit
- runtime::sync::RwLock
- runtime::sync::RwLockMappedWriteGuard
- runtime::sync::RwLockReadGuard
- runtime::sync::RwLockWriteGuard
- runtime::sync::Semaphore
- runtime::sync::SemaphorePermit
- runtime::sync::TryLockError
- runtime::sync::broadcast::Receiver
- runtime::sync::broadcast::Sender
- runtime::sync::broadcast::WeakSender
- runtime::sync::broadcast::error::SendError
- runtime::sync::futures::Notified
- runtime::sync::mpsc::OwnedPermit
- runtime::sync::mpsc::Permit
- runtime::sync::mpsc::PermitIterator
- runtime::sync::mpsc::Receiver
- runtime::sync::mpsc::Sender
- runtime::sync::mpsc::UnboundedReceiver
- runtime::sync::mpsc::UnboundedSender
- runtime::sync::mpsc::WeakSender
- runtime::sync::mpsc::WeakUnboundedSender
- runtime::sync::mpsc::error::SendError
- runtime::sync::oneshot::Receiver
- runtime::sync::oneshot::Sender
- runtime::sync::oneshot::error::RecvError
- runtime::sync::watch::Receiver
- runtime::sync::watch::Ref
- runtime::sync::watch::Sender
- runtime::sync::watch::error::RecvError
- runtime::sync::watch::error::SendError
- runtime::task::AbortHandle
- runtime::task::Id
- runtime::task::JoinError
- runtime::task::JoinHandle
- runtime::task::JoinSet
- runtime::task::LocalEnterGuard
- runtime::task::LocalKey
- runtime::task::LocalSet
- runtime::task::Unconstrained
- runtime::task::coop::Unconstrained
- runtime::task::futures::TaskLocalFuture
- runtime::time::Duration
- runtime::time::Instant
- runtime::time::Interval
- runtime::time::Sleep
- runtime::time::Timeout
- runtime::time::error::Elapsed
- runtime::time::error::Error
- session::Message
- session::MessageMetadata
- session::Session
- session::SessionMetadata
- session::TokenUsage
- session::ToolCall
- session::manager::SessionInfo
- session::manager::SessionManager
- storage::FileStorage
- sync::CircuitBreaker
- sync::Debouncer
- sync::RateLimiter
- sync::TimeoutWrapper
- tool::ToolConfig
- tool::ToolContext
- tool::ToolDefinition
- tool::ToolRegistry
- tool::ToolRegistryFactory
- tool::ToolResult
- tool::audit::AuditLogEntry
- tool::audit::AuditLogger
- tool::audit::AuditStatistics
- tool::audit::SystemContext
- tool::bash::BashTool
- tool::edit::EditTool
- tool::edit::IndentationFlexibleReplacer
- tool::edit::LineTrimmedReplacer
- tool::edit::ReplaceResult
- tool::edit::SimpleReplacer
- tool::edit::WhitespaceNormalizedReplacer
- tool::file_watcher::FileChangeEvent
- tool::file_watcher::FileWatcherTool
- tool::glob::GlobAdvancedTool
- tool::glob::GlobTool
- tool::grep::GrepTool
- tool::http::CookieInterceptor
- tool::http::CookieJar
- tool::http::HttpClientBuilder
- tool::http::HttpRequest
- tool::http::HttpResponse
- tool::http::NativeHttpClient
- tool::http::RateLimiter
- tool::http::UserAgentInterceptor
- tool::multiedit::EditOperation
- tool::multiedit::MultiEditTool
- tool::permission::AutoApprovePermissionProvider
- tool::permission::InteractivePermissionProvider
- tool::permission::PermissionManager
- tool::permission::PermissionRequest
- tool::read::ReadTool
- tool::task::AgentRegistry
- tool::task::QueuedTask
- tool::task::TaskParams
- tool::task::TaskQueue
- tool::task::TaskTool
- tool::todo::Task
- tool::todo::TaskDependency
- tool::todo::TaskList
- tool::todo::TaskMetadata
- tool::todo::TaskStats
- tool::todo::TaskStorage
- tool::todo::TodoTool
- tool::web::WebFetchTool
- tool::web::WebSearchTool
- tool::write::WriteTool
Enums
- agent::TaskStatus
- auth::AuthCredentials
- auth::github_copilot::GitHubCopilotAuthResult
- auth::github_copilot::GitHubCopilotError
- error::Error
- events::EventPriority
- llm::FinishReason
- llm::MessageContent
- llm::MessagePart
- llm::MessageRole
- llm::anthropic::AnthropicMode
- llm::github_copilot::GitHubCopilotError
- llm::provider::ModelStatus
- llm::provider::ProviderSource
- llm::provider::ProviderStatus
- permission::PermissionConstraint
- permission::PermissionLevel
- planner::DependencyType
- runtime::io::ErrorKind
- runtime::io::SeekFrom
- runtime::runtime::RuntimeFlavor
- runtime::sync::SetError
- runtime::sync::TryAcquireError
- runtime::sync::broadcast::error::RecvError
- runtime::sync::broadcast::error::TryRecvError
- runtime::sync::mpsc::error::SendTimeoutError
- runtime::sync::mpsc::error::TryRecvError
- runtime::sync::mpsc::error::TrySendError
- runtime::sync::oneshot::error::TryRecvError
- runtime::time::MissedTickBehavior
- session::MessageRole
- storage::StorageError
- sync::CircuitState
- tool::PermissionProviderConfig
- tool::SecurityMode
- tool::ToolError
- tool::audit::ExecutionStatus
- tool::audit::OperationType
- tool::http::HttpMethod
- tool::permission::PermissionResult
- tool::permission::RiskLevel
- tool::task::TaskPriority
- tool::todo::DependencyType
- tool::todo::TaskPriority
- tool::todo::TaskStatus
Traits
- agent::Agent
- auth::Auth
- auth::AuthStorage
- events::Event
- events::EventHandler
- llm::LanguageModel
- llm::provider::Model
- llm::provider::Provider
- memory::Memory
- planner::Planner
- runtime::io::AsyncBufRead
- runtime::io::AsyncBufReadExt
- runtime::io::AsyncRead
- runtime::io::AsyncReadExt
- runtime::io::AsyncSeek
- runtime::io::AsyncSeekExt
- runtime::io::AsyncWrite
- runtime::io::AsyncWriteExt
- runtime::net::ToSocketAddrs
- storage::Storage
- tool::Tool
- tool::edit::ReplacementStrategy
- tool::http::HttpClient
- tool::http::HttpInterceptor
- tool::permission::PermissionProvider
Macros
Attribute Macros
Functions
- llm::provider::retry_with_backoff
- llm::registry::create_default_registry
- llm::registry::create_registry_with_models_dev
- prompts::get_system_prompt
- runtime::fs::canonicalize
- runtime::fs::copy
- runtime::fs::create_dir
- runtime::fs::create_dir_all
- runtime::fs::hard_link
- runtime::fs::metadata
- runtime::fs::read
- runtime::fs::read_dir
- runtime::fs::read_link
- runtime::fs::read_to_string
- runtime::fs::remove_dir
- runtime::fs::remove_dir_all
- runtime::fs::remove_file
- runtime::fs::rename
- runtime::fs::set_permissions
- runtime::fs::symlink
- runtime::fs::symlink_metadata
- runtime::fs::try_exists
- runtime::fs::write
- runtime::io::copy
- runtime::io::copy_bidirectional
- runtime::io::copy_bidirectional_with_sizes
- runtime::io::copy_buf
- runtime::io::duplex
- runtime::io::empty
- runtime::io::join
- runtime::io::repeat
- runtime::io::simplex
- runtime::io::sink
- runtime::io::split
- runtime::io::stderr
- runtime::io::stdin
- runtime::io::stdout
- runtime::net::lookup_host
- runtime::net::unix::pipe::pipe
- runtime::signal::ctrl_c
- runtime::signal::unix::signal
- runtime::spawn
- runtime::sync::broadcast::channel
- runtime::sync::mpsc::channel
- runtime::sync::mpsc::unbounded_channel
- runtime::sync::oneshot::channel
- runtime::sync::watch::channel
- runtime::task::block_in_place
- runtime::task::consume_budget
- runtime::task::coop::consume_budget
- runtime::task::coop::has_budget_remaining
- runtime::task::coop::unconstrained
- runtime::task::id
- runtime::task::spawn
- runtime::task::spawn_blocking
- runtime::task::spawn_local
- runtime::task::try_id
- runtime::task::unconstrained
- runtime::task::yield_now
- runtime::time::interval
- runtime::time::interval_at
- runtime::time::sleep
- runtime::time::sleep_until
- runtime::time::timeout
- runtime::time::timeout_at
- tool::audit::operation_type_from_tool
- tool::http::default_user_agent
- tool::http::is_safe_url
- tool::http::sanitize_url
- tool::permission::create_permission_request
- utils::config::cache_dir
- utils::config::config_dir
- utils::config::data_dir
- utils::config::ensure_app_dirs
- utils::fs::ensure_dir
- utils::fs::file_extension
- utils::fs::file_size
- utils::fs::is_binary_file
- utils::fs::is_safe_path
- utils::fs::safe_canonicalize
- utils::hash::content_hash
- utils::hash::sha256
- utils::hash::sha256_string
- utils::memory::format_bytes
- utils::memory::parse_bytes
- utils::process::command_exists
- utils::process::escape_shell_arg
- utils::process::get_shell
- utils::string::camel_to_snake
- utils::string::escape_json
- utils::string::extract_context
- utils::string::sanitize_filename
- utils::string::truncate
- utils::time::format_duration
- utils::time::now_timestamp
- utils::time::parse_duration
- utils::url::extract_domain
- utils::url::is_valid_url
- utils::url::join_path
- utils::validation::is_valid_api_key
- utils::validation::is_valid_email
- utils::validation::is_valid_model_name
- utils::validation::is_valid_session_id
Type Aliases
- error::Result
- runtime::Handle
- runtime::Runtime
- runtime::io::Result
- runtime::net::unix::gid_t
- runtime::net::unix::pid_t
- runtime::net::unix::uid_t
- sync::AsyncMutex
- sync::AsyncRwLock
Constants
- VERSION
- features::HAS_ADVANCED_CRYPTO
- features::HAS_ANTHROPIC
- features::HAS_COMPRESSION
- features::HAS_FILE_WATCHING
- features::HAS_MISTRAL
- features::HAS_OPENAI
- features::HAS_TOKIO
- features::HAS_WASM
- features::HAS_WEB
- prompts::ANTHROPIC_IDENTITY
- prompts::BEAST_MODE_PROMPT
- prompts::INITIALIZE_PROMPT
- prompts::PLAN_MODE_PROMPT
- prompts::SUMMARIZE_PROMPT
- prompts::SYSTEM_PROMPT
- prompts::TITLE_PROMPT