List of all items
Structs
- application::dto::event_dto::EventDto
- application::dto::event_dto::IngestEventRequest
- application::dto::event_dto::IngestEventResponse
- application::dto::event_dto::QueryEventsRequest
- application::dto::event_dto::QueryEventsResponse
- application::dto::projection_dto::CreateProjectionRequest
- application::dto::projection_dto::CreateProjectionResponse
- application::dto::projection_dto::ListProjectionsResponse
- application::dto::projection_dto::PauseProjectionRequest
- application::dto::projection_dto::ProjectionConfigDto
- application::dto::projection_dto::ProjectionDto
- application::dto::projection_dto::ProjectionStatsDto
- application::dto::projection_dto::RebuildProjectionRequest
- application::dto::projection_dto::StartProjectionRequest
- application::dto::projection_dto::UpdateProjectionRequest
- application::dto::schema_dto::ListSchemasResponse
- application::dto::schema_dto::RegisterSchemaRequest
- application::dto::schema_dto::RegisterSchemaResponse
- application::dto::schema_dto::SchemaDto
- application::dto::schema_dto::UpdateSchemaRequest
- application::dto::schema_dto::ValidateEventRequest
- application::dto::schema_dto::ValidateEventResponse
- application::dto::tenant_dto::CreateTenantRequest
- application::dto::tenant_dto::CreateTenantResponse
- application::dto::tenant_dto::ListTenantsResponse
- application::dto::tenant_dto::TenantDto
- application::dto::tenant_dto::TenantQuotasDto
- application::dto::tenant_dto::UpdateTenantRequest
- application::dto::tenant_dto::UpdateTenantResponse
- application::services::analytics::AnalyticsEngine
- application::services::analytics::CorrelationExample
- application::services::analytics::CorrelationRequest
- application::services::analytics::CorrelationResponse
- application::services::analytics::EntityCount
- application::services::analytics::EventFrequencyRequest
- application::services::analytics::EventFrequencyResponse
- application::services::analytics::EventTypeCount
- application::services::analytics::StatsSummaryRequest
- application::services::analytics::StatsSummaryResponse
- application::services::analytics::TimeBucket
- application::services::analytics::TimeRange
- application::services::audit_logger::AuditLogBuilder
- application::services::audit_logger::AuditLogEntry
- application::services::audit_logger::AuditLogger
- application::services::audit_logger::RequestContext
- application::services::pipeline::Pipeline
- application::services::pipeline::PipelineConfig
- application::services::pipeline::PipelineManager
- application::services::pipeline::PipelineStats
- application::services::pipeline::StatefulOperator
- application::services::pipeline::WindowConfig
- application::services::projection::EntitySnapshotProjection
- application::services::projection::EventCounterProjection
- application::services::projection::ProjectionManager
- application::services::replay::ReplayConfig
- application::services::replay::ReplayManager
- application::services::replay::ReplayProgress
- application::services::replay::StartReplayRequest
- application::services::replay::StartReplayResponse
- application::services::schema::CompatibilityCheckResult
- application::services::schema::RegisterSchemaRequest
- application::services::schema::RegisterSchemaResponse
- application::services::schema::Schema
- application::services::schema::SchemaRegistry
- application::services::schema::SchemaRegistryConfig
- application::services::schema::SchemaRegistryStats
- application::services::schema::ValidateEventRequest
- application::services::schema::ValidateEventResponse
- application::services::tenant_service::Tenant
- application::services::tenant_service::TenantManager
- application::services::tenant_service::TenantQuotas
- application::services::tenant_service::TenantUsage
- application::use_cases::ingest_event::IngestEventUseCase
- application::use_cases::ingest_event::IngestEventsBatchUseCase
- application::use_cases::manage_projection::CreateProjectionUseCase
- application::use_cases::manage_projection::ListProjectionsUseCase
- application::use_cases::manage_projection::PauseProjectionUseCase
- application::use_cases::manage_projection::RebuildProjectionUseCase
- application::use_cases::manage_projection::StartProjectionUseCase
- application::use_cases::manage_projection::StopProjectionUseCase
- application::use_cases::manage_projection::UpdateProjectionUseCase
- application::use_cases::manage_schema::CreateNextSchemaVersionUseCase
- application::use_cases::manage_schema::ListSchemasUseCase
- application::use_cases::manage_schema::RegisterSchemaUseCase
- application::use_cases::manage_schema::UpdateSchemaMetadataUseCase
- application::use_cases::manage_tenant::ActivateTenantUseCase
- application::use_cases::manage_tenant::CreateTenantUseCase
- application::use_cases::manage_tenant::DeactivateTenantUseCase
- application::use_cases::manage_tenant::ListTenantsUseCase
- application::use_cases::manage_tenant::UpdateTenantUseCase
- application::use_cases::query_events::QueryEventsUseCase
- domain::entities::audit_event::AuditEvent
- domain::entities::audit_event::AuditEventId
- domain::entities::event::Event
- domain::entities::event_stream::EventStream
- domain::entities::projection::Projection
- domain::entities::projection::ProjectionConfig
- domain::entities::projection::ProjectionStats
- domain::entities::schema::Schema
- domain::entities::tenant::Tenant
- domain::entities::tenant::TenantQuotas
- domain::entities::tenant::TenantUsage
- domain::repositories::audit_event_repository::AuditEventQuery
- domain::repositories::tenant_repository::TenantQuery
- domain::value_objects::entity_id::EntityId
- domain::value_objects::event_type::EventType
- domain::value_objects::partition_key::PartitionKey
- domain::value_objects::tenant_id::TenantId
- infrastructure::cluster::node_registry::Node
- infrastructure::cluster::node_registry::NodeRegistry
- infrastructure::cluster::request_router::RequestRouter
- infrastructure::config::config::AuthConfig
- infrastructure::config::config::BackupConfigFile
- infrastructure::config::config::Config
- infrastructure::config::config::LoggingConfig
- infrastructure::config::config::MetricsConfig
- infrastructure::config::config::RateLimitConfigFile
- infrastructure::config::config::ServerConfig
- infrastructure::config::config::StorageConfig
- infrastructure::observability::metrics::MetricsRegistry
- infrastructure::persistence::arena_pool::ArenaPoolStats
- infrastructure::persistence::arena_pool::PooledArena
- infrastructure::persistence::arena_pool::ScopedArena
- infrastructure::persistence::arena_pool::SizedBufferPool
- infrastructure::persistence::backup::BackupConfig
- infrastructure::persistence::backup::BackupManager
- infrastructure::persistence::backup::BackupMetadata
- infrastructure::persistence::batch_processor::ArenaBatchBuffer
- infrastructure::persistence::batch_processor::BatchProcessor
- infrastructure::persistence::batch_processor::BatchProcessorConfig
- infrastructure::persistence::batch_processor::BatchProcessorStats
- infrastructure::persistence::batch_processor::BatchResult
- infrastructure::persistence::batch_processor::RawEventData
- infrastructure::persistence::compaction::CompactionConfig
- infrastructure::persistence::compaction::CompactionManager
- infrastructure::persistence::compaction::CompactionResult
- infrastructure::persistence::compaction::CompactionStats
- infrastructure::persistence::compaction::CompactionTask
- infrastructure::persistence::index::EventIndex
- infrastructure::persistence::index::IndexEntry
- infrastructure::persistence::index::IndexStats
- infrastructure::persistence::lock_free::metrics::LockFreeMetrics
- infrastructure::persistence::lock_free::metrics::MetricsSnapshot
- infrastructure::persistence::lock_free::queue::LockFreeEventQueue
- infrastructure::persistence::lock_free::sharded_queue::ShardedEventQueue
- infrastructure::persistence::lock_free::sharded_queue::ShardedQueueStats
- infrastructure::persistence::performance::BatchWriter
- infrastructure::persistence::performance::MemoryPool
- infrastructure::persistence::performance::PerformanceMetrics
- infrastructure::persistence::simd_json::BatchEventParser
- infrastructure::persistence::simd_json::SimdJsonParser
- infrastructure::persistence::simd_json::SimdJsonStats
- infrastructure::persistence::simd_json::ZeroCopyJson
- infrastructure::persistence::snapshot::CreateSnapshotRequest
- infrastructure::persistence::snapshot::CreateSnapshotResponse
- infrastructure::persistence::snapshot::ListSnapshotsRequest
- infrastructure::persistence::snapshot::ListSnapshotsResponse
- infrastructure::persistence::snapshot::Snapshot
- infrastructure::persistence::snapshot::SnapshotConfig
- infrastructure::persistence::snapshot::SnapshotInfo
- infrastructure::persistence::snapshot::SnapshotManager
- infrastructure::persistence::snapshot::SnapshotMetadata
- infrastructure::persistence::snapshot::SnapshotStats
- infrastructure::persistence::storage::ParquetStorage
- infrastructure::persistence::storage::StorageStats
- infrastructure::persistence::storage_integrity::IntegrityCheckResult
- infrastructure::persistence::storage_integrity::StorageIntegrity
- infrastructure::persistence::wal::WALConfig
- infrastructure::persistence::wal::WALEntry
- infrastructure::persistence::wal::WALStats
- infrastructure::persistence::wal::WriteAheadLog
- infrastructure::repositories::in_memory_audit_repository::InMemoryAuditRepository
- infrastructure::repositories::in_memory_event_stream_repository::InMemoryEventStreamRepository
- infrastructure::repositories::in_memory_tenant_repository::InMemoryTenantRepository
- infrastructure::security::auth::ApiKey
- infrastructure::security::auth::AuthManager
- infrastructure::security::auth::Claims
- infrastructure::security::auth::User
- infrastructure::security::ip_filter::FilterResult
- infrastructure::security::ip_filter::IpFilter
- infrastructure::security::ip_filter::IpFilterStats
- infrastructure::security::middleware::Admin
- infrastructure::security::middleware::AuthContext
- infrastructure::security::middleware::AuthError
- infrastructure::security::middleware::AuthState
- infrastructure::security::middleware::Authenticated
- infrastructure::security::middleware::IpFilterState
- infrastructure::security::middleware::OptionalAuth
- infrastructure::security::middleware::RateLimitState
- infrastructure::security::middleware::RequestId
- infrastructure::security::middleware::SecurityConfig
- infrastructure::security::middleware::SecurityState
- infrastructure::security::middleware::TenantContext
- infrastructure::security::middleware::TenantState
- infrastructure::security::rate_limit::RateLimitConfig
- infrastructure::security::rate_limit::RateLimitResult
- infrastructure::security::rate_limit::RateLimitStats
- infrastructure::security::rate_limit::RateLimiter
- infrastructure::web::api::BulkGetStateRequest
- infrastructure::web::api::EntityStateParams
- infrastructure::web::api::GetSchemaParams
- infrastructure::web::api::SaveProjectionStateRequest
- infrastructure::web::api::SetCompatibilityRequest
- infrastructure::web::api_v1::AppState
- infrastructure::web::auth_api::ApiKeyInfo
- infrastructure::web::auth_api::CreateApiKeyRequest
- infrastructure::web::auth_api::CreateApiKeyResponse
- infrastructure::web::auth_api::LoginRequest
- infrastructure::web::auth_api::LoginResponse
- infrastructure::web::auth_api::RegisterRequest
- infrastructure::web::auth_api::RegisterResponse
- infrastructure::web::auth_api::UserInfo
- infrastructure::web::tenant_api::CreateTenantRequest
- infrastructure::web::tenant_api::TenantResponse
- infrastructure::web::tenant_api::UpdateQuotasRequest
- infrastructure::web::websocket::EventFilters
- infrastructure::web::websocket::WebSocketManager
- infrastructure::web::websocket::WebSocketStats
- security::adaptive_rate_limit::AdaptiveLimitStats
- security::adaptive_rate_limit::AdaptiveRateLimitConfig
- security::adaptive_rate_limit::AdaptiveRateLimiter
- security::adaptive_rate_limit::AdaptiveRateLimiterStats
- security::adaptive_rate_limit::SystemLoad
- security::anomaly_detection::AnomalyDetectionConfig
- security::anomaly_detection::AnomalyDetector
- security::anomaly_detection::AnomalyResult
- security::anomaly_detection::DetectionStats
- security::automation::CiCdIntegration
- security::automation::ScanSummary
- security::automation::SecurityFinding
- security::automation::SecurityScanConfig
- security::automation::SecurityScanResult
- security::automation::SecurityScanner
- security::encryption::EncryptedData
- security::encryption::EncryptionConfig
- security::encryption::EncryptionStats
- security::encryption::FieldEncryption
- security::kms::EnvelopeEncryptedData
- security::kms::KeyMetadata
- security::kms::KmsConfig
- security::kms::KmsManager
- security::kms::LocalKms
- store::EventStore
- store::EventStoreConfig
- store::StoreStats
Enums
- application::dto::projection_dto::ProjectionStatusDto
- application::dto::projection_dto::ProjectionTypeDto
- application::dto::schema_dto::CompatibilityModeDto
- application::services::analytics::TimeWindow
- application::services::pipeline::PipelineOperator
- application::services::pipeline::WindowType
- application::services::replay::ReplayStatus
- application::services::schema::CompatibilityMode
- domain::entities::audit_event::Actor
- domain::entities::audit_event::AuditAction
- domain::entities::audit_event::AuditCategory
- domain::entities::audit_event::AuditOutcome
- domain::entities::projection::ProjectionStatus
- domain::entities::projection::ProjectionType
- domain::entities::schema::CompatibilityMode
- domain::entities::tenant::QuotaResource
- error::AllSourceError
- infrastructure::config::config::CompressionType
- infrastructure::config::config::LogFormat
- infrastructure::config::config::LogLevel
- infrastructure::config::config::LogOutput
- infrastructure::config::config::RateLimitTier
- infrastructure::persistence::backup::BackupType
- infrastructure::persistence::compaction::CompactionStrategy
- infrastructure::persistence::simd_json::SimdJsonError
- infrastructure::persistence::snapshot::SnapshotType
- infrastructure::security::auth::Permission
- infrastructure::security::auth::Role
- infrastructure::security::ip_filter::FilterAction
- infrastructure::security::middleware::FrameOptions
- infrastructure::security::middleware::IpFilterError
- infrastructure::security::middleware::RateLimitError
- infrastructure::security::middleware::TenantError
- security::anomaly_detection::AnomalyType
- security::anomaly_detection::RecommendedAction
- security::automation::FindingCategory
- security::automation::ScanStatus
- security::automation::Severity
- security::encryption::EncryptionAlgorithm
- security::kms::KeyAlgorithm
- security::kms::KeyPurpose
- security::kms::KeyStatus
- security::kms::KmsProvider
Traits
- application::services::projection::Projection
- domain::repositories::audit_event_repository::AuditEventRepository
- domain::repositories::event_repository::EventReader
- domain::repositories::event_repository::EventRepository
- domain::repositories::event_repository::EventWriter
- domain::repositories::event_stream_repository::EventStreamReader
- domain::repositories::event_stream_repository::EventStreamRepository
- domain::repositories::event_stream_repository::EventStreamWriter
- domain::repositories::tenant_repository::TenantRepository
- security::encryption::Encryptable
- security::kms::KmsClient
Macros
Functions
- infrastructure::persistence::arena_pool::arena_stats
- infrastructure::persistence::arena_pool::get_arena
- infrastructure::persistence::arena_pool::get_arena_with_capacity
- infrastructure::persistence::arena_pool::reset_stats
- infrastructure::security::middleware::auth_middleware
- infrastructure::security::middleware::ip_filter_middleware
- infrastructure::security::middleware::optional_auth_middleware
- infrastructure::security::middleware::rate_limit_middleware
- infrastructure::security::middleware::request_id_middleware
- infrastructure::security::middleware::security_headers_middleware
- infrastructure::security::middleware::tenant_isolation_middleware
- infrastructure::web::api::all_pipeline_stats
- infrastructure::web::api::analytics_correlation
- infrastructure::web::api::analytics_frequency
- infrastructure::web::api::analytics_summary
- infrastructure::web::api::bulk_get_projection_states
- infrastructure::web::api::cancel_replay
- infrastructure::web::api::compaction_stats
- infrastructure::web::api::create_snapshot
- infrastructure::web::api::delete_replay
- infrastructure::web::api::events_websocket
- infrastructure::web::api::get_entity_snapshot
- infrastructure::web::api::get_entity_state
- infrastructure::web::api::get_latest_snapshot
- infrastructure::web::api::get_pipeline
- infrastructure::web::api::get_pipeline_stats
- infrastructure::web::api::get_projection
- infrastructure::web::api::get_projection_state
- infrastructure::web::api::get_replay_progress
- infrastructure::web::api::get_schema
- infrastructure::web::api::get_stats
- infrastructure::web::api::health
- infrastructure::web::api::ingest_event
- infrastructure::web::api::list_pipelines
- infrastructure::web::api::list_projections
- infrastructure::web::api::list_replays
- infrastructure::web::api::list_schema_versions
- infrastructure::web::api::list_snapshots
- infrastructure::web::api::list_subjects
- infrastructure::web::api::prometheus_metrics
- infrastructure::web::api::query_events
- infrastructure::web::api::register_pipeline
- infrastructure::web::api::register_schema
- infrastructure::web::api::remove_pipeline
- infrastructure::web::api::reset_pipeline
- infrastructure::web::api::save_projection_state
- infrastructure::web::api::serve
- infrastructure::web::api::set_compatibility_mode
- infrastructure::web::api::start_replay
- infrastructure::web::api::trigger_compaction
- infrastructure::web::api::validate_event_schema
- infrastructure::web::api_v1::serve_v1
- infrastructure::web::auth_api::create_api_key_handler
- infrastructure::web::auth_api::delete_user_handler
- infrastructure::web::auth_api::list_api_keys_handler
- infrastructure::web::auth_api::list_users_handler
- infrastructure::web::auth_api::login_handler
- infrastructure::web::auth_api::me_handler
- infrastructure::web::auth_api::register_handler
- infrastructure::web::auth_api::revoke_api_key_handler
- infrastructure::web::tenant_api::activate_tenant_handler
- infrastructure::web::tenant_api::create_tenant_handler
- infrastructure::web::tenant_api::deactivate_tenant_handler
- infrastructure::web::tenant_api::delete_tenant_handler
- infrastructure::web::tenant_api::get_tenant_handler
- infrastructure::web::tenant_api::get_tenant_stats_handler
- infrastructure::web::tenant_api::list_tenants_handler
- infrastructure::web::tenant_api::update_quotas_handler
- security::encryption::decrypt_json_value
- security::encryption::encrypt_json_value