feat(deepql): add initial setup for deepql #215
GitHub Actions / GO Tests
succeeded
Mar 25, 2024 in 0s
665 passed, 0 failed and 0 skipped
✅ report.xml
665 tests were completed in 406s with 665 passed, 0 failed and 0 skipped.
✅ github.com/intergral/deep/cmd/deep/app
✅ TestConfig_CheckConfig
✅ TestConfig_CheckConfig/check_default_cfg_and_expect_no_warnings
✅ TestConfig_CheckConfig/hit_all_except_local_backend_warnings
✅ TestConfig_CheckConfig/hit_local_backend_warnings
✅ TestConfig_CheckConfig/warnings_for_v2_settings_when_they_drift_from_default
✅ github.com/intergral/deep/modules/distributor
✅ TestDistributor
✅ TestDistributor/[0](samples=10)
✅ TestDistributor/[1](samples=100)
✅ TestLogSnapshots
✅ TestLogSnapshots/[0]_TestLogSnapshots_LogReceivedSnapshots=false_LogReceivedSnapshotsEnabled=false_filterByStatusError=false_includeAllAttributes=false
✅ TestLogSnapshots/[1]_TestLogSnapshots_LogReceivedSnapshots=false_LogReceivedSnapshotsEnabled=true_filterByStatusError=false_includeAllAttributes=false
✅ TestForwarder
✅ TestForwarder_shutdown
✅ TestIngestionRateStrategy
✅ TestIngestionRateStrategy/local_rate_limiter_should_just_return_configured_limits
✅ TestIngestionRateStrategy/global_rate_limiter_should_share_the_limit_across_the_number_of_distributors
✅ github.com/intergral/deep/modules/distributor/forwarder
✅ TestConfig_Validate
✅ TestConfig_Validate/ReturnsNoErrorWithValidArguments
✅ TestConfig_Validate/ReturnsErrorWithEmptyName
✅ TestConfig_Validate/ReturnsErrorWithUnsupportedBackendName
✅ TestList_ForwardTraces_ReturnsNoErrorAndCallsForwardTracesOnAllUnderlyingWorkingForwarders
✅ TestList_ForwardTraces_ReturnsErrorAndCallsForwardTracesOnAllUnderlyingForwardersWithSingleFailingForwarder
✅ TestList_ForwardTraces_ReturnsErrorAndCallsForwardTracesOnAllUnderlyingForwardersWithAllFailingForwarder
✅ TestList_ForwardTraces_DoesNotPanicWhenNil
✅ TestNewManager_ReturnsNoErrorAndNonNilManagerWithValidConfigList
✅ TestNewManager_ReturnsErrorAndNilManagerWithInvalidConfigList
✅ TestManager_ForTenant_ReturnsSingleForwarderWhenSingleForwarderForTenantConfigured
✅ TestManager_ForTenant_ReturnsTwoForwardersWhenTwoForwarderForTenantConfigured
✅ TestManager_ForTenant_ReturnsEmptySliceWhenNoForwardersForTenantConfigured
✅ TestManager_ForTenant_ReturnsEmptySliceWhenTenantNotConfigured
✅ TestManager_ForTenant_List_ForwardTraces_ReturnsNoErrorAndCorrectlyForwardsBatchesToSingleForwarder
✅ TestManager_ForTenant_List_ForwardTraces_ReturnsNoErrorAndCorrectlyForwardsBatchesToMultipleForwarders
✅ TestManager_ForTenant_List_ForwardTraces_ReturnsNoErrorAndCorrectlyForwardsBatchesToProperForwardersWhenNewForwarderIsAddedToOverridesConfig
✅ TestManager_ForTenant_List_ForwardTraces_ReturnsNoErrorAndCorrectlyForwardsBatchesToProperForwardersWhenOldForwarderIsRemovedFromOverridesConfig
✅ TestManager_ForTenant_List_ForwardTraces_ReturnsNoErrorAndCorrectlyForwardsBatchesToMultipleForwardersForMultipleTenants
✅ TestManager_ForTenant_List_ForwardTraces_ReturnsNoErrorAndCorrectlyForwardsBatchesToProperForwardersWhenNewTenantIsAddedToOverridesConfig
✅ TestManager_ForTenant_List_ForwardTraces_ReturnsNoErrorAndCorrectlyDoesNotForwardTracesToForwardersWhenTenantIsRemovedFromOverridesConfig
✅ github.com/intergral/deep/modules/distributor/forwarder/otlpgrpc
✅ TestConfig_Validate
✅ TestConfig_Validate/ReturnsNoErrorForValidInsecureConfig
✅ TestConfig_Validate/ReturnsNoErrorForValidSecureConfig
✅ TestConfig_Validate/ReturnsErrorWithInsecureFalseAndNoCertFile
✅ TestNewForwarder_ReturnsNoErrorAndNonNilForwarderWithValidConfig
✅ TestNewForwarder_ReturnsErrorAndNilForwarderWithInvalidConfig
✅ Test_Forwarder_Dial_ReturnsNoErrorWithWorkingDialer
✅ Test_Forwarder_Dial_ReturnsErrorWithFailingContextDialer
✅ Test_Forwarder_Dial_ReturnsErrorWithCancelledContext
✅ Test_Forwarder_Dial_ReturnsErrorWhenCalledSecondTime
✅ Test_Forwarder_ForwardTraces_ReturnsNoErrorAndSentTracesMatchReceivedTraces
✅ Test_Forwarder_ForwardTraces_ReturnsErrorWithNoOrgIDInContext
✅ Test_Forwarder_Shutdown_CallsCloseOnConnection
✅ github.com/intergral/deep/modules/distributor/queue
✅ TestNew_ReturnsNotNilAndSetsCorrectFieldsFromConfig
✅ TestQueue_Push_ReturnsNoErrorAndWorkersInvokeProcessFuncCorrectNumberOfTimesWithRunningWorkers
✅ TestQueue_Push_ReturnsNoErrorWhenPushingLessItemsThanSizeWithStoppedWorkers
✅ TestQueue_Push_ReturnsErrorWhenPushingItemsToShutdownQueue
✅ TestQueue_Push_QueueGetsProperlyDrainedOnShutdown
✅ TestQueue_Push_ReturnsErrorWhenPushingItemsWithCancelledContext
✅ TestQueue_Push_ReturnsErrorWhenPushingItemsToFullQueueWithStoppedWorkers
✅ TestQueue_ShouldUpdate_ReturnsTrueWhenWorkerCountDiffersFromOriginalValue
✅ TestQueue_ShouldUpdate_ReturnsTrueWhenSizeDiffersFromOriginalValue
✅ TestQueue_ShouldUpdate_ReturnsTrueWhenBothParametersDifferFromOriginalValue
✅ TestQueue_ShouldUpdate_ReturnsFalseWhenBothParametersEqualOriginalValues
✅ github.com/intergral/deep/modules/distributor/snapshotreceiver
✅ TestFakeTenantMiddleware
✅ TestFakeTenantMiddleware/injects_tenant_id
✅ TestMultiTenancyMiddleware
✅ TestMultiTenancyMiddleware/injects_tenant_id_grpc
✅ TestMultiTenancyMiddleware/injects_tenant_id_http
✅ TestMultiTenancyMiddleware/returns_error_if_tenant_id_cannot_be_extracted
✅ github.com/intergral/deep/modules/frontend
✅ TestFrontendRoundTripsSearch
✅ TestFrontendBadConfigFails
✅ TestRetry
✅ TestRetry/retry_errors_until_success
✅ TestRetry/don't_retry_400's
✅ TestRetry/don't_retry_GRPC_request_with_HTTP_400's
✅ TestRetry/retry_500s
✅ TestRetry/return_last_error
✅ TestRetry/maxRetries=1
✅ TestRetry/maxRetries=0
✅ TestRetry_CancelledRequest
✅ TestSearchResponseShouldQuit
✅ TestCancelFuncEvents
✅ TestSearchResponseCombineResults
✅ TestBackendRequests
✅ TestIngesterRequest
✅ TestIngesterRequest/start/end_is_outside_queryIngestersUntil
✅ TestIngesterRequest/start/end_is_inside_queryBackendAfter
✅ TestIngesterRequest/backendAfter/ingsetersUntil_=_0_results_in_no_ingester_query
✅ TestIngesterRequest/ingester_start/End_=_15_-_10_mins_ago
✅ TestIngesterRequest/backend_start/End_=_15_-_10_mins_ago
✅ TestIngesterRequest/backend_start/End_=_20_-_5_mins_ago
✅ TestBackendRange
✅ TestSearchSharderRoundTrip
✅ TestSearchSharderRoundTrip/empty_returns
✅ TestSearchSharderRoundTrip/404+200
✅ TestSearchSharderRoundTrip/200+400
✅ TestSearchSharderRoundTrip/500+404
✅ TestSearchSharderRoundTrip/404+500
✅ TestSearchSharderRoundTrip/500+200
✅ TestSearchSharderRoundTrip/200+500
✅ TestSearchSharderRoundTrip/200+200
✅ TestSearchSharderRoundTrip/200+err
✅ TestSearchSharderRoundTrip/err+200
✅ TestSearchSharderRoundTrip/500+err
✅ TestSearchSharderRoundTrip/err+500
✅ TestSearchSharderRoundTripBadRequest
✅ TestAdjustLimit
✅ TestMaxDuration
✅ TestCreateBlockBoundaries
✅ TestCreateBlockBoundaries/single_shard
✅ TestCreateBlockBoundaries/multiple_shards
✅ TestBuildShardedRequests
✅ TestShardingWareDoRequest
✅ TestShardingWareDoRequest/404
✅ TestShardingWareDoRequest/400
✅ TestShardingWareDoRequest/500+404
✅ TestShardingWareDoRequest/404+500
✅ TestShardingWareDoRequest/500+200
✅ TestShardingWareDoRequest/200+500
✅ TestShardingWareDoRequest/503+200
✅ TestShardingWareDoRequest/200+503
✅ TestShardingWareDoRequest/200+404
✅ TestShardingWareDoRequest/404+200
✅ TestShardingWareDoRequest/200+200
✅ TestShardingWareDoRequest/200+err
✅ TestShardingWareDoRequest/err+200
✅ TestShardingWareDoRequest/500+err
✅ TestShardingWareDoRequest/failedBlocks_under:_200+200
✅ TestShardingWareDoRequest/failedBlocks_over:_200+200
✅ TestShardingWareDoRequest/failedBlocks_under:_200+404
✅ TestShardingWareDoRequest/failedBlocks_under:_404+200
✅ TestShardingWareDoRequest/failedBlocks_over:_404+200
✅ TestShardingWareDoRequest/failedBlocks_over:_404+404
✅ github.com/intergral/deep/modules/generator
✅ TestProcessorConfig_copyWithOverrides
✅ TestProcessorConfig_copyWithOverrides/overrides_buckets_and_dimension
✅ TestProcessorConfig_copyWithOverrides/empty_overrides
✅ TestProcessorConfig_copyWithOverrides/invalid_overrides
✅ Test_instance_concurrency
✅ Test_instance_updateProcessors
✅ Test_instance_updateProcessors/add_spanmetrics_processor
✅ Test_instance_updateProcessors/replace_spanmetrics_processor
✅ Test_instance_updateProcessors/remove_processor
✅ github.com/intergral/deep/modules/generator/processor/util
✅ TestFindServiceName
✅ TestFindServiceName/empty_attributes
✅ TestFindServiceName/service_name
✅ TestFindServiceName/service_name#01
✅ TestFindServiceName/no_service_name
✅ TestFindServiceName/service_name_is_other_type
✅ github.com/intergral/deep/modules/generator/registry
✅ Test_counter
✅ Test_counter_invalidLabelValues
✅ Test_counter_cantAdd
✅ Test_counter_removeStaleSeries
✅ Test_counter_externalLabels
✅ Test_counter_concurrencyDataRace
✅ Test_counter_concurrencyCorrectness
✅ Test_hashLabelValues
✅ Test_hashLabelValues/foo_-_bar
✅ Test_hashLabelValues/foo,bar_-_foob,ar
✅ Test_hashLabelValues/foo,bar_-_foobar,
✅ Test_hashLabelValues/foo,bar_-_foo_bar,
✅ Test_hashLabelValues/foo_,bar_-_foo,_bar
✅ Test_hashLabelValues/123,456_-_1234,56
✅ Test_histogram
✅ Test_histogram_invalidLabelValues
✅ Test_histogram_cantAdd
✅ Test_histogram_removeStaleSeries
✅ Test_histogram_externalLabels
✅ Test_histogram_concurrencyDataRace
✅ Test_histogram_concurrencyCorrectness
✅ Test_histogram_span_multiplier
✅ Test_newLabelValuesWithMax
✅ Test_newLabelValuesWithMax_zeroLength
✅ Test_job
✅ TestManagedRegistry_concurrency
✅ TestManagedRegistry_counter
✅ TestManagedRegistry_histogram
✅ TestManagedRegistry_removeStaleSeries
✅ TestManagedRegistry_externalLabels
✅ TestManagedRegistry_maxSeries
✅ TestManagedRegistry_disableCollection
✅ TestManagedRegistry_maxLabelNameLength
✅ TestTestRegistry_counter
✅ TestTestRegistry_histogram
✅ github.com/intergral/deep/modules/generator/storage
✅ TestConfig
✅ Test_generateTenantRemoteWriteConfigs
✅ Test_generateTenantRemoteWriteConfigs_singleTenant
✅ Test_copyMap
✅ TestInstance
✅ TestInstance_multiTenancy
✅ TestInstance_cantWriteToWAL
✅ github.com/intergral/deep/modules/ingester
✅ TestPushQueryAllEncodings
✅ TestPushQueryAllEncodings/v1
✅ TestFullSnapshotReturned
✅ TestWal
✅ TestWalDropsZeroLength
✅ TestSearchWAL
✅ TestFlush
✅ TestInstanceSearch
✅ TestInstanceSearchDeepQL
✅ TestInstanceSearchDeepQL/Query:{_.service.name_=_"test-service"_}
✅ TestInstanceSearchDeepQL/Query:{_duration_>=_1s_}
✅ TestInstanceSearchDeepQL/Query:{_duration_>=_1s_&&_.service.name_=_"test-service"_}
✅ TestInstanceSearchTags
✅ TestInstanceSearchMaxBytesPerTagValuesQueryReturnsPartial
✅ TestInstanceSearchNoData
✅ TestInstanceSearchDoesNotRace
✅ TestWALBlockDeletedDuringSearch
✅ TestInstanceSearchMetrics
✅ TestSnapshotStartEndTime
✅ TestInstance
✅ TestInstanceFind
✅ TestInstanceDoesNotRace
✅ TestInstanceLimits
✅ TestInstanceLimits/bytes_-_succeeds
✅ TestInstanceLimits/bytes_-_one_fails
✅ TestInstanceLimits/bytes_-_multiple_pushes_same_snapshot
✅ TestInstanceLimits/max_snapshots_-_too_many
✅ TestInstanceCutCompleteSnapshots
✅ TestInstanceCutCompleteSnapshots/empty
✅ TestInstanceCutCompleteSnapshots/cut_immediate
✅ TestInstanceCutCompleteSnapshots/cut_recent
✅ TestInstanceCutCompleteSnapshots/cut_all_time
✅ TestInstanceCutBlockIfReady
✅ TestInstanceCutBlockIfReady/empty
✅ TestInstanceCutBlockIfReady/doesnt_cut_anything
✅ TestInstanceCutBlockIfReady/cut_immediate
✅ TestInstanceCutBlockIfReady/cut_based_on_block_lifetime
✅ TestInstanceCutBlockIfReady/cut_based_on_block_size
✅ TestInstanceMetrics
✅ TestInstanceFailsLargeSnapshotsEvenAfterFlushing
✅ TestInstanceSearchCompleteParquet
✅ github.com/intergral/deep/modules/overrides
✅ TestLimitsTagsYamlMatchJson
✅ TestLimitsYamlMatchJson
✅ TestListToMapMarshalOperationsYAML
✅ TestListToMapMarshalOperationsYAML/empty_map
✅ TestListToMapMarshalOperationsYAML/map_with_entries
✅ TestListToMapMarshalOperationsYAML/explicit_string_entries
✅ TestListToMapMarshalOperationsJSON
✅ TestListToMapMarshalOperationsJSON/empty_map
✅ TestListToMapMarshalOperationsJSON/map_with_entries
✅ TestOverrides
✅ TestOverrides/limits_only
✅ TestOverrides/basic_overrides
✅ TestOverrides/wildcard_override
✅ github.com/intergral/deep/modules/querier
✅ TestQuerierUsesSearchExternalEndpoint
✅ github.com/intergral/deep/modules/tracepoint/store
✅ TestNewOrgIsHandled
✅ TestCreatingDeleteTracepoint
✅ TestCanLoadAfterFlush
✅ TestShouldGetCorrectTypeWhenProcessingRequests
✅ TestGetNewTracepointsOnPoll
✅ github.com/intergral/deep/modules/tracepoint/store/encoding/v1
✅ TestTargeting
✅ TestTargeting/Match_All
✅ TestTargeting/Match_None
✅ TestTargeting/Match_single
✅ TestTargeting/Match_many
✅ TestTargeting/Not_match_one
✅ TestFlush
✅ github.com/intergral/deep/pkg/api
✅ TestEquality
✅ TestQuerierParseSearchRequest
✅ TestQuerierParseSearchRequest/empty_query
✅ TestQuerierParseSearchRequest/limit_set
✅ TestQuerierParseSearchRequest/zero_limit
✅ TestQuerierParseSearchRequest/negative_limit
✅ TestQuerierParseSearchRequest/non-numeric_limit
✅ TestQuerierParseSearchRequest/minDuration_and_maxDuration
✅ TestQuerierParseSearchRequest/minDuration_greater_than_maxDuration
✅ TestQuerierParseSearchRequest/invalid_minDuration
✅ TestQuerierParseSearchRequest/invalid_maxDuration
✅ TestQuerierParseSearchRequest/deepql_query
✅ TestQuerierParseSearchRequest/invalid_deepql_query
✅ TestQuerierParseSearchRequest/deepql_query_and_tags
✅ TestQuerierParseSearchRequest/tags_and_limit
✅ TestQuerierParseSearchRequest/tags_query_parameter_with_duplicate_tag
✅ TestQuerierParseSearchRequest/top-level_tags_with_conflicting_query_parameter_tags
✅ TestQuerierParseSearchRequest/start_and_end_both_set
✅ TestQuerierParseSearchRequest/end_before_start
✅ TestQuerierParseSearchRequest/top-level_tags
✅ TestQuerierParseSearchRequest/top-level_tags_with_range_specified_are_ignored
✅ TestQuerierParseSearchRequestTags
✅ TestQuerierParseSearchRequestTags/service.name=foo_http.url=api/search
✅ TestQuerierParseSearchRequestTags/service%n@me=foo
✅ TestQuerierParseSearchRequestTags/service.name=foo_error
✅ TestQuerierParseSearchRequestTags/service.name="foo_bar"
✅ TestQuerierParseSearchRequestTags/service.name="foo=bar"
✅ TestQuerierParseSearchRequestTags/service.name="foo\bar"
✅ TestQuerierParseSearchRequestTags/service.name="foo_\"bar\""
✅ TestQuerierParseSearchRequestTagsError
✅ TestQuerierParseSearchRequestTagsError/service.name=foo_=error
✅ TestQuerierParseSearchRequestTagsError/service.name=foo=bar
✅ TestQuerierParseSearchRequestTagsError/service.name="foo_bar
✅ TestQuerierParseSearchRequestTagsError/"service_name"=foo
✅ TestParseSearchBlockRequest
✅ TestBuildSearchBlockRequest
✅ TestValidateAndSanitizeRequest
✅ TestBuildSearchRequest
✅ TestAddServerlessParams
✅ TestExtractServerlessParam
✅ TestIsBackendSearch
✅ TestIsSearchBlock
✅ github.com/intergral/deep/pkg/boundedwaitgroup
✅ TestBoundedWaitGroupExecutesCorrectNumberOfTimes
✅ TestBoundedWaitGroupDoesntExceedCapacity
✅ TestBoundedWaitGroupPanics
✅ github.com/intergral/deep/pkg/cache
✅ TestRedisCache
✅ TestRedisClient
✅ TestRedisClient/single_redis_client
✅ TestRedisClient/cluster_redis_client
✅ TestBackground
✅ TestNatSort
✅ TestMemcachedJumpHashSelector_PickSever
✅ TestMemcachedJumpHashSelector_PickSever_ErrNoServers
✅ TestMemcached
✅ TestMemcached/unbatched
✅ TestMemcached/batched
✅ TestMemcacheFailure
✅ TestMemcacheFailure/unbatched
✅ TestMemcacheFailure/batched
✅ TestMemcacheStop
✅ TestMemcacheStop/unbatched
✅ TestMemcacheStop/batched
✅ github.com/intergral/deep/pkg/deepdb
✅ TestTimeWindowBlockSelectorBlocksToCompact
✅ TestTimeWindowBlockSelectorBlocksToCompact/nil_-_nil
✅ TestTimeWindowBlockSelectorBlocksToCompact/empty_-_nil
✅ TestTimeWindowBlockSelectorBlocksToCompact/only_two
✅ TestTimeWindowBlockSelectorBlocksToCompact/choose_smallest_two
✅ TestTimeWindowBlockSelectorBlocksToCompact/different_windows
✅ TestTimeWindowBlockSelectorBlocksToCompact/different_sizes
✅ TestTimeWindowBlockSelectorBlocksToCompact/different_compaction_lvls
✅ TestTimeWindowBlockSelectorBlocksToCompact/active_time_window_vs_not
✅ TestTimeWindowBlockSelectorBlocksToCompact/choose_lowest_compaction_level
✅ TestTimeWindowBlockSelectorBlocksToCompact/doesn't_choose_across_time_windows
✅ TestTimeWindowBlockSelectorBlocksToCompact/doesn't_exceed_max_compaction_objects
✅ TestTimeWindowBlockSelectorBlocksToCompact/doesn't_exceed_max_block_size
✅ TestTimeWindowBlockSelectorBlocksToCompact/Returns_as_many_blocks_as_possible_without_exceeding_max_compaction_objects
✅ TestTimeWindowBlockSelectorBlocksToCompact/Returns_as_many_blocks_as_possible_without_exceeding_max_block_size
✅ TestTimeWindowBlockSelectorBlocksToCompact/choose_more_than_2_blocks
✅ TestTimeWindowBlockSelectorBlocksToCompact/honors_minimum_block_count
✅ TestTimeWindowBlockSelectorBlocksToCompact/can_choose_blocks_not_at_the_lowest_compaction_level
✅ TestTimeWindowBlockSelectorBlocksToCompact/doesn't_select_blocks_in_last_active_window
✅ TestTimeWindowBlockSelectorBlocksToCompact/don't_compact_across_dataEncodings
✅ TestTimeWindowBlockSelectorBlocksToCompact/ensures_blocks_of_different_versions_are_not_compacted
✅ TestTimeWindowBlockSelectorBlocksToCompact/ensures_blocks_of_the_same_version_are_compacted
✅ TestCompactionRoundtrip
✅ TestCompactionRoundtrip/vParquet
✅ TestCompactionUpdatesBlocklist
✅ TestCompactionMetrics
✅ TestCompactionIteratesThroughTenants
✅ TestCompactionHonorsBlockStartEndTimes
✅ TestCompactionHonorsBlockStartEndTimes/vParquet
✅ TestApplyToOptions
✅ TestValidateConfig
✅ TestSearchCompleteBlock
✅ TestSearchCompleteBlock/vParquet
✅ TestDeepQLCompleteBlock
✅ TestDeepQLCompleteBlock/vParquet
✅ TestAdvancedDeepQLCompleteBlock
✅ TestAdvancedDeepQLCompleteBlock/vParquet
✅ TestDB
✅ TestBlockSharding
✅ TestNilOnUnknownTenantID
✅ TestBlockCleanup
✅ TestIncludeBlock
✅ TestIncludeBlock/include_-_duh
✅ TestIncludeBlock/include_-_min_id_range
✅ TestIncludeBlock/include_-_max_id_range
✅ TestIncludeBlock/include_-_min_block_range
✅ TestIncludeBlock/include_-_max_block_range
✅ TestIncludeBlock/include_-_max_block_range#01
✅ TestIncludeBlock/include_-_exact_hit
✅ TestIncludeBlock/exclude_-_duh
✅ TestIncludeBlock/exclude_-_min_block_range
✅ TestIncludeBlock/exclude_-_max_block_range
✅ TestIncludeCompactedBlock
✅ TestIncludeCompactedBlock/include_recent
✅ TestIncludeCompactedBlock/skip_old
✅ TestIncludeCompactedBlock/skip_recent_but_out_of_range
✅ TestSearchCompactedBlocks
✅ TestCompleteBlock
✅ TestCompleteBlock/vParquet->vParquet
✅ TestCompleteBlockHonorsStartStopTimes
✅ TestCompleteBlockHonorsStartStopTimes/vParquet
✅ TestShouldCache
✅ TestShouldCache/both_pass
✅ TestShouldCache/startTime_fail
✅ TestShouldCache/compactionLevel_fail
✅ TestShouldCache/both_fail
✅ TestSimpleDeepQL
✅ TestRetention
✅ TestRetentionUpdatesBlocklistImmediately
✅ TestBlockRetentionOverride
✅ github.com/intergral/deep/pkg/deepdb/backend
✅ TestNewBlockMeta
✅ TestBlockMetaObjectAdded
✅ TestBlockMetaParsing
✅ TestUnmarshalMarshalYaml
✅ TestUnmarshalMarshalJson
✅ TestWriter
✅ TestReader
✅ TestKeyPathForBlock
✅ TestIndexMarshalUnmarshal
✅ TestIndexUnmarshalErrors
✅ github.com/intergral/deep/pkg/deepdb/backend/azure
✅ TestGetStorageAccountNameInConfig
✅ TestGetStorageAccountNameInEnv
✅ TestGetStorageAccountNameNotSet
✅ TestGetStorageAccountKeyInConfig
✅ TestGetStorageAccountKeyInEnv
✅ TestGetStorageAccountKeyNotSet
✅ TestGetContainerURL
✅ TestGetContainerURL/localhost
✅ TestGetContainerURL/Azure_China
✅ TestGetContainerURL/Azure_US_Government
✅ TestGetContainerURL/Azure_German
✅ TestServicePrincipalTokenFromFederatedToken
✅ TestCredentials
✅ TestHedge
✅ TestHedge/hedge_disabled
✅ TestHedge/hedge_enabled_doesn't_hit
✅ TestHedge/hedge_enabled_and_hits
✅ TestReadError
✅ github.com/intergral/deep/pkg/deepdb/backend/cache
✅ TestReadWrite
✅ TestReadWrite/should_cache
✅ TestReadWrite/should_not_cache
✅ TestList
✅ TestList/list_passthrough
✅ github.com/intergral/deep/pkg/deepdb/backend/gcs
✅ TestHedge
✅ TestHedge/hedge_disabled
✅ TestHedge/hedge_enabled_doesn't_hit
✅ TestHedge/hedge_enabled_and_hits
✅ TestReadError
✅ TestObjectConfigAttributes
✅ TestObjectConfigAttributes/cache_controle_enabled
✅ TestObjectConfigAttributes/medata_set
✅ TestRetry_MarkBlockCompacted
✅ github.com/intergral/deep/pkg/deepdb/backend/local
✅ TestReadWrite
✅ TestShutdownLeavesTenantsWithBlocks
✅ TestShutdownRemovesTenantsWithoutBlocks
✅ github.com/intergral/deep/pkg/deepdb/backend/s3
✅ TestHedge
✅ TestHedge/hedge_disabled
✅ TestHedge/hedge_enabled_doesn't_hit
✅ TestHedge/hedge_enabled_and_hits
✅ TestReadError
✅ TestObjectBlockTags
✅ TestObjectBlockTags/env
✅ TestObjectStorageClass
✅ TestObjectStorageClass/Standard
✅ github.com/intergral/deep/pkg/deepdb/blocklist
✅ TestApplyPollResults
✅ TestApplyPollResults/all_nil
✅ TestApplyPollResults/meta_only
✅ TestApplyPollResults/compacted_meta_only
✅ TestApplyPollResults/all
✅ TestUpdate
✅ TestUpdate/all_nil
✅ TestUpdate/add_to_nil
✅ TestUpdate/add_to_existing
✅ TestUpdate/remove_from_nil
✅ TestUpdate/remove_nil
✅ TestUpdate/remove_existing
✅ TestUpdate/remove_no_match
✅ TestUpdate/add_and_remove
✅ TestUpdate/add_already_exists
✅ TestUpdateCompacted
✅ TestUpdateCompacted/all_nil
✅ TestUpdateCompacted/add_to_nil
✅ TestUpdateCompacted/add_to_existing
✅ TestUpdateCompacted/add_already_exists
✅ TestUpdateCompacted/add_and_remove
✅ TestUpdatesSaved
✅ TestTenantIndexBuilder
✅ TestTenantIndexBuilder/nothing!
✅ TestTenantIndexBuilder/err
✅ TestTenantIndexBuilder/block_meta
✅ TestTenantIndexBuilder/compacted_block_meta
✅ TestTenantIndexBuilder/all
✅ TestTenantIndexFallback
✅ TestTenantIndexFallback/builder_writes_index
✅ TestTenantIndexFallback/reader_does_not_write_index
✅ TestTenantIndexFallback/reader_does_not_write_index_on_error_if_no_fallback
✅ TestTenantIndexFallback/reader_writes_index_on_error_if_fallback
✅ TestTenantIndexFallback/reader_does_not_write_index_on_stale_if_no_fallback
✅ TestTenantIndexFallback/reader_writes_index_on_stale_if_fallback
✅ TestPollBlock
✅ TestPollBlock/block_and_tenant_don't_exist
✅ TestPollBlock/block_exists
✅ TestPollBlock/compactedblock_exists
✅ TestPollBlock/errors
✅ TestTenantIndexPollError
✅ TestBlockListBackendMetrics
✅ TestBlockListBackendMetrics/total_backend_objects_calculation_is_correct
✅ TestBlockListBackendMetrics/total_backend_bytes_calculation_is_correct
✅ github.com/intergral/deep/pkg/deepdb/encoding
✅ TestFromVersionErrors
✅ TestAllVersions
✅ github.com/intergral/deep/pkg/deepdb/encoding/common
✅ TestShardedBloom
✅ TestShardedBloomFalsePositive
✅ TestShardedBloomFalsePositive/regular
✅ TestShardedBloomFalsePositive/large_estimated_objects
✅ TestShardedBloomFalsePositive/large_shard_size
✅ TestBloomShardCount
✅ TestBloomShardCount/too_many_shards
✅ TestBloomShardCount/too_few_shards
✅ github.com/intergral/deep/pkg/deepdb/encoding/vparquet
✅ TestBackendBlockSearchFetchMetaData
✅ TestOne
✅ TestBackendBlockSearchDeepql
✅ TestBackendBlockFindSnapshotByID
✅ TestBackendBlockFindSnapshotByID_TestData
✅ TestRawIteratorReadsAllRows
✅ TestBackendBlockSearchTags
✅ TestBackendBlockSearchTagValues
✅ TestBackendBlockSearchTagValuesV2
✅ TestBackendBlockSearch
✅ TestValueAlloc
✅ TestCreateBlockHonorsSnapshotStartEndTimesFromWalMeta
✅ TestMultiBlockIterator
✅ TestParquetGoSetsMetadataSections
✅ TestParquetReaderAt
✅ TestCachingReaderAt
✅ TestProtoParquetRoundTrip
✅ TestProtoToParquetEmptySnapshot
✅ TestProtoParquetRando
✅ TestFieldsAreCleared
✅ TestCovertDefaultWatch
✅ TestConvertWatch
✅ TestConvertWatch/Log
✅ TestConvertWatch/Metric
✅ TestConvertWatch/Watch
✅ TestParquetRowSizeEstimate
✅ TestExtendReuseSlice
✅ TestExtendReuseSlice/0
✅ TestExtendReuseSlice/2
✅ TestExtendReuseSlice/5
✅ TestFullFilename
✅ TestFullFilename/basic
✅ TestFullFilename/no_path
✅ TestPartialReplay
✅ TestParseFilename
✅ TestParseFilename/happy_path
✅ TestParseFilename/path_fails
✅ TestParseFilename/no_+
✅ TestParseFilename/empty_string
✅ TestParseFilename/bad_uuid
✅ TestParseFilename/no_tenant
✅ TestParseFilename/no_version
✅ TestParseFilename/wrong_version
✅ TestParseFilename/wrong_splits_-_4
✅ TestParseFilename/wrong_splits_-_2
✅ TestParseFilename/wrong_splits_-_1
✅ TestWalBlockFindSnapshotByID
✅ TestWalBlockIterator
✅ TestRowIterator
✅ github.com/intergral/deep/pkg/deepdb/pool
✅ TestResults
✅ TestNoResults
✅ TestMultipleHits
✅ TestError
✅ TestMultipleErrors
✅ TestTooManyJobs
✅ TestOneWorker
✅ TestGoingHam
✅ TestOverloadingASmallPool
✅ TestShutdown
✅ TestDataEncodings
✅ TestCancellation
✅ github.com/intergral/deep/pkg/deepdb/wal
✅ TestCompletedDirIsRemoved
✅ TestAppendBlockStartEnd
✅ TestAppendBlockStartEnd/vParquet
✅ TestIngestionSlack
✅ TestIngestionSlack/vParquet
✅ TestFindBySnapshotID
✅ TestFindBySnapshotID/vParquet
✅ TestIterator
✅ TestIterator/vParquet
✅ TestSearch
✅ TestSearch/vParquet
✅ TestFetch
✅ TestFetch/vParquet
✅ TestInvalidFilesAndFoldersAreHandled
✅ github.com/intergral/deep/pkg/flushqueues
✅ TestExclusiveQueues
✅ TestMultipleQueues
✅ TestPriorityQueueBasic
✅ TestPriorityQueuePriorities
✅ TestPriorityQueuePriorities2
✅ TestPriorityQueueWait
✅ github.com/intergral/deep/pkg/io
✅ TestBufferedReaderAtCalculateBounds
✅ TestBufferedReaderAt
✅ TestBufferedReaderConcurrency
✅ TestBufferedWriterWithQueueWritesToBackend
✅ TestReadAllWithEstimate
✅ github.com/intergral/deep/pkg/model
✅ TestSegmentDecoderToObjectDecoder
✅ TestSegmentDecoderToObjectDecoder/v1
✅ TestSegmentDecoderToObjectDecoderRange
✅ TestSegmentDecoderToObjectDecoderRange/v1
✅ TestSegmentDecoderFastRange
✅ TestSegmentDecoderFastRange/v1
✅ github.com/intergral/deep/pkg/parquetquery
✅ TestRowNumber
✅ TestCompareRowNumbers
✅ TestColumnIterator
✅ TestColumnIteratorExitEarly
✅ TestColumnIteratorExitEarly/cancelledEarly
✅ TestColumnIteratorExitEarly/cancelledPartial
✅ TestColumnIteratorExitEarly/closedEarly
✅ TestColumnIteratorExitEarly/closedPartial
✅ TestSubstringPredicate
✅ TestOrPredicateCallsKeepColumnChunk
✅ github.com/intergral/deep/pkg/ql
✅ TestParseString
✅ TestParseString/trigger{}
✅ TestParseString/log{file="simple_test.py"}
✅ TestParseString/metric{line=12}
✅ TestParseString/span{line=12_file="SimpleTest.java"_span="nest"}
✅ TestParseString/snapshot{line=12_file="SimpleTest.java"_target="nest"}
✅ TestParseString/log_{log="this_is_a_log_message"}
✅ TestParseString/log{log="this_is_a_log_message"_line=12_file="SimpleTest.java"}
✅ TestParseString/log{log="this_is_a_log_message"_label_my_label="atest"_line=12_file="SimpleTest.java"}
✅ TestParseString/log{log="this_is_a_log_message"_label_my_label="atest"_file="simple_test.py"_line=44_osname="windows"}
✅ TestParseString/log{log="this_is_a_log_message"_label_my_label="atest"_file="simple_test.py"_line=44_resource.osname="windows"}
✅ TestParseString/log{log="this_is_a_log_message"_label_my_label="atest"_file="simple_test.py"_line=44_os.name="windows"}
✅ TestParseString/list{}
✅ TestParseString/list{file="some_file.py"}
✅ TestParseString/delete{file="some_file.py"}
✅ TestParseString/delete{id="alksjdsa89dashd89"}
✅ TestParseString/delete{line=88}
✅ github.com/intergral/deep/pkg/receivers
✅ TestLoadDeepReceiver
✅ github.com/intergral/deep/pkg/receivers/deep
✅ TestCreateConfig
✅ TestCreateConfig/empty_config_gets_default
✅ TestCreateConfig/will_default_protocols_if_not_set
✅ TestCreateConfig/can_set_new_port
✅ github.com/intergral/deep/pkg/search
✅ TestResultsDoesNotRace
✅ TestResultsDoesNotRace/default
✅ TestResultsDoesNotRace/exit_early
✅ TestResultsDoesNotRace/exit_early_due_to_error
✅ github.com/intergral/deep/pkg/usagestats
✅ Test_LeaderElection
✅ Test_LeaderElectionWithBrokenSeedFile
✅ Test_ReportLoop
✅ Test_NextReport
✅ Test_NextReport/createdAt_aligned_with_interval
✅ Test_NextReport/createdAt_not_aligned
✅ Test_NextReport/createdAt_aligned_with_interval_and_now
✅ TestWrongKV
✅ Test_Memberlist
✅ Test_BuildReport
✅ Test_BuildStats
✅ TestCounter
✅ TestStatistic
✅ TestWordCounter
✅ TestPanics
✅ github.com/intergral/deep/pkg/util
✅ TestStringifyAnyValue
✅ TestStringifyAnyValue/string_value
✅ TestStringifyAnyValue/int_value
✅ TestStringifyAnyValue/bool_value
✅ TestStringifyAnyValue/float_value
✅ TestStringifyAnyValue/array_value
✅ TestStringifyAnyValue/map_value
✅ TestDistinctStringCollector
✅ TestHexStringToSnapshotID
✅ TestHexStringToSnapshotID/12
✅ TestHexStringToSnapshotID/1234567890abcdef
✅ TestHexStringToSnapshotID/1234567890abcdef1234567890abcdef
✅ TestHexStringToSnapshotID/121234567890abcdef1234567890abcdef
✅ TestHexStringToSnapshotID/234567890abcdef
✅ TestHexStringToSnapshotID/1234567890abcdef_
✅ TestSnapshotIDToFromString
✅ TestSnapshotIDToHexString
✅ TestSnapshotIDToHexString/12
✅ TestSnapshotIDToHexString/1234567890abcdef
✅ TestSnapshotIDToHexString/1234567890abcdef1234567890abcdef
✅ TestSnapshotIDToHexString/12a0
✅ TestEqualHexStringSnapshotIDs
✅ TestPadSnapshotIDTo16Bytes
✅ TestPadSnapshotIDTo16Bytes/small
✅ TestPadSnapshotIDTo16Bytes/exact
✅ TestPadSnapshotIDTo16Bytes/large
✅ github.com/intergral/deep/pkg/util/log
✅ TestRateLimitedLogger
Loading